You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by es...@apache.org on 2018/08/27 20:46:06 UTC

[geode] 02/02: Merge remote-tracking branch 'origin/develop' into feature/GEODE-5624

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

eshu11 pushed a commit to branch feature/GEODE-5624
in repository https://gitbox.apache.org/repos/asf/geode.git

commit 5ebd326244f3033abf70610251eab2416b7688df
Merge: bc42e83 76af1dd
Author: eshu <es...@pivotal.io>
AuthorDate: Mon Aug 27 13:45:37 2018 -0700

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

 build.gradle                                       |   2 +-
 ci/pipelines/geode-build/deploy_pipeline.sh        |   2 +
 ci/pipelines/geode-build/jinja.template.yml        |  39 ++-
 ci/scripts/publish.sh                              |  96 ++++++
 geode-assembly/build.gradle                        |  47 +--
 .../cli/commands/StopLocatorCommandDUnitTest.java  |  29 +-
 .../geode/AssemblyContentsIntegrationTest.java     |   4 +-
 ...java => GeodeDependencyJarIntegrationTest.java} |  69 +++--
 .../resources/dependency_classpath.txt             |  67 +++++
 .../test/junit/rules/MySqlConnectionRule.java      |   5 +-
 .../junit/rules/SqlDatabaseConnectionRule.java     |   4 +-
 .../geode/connectors/jdbc/JdbcAsyncWriterTest.java |   4 +-
 .../geode/connectors/jdbc/JdbcWriterTest.java      |   2 +-
 geode-core/build.gradle                            |  14 +-
 .../CreateAndLocalDestroyInTXRegressionTest.java   |   7 +-
 .../PRCreationTotalNumBucketsDistributedTest.java  |   8 +-
 .../cache/RegionClearStatsDistributedTest.java     |   8 +-
 .../cache/RegionExpirationDistributedTest.java     |   8 +-
 .../ReplicateCacheListenerDistributedTest.java     |  18 +-
 .../internal/AutoConnectionSourceDUnitTest.java    |   3 +-
 .../management/MemoryThresholdsDUnitTest.java      |   2 +-
 .../MemoryThresholdsOffHeapDUnitTest.java          |  18 +-
 .../dunit/QueryDataInconsistencyDUnitTest.java     |  34 +--
 .../query/dunit/QueryIndexUsingXMLDUnitTest.java   |   3 +-
 .../partitioned/PRColocatedEquiJoinDUnitTest.java  |  47 ---
 .../query/partitioned/PRQueryDUnitHelper.java      |  86 +-----
 .../geode/cache30/DiskRegionDistributedTest.java   |  11 +-
 ...okenSerializationConsistencyRegressionTest.java |   8 +-
 .../cache/BucketCreationCrashRegressionTest.java   |  11 +-
 ...ntServerTransactionFailoverDistributedTest.java |  35 +--
 ...overWithMixedVersionServersDistributedTest.java |  44 +--
 .../EntriesDoNotExpireDuringGiiRegressionTest.java |  14 +-
 ...zedDiskRegionWithIoExceptionRegressionTest.java |  18 +-
 .../cache/PRCustomPartitioningDistributedTest.java |  10 +-
 .../PREntryIdleExpirationDistributedTest.java      |  31 +-
 .../internal/cache/PRQueryDistributedTest.java     |   8 +-
 .../PRQueryWithIndexAndPdxDistributedTest.java     |   9 +-
 .../cache/PRQueryWithIndexDistributedTest.java     |   9 +-
 .../cache/PRQueryWithOrderByDistributedTest.java   |   9 +-
 ...RQueryWithPdxDuringRebalanceRegressionTest.java |   9 +-
 .../PRWithIndexAfterRebalanceRegressionTest.java   |   9 +-
 .../PartitionedRegionCloseDistributedTest.java     |  19 +-
 .../cache/PersistentRegionRecoveryDUnitTest.java   |  19 +-
 .../cache/RegionListenerDistributedTest.java       |  17 +-
 ...eplicateEntryIdleExpirationDistributedTest.java |  36 ++-
 .../cache/backup/BackupDistributedTest.java        |  12 +-
 .../backup/IncrementalBackupDistributedTest.java   |  12 +-
 .../PrepareAndFinishBackupDistributedTest.java     |   6 +-
 .../ClientFunctionTimeoutRegressionTest.java       |  26 +-
 ...ctionExecutionWithExceptionDistributedTest.java |   9 +-
 ...ctionOnBehalfOfClientMemberDistributedTest.java |  14 +-
 .../cache/ha/HARegionQueueSizeRegressionTest.java  |   9 +-
 .../HARegionQueueThreadIdExpiryRegressionTest.java |  11 +-
 ...BucketCreationCrashCompletesRegressionTest.java |  55 ++--
 .../BucketRebalanceStatRegressionTest.java         |   4 +-
 ...RDiskConflictWithColocationDistributedTest.java |   5 +-
 ...PersistentPartitionedRegionDistributedTest.java |  21 +-
 .../PersistentPartitionedRegionRegressionTest.java |   7 +-
 ...eueRemovalMessageProcessingDistributedTest.java |  87 +++---
 .../RegisterInterestKeysValuesDistributedTest.java |  50 ++--
 .../DeltaPropagationFailureRegressionTest.java     |  33 +--
 .../AcceptorImplClientQueueDistributedTest.java    |  42 +--
 ...entDestroyRegionNotificationRegressionTest.java |  31 +-
 ...troyRegionUnregisterInterestRegressionTest.java |  31 +-
 .../ClientProxyWithDeltaDistributedTest.java       |  34 +--
 .../ClientWithInterestFailoverDistributedTest.java |  32 +-
 .../GetConnectedServerCountRegressionTest.java     |   8 +-
 .../HARegionQueueStatsCloseRegressionTest.java     |  24 +-
 .../MessageTrackingTimeoutRegressionTest.java      |  18 +-
 ...nterestOnServerWithoutRegionRegressionTest.java |  15 +-
 ...isterInterestServerMetaDataDistributedTest.java |  44 ++-
 ...RootRegionsExcludesHARegionsRegressionTest.java |  24 +-
 .../AsyncEventListenerDistributedTest.java         |   4 +-
 ...ventListenerWithCacheLoaderDistributedTest.java |   6 +-
 ...syncEventListenerWithFilterDistributedTest.java |   6 +-
 ...oncurrentAsyncEventListenerDistributedTest.java |   4 +-
 .../ParallelAsyncEventListenerDistributedTest.java |   6 +-
 .../SerialEventListenerDistributedTest.java        |   4 +-
 .../ClientServerJTAFailoverDistributedTest.java    |  48 +--
 .../apache/geode/management/JMXMBeanDUnitTest.java |  59 ++--
 .../management/JMXMBeanReconnectDUnitTest.java     |  10 +-
 .../management/RegionManagementDUnitTest.java      |  11 +-
 .../internal/pulse/TestClientIdsDUnitTest.java     |   8 +-
 .../internal/pulse/TestFunctionsDUnitTest.java     |  96 +++---
 .../tests/GetCurrentVmNumDistributedTest.java      |   5 +-
 .../GetPidAndIdAfterBounceDistributedTest.java     |  11 +-
 .../dunit/tests/GetPidAndIdDistributedTest.java    |   9 +-
 .../query/internal/IndexManagerJUnitTest.java      |  12 +-
 .../query/partitioned/PRColocatedEquiJoinTest.java | 110 +++++++
 .../gms/messenger/GMSEncryptJUnitTest.java         | 122 +++-----
 .../geode/internal/cache/DiskRegionJUnitTest.java  |  94 +++---
 .../CacheClientNotifierIntegrationTest.java        |  24 +-
 .../cache/query/internal/DefaultQueryService.java  |  17 +-
 .../query/internal/IndexTrackingQueryObserver.java |   1 +
 .../geode/cache/query/internal/QueryUtils.java     |  10 +-
 .../cache/query/internal/index/IndexManager.java   |  30 +-
 .../cache/query/internal/index/RangeIndex.java     |   7 +-
 .../internal/cache/AbstractBucketRegionQueue.java  |  12 +
 .../geode/internal/cache/BucketRegionQueue.java    |   1 +
 .../internal/cache/CacheDistributionAdvisor.java   |   2 +-
 .../geode/internal/cache/DistributedRegion.java    |  41 +--
 .../geode/internal/cache/InternalRegion.java       |   2 +
 .../apache/geode/internal/cache/LocalRegion.java   |  63 ++--
 .../geode/internal/cache/MemoryThresholdInfo.java  |  53 ++++
 .../geode/internal/cache/PartitionedRegion.java    |  29 +-
 .../internal/cache/control/HeapMemoryMonitor.java  |  70 ++++-
 .../internal/cache/control/ResourceAdvisor.java    |   2 +-
 .../execute/DistributedRegionFunctionExecutor.java |  16 +-
 .../cache/execute/MemberFunctionExecutor.java      |  19 +-
 .../cache/execute/MultiRegionFunctionExecutor.java |  32 +-
 .../execute/PartitionedRegionFunctionExecutor.java |  17 +-
 .../partitioned/PartitionedRegionRebalanceOp.java  |   2 +-
 .../internal/cache/partitioned/RegionAdvisor.java  |   4 +-
 .../tier/sockets/command/ExecuteFunction.java      |  19 +-
 .../tier/sockets/command/ExecuteFunction65.java    |  20 +-
 .../tier/sockets/command/ExecuteFunction66.java    |  20 +-
 .../wan/parallel/ParallelQueueRemovalMessage.java  |  10 +-
 .../monitoring/ThreadsMonitoringProcess.java       |   8 +-
 .../monitoring/executor/AbstractExecutor.java      |  24 +-
 .../internal/QueueConnectionImplJUnitTest.java     |   6 +-
 ...pClientExecutorSubmitTaskWithExceptionTest.java |   9 +-
 .../cache/query/internal/QueryMonitorTest.java     |   5 +-
 .../internal/cache/DistributedRegionJUnitTest.java |  32 ++
 .../internal/cache/MemoryThresholdInfoTest.java    |  25 +-
 .../cache/control/HeapMemoryMonitorTest.java       | 325 +++++++++++++++++++++
 .../sockets/command/ExecuteFunction66Test.java     |   4 +
 .../ParallelQueueRemovalMessageJUnitTest.java      |  24 ++
 .../GemFireBasicDataSourceJUnitTest.java           |  17 +-
 ...ientStatisticsPublicationSecurityDUnitTest.java |  14 +-
 .../tier/sockets/ClientServerMiscBCDUnitTest.java  |  15 +-
 .../examples/AsyncInvokeCallableExampleTest.java   |  26 +-
 .../examples/AsyncInvokeRunnableExampleTest.java   |  12 +-
 .../CatchingUnexpectedExceptionExampleTest.java    |  13 +-
 ... => DistributedRuleAsClassRuleExampleTest.java} |  32 +-
 .../dunit/examples/InvokeRunnableExampleTest.java  |  13 +-
 .../examples/LocatorPortClusterExampleTest.java    |   7 +-
 .../examples/ReplaceTryFinallyExampleTest.java     |  14 +-
 .../tests/CacheRuleBuilderDistributedTest.java     |   9 +-
 .../rules/tests/CacheRuleDistributedTest.java      |   4 +-
 .../tests/ClientCacheRuleDistributedTest.java      | 114 ++++++++
 ...utedRestoreSystemPropertiesDistributedTest.java |  14 +-
 ...st.java => DistributedRuleDistributedTest.java} |  11 +-
 .../tests/SharedCountersRuleDistributedTest.java   |  69 +++--
 .../tests/SharedErrorCollectorDistributedTest.java |  45 ++-
 .../internal/cache/functions/TestFunction.java     | 286 ++++++++----------
 .../dunit/internal/JUnit4DistributedTestCase.java  |   4 +-
 ...dTestRule.java => AbstractDistributedRule.java} |   8 +-
 .../apache/geode/test/dunit/rules/CacheRule.java   |  39 ++-
 .../test/dunit/rules/CleanupDUnitVMsRule.java      |   2 +-
 .../geode/test/dunit/rules/ClientCacheRule.java    |  52 +++-
 .../geode/test/dunit/rules/ClusterStartupRule.java |   8 +
 .../rules/DistributedRestoreSystemProperties.java  |   2 +-
 ...stributedTestRule.java => DistributedRule.java} |  95 ++++--
 .../geode/test/dunit/rules/SharedCountersRule.java |  57 +++-
 .../test/dunit/rules/SharedErrorCollector.java     |  22 +-
 .../geode/test/junit/rules/ServerStarterRule.java  |  21 ++
 .../DoNotHandleUnexpectedExceptionExampleTest.java |   2 -
 geode-junit/build.gradle                           |   2 +-
 .../geode/test/junit/rules/ConcurrencyRule.java    |   8 +-
 .../test/junit/rules/ConcurrencyRuleTest.java      |   7 +
 geode-lucene/build.gradle                          |   2 +-
 .../geode/cache/lucene/ExpirationDUnitTest.java    |   9 +-
 ...eneIndexCreationPersistenceIntegrationTest.java |  13 +-
 .../LuceneSearchWithRollingUpgradeDUnit.java       |  15 +-
 geode-pulse/build.gradle                           |  10 +-
 .../geode/cache/util/AutoBalancerJUnitTest.java    |   6 +-
 .../GatewayLegacyAuthenticationRegressionTest.java |  22 +-
 geode-web-api/build.gradle                         |   2 +-
 geode-web/build.gradle                             |  10 +-
 gradle/publish.gradle                              | 117 +++++++-
 gradle/test.gradle                                 |  10 +-
 gradle/utilities.gradle                            |   3 +
 172 files changed, 2657 insertions(+), 1832 deletions(-)

diff --cc geode-core/src/distributedTest/java/org/apache/geode/internal/jta/ClientServerJTAFailoverDistributedTest.java
index 2ae4e9b,cb6be25..d518153
--- a/geode-core/src/distributedTest/java/org/apache/geode/internal/jta/ClientServerJTAFailoverDistributedTest.java
+++ b/geode-core/src/distributedTest/java/org/apache/geode/internal/jta/ClientServerJTAFailoverDistributedTest.java
@@@ -29,13 -31,11 +31,12 @@@ import org.junit.Before
  import org.junit.Rule;
  import org.junit.Test;
  
- import org.apache.geode.cache.PartitionAttributes;
  import org.apache.geode.cache.PartitionAttributesFactory;
  import org.apache.geode.cache.Region;
+ import org.apache.geode.cache.RegionFactory;
 +import org.apache.geode.cache.RegionShortcut;
  import org.apache.geode.cache.TransactionId;
  import org.apache.geode.cache.client.ClientRegionFactory;
- import org.apache.geode.cache.client.ClientRegionShortcut;
  import org.apache.geode.cache.client.PoolFactory;
  import org.apache.geode.cache.client.PoolManager;
  import org.apache.geode.cache.client.internal.InternalClientCache;
@@@ -66,14 -71,9 +73,10 @@@ public class ClientServerJTAFailoverDis
    private VM client1;
    private int port1;
    private int port2;
 +  private boolean hasReplicateRegion = false;
  
-   private final int key = 1;
-   private final String value = "value1";
-   private final String newValue = "value2";
- 
    @Rule
-   public DistributedTestRule distributedTestRule = new DistributedTestRule();
+   public DistributedRule distributedRule = new DistributedRule();
  
    @Rule
    public CacheRule cacheRule = new CacheRule();
@@@ -121,19 -120,16 +124,22 @@@
    }
  
    private int createServerRegion(int totalNumBuckets, boolean isAccessor) throws Exception {
-     PartitionAttributesFactory factory = new PartitionAttributesFactory();
-     factory.setTotalNumBuckets(totalNumBuckets);
+     PartitionAttributesFactory<?, ?> partitionAttributesFactory = new PartitionAttributesFactory();
+     partitionAttributesFactory.setTotalNumBuckets(totalNumBuckets);
      if (isAccessor) {
-       factory.setLocalMaxMemory(0);
+       partitionAttributesFactory.setLocalMaxMemory(0);
      }
-     PartitionAttributes partitionAttributes = factory.create();
-     cacheRule.getOrCreateCache().createRegionFactory(RegionShortcut.PARTITION)
-         .setPartitionAttributes(partitionAttributes).create(regionName);
+ 
+     RegionFactory regionFactory = cacheRule.getOrCreateCache().createRegionFactory(PARTITION);
+     regionFactory.setPartitionAttributes(partitionAttributesFactory.create());
+     regionFactory.create(regionName);
+ 
 +    if (hasReplicateRegion) {
 +      cacheRule.getOrCreateCache().createRegionFactory(RegionShortcut.REPLICATE)
 +          .create(replicateRegionName);
 +    }
 +
++
      CacheServer server = cacheRule.getCache().addCacheServer();
      server.setPort(0);
      server.start();
@@@ -151,13 -147,11 +157,15 @@@
        CacheServerTestUtil.enableShufflingOfEndpoints();
      }
  
-     ClientRegionFactory crf =
-         clientCacheRule.getClientCache().createClientRegionFactory(ClientRegionShortcut.LOCAL);
-     crf.setPoolName(pool.getName());
-     crf.create(regionName);
-     if (hasReplicateRegion)
-       crf.create(replicateRegionName);
+     ClientRegionFactory<?, ?> clientRegionFactory =
+         clientCacheRule.getClientCache().createClientRegionFactory(LOCAL);
+     clientRegionFactory.setPoolName(pool.getName());
+     clientRegionFactory.create(regionName);
+ 
++    if (hasReplicateRegion) {
++      clientRegionFactory.create(replicateRegionName);
++    }
 +
      if (ports.length > 1) {
        pool.acquireConnection(new ServerLocation(hostName, port1));
      }