You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by je...@apache.org on 2018/08/29 19:00:38 UTC

[geode] branch windows-heavy-lifter updated (8b19a81 -> 2bca4fc)

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

jensdeppe pushed a change to branch windows-heavy-lifter
in repository https://gitbox.apache.org/repos/asf/geode.git.


 discard 8b19a81  Even larger disks for heavy lifters
 discard 604622d  Larger disks for heavy lifters
 discard 6b7345d  restrict class scanning to 2 threads
 discard f5889a5  only rsync the geode directory
 discard 6386abc  no need for a daemon when combining reports
 discard 301fd76  remote command calls bash
 discard e77ad29  Increase gradle JVM memory to 4GB
 discard b45f425  Use the public key
 discard 79fee3b  Revert to using the external IP
 discard 341430b  generate key
 discard 757b988  Correct regex for windows job detection
 discard 1fe319a  Debug output
 discard 97a7795  initial commit for windows heavy lifting
     add 583d141  GEODE-5562 Reading the values of LocalRegion.memoryThresholdReached and DistributedRegion.memoryThresholdReachedMembers must be atomic (#2320)
     add 9de289d  GEODE-5632: import Assertions instead of AssertionsForClassTypes
     add b951146  GEODE-5142 new Thread Monitoring Mechanism
     add 123b8c4  GEODE-5614: rename DistributedTestRule as DistributedRule
     add 16d0f69  GEODE-5614: rename distributedTestRule field to distributedRule
     add f91c2df  GEODE-5614: update RegionManagementDUnitTest usage of DistributedRule
     add e719331  GEODE-5629: Changing GMSEncryptJUnitTest to use ConcurrencyRule
     add a383053  GEODE-5623: Use Awaitility in StopLcoatorCommandDUnitTest (#2379)
     add 85953f0  GEODE-5631: failedBatchRemovalMessageKeys not used after GII (#2375)
     add 45138b4  GEODE-5630: fixup usage of Awaitility
     add 0cbf8e5  GEODE-5620: Adds project property to control test forking
     add 76af1dd  GEODE-5597 Publish geode artifacts to maven repo on GCS (#2347)
     add 48fe306  GEODE-5642 remove gradle task :cleanAll (#2385)
     add 3651a9a  GEODE-5646 Client throws ToDataException when locator is shutting down
     add 60ea939  GEODE-5618: Auth Attributes in FunctionService (#2360)
     add 58e4035  GEODE-5608 truncate fork/branch names in image/instance naming (#2363)
     add 366594c  Revert "GEODE-5608 truncate fork/branch names in image/instance naming (#2363)"
     add aa915c2  GEODE-5608 truncate fork/branch names in image/instance naming (#2390)
     add fd29e62  GEODE-5594: Enable endpoint identification during using SSL handshake. (#2346)
     add 926f35e  Feature/geode 5624 Use a single thread to ensure beforeCompletion and afterCompletion are executed by the same thread. (#2388)
     add 8382f8c  GEODE-5650: Improve ClusterStartupRule tear down (#2392)
     add b66beba  GEODE-5637: move SingleHopClientExecutorSubmitTaskWithExceptionTest to integrationTest
     add 7b6f5fa  GEODE-5633 pr pipeline name has fork and branch (#2391)
     add b3cf86b  GEODE-5604 Update gradle syntax to comply with 5.0 (#2350)
     add ebe44c2  GEODE-5641: add no-arg constructor to DiskDirRule
     add f550cc4  GEODE-5639: use AssertJ instead of CatchException
     add 281492a  GEODE-5639: remove CatchException dependencies from Gradle
     add 34ec001  GEODE-5637: disable SingleHopClientExecutorWithLoggingIntegrationTest
     add 1c349b5  Markdown format improvements.
     add 238706c  GEODE-5636: DescribeClientCommandDUnitTest fails on Windows (#2382)
     add be5430d  GEODE-5656: Upgrades Gradle to 4.10 (#2397)
     add ad37e34  GEODE-5601: Serialize running of acceptance tests in lieu of containerizing them (#2389)
     add 8ae1bdb  GEODE-5530: Moves more shared test code into the DUnit framework.
     add 30c1eff  Improve readability and failure reporting in new ThreadMonitorIntegrationTest.
     add 81cfad6  Move failing integration test to integrationTests.
     add e396d91  Bump for precheckin rerun
     add 7c57aef  Merge pull request #2396 from PurelyApplied/geode-5654
     add 7aee737  GEODE-5661: Pulse does not work when legacy SSL options are used (#2401)
     new 2bca4fc  initial commit for windows heavy lifting

This update added new revisions after undoing existing revisions.
That is to say, some revisions that were in the old version of the
branch are not in the new version.  This situation occurs
when a user --force pushes a change and generates a repository
containing something like this:

 * -- * -- B -- O -- O -- O   (8b19a81)
            \
             N -- N -- N   refs/heads/windows-heavy-lifter (2bca4fc)

You should already have received notification emails for all of the O
revisions, and so the following emails describe only the N revisions
from the common base, B.

Any revisions marked "omit" are not gone; other references still
refer to them.  Any revisions marked "discard" are gone forever.

The 1 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 BUILDING.md                                        |  16 +-
 README.md                                          |  99 ++++---
 build.gradle                                       |  16 +-
 buildSrc/build.gradle                              |  10 +-
 ci/images/alpine-tools/Dockerfile                  |   5 +-
 ci/images/google-geode-builder/build_image.sh      |   9 +-
 ci/pipelines/README.md                             |   2 +-
 ci/pipelines/clean_fork_pipelines.sh               |  18 +-
 ci/pipelines/deploy_meta.sh                        |  15 +-
 ci/pipelines/examples/deploy_pipeline.sh           |  22 +-
 ci/pipelines/geode-build/deploy_pipeline.sh        |  18 +-
 ci/pipelines/geode-build/jinja.template.yml        |  40 ++-
 ci/pipelines/images/deploy_images_pipeline.sh      |  10 +-
 ci/pipelines/meta.yml                              |   3 +
 ci/pipelines/pull-request/deploy_pr_pipeline.sh    |  26 +-
 ci/pipelines/pull-request/jinja.template.yml       |   1 +
 ci/pipelines/render.py                             |  39 ++-
 ci/pipelines/shared/jinja.variables.yml            |   7 +-
 ci/pipelines/shared/shared_jinja.yml               |   2 +-
 ci/pipelines/shared/utilities.sh                   |  26 ++
 ci/scripts/execute_tests.sh                        |   7 +-
 ci/scripts/publish.sh                              |  96 ++++++
 ci/scripts/start_instance.sh                       |  15 +-
 extensions/geode-modules-assembly/build.gradle     |  40 +--
 .../geode-modules-session-internal/build.gradle    |   2 +-
 extensions/geode-modules-session/build.gradle      |   2 +-
 extensions/geode-modules-test/build.gradle         |   2 +-
 extensions/geode-modules-tomcat7/build.gradle      |   4 +-
 extensions/geode-modules-tomcat8/build.gradle      |   4 +-
 extensions/geode-modules/build.gradle              |   2 +-
 geode-assembly/build.gradle                        |  74 ++---
 geode-assembly/geode-assembly-test/build.gradle    |   2 +-
 .../cli/commands/StopLocatorCommandDUnitTest.java  |  29 +-
 .../test/junit/rules/GeodeHttpClientRule.java      |  36 ++-
 .../tools/pulse/PulseSecurityWithSSLTest.java      |  80 ++++-
 .../integrationTest/resources/assembly_content.txt |   6 +
 geode-connectors/build.gradle                      |   2 +-
 .../connectors/jdbc/JdbcWriterIntegrationTest.java |   9 +-
 .../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                            |  21 +-
 .../CreateAndLocalDestroyInTXRegressionTest.java   |   7 +-
 .../PRCreationTotalNumBucketsDistributedTest.java  |   8 +-
 .../cache/RegionClearStatsDistributedTest.java     |   8 +-
 .../cache/RegionExpirationDistributedTest.java     |   8 +-
 .../ReplicateCacheListenerDistributedTest.java     |  18 +-
 .../internal/AutoConnectionSourceDUnitTest.java    |   3 +-
 ...tServerHostNameVerificationDistributedTest.java | 228 +++++++++++++++
 .../management/MemoryThresholdsDUnitTest.java      |   2 +-
 .../MemoryThresholdsOffHeapDUnitTest.java          |  18 +-
 .../dunit/QueryDataInconsistencyDUnitTest.java     |  34 +--
 .../query/dunit/QueryIndexUsingXMLDUnitTest.java   |   3 +-
 .../geode/cache30/DiskRegionDistributedTest.java   |  11 +-
 ...okenSerializationConsistencyRegressionTest.java |  20 +-
 .../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 +-
 ...ExceptionsIncludeLocalMemberRegressionTest.java |  54 ++--
 ...ctionExecutionWithExceptionDistributedTest.java |   9 +-
 ...UserAuthenticationFunctionServiceDUnitTest.java | 183 ++++++++++++
 .../cache/execute/PRTransactionDUnitTest.java      | 152 +++++-----
 ...ctionOnBehalfOfClientMemberDistributedTest.java |  14 +-
 .../cache/ha/HARegionQueueSizeRegressionTest.java  |   9 +-
 .../HARegionQueueThreadIdExpiryRegressionTest.java |  11 +-
 ...BucketCreationCrashCompletesRegressionTest.java |  51 ++--
 .../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    |  76 +++--
 .../apache/geode/management/JMXMBeanDUnitTest.java |  59 ++--
 .../management/JMXMBeanReconnectDUnitTest.java     |  10 +-
 .../management/RegionManagementDUnitTest.java      |  11 +-
 .../GfshHostNameVerificationDistributedTest.java   | 191 ++++++++++++
 .../internal/pulse/TestClientIdsDUnitTest.java     |   8 +-
 .../geode/pdx/PdxAttributesDistributedTest.java}   |  88 +++---
 .../test/dunit/tests/BasicDistributedTest.java     |  73 +++--
 .../tests/GetCurrentVmNumDistributedTest.java      |   5 +-
 .../GetPidAndIdAfterBounceDistributedTest.java     |  11 +-
 .../dunit/tests/GetPidAndIdDistributedTest.java    |   9 +-
 .../AutoConnectionSourceImplJUnitTest.java         |  24 ++
 ...opClientExecutorWithLoggingIntegrationTest.java |  66 +++++
 .../LocatorLauncherIntegrationTest.java            |  53 ++--
 .../ServerLauncherBuilderIntegrationTest.java      |  30 +-
 .../distributed/ServerLauncherIntegrationTest.java |  53 ++--
 .../gms/messenger/GMSEncryptJUnitTest.java         | 122 +++-----
 .../tcpserver/TCPClientSSLIntegrationTest.java     | 175 +++++++++++
 .../eviction/TransactionsWithOverflowTest.java     |  43 +--
 .../CacheClientNotifierIntegrationTest.java        |  24 +-
 .../ThreadsMonitoringIntegrationTest.java          |  67 +++--
 .../FileProcessControllerIntegrationTest.java      |   7 +-
 .../pdx/PdxInstanceLoaderIntegrationTest.java      |  30 +-
 .../client/internal/AutoConnectionSourceImpl.java  |  16 +-
 .../cache/query/internal/DefaultQueryService.java  |  17 +-
 .../geode/distributed/ConfigurationProperties.java |  11 +
 .../internal/AbstractDistributionConfig.java       |   4 +
 .../distributed/internal/DistributionConfig.java   |  28 ++
 .../internal/DistributionConfigImpl.java           |  13 +
 .../org/apache/geode/internal/admin/SSLConfig.java |  10 +
 .../internal/cache/AbstractBucketRegionQueue.java  |  12 +
 .../geode/internal/cache/AfterCompletion.java      | 100 +++++++
 .../geode/internal/cache/BeforeCompletion.java     |  68 +++++
 .../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/SingleThreadJTAExecutor.java    |  71 +++++
 .../org/apache/geode/internal/cache/TXState.java   |  56 +++-
 .../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 +-
 .../cache/execute/ServerFunctionExecutor.java      |  43 +--
 .../execute/ServerRegionFunctionExecutor.java      |  42 ++-
 .../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/net/SSLConfigurationFactory.java      |   2 +
 .../apache/geode/internal/net/SocketCreator.java   |   7 +
 .../geode/management/internal/ManagementAgent.java |  40 +--
 .../internal/cli/util/ClasspathScanLoadHelper.java |   2 +-
 .../internal/QueueConnectionImplJUnitTest.java     |   6 +-
 ...pClientExecutorSubmitTaskWithExceptionTest.java |  61 ----
 .../cache/query/internal/QueryMonitorTest.java     |   5 +-
 .../apache/geode/distributed/LocatorStateTest.java |  34 +--
 .../internal/DistributionConfigJUnitTest.java      |  23 +-
 .../geode/internal/cache/AfterCompletionTest.java  | 131 +++++++++
 .../geode/internal/cache/BeforeCompletionTest.java |  98 +++++++
 .../internal/cache/DistributedRegionJUnitTest.java |  32 ++
 .../cache/EntryEventSerializationTest.java         |   6 +-
 .../internal/cache/MemoryThresholdInfoTest.java    |  25 +-
 .../cache/SingleThreadJTAExecutorTest.java         |  66 +++++
 .../apache/geode/internal/cache/TXStateTest.java   |  50 +---
 .../cache/control/HeapMemoryMonitorTest.java       | 325 +++++++++++++++++++++
 .../sockets/command/ExecuteFunction66Test.java     |   4 +
 .../ParallelQueueRemovalMessageJUnitTest.java      |  24 ++
 .../cache/xmlcache/CacheCreationJUnitTest.java     |  15 +-
 .../GemFireBasicDataSourceJUnitTest.java           |  17 +-
 .../geode/internal/lang/ThrowableUtilsTest.java    |  64 ++--
 .../internal/offheap/FreeListManagerTest.java      |  41 ++-
 .../MemoryAllocatorFillPatternJUnitTest.java       |  25 +-
 .../security/GemFireSecurityExceptionTest.java     |  91 +++---
 .../geode/security/NotAuthorizedExceptionTest.java |  97 +++---
 geode-cq/build.gradle                              |   1 +
 ...ientStatisticsPublicationSecurityDUnitTest.java |  14 +-
 .../commands/DescribeClientCommandDUnitTest.java   |   5 +-
 .../tier/sockets/ClientServerMiscBCDUnitTest.java  |  15 +-
 geode-dunit/build.gradle                           |   3 -
 .../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 ++-
 .../geode/internal/cache/CommitFunction.java       |   0
 .../internal/cache/NestedTransactionFunction.java  |   0
 .../cache/PartitionedRegionGetSomeKeys.java        |   0
 .../geode/internal/cache/RollbackFunction.java     |   0
 .../apache/geode/internal/cache/ha/HAHelper.java   |   0
 .../internal/cache/tier/sockets/HaHelper.java      |   0
 .../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 |  44 +--
 .../test/dunit/rules/DistributedDiskDirRule.java   |  29 +-
 .../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/ClientCacheRule.java    |   4 +
 .../apache/geode/test/junit/rules/DiskDirRule.java |  23 +-
 .../DoNotHandleUnexpectedExceptionExampleTest.java |   2 -
 geode-junit/build.gradle                           |   4 +-
 .../org/apache/geode/cache/ssl/CertStores.java     | 145 +++++++++
 .../org/apache/geode/cache/ssl/TestSSLUtils.java   | 195 +++++++++++++
 geode-lucene/build.gradle                          |  10 +-
 .../geode/cache/lucene/ExpirationDUnitTest.java    |   9 +-
 ...eneIndexCreationPersistenceIntegrationTest.java |  13 +-
 .../LuceneSearchWithRollingUpgradeDUnit.java       |  15 +-
 geode-old-client-support/build.gradle              |   2 +-
 geode-old-versions/build.gradle                    |   4 +-
 geode-protobuf/build.gradle                        |   7 +-
 geode-pulse/build.gradle                           |  14 +-
 .../GatewayLegacyAuthenticationRegressionTest.java |  22 +-
 .../ParallelGatewaySenderOperationsDUnitTest.java  |  11 +-
 .../WANHostNameVerificationDistributedTest.java    | 313 ++++++++++++++++++++
 geode-web-api/build.gradle                         |   3 +-
 geode-web/build.gradle                             |  10 +-
 gradle.properties                                  |   2 +-
 gradle/dependency-versions.properties              |   3 +-
 gradle/ide.gradle                                  |  16 +-
 gradle/java.gradle                                 |   8 +
 gradle/publish.gradle                              | 119 +++++++-
 gradle/sonar.gradle                                |   8 +-
 gradle/test.gradle                                 |  26 +-
 gradle/utilities.gradle                            |   3 +
 gradle/wrapper/gradle-wrapper.jar                  | Bin 54413 -> 56172 bytes
 gradle/wrapper/gradle-wrapper.properties           |   2 +-
 settings.gradle                                    |  29 +-
 259 files changed, 5488 insertions(+), 2366 deletions(-)
 create mode 100644 ci/pipelines/shared/utilities.sh
 create mode 100755 ci/scripts/publish.sh
 create mode 100644 geode-core/src/distributedTest/java/org/apache/geode/cache/client/internal/ClientServerHostNameVerificationDistributedTest.java
 create mode 100644 geode-core/src/distributedTest/java/org/apache/geode/internal/cache/execute/MultiUserAuthenticationFunctionServiceDUnitTest.java
 create mode 100644 geode-core/src/distributedTest/java/org/apache/geode/management/internal/cli/commands/GfshHostNameVerificationDistributedTest.java
 rename geode-core/src/{integrationTest/java/org/apache/geode/pdx/PdxAttributesJUnitTest.java => distributedTest/java/org/apache/geode/pdx/PdxAttributesDistributedTest.java} (81%)
 create mode 100644 geode-core/src/integrationTest/java/org/apache/geode/cache/client/internal/SingleHopClientExecutorWithLoggingIntegrationTest.java
 create mode 100644 geode-core/src/integrationTest/java/org/apache/geode/distributed/internal/tcpserver/TCPClientSSLIntegrationTest.java
 rename geode-core/src/{test => integrationTest}/java/org/apache/geode/internal/monitoring/ThreadsMonitoringIntegrationTest.java (57%)
 create mode 100644 geode-core/src/main/java/org/apache/geode/internal/cache/AfterCompletion.java
 create mode 100644 geode-core/src/main/java/org/apache/geode/internal/cache/BeforeCompletion.java
 create mode 100644 geode-core/src/main/java/org/apache/geode/internal/cache/MemoryThresholdInfo.java
 create mode 100644 geode-core/src/main/java/org/apache/geode/internal/cache/SingleThreadJTAExecutor.java
 delete mode 100644 geode-core/src/test/java/org/apache/geode/cache/client/internal/SingleHopClientExecutorSubmitTaskWithExceptionTest.java
 create mode 100644 geode-core/src/test/java/org/apache/geode/internal/cache/AfterCompletionTest.java
 create mode 100644 geode-core/src/test/java/org/apache/geode/internal/cache/BeforeCompletionTest.java
 copy geode-dunit/src/distributedTest/java/org/apache/geode/test/dunit/examples/DistributedTestRuleExampleTest.java => geode-core/src/test/java/org/apache/geode/internal/cache/MemoryThresholdInfoTest.java (58%)
 create mode 100644 geode-core/src/test/java/org/apache/geode/internal/cache/SingleThreadJTAExecutorTest.java
 create mode 100644 geode-core/src/test/java/org/apache/geode/internal/cache/control/HeapMemoryMonitorTest.java
 rename geode-dunit/src/distributedTest/java/org/apache/geode/test/dunit/examples/{DistributedTestRuleExampleTest.java => DistributedRuleAsClassRuleExampleTest.java} (50%)
 create mode 100644 geode-dunit/src/distributedTest/java/org/apache/geode/test/dunit/rules/tests/ClientCacheRuleDistributedTest.java
 rename geode-dunit/src/distributedTest/java/org/apache/geode/test/dunit/rules/tests/{DistributedTestRuleDistributedTest.java => DistributedRuleDistributedTest.java} (76%)
 rename {geode-core/src/distributedTest => geode-dunit/src/main}/java/org/apache/geode/internal/cache/CommitFunction.java (100%)
 rename {geode-core/src/distributedTest => geode-dunit/src/main}/java/org/apache/geode/internal/cache/NestedTransactionFunction.java (100%)
 rename {geode-core/src/distributedTest => geode-dunit/src/main}/java/org/apache/geode/internal/cache/PartitionedRegionGetSomeKeys.java (100%)
 rename {geode-core/src/distributedTest => geode-dunit/src/main}/java/org/apache/geode/internal/cache/RollbackFunction.java (100%)
 rename {geode-core/src/distributedTest => geode-dunit/src/main}/java/org/apache/geode/internal/cache/ha/HAHelper.java (100%)
 rename {geode-core/src/distributedTest => geode-dunit/src/main}/java/org/apache/geode/internal/cache/tier/sockets/HaHelper.java (100%)
 rename geode-dunit/src/main/java/org/apache/geode/test/dunit/rules/{AbstractDistributedTestRule.java => AbstractDistributedRule.java} (90%)
 rename geode-dunit/src/main/java/org/apache/geode/test/dunit/rules/{DistributedTestRule.java => DistributedRule.java} (71%)
 create mode 100644 geode-junit/src/main/java/org/apache/geode/cache/ssl/CertStores.java
 create mode 100644 geode-junit/src/main/java/org/apache/geode/cache/ssl/TestSSLUtils.java
 create mode 100644 geode-wan/src/distributedTest/java/org/apache/geode/internal/cache/wan/serial/WANHostNameVerificationDistributedTest.java


[geode] 01/01: initial commit for windows heavy lifting

Posted by je...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

jensdeppe pushed a commit to branch windows-heavy-lifter
in repository https://gitbox.apache.org/repos/asf/geode.git

commit 2bca4fc2b0e08be24f3f621361f8f008ae1d38e2
Author: Jens Deppe <jd...@pivotal.io>
AuthorDate: Wed Aug 22 11:58:01 2018 -0700

    initial commit for windows heavy lifting
---
 ci/images/alpine-tools/Dockerfile           |  5 +-
 ci/pipelines/geode-build/jinja.template.yml | 71 +++--------------------------
 ci/pipelines/shared/jinja.variables.yml     | 53 ++++++++++-----------
 ci/scripts/execute_tests.sh                 |  2 +-
 ci/scripts/rsync_code_down.sh               |  4 +-
 ci/scripts/start_instance.sh                | 30 ++++++++++--
 gradle.properties                           |  2 +-
 7 files changed, 65 insertions(+), 102 deletions(-)

diff --git a/ci/images/alpine-tools/Dockerfile b/ci/images/alpine-tools/Dockerfile
index 1337fd9..a5bf091 100644
--- a/ci/images/alpine-tools/Dockerfile
+++ b/ci/images/alpine-tools/Dockerfile
@@ -38,4 +38,7 @@ RUN apk --no-cache add \
   && (cd winrm-cli; GOPATH=$PWD PATH=$PATH:$PWD/bin make) \
   && cp winrm-cli/bin/winrm /usr/local/bin/ \
   && rm -rf winrm-cli \
-  && gcloud components install -q beta
+  && gcloud components install -q beta \
+  && echo "Host *" >> /etc/ssh/ssh_config \
+  && echo "    ServerAliveInterval 60" >> /etc/ssh/ssh_config \
+  && echo "    ServerAliveCountMax 2" >> /etc/ssh/ssh_config
diff --git a/ci/pipelines/geode-build/jinja.template.yml b/ci/pipelines/geode-build/jinja.template.yml
index e94c99d..e72b2ca 100644
--- a/ci/pipelines/geode-build/jinja.template.yml
+++ b/ci/pipelines/geode-build/jinja.template.yml
@@ -31,7 +31,12 @@
 {% endmacro %}
 
 {% macro common_test_params(test) %}
+  {% if test.CALL_STACK_TIMEOUT %}
 CALL_STACK_TIMEOUT: {{test.CALL_STACK_TIMEOUT}}
+  {% endif %}
+  {% if test.GRADLE_TASK_OPTIONS %}
+GRADLE_TASK_OPTIONS: {{test.GRADLE_TASK_OPTIONS}}
+  {% endif %}
 DUNIT_PARALLEL_FORKS: {{test.DUNIT_PARALLEL_FORKS}}
 MAINTENANCE_VERSION: {{repository.branch}}
 PARALLEL_DUNIT: {{test.PARALLEL_DUNIT}}
@@ -44,7 +49,7 @@ groups:
 - name: main
   jobs:
   - Build
-  {% for test in (tests + windowstests) if not test.name=="StressNew" -%}
+  {% for test in tests if not test.name=="StressNew" -%}
   - {{test.name}}Test
   {% endfor -%}
   - UpdatePassingRef
@@ -321,67 +326,3 @@ jobs:
               - name: instance-data
             timeout: 1h
 {% endfor -%}
-{% for test in windowstests %}
-- name: {{test.name}}Test
-  public: true
-  serial: true
-  plan:
-  {{ plan_resource_gets() |indent(2) }}
-  - task: cleanup-java-processes
-    config:
-      platform: windows
-      run:
-        path: powershell
-        args:
-        - -command
-        - |
-          gwmi win32_process -filter 'name = "java.exe"' | select commandline | format-list
-          kill -name java -force
-          exit 0
-    tags:
-    - windows-{{test.tags}}-tests
-  - task: execute_tests
-    config:
-      platform: windows
-      params:
-        JAVA_HOME: C:\progra~1\java\jdk1.8.0_181
-        SOURCE_REPOSITORY: {{repository.branch}}
-        {{ common_test_params(test) | indent(8) }}
-      run:
-        path: bash
-        args:
-        - geode-ci/ci/scripts/windows/test-run.sh
-        - {{test.target_arg}}
-        - {{test.dir_arg}}
-        - {{test.package_arg}}
-      inputs:
-      - name: geode-ci
-      - name: geode
-      outputs:
-      - name: built-geode
-    tags:
-    - windows-{{test.tags}}-tests
-    ensure:
-      aggregate:
-      - task: archive_results
-        config:
-          platform: windows
-          params:
-            MAINTENANCE_VERSION: {{repository.branch}}
-            PUBLIC_BUCKET: ((!public-bucket))
-            SERVICE_ACCOUNT: ((!concourse-gcp-account))
-          run:
-            path: bash
-            args:
-            - geode-ci/ci/scripts/windows/test-archive.sh
-            - {{test.target_arg}}
-            - {{test.dir_arg}}
-          inputs:
-          - name: geode-ci
-          - name: geode-build-version
-          - name: built-geode
-        tags:
-        - windows-{{test.tags}}-tests
-        timeout: 1h
-    timeout: 6h
-{% endfor %}
diff --git a/ci/pipelines/shared/jinja.variables.yml b/ci/pipelines/shared/jinja.variables.yml
index 85d495a..41ba532 100644
--- a/ci/pipelines/shared/jinja.variables.yml
+++ b/ci/pipelines/shared/jinja.variables.yml
@@ -18,12 +18,6 @@
 repository:
   project: geode
 
-platforms:
-- name: "Linux"
-  prefix: ""
-- name: "Windows"
-  prefix: "Windows"
-
 tests:
 - name: "Acceptance"
   CPUS: "8"
@@ -71,37 +65,40 @@ tests:
   GRADLE_TASK: repeatTest
   execute_test_timeout: 2h15m
   PARALLEL_DUNIT: "true"
-
-windowstests:
 - name: "WindowsAcceptance"
-  tags: "acceptance"
-  CALL_STACK_TIMEOUT: "1800"
+  tags: "windows"
+  CPUS: "16"
+  RAM: "32"
+  ARTIFACT_SLUG: windows-acceptancetestfiles
   DUNIT_PARALLEL_FORKS: "0"
+  GRADLE_TASK: :geode-assembly:acceptanceTest
+  execute_test_timeout: 6h
   PARALLEL_DUNIT: "false"
-  target_arg: :geode-assembly:acceptanceTest
-  dir_arg: windows-acceptancetestfiles
-  package_arg: ""
 - name: "WindowsGfshDistributed"
-  tags: "distributed"
-  CALL_STACK_TIMEOUT: "1800"
+  tags: "windows"
+  CPUS: "16"
+  RAM: "32"
+  ARTIFACT_SLUG: windows-gfshdistributedtest
   DUNIT_PARALLEL_FORKS: "0"
+  GRADLE_TASK: distributedTest
+  GRADLE_TASK_OPTIONS: "-PtestCategory=org.apache.geode.test.junit.categories.GfshTest"
+  execute_test_timeout: 6h
   PARALLEL_DUNIT: "false"
-  target_arg: distributedTest
-  dir_arg: windows-gfshdistributedtest
-  package_arg: org.apache.geode.test.junit.categories.GfshTest
 - name: "WindowsIntegration"
-  tags: "integration"
-  CALL_STACK_TIMEOUT: "1800"
+  tags: "windows"
+  CPUS: "16"
+  RAM: "32"
+  ARTIFACT_SLUG: windows-integrationtestfiles
   DUNIT_PARALLEL_FORKS: "0"
+  GRADLE_TASK: integrationTest
+  execute_test_timeout: 6h
   PARALLEL_DUNIT: "false"
-  target_arg: integrationTest
-  dir_arg: windows-integrationtestfiles
-  package_arg: ""
 - name: "WindowsUnit"
-  tags: "unit"
-  CALL_STACK_TIMEOUT: "1800"
+  tags: "windows"
+  CPUS: "16"
+  RAM: "32"
+  ARTIFACT_SLUG: windows-unittestfiles
   DUNIT_PARALLEL_FORKS: "0"
+  GRADLE_TASK: test
+  execute_test_timeout: 6h
   PARALLEL_DUNIT: "false"
-  target_arg: test
-  dir_arg: windows-unittestfiles
-  package_arg: ""
diff --git a/ci/scripts/execute_tests.sh b/ci/scripts/execute_tests.sh
index d36f85b..c4bd456 100755
--- a/ci/scripts/execute_tests.sh
+++ b/ci/scripts/execute_tests.sh
@@ -84,4 +84,4 @@ GRADLE_COMMAND="./gradlew \
     ${SCM_PROPS}"
 
 echo "${GRADLE_COMMAND}"
-ssh -i ${SSHKEY_FILE} geode@${INSTANCE_IP_ADDRESS} "mkdir -p tmp && cd geode && ${GRADLE_COMMAND}"
+ssh -i ${SSHKEY_FILE} geode@${INSTANCE_IP_ADDRESS} "bash -c 'mkdir -p tmp; cd geode; ${GRADLE_COMMAND}'"
diff --git a/ci/scripts/rsync_code_down.sh b/ci/scripts/rsync_code_down.sh
index ce12bcc..a94bb90 100755
--- a/ci/scripts/rsync_code_down.sh
+++ b/ci/scripts/rsync_code_down.sh
@@ -40,7 +40,7 @@ echo 'StrictHostKeyChecking no' >> /etc/ssh/ssh_config
 
 OUTPUT_DIR=${BASE_DIR}/geode-results
 
-ssh -i ${SSHKEY_FILE} geode@${INSTANCE_IP_ADDRESS} "cd geode && ./gradlew combineReports"
+ssh -i ${SSHKEY_FILE} geode@${INSTANCE_IP_ADDRESS} "bash -c 'cd geode; ./gradlew --no-daemon combineReports'"
 
-time rsync -e "ssh -i ${SSHKEY_FILE}" -ah geode@${INSTANCE_IP_ADDRESS}:. ${OUTPUT_DIR}/.
+time rsync -e "ssh -i ${SSHKEY_FILE}" -ah geode@${INSTANCE_IP_ADDRESS}:geode ${OUTPUT_DIR}/
 set +x
diff --git a/ci/scripts/start_instance.sh b/ci/scripts/start_instance.sh
index 3bee7f9..88621f8 100755
--- a/ci/scripts/start_instance.sh
+++ b/ci/scripts/start_instance.sh
@@ -18,6 +18,7 @@
 # limitations under the License.
 
 set -e
+set -x
 
 BASE_DIR=$(pwd)
 
@@ -54,11 +55,16 @@ SANITIZED_BUILD_PIPELINE_NAME=$(echo ${BUILD_PIPELINE_NAME} | tr "/" "-" | tr '[
 SANITIZED_BUILD_JOB_NAME=$(echo ${BUILD_JOB_NAME} | tr "/" "-" | tr '[:upper:]' '[:lower:]')
 SANITIZED_BUILD_NAME=$(echo ${BUILD_NAME} | tr "/" "-" | tr '[:upper:]' '[:lower:]')
 IMAGE_FAMILY_PREFIX=""
+WINDOWS_PREFIX=""
 
 if [[ "${SANITIZED_GEODE_FORK}" != "apache" ]]; then
   IMAGE_FAMILY_PREFIX="${SANITIZED_GEODE_FORK}-${SANITIZED_GEODE_BRANCH}-"
 fi
 
+if [[ "${SANITIZED_BUILD_JOB_NAME}" =~ [Ww]indows ]]; then
+  WINDOWS_PREFIX="windows-"
+fi
+
 INSTANCE_NAME="$(echo "${BUILD_PIPELINE_NAME}-${BUILD_JOB_NAME}-${BUILD_NAME}" | tr '[:upper:]' '[:lower:]')"
 PROJECT=apachegeode-ci
 ZONE=us-central1-f
@@ -80,7 +86,7 @@ while true; do
       --min-cpu-platform=Intel\ Skylake \
       --network="heavy-lifters" \
       --subnet="heavy-lifters" \
-      --image-family="${IMAGE_FAMILY_PREFIX}geode-builder" \
+      --image-family="${IMAGE_FAMILY_PREFIX}${WINDOWS_PREFIX}geode-builder" \
       --image-project=${PROJECT} \
       --boot-disk-size=100GB \
       --boot-disk-type=pd-ssd \
@@ -103,6 +109,22 @@ echo "${INSTANCE_INFORMATION}" > instance-data/instance-information
 INSTANCE_IP_ADDRESS=$(echo ${INSTANCE_INFORMATION} | jq -r '.[].networkInterfaces[0].accessConfigs[0].natIP')
 echo "${INSTANCE_IP_ADDRESS}" > "instance-data/instance-ip-address"
 
-while ! gcloud compute --project=${PROJECT} ssh geode@${INSTANCE_NAME} --zone=${ZONE} --ssh-key-file=${SSHKEY_FILE} --quiet -- true; do
-  echo -n .
-done
+if [[ -z "${WINDOWS_PREFIX}" ]]; then
+  while ! gcloud compute --project=${PROJECT} ssh geode@${INSTANCE_NAME} --zone=${ZONE} --ssh-key-file=${SSHKEY_FILE} --quiet -- true; do
+    echo -n .
+  done
+else
+  # Set up ssh access for Windows systems
+  while [[ -z "${PASSWORD}" ]]; do
+    PASSWORD=$( yes | gcloud beta compute reset-windows-password ${INSTANCE_NAME} --user=geode --zone=${ZONE} --format json | jq -r .password )
+    sleep 5
+  done
+
+  ssh-keygen -N "" -f ${SSHKEY_FILE}
+
+  KEY=$( cat ${SSHKEY_FILE}.pub )
+
+  winrm -hostname ${INSTANCE_IP_ADDRESS} -username geode -password "${PASSWORD}" \
+    -https -insecure -port 5986 \
+    "powershell -command \"&{ mkdir c:\users\geode\.ssh -force; set-content -path c:\users\geode\.ssh\authorized_keys -encoding utf8 -value '${KEY}' }\""
+fi
diff --git a/gradle.properties b/gradle.properties
index 3edf13d..e9c97ec 100755
--- a/gradle.properties
+++ b/gradle.properties
@@ -42,7 +42,7 @@ productName = Apache Geode
 productOrg = Apache Software Foundation (ASF)
 
 org.gradle.daemon = true
-org.gradle.jvmargs = -Xmx3g
+org.gradle.jvmargs = -Xmx4g
 
 minimumGradleVersion = 4.10
 # Set this on the command line with -P or in ~/.gradle/gradle.properties