You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by mh...@apache.org on 2020/04/29 16:40:48 UTC

[geode] branch mass-test-run updated (51a6897 -> fbc7812)

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

mhanson pushed a change to branch mass-test-run
in repository https://gitbox.apache.org/repos/asf/geode.git.


 discard 51a6897  remove meta-* jobs that we won't use for mass-test-run
 discard a4d211d  Mass-test-run branch, no windows or publication jobs
     add 0a1701e  GEODE-7964: Upgrade Mockito to 3.3.3 (#4924)
     add 2999414  GEODE-7851: Pulse refreshes expired access tokens (#4977)
     add 0aae6cb  GEODE-8022: Fix windows image build via pinning. (#4993)
     add 326f228  GEODE-8023: add old version on support branch too (#4995)
     add 8e68aba  GEODE-8024: fix wan test to also work on support branches (#4997)
     add fad52b8  GEODE-8025: fix lucene test to not hang on support branches (#4999)
     add edcc077  GEODE-8026: release improvements (#5002)
     add 33ae60f  GEODE-7999: make support branches publish snapshots (#4996)
     add be81285  GEODE-8027: documentation script to attach swagger json (#5001)
     add ec8db54  GEODE-8020: buffer corruption in SSL communications (#4994)
     add 0f99185  GEODE-7953: Restore Redundancy Internal API (#4909)
     add ccc3f46  GEODE-7981: fix docs for redis PARTITION_REDUNDANT (#5003)
     add 9fad2c0  Revert "GEODE-7953: Restore Redundancy Internal API (#4909)" (#5006)
     add ee21019  GEODE-8031: Close lingering SocketCreatorFactory instances (#5007)
     add 6d35884  GEODE-7953: Restore Redundancy Internal API (#5010)
     add 5e0b25a  GEODE-7964: Fixup all tests touched for Mockito upgrade (#4986)
     add 3aa3659  GEODE 8014: delete redis sets and hashes when empty (#4989)
     add aa330f3  GEODE-8028: refactor RedisCommandType (#4998)
     add e7b0186  GEODE-6636: Create multiple buffer pools (#4234)
     add 35718a5  GEODE-8034: Create distributed tests for SREM command (#5013)
     add 1098fc2  GEODE-8038: Fix product name in docs (#5017)
     add c12e8cc  GEODE-7503: Block Cache.close() until everything is disconnected (#4963)
     new a9a7ee2  Mass-test-run branch, no windows or publication jobs
     new fbc7812  remove meta-* jobs that we won't use for mass-test-run

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   (51a6897)
            \
             N -- N -- N   refs/heads/mass-test-run (fbc7812)

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 2 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:
 .../src/test/resources/expected-pom.xml            |    2 +-
 .../gradle/plugins/DependencyConstraints.groovy    |    2 +-
 ci/images/google-geode-builder/build_image.sh      |   63 -
 ci/images/google-geode-builder/packer.json         |    2 +-
 .../{windows-packer.json => packer.json}           |    2 +-
 ci/pipelines/images/jinja.template.yml             |   16 +-
 .../build_image.sh                                 |   22 +-
 dev-tools/release/README.md                        |    1 +
 dev-tools/release/commit_rc.sh                     |   11 +-
 dev-tools/release/create_support_branches.sh       |   60 +-
 dev-tools/release/deploy_rc_pipeline.sh            |  129 +-
 dev-tools/release/prepare_rc.sh                    |   59 +-
 dev-tools/release/promote_rc.sh                    |   26 +-
 dev-tools/release/set_copyright.sh                 |   57 +
 dev-tools/release/set_versions.sh                  |   98 +-
 .../integrationTest/resources/assembly_content.txt |    5 +
 .../source/subnavs/geode-subnav.erb                |    2 +-
 .../geode/connectors/jdbc/JdbcAsyncWriterTest.java |    4 +-
 .../geode/connectors/jdbc/JdbcWriterTest.java      |    6 +-
 .../jdbc/internal/xml/ElementTypeTest.java         |    4 +-
 .../xml/JdbcConnectorServiceXmlParserTest.java     |    6 +-
 .../geode/ClusterCommunicationsDUnitTest.java      |   33 +-
 .../RestoreRedundancyOperationDUnitTest.java       |  347 +++
 ...butedSystemMXBeanWithAlertsDistributedTest.java |   10 +-
 .../client/internal/QueueManagerJUnitTest.java     |  285 +-
 .../AvailableConnectionManagerConcurrentTest.java  |  152 +-
 .../pooling/ConnectionManagerJUnitTest.java        | 1130 ++++---
 .../CacheDistributionAdvisorConcurrentTest.java    |   63 +-
 .../cache/ha/HARegionQueueIntegrationTest.java     |  460 ++-
 .../ControlFileWatchdogIntegrationTest.java        |    6 +-
 .../codeAnalysis/sanctionedDataSerializables.txt   |    8 +
 .../geode/cache/client/internal/Connection.java    |    6 +
 .../cache/client/internal/ConnectionImpl.java      |   15 +
 .../cache/client/internal/QueueConnectionImpl.java |   15 +
 .../pooling/AvailableConnectionManager.java        |   36 +-
 .../client/internal/pooling/ConnectionManager.java |    9 +-
 .../internal/pooling/ConnectionManagerImpl.java    |    8 +-
 .../client/internal/pooling/PooledConnection.java  |    3 +
 .../cache/control/RegionRedundancyStatus.java      |   69 +
 .../geode/cache/control/ResourceManager.java       |   22 +
 .../cache/control/RestoreRedundancyOperation.java  |   62 +
 .../cache/control/RestoreRedundancyResults.java    |  119 +
 .../internal/InternalDistributedSystem.java        |    2 +-
 .../distributed/internal/InternalLocator.java      |    2 +-
 .../org/apache/geode/internal/DSFIDFactory.java    |    4 +
 .../geode/internal/cache/GemFireCacheImpl.java     |  458 +--
 .../apache/geode/internal/cache/InternalCache.java |    3 +-
 .../cache/InternalCacheForClientAccess.java        |    6 +-
 .../cache/control/InternalResourceManager.java     |   56 +-
 .../cache/control/RegionRedundancyStatusImpl.java  |  153 +
 .../cache/control/ResourceManagerStats.java        |   40 +
 .../control/RestoreRedundancyOperationImpl.java    |  179 ++
 .../control/RestoreRedundancyResultsImpl.java      |  206 ++
 .../partitioned/PartitionedRegionRebalanceOp.java  |   33 +-
 .../partitioned/rebalance/CompositeDirector.java   |   21 +-
 .../partitioned/rebalance/SatisfyRedundancy.java   |    3 -
 .../model/PartitionedRegionLoadModel.java          |    3 +
 .../internal/cache/xmlcache/CacheCreation.java     |    2 +-
 .../cache/xmlcache/ResourceManagerCreation.java    |   23 +
 .../org/apache/geode/internal/net/BufferPool.java  |  172 +-
 .../apache/geode/internal/net/NioSslEngine.java    |    4 +-
 .../org/apache/geode/internal/tcp/Connection.java  |   18 +-
 .../sanctioned-geode-core-serializables.txt        |    2 +
 .../internal/ClusterAlertMessagingTest.java        |    4 +-
 .../client/internal/OpExecutorImplJUnitTest.java   |  517 ++--
 .../pooling/AvailableConnectionManagerTest.java    |   66 +-
 .../geode/distributed/ServerLauncherTest.java      |   10 +-
 .../internal/cache/GemFireCacheImplCloseTest.java  |   56 +-
 .../internal/cache/InternalCacheBuilderTest.java   |    4 +-
 .../PartitionedRegionRedundancyTrackerTest.java    |    3 +-
 .../internal/cache/backup/BackupOperationTest.java |    6 +-
 .../control/RegionRedundancyStatusImplTest.java    |   94 +
 .../RestoreRedundancyOperationImplTest.java        |  206 ++
 .../control/RestoreRedundancyResultsImplTest.java  |  186 ++
 .../SingleThreadColocationLoggerTest.java          |    3 +-
 .../rebalance/BucketOperatorImplTest.java          |    7 +-
 .../sockets/command/ExecuteFunction65Test.java     |    4 +-
 .../sockets/command/ExecuteFunction66Test.java     |    6 +-
 .../tier/sockets/command/ExecuteFunctionTest.java  |    6 +-
 .../io/CompositeOutputStreamJUnitTest.java         |    8 +-
 .../apache/geode/internal/net/BufferPoolTest.java  |   48 +
 .../geode/internal/net/NioPlainEngineTest.java     |    4 +-
 .../geode/internal/net/NioSslEngineTest.java       |    9 +-
 .../net/SocketCreatorFactoryJUnitTest.java         |    7 +
 .../management/internal/FederatingManagerTest.java |    4 +-
 .../internal/beans/ManagementListenerTest.java     |    8 +-
 geode-docs/prereq_and_install.html.md.erb          |   10 +-
 geode-docs/tools_modules/redis_adapter.html.md.erb |    6 +-
 .../test/dunit/internal/VMEventNotifierTest.java   |    4 +-
 .../functions/AlterQueryServiceFunctionTest.java   |    8 +-
 .../cli/functions/RegionAlterFunctionTest.java     |    4 +-
 ...ccessfulWhenAllServersRollToCurrentVersion.java |   14 +
 .../src/test/script/update-management-wiki.sh      |   32 +-
 .../geode/memcached/IntegrationJUnitTest.java      |    4 +-
 .../security/OAuthSecurityTokenHandoffTest.java    |   80 +-
 .../internal/controllers/PulseController.java      |    7 +
 .../geode/tools/pulse/internal/data/Cluster.java   |   12 +
 .../tools/pulse/internal/data/Repository.java      |  262 +-
 .../src/main/webapp/scripts/pulsescript/common.js  |    3 +
 .../SaddDUnitTest.java}                            |    4 +-
 .../SremDUnitTest.java}                            |  101 +-
 .../apache/geode/redis/HashesIntegrationTest.java  |   79 +
 .../apache/geode/redis/SetsIntegrationTest.java    |   77 +
 .../org/apache/geode/redis/GeodeRedisServer.java   |   10 +
 .../geode/redis/internal/RedisCommandType.java     | 3118 +-------------------
 .../geode/redis/internal/RedisConstants.java       |    2 +-
 .../executor/hash/GeodeRedisHashSynchronized.java  |    7 +
 .../redis/internal/executor/hash/HDelExecutor.java |    2 +
 .../executor/set/GeodeRedisSetSynchronized.java    |   10 +
 .../redis/internal/executor/set/SRemExecutor.java  |    1 +
 .../sanctioned-geode-redis-serializables.txt       |  127 +-
 .../internal/ExecutionHandlerContextJUnitTest.java |   12 +-
 .../executor/string/GetSetExecutorJUnitTest.java   |   21 -
 .../serialization/DataSerializableFixedID.java     |    3 +
 ...ateGatewaySenderMixedSiteOneCurrentSiteTwo.java |   25 +-
 115 files changed, 4887 insertions(+), 5249 deletions(-)
 delete mode 100755 ci/images/google-geode-builder/build_image.sh
 rename ci/images/google-windows-geode-builder/{windows-packer.json => packer.json} (99%)
 rename ci/{images/google-windows-geode-builder => scripts}/build_image.sh (80%)
 create mode 100755 dev-tools/release/set_copyright.sh
 create mode 100644 geode-core/src/distributedTest/java/org/apache/geode/internal/cache/control/RestoreRedundancyOperationDUnitTest.java
 create mode 100644 geode-core/src/main/java/org/apache/geode/cache/control/RegionRedundancyStatus.java
 create mode 100644 geode-core/src/main/java/org/apache/geode/cache/control/RestoreRedundancyOperation.java
 create mode 100644 geode-core/src/main/java/org/apache/geode/cache/control/RestoreRedundancyResults.java
 create mode 100644 geode-core/src/main/java/org/apache/geode/internal/cache/control/RegionRedundancyStatusImpl.java
 create mode 100644 geode-core/src/main/java/org/apache/geode/internal/cache/control/RestoreRedundancyOperationImpl.java
 create mode 100644 geode-core/src/main/java/org/apache/geode/internal/cache/control/RestoreRedundancyResultsImpl.java
 create mode 100644 geode-core/src/test/java/org/apache/geode/internal/cache/control/RegionRedundancyStatusImplTest.java
 create mode 100644 geode-core/src/test/java/org/apache/geode/internal/cache/control/RestoreRedundancyOperationImplTest.java
 create mode 100644 geode-core/src/test/java/org/apache/geode/internal/cache/control/RestoreRedundancyResultsImplTest.java
 copy geode-redis/src/distributedTest/java/org/apache/geode/redis/{SaddDistDunitTest.java => executors/SaddDUnitTest.java} (99%)
 rename geode-redis/src/distributedTest/java/org/apache/geode/redis/{SaddDistDunitTest.java => executors/SremDUnitTest.java} (67%)


[geode] 02/02: remove meta-* jobs that we won't use for mass-test-run

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

mhanson pushed a commit to branch mass-test-run
in repository https://gitbox.apache.org/repos/asf/geode.git

commit fbc781251c6d3ebf9ed1495b5a12e4f9ffcd2f5c
Author: Mark Hanson <mh...@pivotal.io>
AuthorDate: Mon Jan 27 15:27:19 2020 -0800

    remove meta-* jobs that we won't use for mass-test-run
---
 ci/pipelines/meta/jinja.template.yml | 206 +----------------------------------
 1 file changed, 1 insertion(+), 205 deletions(-)

diff --git a/ci/pipelines/meta/jinja.template.yml b/ci/pipelines/meta/jinja.template.yml
index 792254f..a67e377 100644
--- a/ci/pipelines/meta/jinja.template.yml
+++ b/ci/pipelines/meta/jinja.template.yml
@@ -51,13 +51,7 @@ resources:
     branch: ((!geode-build-branch))
     paths:
     - ci/pipelines/images/*
-- name: geode-reaper-pipeline
-  type: git
-  source:
-    {{ github_access() | indent(4) }}
-    branch: ((!geode-build-branch))
-    paths:
-    - ci/pipelines/reaper/*
+
 - name: meta-mini-dockerfile
   type: git
   source:
@@ -71,35 +65,6 @@ resources:
     username: ((!docker-username))
     password: ((!docker-password))
     repository: gcr.io/((!gcp-project))/((!sanitized-geode-fork))-((!sanitized-geode-build-branch))-meta-img
-{% if repository.fork == repository.upstream_fork %}
-- name: geode-examples-pipeline
-  type: git
-  source:
-    {{ github_access() | indent(4) }}
-    branch: ((!geode-build-branch))
-    paths:
-    - ci/pipelines/examples/*
-    - ci/pipelines/shared/*
-    - ci/pipelines/render.py
-    - ci/pipelines/meta/meta.properties
-- name: geode-pr-pipeline
-  type: git
-  source:
-    {{ github_access() | indent(4) }}
-    branch: ((!geode-build-branch))
-    paths:
-    - ci/pipelines/pull-request/*
-    - ci/pipelines/shared/*
-    - ci/pipelines/render.py
-    - ci/pipelines/meta/meta.properties
-{% endif %}
-- name: geode-metrics-pipeline
-  type: git
-  source:
-    {{ github_access() | indent(4) }}
-    branch: ((!geode-build-branch))
-    paths:
-    - ci/pipelines/metrics/*
 
 jobs:
 - name: set-images-pipeline
@@ -187,175 +152,6 @@ jobs:
         - results/pipeline-vars.yml
 
 
-{% if repository.fork == repository.upstream_fork %}
-- name: set-examples-pipeline
-  serial: true
-  public: ((!public-pipelines))
-  plan:
-  - get: geode-examples-pipeline
-    trigger: true
-  - get: meta-mini-image
-    trigger: true
-    passed: [build-meta-mini-docker-image]
-  - task: deploy-build
-    image: meta-mini-image
-    config:
-      platform: linux
-      inputs:
-        - name: geode-examples-pipeline
-      outputs:
-        - name: results
-      params:
-        OUTPUT_DIRECTORY: results
-        GEODE_BRANCH: ((geode-build-branch))
-        GEODE_FORK: ((geode-fork))
-        GEODE_REPO_NAME: ((geode-repo-name))
-        REPOSITORY_PUBLIC: {{ repository.public }}
-        ARTIFACT_BUCKET: ((artifact-bucket))
-        UPSTREAM_FORK: {{ repository.upstream_fork }}
-        PIPELINE_PREFIX: ((pipeline-prefix))
-        SANITIZED_GEODE_BRANCH: ((sanitized-geode-build-branch))
-        SANITIZED_GEODE_FORK: ((sanitized-geode-fork))
-        GCP_PROJECT: ((gcp-project))
-        PUBLIC_PIPELINES: ((public-pipelines))
-        SEMVER_PRERELEASE_TOKEN: ((semver-prerelease-token))
-      run:
-        path: geode-examples-pipeline/ci/pipelines/examples/deploy_pipeline.sh
-  - put: concourse
-    params:
-      pipelines:
-      - name: ((!pipeline-prefix))examples
-        team: ((!concourse-team))
-        config_file: results/generated-pipeline.yml
-        vars_files:
-        - results/pipeline-vars.yml
-
-- name: set-pr-pipeline
-  serial: true
-  public: ((!public-pipelines))
-  plan:
-  - get: geode-pr-pipeline
-    trigger: true
-  - get: meta-mini-image
-    trigger: true
-    passed: [build-meta-mini-docker-image]
-  - task: deploy-pr
-    image: meta-mini-image
-    config:
-      platform: linux
-      inputs:
-        - name: geode-pr-pipeline
-      outputs:
-        - name: results
-      params:
-        OUTPUT_DIRECTORY: results
-        GEODE_BRANCH: ((!geode-build-branch))
-        GEODE_FORK: ((!geode-fork))
-        GEODE_REPO_NAME: ((geode-repo-name))
-        REPOSITORY_PUBLIC: {{ repository.public }}
-        ARTIFACT_BUCKET: ((artifact-bucket))
-        UPSTREAM_FORK: {{ repository.upstream_fork }}
-        PIPELINE_PREFIX: ((pipeline-prefix))
-        GCP_PROJECT: ((gcp-project))
-        PUBLIC_PIPELINES: ((public-pipelines))
-        GRADLE_GLOBAL_ARGS: ((gradle-global-args))
-      run:
-        path: geode-pr-pipeline/ci/pipelines/pull-request/deploy_pr_pipeline.sh
-  - put: concourse
-    params:
-      pipelines:
-      - name: ((!pipeline-prefix))pr
-        team: ((!concourse-team))
-        config_file: results/generated-pipeline.yml
-        vars_files:
-        - results/pipeline-vars.yml
-
-{% endif %}
-
-- name: set-metrics-pipeline
-  serial: true
-  public: ((!public-pipelines))
-  plan:
-    - get: geode-metrics-pipeline
-      trigger: true
-    - get: meta-mini-image
-      trigger: true
-      passed: [build-meta-mini-docker-image]
-    - task: create-metrics-pipeline-yml
-      image: meta-mini-image
-      config:
-        platform: linux
-        inputs:
-          - name: geode-metrics-pipeline
-        outputs:
-          - name: results
-        params:
-          OUTPUT_DIRECTORY: results
-          GEODE_BRANCH: ((geode-build-branch))
-          GEODE_FORK: ((geode-fork))
-          GEODE_REPO_NAME: ((geode-repo-name))
-          REPOSITORY_PUBLIC: {{ repository.public }}
-          ARTIFACT_BUCKET: ((artifact-bucket))
-          UPSTREAM_FORK: {{ repository.upstream_fork }}
-          PIPELINE_PREFIX: ((pipeline-prefix))
-          SANITIZED_GEODE_BRANCH: ((sanitized-geode-build-branch))
-          SANITIZED_GEODE_FORK: ((sanitized-geode-fork))
-          GCP_PROJECT: ((gcp-project))
-          PUBLIC_PIPELINES: ((public-pipelines))
-          CONCOURSE_URL: ((concourse-url))
-          CONCOURSE_HOST: ((concourse-host))
-          CONCOURSE_TEAM: ((concourse-team))
-        run:
-          path: geode-metrics-pipeline/ci/pipelines/metrics/deploy_metrics_pipeline.sh
-    - put: concourse
-      params:
-        pipelines:
-          - name: ((!pipeline-prefix))metrics
-            team: ((!concourse-team))
-            config_file: results/generated-pipeline.yml
-            vars_files:
-              - results/pipeline-vars.yml
-
-- name: set-reaper-pipeline
-  serial: true
-  public: ((!public-pipelines))
-  plan:
-    - get: geode-reaper-pipeline
-      trigger: true
-    - get: meta-mini-image
-      trigger: true
-      passed: [build-meta-mini-docker-image]
-    - task: create-image-yml
-      image: meta-mini-image
-      config:
-        platform: linux
-        inputs:
-          - name: geode-reaper-pipeline
-        outputs:
-          - name: results
-        params:
-          OUTPUT_DIRECTORY: results
-          GEODE_BRANCH: ((geode-build-branch))
-          GEODE_FORK: ((geode-fork))
-          GEODE_REPO_NAME: ((geode-repo-name))
-          REPOSITORY_PUBLIC: {{ repository.public }}
-          UPSTREAM_FORK: {{ repository.upstream_fork }}
-          PIPELINE_PREFIX: ((pipeline-prefix))
-          SANITIZED_GEODE_BRANCH: ((sanitized-geode-build-branch))
-          SANITIZED_GEODE_FORK: ((sanitized-geode-fork))
-          GCP_PROJECT: ((gcp-project))
-          PUBLIC_PIPELINES: ((public-pipelines))
-        run:
-          path: geode-reaper-pipeline/ci/pipelines/reaper/deploy_reaper_pipeline.sh
-    - put: concourse
-      params:
-        pipelines:
-          - name: ((!pipeline-prefix))reaper
-            team: ((!concourse-team))
-            config_file: results/generated-pipeline.yml
-            vars_files:
-              - results/pipeline-vars.yml
-
 - name: build-meta-mini-docker-image
   public: ((!public-pipelines))
   serial: true


[geode] 01/02: Mass-test-run branch, no windows or publication jobs

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

mhanson pushed a commit to branch mass-test-run
in repository https://gitbox.apache.org/repos/asf/geode.git

commit a9a7ee291ee3b07a3240bd21499ea4681adf9714
Author: Robert Houghton <rh...@pivotal.io>
AuthorDate: Mon Jan 27 15:20:46 2020 -0800

    Mass-test-run branch, no windows or publication jobs
    
    Co-authored-by: Robert Houghton <rh...@pivotal.io>
    Co-authored-by: Mark Hanson <mh...@pivotal.io>
---
 ci/pipelines/geode-build/jinja.template.yml | 305 +---------------------------
 ci/pipelines/shared/jinja.variables.yml     |  77 +------
 2 files changed, 13 insertions(+), 369 deletions(-)

diff --git a/ci/pipelines/geode-build/jinja.template.yml b/ci/pipelines/geode-build/jinja.template.yml
index 1d88496..e4b65b0 100644
--- a/ci/pipelines/geode-build/jinja.template.yml
+++ b/ci/pipelines/geode-build/jinja.template.yml
@@ -92,66 +92,6 @@ GRADLE_GLOBAL_ARGS: ((gradle-global-args))
   {%- endfor -%}
 {% endmacro %}
 
-groups:
-- name: main
-  jobs:
-  - {{ build_test.name }}
-  {{- all_gating_jobs() | indent(2) }}
-  - UpdatePassingTokens
-  {%- if repository.upstream_fork != "apache" or repository.branch == "develop" or repository.branch.startswith("support/") %}
-  - PublishArtifacts
-  {%- endif %}
-  {%- for flavor in (benchmarks.flavors) %}
-  - Benchmark{{flavor.title}}
-  {%- endfor %}
-- name: complete
-  jobs:
-  - {{ build_test.name }}
-  {%- for test in (tests) if not test.name=="StressNew" -%}
-    {%- for java_test_version in (java_test_versions) %}
-  - {{test.name}}Test{{java_test_version.name}}
-    {%- endfor -%}
-  {%- endfor %}
-  - UpdatePassingTokens
-  {%- if repository.upstream_fork != "apache" or repository.branch == "develop" or repository.branch.startswith("support/") %}
-  - PublishArtifacts
-  {%- endif %}
-  {%- for flavor in (benchmarks.flavors) %}
-  - Benchmark{{flavor.title}}
-  {%- endfor %}
-- name: linux
-  jobs:
-  - {{ build_test.name }}
-  {%- for test in (tests) if test.PLATFORM=="linux" and not test.name=="StressNew" -%}
-    {% for java_test_version in (java_test_versions) %}
-  - {{test.name}}Test{{java_test_version.name}}
-    {%- endfor -%}
-  {%- endfor %}
-  {%- for flavor in (benchmarks.flavors) %}
-  - Benchmark{{flavor.title}}
-  {%- endfor %}
-- name: windows
-  jobs:
-  - {{ build_test.name }}
-  {%- for test in (tests) if test.PLATFORM=="windows" -%}
-    {% for java_test_version in (java_test_versions) %}
-  - {{test.name}}Test{{java_test_version.name}}
-    {%- endfor -%}
-  {%- endfor %}
-{%- for java_test_version in (java_test_versions) %}
-- name: {{java_test_version.name}}
-  jobs:
-  - {{ build_test.name }}
-  {%- for test in (tests) if not test.name=="StressNew" %}
-  - {{test.name}}Test{{java_test_version.name}}
-  {%- endfor -%}
-{%- endfor %}
-- name: Semver Management
-  jobs:
-  {%- for semverPiece in ['major', 'minor', 'patch'] %}
-  - Bump{{ semverPiece.title() }}
-  {%- endfor %}
-
 resources:
 - name: concourse-metadata-resource
   type: concourse-metadata-resource
@@ -173,12 +113,7 @@ resources:
     paths:
     - ci/*
     {{ github_access() | indent(4) }}
-- name: geode-benchmarks
-  type: git
-  source:
-    branch: {{benchmarks.benchmark_branch}}
-    depth: 1
-    uri: https://github.com/apache/geode-benchmarks.git
+
 - name: geode-build-version
   type: semver
   source:
@@ -186,13 +121,8 @@ resources:
     driver: gcs
     initial_version: {{ metadata.initial_version }}
     json_key: ((!concourse-gcp-key))
-    key: semvers/((pipeline-prefix))((geode-build-branch))/number
-- name: geode-passing-tokens
-  type: gcs-resource
-  source:
-    bucket: ((artifact-bucket))
-    json_key: ((concourse-gcp-key))
-    versioned_file: semvers/((pipeline-prefix))((geode-build-branch))/passing-build-tokens.json
+    key: semvers/((pipeline-prefix))((geode-build-branch))/version
+
 - name: alpine-tools-image
   type: docker-image
   source:
@@ -201,12 +131,6 @@ resources:
     repository: gcr.io/((gcp-project))/((pipeline-prefix))alpine-tools
     tag: latest
 
-- name: windows-builder-image-family
-  type: gci
-  source:
-    key: ((concourse-gcp-key))
-    family_project: ((gcp-project))
-    family: ((pipeline-prefix))windows-geode-builder
 
 - name: linux-builder-image-family
   type: gci
@@ -233,6 +157,7 @@ resource_types:
   source:
     repository: frodenas/gcs-resource
 jobs:
+<<<<<<< HEAD
 {% for semverPiece in ['major', 'minor', 'patch'] -%}
 - name: Bump{{ semverPiece.title() }}
   serial: true
@@ -245,6 +170,10 @@ jobs:
     params:
       file: geode-build-version/number
 {% endfor %}
+=======
+
+
+>>>>>>> Mass-test-run branch, no windows or publication jobs
 - name: {{build_test.name}}
   public: true
   max_in_flight: {{build_test.MAX_IN_FLIGHT}}
@@ -390,224 +319,6 @@ jobs:
               - name: instance-data
             timeout: 1h
 
-- name: UpdatePassingTokens
-  public: true
-  serial: true
-  plan:
-  - aggregate:
-    - get: alpine-tools-image
-    - get: geode
-      passed: &update-token-passed-anchor
-{%- if repository.upstream_fork != "apache" or repository.branch == "develop" or repository.branch.startswith("support/") %}
-      - PublishArtifacts
-{% else %}
-      {% for flavor in (benchmarks.flavors) %}
-      - Benchmark{{flavor.title}}
-      {% endfor %}
-{% endif %}
-      trigger: true
-    - get: geode-build-version
-      trigger: true
-      passed: *update-token-passed-anchor
-  - task: couple-sha-and-build-id
-    image: alpine-tools-image
-    config:
-      platform: linux
-      inputs:
-      - name: geode
-      - name: geode-build-version
-      outputs:
-      - name: geode-passing-tokens
-      run:
-        path: bash
-        args:
-        - -cx
-        - |
-          pushd geode
-            GEODE_SHA=$(git rev-parse HEAD)
-          popd
-          GEODE_SEMVER=$(cat geode-build-version/number)
-
-          GS_PATH=gs://((artifact-bucket))/semvers/((pipeline-prefix))((geode-build-branch))/passing-build-tokens.json
-          CURRENT_PASSING_SHA=$(gsutil cat ${GS_PATH} | jq -r .ref)
-          set -e
-          # Check that the incoming GEODE_SHA is a descendent of the currently stored value.
-          # Keeps us from winding back the repository in the case of an out-of-order pipeline pass
-          if [ -z "${CURRENT_PASSING_SHA}" ] || (cd geode; git merge-base --is-ancestor ${CURRENT_PASSING_SHA} ${GEODE_SHA}); then
-            cat > geode-passing-tokens/passing-build-tokens.json <<JSON
-          {
-            "ref": "${GEODE_SHA}",
-            "semver": "${GEODE_SEMVER}"
-          }
-          JSON
-          fi
-  - aggregate:
-    - put: geode-passing-tokens
-      params:
-        file: geode-passing-tokens/passing-build-tokens.json
-
-{% for run_var in (benchmarks.flavors) %}
-- name: Benchmark{{ run_var.title }}
-  public: true
-  max_in_flight: 3
-  plan:
-  - get: geode-ci
-    passed:
-    {{ all_gating_jobs() | indent(4) }}
-  - get: alpine-tools-image
-  - aggregate:
-    - get: geode
-      passed:
-      {{ all_gating_jobs() | indent(6) }}
-      trigger: true
-    - get: geode-benchmarks
-    - get: geode-build-version
-      trigger: true
-      passed:
-      {{ all_gating_jobs() | indent(6) }}
-    - put: concourse-metadata-resource
-  - do:
-    - task: run_benchmarks{{ run_var.title }}
-      image: alpine-tools-image
-      config:
-        platform: linux
-        params:
-          AWS_ACCESS_KEY_ID: ((benchmarks-access-key-id))
-          AWS_SECRET_ACCESS_KEY: ((benchmarks-secret-access-key))
-          AWS_DEFAULT_REGION: us-west-2
-          AWS_REGION: us-west-2
-          ARTIFACT_BUCKET: ((artifact-bucket))
-          BENCHMARKS_BRANCH: {{benchmarks.benchmark_branch}}
-          BASELINE_BRANCH: {{benchmarks.baseline_branch}}
-          BASELINE_VERSION: {{benchmarks.baseline_version}}
-          FLAGS: {{ run_var.flag }}
-          TAG_POSTFIX: {{ run_var.title }}
-          TEST_OPTIONS: {{ run_var.options }}
-        run:
-          path: geode-ci/ci/scripts/run_benchmarks.sh
-        inputs:
-        - name: geode
-        - name: geode-ci
-        - name: geode-benchmarks
-        - name: concourse-metadata-resource
-        outputs:
-        - name: results
-      timeout: 8h
-      ensure:
-        do:
-        - task: cleanup_benchmarks
-          image: alpine-tools-image
-          config:
-            platform: linux
-            params:
-              AWS_ACCESS_KEY_ID: ((benchmarks-access-key-id))
-              AWS_SECRET_ACCESS_KEY: ((benchmarks-secret-access-key))
-              AWS_DEFAULT_REGION: us-west-2
-              AWS_REGION: us-west-2
-              ARTIFACT_BUCKET: ((artifact-bucket))
-              BASELINE_BRANCH: {{benchmarks.baseline_branch}}
-              BASELINE_VERSION: {{benchmarks.baseline_version}}
-              FLAGS: {{ run_var.flag }}
-              TAG_POSTFIX: {{ run_var.title }}
-              TEST_OPTIONS: {{ run_var.options }}
-            run:
-              path: geode-ci/ci/scripts/cleanup_benchmarks.sh
-            inputs:
-            - name: geode
-            - name: geode-ci
-            - name: geode-benchmarks
-            - name: concourse-metadata-resource
-            - name: results
-{% endfor %}
-{% if repository.upstream_fork != "apache" or repository.branch == "develop" or repository.branch.startswith("support/") %}
-- name: PublishArtifacts
-  public: true
-  plan:
-  - aggregate:
-    - get: geode-ci
-      passed: &publish-passed-inputs
-      {% for flavor in (benchmarks.flavors) %}
-      - Benchmark{{flavor.title}}
-      {% endfor %}
-    - get: alpine-tools-image
-    - get: geode
-      passed: *publish-passed-inputs
-      trigger: true
-    - get: linux-builder-image-family
-  - aggregate:
-    - get: geode-build-version
-      trigger: true
-      passed: *publish-passed-inputs
-    - put: concourse-metadata-resource
-    {{ init_retry()|indent(4) }}
-  - task: create_instance
-    image: alpine-tools-image
-    config:
-      platform: linux
-      params:
-        {{ common_instance_params(publish_artifacts) | indent(8) }}
-        GEODE_BRANCH: {{repository.branch}}
-        GEODE_FORK: {{repository.fork}}
-        JAVA_BUILD_VERSION: {{ java_build_version.version }}
-        IMAGE_FAMILY_NAME: ((pipeline-prefix))linux-geode-builder
-      run:
-        path: geode-ci/ci/scripts/create_instance.sh
-      inputs:
-      - name: concourse-metadata-resource
-      - name: geode-ci
-      - name: geode
-      - name: attempts-log
-        path: old
-      outputs:
-      - name: instance-data
-      - name: attempts-log
-        path: new
-    timeout: 20m
-    attempts: 5
-  - task: rsync_code_up
-    image: alpine-tools-image
-    config:
-      platform: linux
-      run:
-        path: geode-ci/ci/scripts/rsync_code_up.sh
-      inputs:
-      - name: geode-ci
-      - name: geode
-      - name: instance-data
-    timeout: 5m
-  - task: publish
-    image: alpine-tools-image
-    config:
-      platform: linux
-      params:
-        MAINTENANCE_VERSION: ((geode-build-branch))
-        ARTIFACT_BUCKET: ((artifact-bucket))
-        SERVICE_ACCOUNT: ((!concourse-gcp-account))
-        JAVA_BUILD_VERSION: {{ java_build_version.version }}
-        MAVEN_SNAPSHOT_BUCKET: ((maven-snapshot-bucket))
-        GRADLE_GLOBAL_ARGS: ((gradle-global-args))
-      run:
-        path: geode-ci/ci/scripts/execute_publish.sh
-      inputs:
-      - name: instance-data
-      - name: geode
-      - name: geode-ci
-      - name: geode-build-version
-    ensure:
-      do:
-      - task: delete_instance
-        image: alpine-tools-image
-        config:
-          platform: linux
-          run:
-            path: geode-ci/ci/scripts/delete_instance.sh
-          inputs:
-          - name: geode-ci
-          - name: instance-data
-        timeout: 1h
-
-{% endif %}
-
 {%- for test in tests if not test.name=="StressNew" %}
   {%- set parameters = {} %}
   {%- do deep_merge(parameters, test) %}
diff --git a/ci/pipelines/shared/jinja.variables.yml b/ci/pipelines/shared/jinja.variables.yml
index c666fc7..74c183d 100644
--- a/ci/pipelines/shared/jinja.variables.yml
+++ b/ci/pipelines/shared/jinja.variables.yml
@@ -84,7 +84,7 @@ tests:
   DUNIT_PARALLEL_FORKS: '0'
   EXECUTE_TEST_TIMEOUT: 30m
   GRADLE_TASK: test
-  MAX_IN_FLIGHT: 1
+  MAX_IN_FLIGHT: 5
   PARALLEL_DUNIT: 'false'
   PARALLEL_GRADLE: 'true'
   PLATFORM: linux
@@ -96,7 +96,7 @@ tests:
   DUNIT_PARALLEL_FORKS: '0'
   EXECUTE_TEST_TIMEOUT: 1h30m
   GRADLE_TASK: acceptanceTest
-  MAX_IN_FLIGHT: 2
+  MAX_IN_FLIGHT: 5
   PARALLEL_DUNIT: 'false'
   PARALLEL_GRADLE: 'false'
   PLATFORM: linux
@@ -108,7 +108,7 @@ tests:
   DUNIT_PARALLEL_FORKS: '24'
   EXECUTE_TEST_TIMEOUT: 3h00m
   GRADLE_TASK: distributedTest
-  MAX_IN_FLIGHT: 3
+  MAX_IN_FLIGHT: 5
   PARALLEL_DUNIT: 'true'
   PLATFORM: linux
   RAM: '250'
@@ -119,7 +119,7 @@ tests:
   DUNIT_PARALLEL_FORKS: '48'
   EXECUTE_TEST_TIMEOUT: 40m
   GRADLE_TASK: integrationTest
-  MAX_IN_FLIGHT: 1
+  MAX_IN_FLIGHT: 5
   PARALLEL_DUNIT: 'true'
   PLATFORM: linux
   RAM: '90'
@@ -130,75 +130,8 @@ tests:
   DUNIT_PARALLEL_FORKS: '48'
   EXECUTE_TEST_TIMEOUT: 1h
   GRADLE_TASK: upgradeTest
-  MAX_IN_FLIGHT: 2
+  MAX_IN_FLIGHT: 5
   PARALLEL_DUNIT: 'true'
   PLATFORM: linux
   RAM: '210'
   name: Upgrade
-- ARTIFACT_SLUG: stressnewtestfiles
-  CALL_STACK_TIMEOUT: '20700'
-  CPUS: '96'
-  DUNIT_PARALLEL_FORKS: '24'
-  EXECUTE_TEST_TIMEOUT: 6h
-  GRADLE_TASK: repeatTest
-  PARALLEL_DUNIT: 'true'
-  PARALLEL_GRADLE: 'false'
-  PLATFORM: linux
-  RAM: '280'
-  name: StressNew
-- ARTIFACT_SLUG: windows-acceptancetestfiles
-  CPUS: '16'
-  DUNIT_PARALLEL_FORKS: '0'
-  EXECUTE_TEST_TIMEOUT: 6h
-  GRADLE_TASK: :geode-assembly:acceptanceTest
-  MAX_IN_FLIGHT: 3
-  PARALLEL_DUNIT: 'false'
-  PARALLEL_GRADLE: 'false'
-  PLATFORM: windows
-  RAM: '64'
-  name: WindowsAcceptance
-- ARTIFACT_SLUG: windows-gfshdistributedtest
-  CPUS: '16'
-  DUNIT_PARALLEL_FORKS: '0'
-  EXECUTE_TEST_TIMEOUT: 6h
-  GRADLE_TASK: distributedTest
-  GRADLE_TASK_OPTIONS: -PtestCategory=org.apache.geode.test.junit.categories.GfshTest
-  MAX_IN_FLIGHT: 5
-  PARALLEL_DUNIT: 'false'
-  PARALLEL_GRADLE: 'false'
-  PLATFORM: windows
-  RAM: '64'
-  name: WindowsGfshDistributed
-- ARTIFACT_SLUG: windows-integrationtestfiles
-  CPUS: '16'
-  DUNIT_PARALLEL_FORKS: '0'
-  EXECUTE_TEST_TIMEOUT: 6h
-  GRADLE_TASK: integrationTest
-  GRADLE_TASK_OPTIONS: -x geode-core:integrationTest
-  MAX_IN_FLIGHT: 2
-  PARALLEL_DUNIT: 'false'
-  PARALLEL_GRADLE: 'false'
-  PLATFORM: windows
-  RAM: '64'
-  name: WindowsIntegration
-- ARTIFACT_SLUG: windows-coreintegrationtestfiles
-  CPUS: '16'
-  DUNIT_PARALLEL_FORKS: '0'
-  EXECUTE_TEST_TIMEOUT: 6h
-  GRADLE_TASK: geode-core:integrationTest
-  MAX_IN_FLIGHT: 6
-  PARALLEL_DUNIT: 'false'
-  PARALLEL_GRADLE: 'false'
-  PLATFORM: windows
-  RAM: '64'
-  name: WindowsCoreIntegration
-- ARTIFACT_SLUG: windows-unittestfiles
-  CPUS: '16'
-  DUNIT_PARALLEL_FORKS: '0'
-  EXECUTE_TEST_TIMEOUT: 6h
-  GRADLE_TASK: test
-  MAX_IN_FLIGHT: 1
-  PARALLEL_DUNIT: 'false'
-  PLATFORM: windows
-  RAM: '64'
-  name: WindowsUnit