Skip to content

Latest commit

 

History

History
503 lines (448 loc) · 136 KB

README.md

File metadata and controls

503 lines (448 loc) · 136 KB

Running Workflows Manually

Most workflows will get kicked off automatically when you open a PR, push code, or on a schedule.

If you would like to manually trigger a job, you have 2 options:

  1. Trigger Phrases: Some jobs have trigger phrases associated with them (e.g. Run XYZ PreCommit). These will appear in statuses of previous PR runs of that check. You can trigger the job on any PR by commenting that trigger phrase in the PR.

    Note: this approach is found not scalable (#28909) and currently only enabled for PreCommit workflows. For PostCommit jobs, it is currently replaced by a temporary approach: test suites are configured to trigger whenever a particular trigger file is modified. Test workflows have pull_request_target paths, which include a trigger file. Whenever a trigger file is modified, the test suite will trigger on the pull request. Make any change to this file to trigger the job. The trigger file looks like the following: .github/trigger_files/<workflow_file_name.json>.

  2. Committers only - Manual triggering: Any committer can start any job with a workflow_dispatch trigger defined (all jobs should have these). To do so, navigate to the Actions tab, click on your desired workflow in the left navigation bar, and then click Run Workflow.

Guidelines for Adding or Modifying Workflows

On top of normal Actions workflow steps, all new CI workflows (excluding release workflows or other workflow automation) should have the following:

  1. Name and phrase set via matrix for re-run to work (See below)
  2. A set of specific triggers
  3. An explicit checkout step
  4. A set of GitHub token permissions
  5. Concurrency Groups
  6. Comment Triggering Support

Each of these is described in more detail below.

Name and Phrase

Due to specifics on how the comment triggered rerun is handled it is required that all jobs have name and phrase set via matrix elements. See the following example:

jobs:
  beam_job_name:
    name: ${{ matrix.job_name }} (${{ matrix.job_phrase }})
    strategy:
      matrix:
        job_name: [beam_job_name]
        job_phrase: [Run Job Phrase]
    if: |
      github.event_name == 'push' ||
      github.event_name == 'pull_request_target' ||
      (github.event_name == 'schedule' && github.repository == 'apache/beam') ||
      github.event_name == 'workflow_dispatch' ||
      github.event.comment.body == 'Run Job Phrase'
    steps:
      - uses: actions/checkout@v3
      - name: Setup repository
        uses: ./.github/actions/setup-action
        with:
          comment_phrase: ${{ matrix.job_phrase }}
          github_token: ${{ secrets.GITHUB_TOKEN }}
          github_job: ${{ matrix.job_name }} (${{ matrix.job_phrase }})

And in case when the workflow already utilizes matrix do the following:

jobs:
  beam_job_with_matrix:
    name: ${{ matrix.job_name }} (${{ matrix.job_phrase }} ${{ matrix.python_version }})
    runs-on: [self-hosted, ubuntu-20.04, main]
    timeout-minutes: 30
    strategy:
      fail-fast: false
      matrix:
        job_name: ["beam_job_with_matrix"]
        job_phrase: ["Run Job With Matrix"]
        python_version: ['3.8','3.9','3.10','3.11']
    if: |
      github.event_name == 'push' ||
      github.event_name == 'pull_request_target' ||
      (github.event_name == 'schedule' && github.repository == 'apache/beam') ||
      github.event_name == 'workflow_dispatch' ||
      startsWith(github.event.comment.body, 'Run Job With Matrix')
    steps:
      - uses: actions/checkout@v3
      - name: Setup repository
        uses: ./.github/actions/setup-action
        with:
          comment_phrase: ${{ matrix.job_phrase }}
          github_token: ${{ secrets.GITHUB_TOKEN }}
          github_job: ${{ matrix.job_name }} (${{ matrix.job_phrase }} ${{ matrix.python_version }})

Notice how the matrix element of python_version is appended to the name.

Workflow triggers

GitHub allows workflows to define a set of triggers that dictate when a job should be run. For more info, see documentation here.

For the purposes of Beam, each CI workflow should define the following triggers:

  1. A push trigger
  2. A pull_request_target trigger
  3. An issue_comment trigger (for issue created). This is needed for comment triggering support (see section below).
  4. A scheduled trigger
  5. A workflow_dispatch trigger

The push/pull_request_target triggers should only run when appropriate paths are modified. See https://github.com/apache/beam/blob/master/.github/workflows/beam_PreCommit_Go.yml#L4 for an example (you can copy and paste this into your workflow, you just need to change the paths).

Checkout step

Because we use the pull_request_target trigger instead of pull_request, we need an explicit checkout of the correct commit. This can be done as a step that uses the setup-action action in your workflow. See

- uses: actions/checkout@v3
- name: Setup repository
uses: ./.github/actions/setup-action
with:
comment_phrase: 'Run Go PreCommit'
github_token: ${{ secrets.GITHUB_TOKEN }}
for an example (you can copy and paste this into your workflow). Please make sure that you checkout the code before using the composite action.

Token Permissions

You should explicitly define the GitHub Actions token scopes needed by your job. For most jobs, this will be actions: write (needed for comment triggering support) and read permissions for all other options. See

for an example (you can copy and paste this into your workflow).

Concurrency Groups

Concurrency groups are a way of making sure that no more than one Actions run is running per job/group at any given time (previous ones can be cancelled). To reduce resource usage, you should define the following concurrency group:

concurrency:
  group: '${{ github.workflow }} @ ${{ github.event.issue.number || github.sha || github.head_ref || github.ref }}-${{ github.event.schedule || github.event.comment.id || github.event.sender.login }}'
  cancel-in-progress: true

this defines the following groups:

  1. Each workflow will represent a different set of groups
  2. Within each workflow, each PR will represent a single group
  3. Within each non-PR run for a workflow, each commit will represent a set of groups
  4. Within each commit, each push event, schedule event, and manual run event will represent a set of groups

Comment Triggering Support

In order to make it easier for non-committers to interact with workflows, workflows should implement comment triggering support. This requires 3 additional components beyond the ones mentioned above:

  1. Each job should be gated on an if condition that maps to that workflow's comment trigger (example: )
  2. Each job should have the rerun action immediately after its checkout step. You can add a step that uses the setup-action action in your workflow, which encapsulates the checkout and rerun logic in one place. This should be gated on the comment trigger (example:
    - uses: actions/checkout@v3
    - name: Setup repository
    uses: ./.github/actions/setup-action
    with:
    comment_phrase: 'Run Go PreCommit'
    github_token: ${{ secrets.GITHUB_TOKEN }}
    )
  3. Each job should have a descriptive name that includes the comment trigger (example:
    name: beam_PreCommit_CommunityMetrics (Run CommunityMetrics PreCommit)
    )

Note: Comment triggering is found not scalable (#28909) and is currently limited to a subset of suites. For more information see the Running Workflows Manually section.

Testing new workflows or workflow updates

Testing New Workflows

New workflows are not added to the UI on the Actions tab until they are merged into the repo's main branch (master for Beam). To test new workflows, we recommend the following pattern:

  1. Fork the Beam repo
  2. Add your proposed workflow to the main branch of your fork.
  3. Run the workflow in the Actions tab of your fork using the Run workflow button.

Note: most workflows use self-hosted runners with the main and ubuntu labels to execute (example). If you are testing on a fork, you likely will not have self-hosted runners set up. To work around this, you can start using hosted runners and then switch over when you're ready to create a PR. You can do this by changing runs-on: [self-hosted, ubuntu-20.04, main] (self-hosted, use in your PR) to runs-on: ubuntu-20.04 (GitHub hosted, use for local testing).

Note when using ubuntu-20.04 as the host, you might need to choose the Java version since some gradle tasks only work with a certain Java version. One example is below to use Java 8 when testing your workflow:

    steps:
      - uses: actions/checkout@v4
      - uses: actions/setup-java@v3
        with:
          distribution: 'temurin'
          java-version: '8'

Testing Workflow Updates

If you need to make more changes to the workflow yaml file after it has been added to the repo, you can develop normally on a branch (using your fork or the main Beam repo if you are a committer). If you are a non-committer, this flow has several caveats mentioned below. To do this:

  1. Make your change on a development branch.
  2. Navigate to your workflow in the Actions tab. If your changes are on a fork, navigate to the fork's Actions tab instead. If you don't see the correct action, make sure that your fork's main branch is up to date with Beam's master branch.
  3. Click run workflow. Before clicking submit, update to run on your branch.

Note: If you run a workflow from your fork of Beam, it will not have access to secrets stored in the Beam repository. This will cause some things like authenticating to external services to fail, which may cause your workflow to fail. If you run into this issue, you can either:

  1. Ask for a committers help to add the workflow to a branch on the main apache/beam repo.
  2. Upload secrets to your repo mirroring the secrets used in the main Beam repo.
  3. Wait until the changes are merged into Beam to test (this should only be done rarely).

Additionally, as mentioned above your fork likely will not have self-hosted runners set up. To work around this, you can start using hosted runners and then switch over when you're ready to create a PR. You can do this by changing runs-on: [self-hosted, ubuntu-20.04, main] (self-hosted, use in your PR) to runs-on: ubuntu-20.04 (GitHub hosted, use for local testing).

Workflows

Please note that jobs with matrix need to have matrix element in the comment. Example: Run Python PreCommit (3.8)

PreCommit Jobs

PreCommit Jobs run in a schedule and also get triggered in a PR if relevant sources has changed. To manually trigger certain PreCommit job, comment with the Trigger Phrase (listed below) in the PR.

Workflow name Matrix Trigger Phrase Cron Status
PreCommit Community Metrics N/A Run CommunityMetrics PreCommit .github/workflows/beam_PreCommit_CommunityMetrics.yml
PreCommit GHA N/A Run GHA PreCommit .github/workflows/beam_PreCommit_GHA.yml
PreCommit Go N/A Run Go PreCommit .github/workflows/beam_PreCommit_Go.yml
PreCommit GoPortable N/A Run GoPortable PreCommit .github/workflows/beam_PreCommit_GoPortable.yml
PreCommit Java N/A Run Java PreCommit .github/workflows/beam_PreCommit_Java.yml
PreCommit Java Amazon Web Services IO Direct N/A Run Java_Amazon-Web-Services_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Amazon-Web-Services_IO_Direct.yml
PreCommit Java Amazon Web Services2 IO Direct N/A Run Java_Amazon-Web-Services2_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Amazon-Web-Services2_IO_Direct.yml
PreCommit Java Amqp IO Direct N/A Run Java_Amqp_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Amqp_IO_Direct.yml
PreCommit Java Azure IO Direct N/A Run Java_Azure_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Azure_IO_Direct.yml
PreCommit Java Cassandra IO Direct N/A Run Java_Cassandra_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Cassandra_IO_Direct.yml
PreCommit Java Cdap IO Direct N/A Run Java_Cdap_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Cdap_IO_Direct.yml
PreCommit Java Clickhouse IO Direct N/A Run Java_Clickhouse_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Clickhouse_IO_Direct.yml
PreCommit Java Csv IO Direct N/A Run Java_Csv_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Csv_IO_Direct.yml
PreCommit Java Debezium IO Direct N/A Run Java_Debezium_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Debezium_IO_Direct.yml
PreCommit Java ElasticSearch IO Direct N/A Run Java_ElasticSearch_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_ElasticSearch_IO_Direct.yml
PreCommit Java Examples Dataflow N/A Run Java_Examples_Dataflow PreCommit .github/workflows/beam_PreCommit_Java_Examples_Dataflow.yml
PreCommit Java Examples Dataflow Java21 N/A Run Java_Examples_Dataflow_Java21 PreCommit .github/workflows/beam_PreCommit_Java_Examples_Dataflow_Java21.yml
PreCommit Java File-schema-transform IO Direct N/A Run Java_File-schema-transform_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_File-schema-transform_IO_Direct.yml
PreCommit Java Flink Versions N/A Run Java_Flink_Versions PreCommit .github/workflows/beam_PreCommit_Java_Flink_Versions.yml
PreCommit Java GCP IO Direct N/A Run Java_GCP_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_GCP_IO_Direct.yml
PreCommit Java Google-ads IO Direct N/A Run Java_Google-ads_IO_Direct PreCommit .github\workflows\beam_PreCommit_Java_Google-ads_IO_Direct.yml
PreCommit Java Hadoop IO Direct N/A Run Java_Hadoop_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Hadoop_IO_Direct.yml
PreCommit Java HBase IO Direct N/A Run Java_HBase_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_HBase_IO_Direct.yml
PreCommit Java HCatalog IO Direct N/A Run Java_HCatalog_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_HCatalog_IO_Direct.yml
PreCommit Java Kafka IO Direct N/A Run Java_Kafka_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Kafka_IO_Direct.yml
PreCommit Java InfluxDb IO Direct N/A Run Java_InfluxDb_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_InfluxDb_IO_Direct.yml
PreCommit Java IOs Direct N/A Run Java_IOs_Direct PreCommit N/A
PreCommit Java JDBC IO Direct N/A Run Java_JDBC_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_JDBC_IO_Direct.yml
PreCommit Java Jms IO Direct N/A Run Java_Jms_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Jms_IO_Direct.yml
PreCommit Java Kinesis IO Direct N/A Run Java_Kinesis_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Kinesis_IO_Direct.yml
PreCommit Java Kudu IO Direct N/A Run Java_Kudu_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Kudu_IO_Direct.yml
PreCommit Java MongoDb IO Direct N/A Run Java_MongoDb_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_MongoDb_IO_Direct.yml
PreCommit Java Mqtt IO Direct N/A Run Java_Mqtt_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Mqtt_IO_Direct.yml
PreCommit Java Neo4j IO Direct N/A Run Java_Neo4j_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Neo4j_IO_Direct.yml
PreCommit Java Parquet IO Direct N/A Run Java_Parquet_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Parquet_IO_Direct.yml
PreCommit Java Pulsar IO Direct N/A Run Java_Pulsar_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Pulsar_IO_Direct.yml
PreCommit Java PVR Flink Batch N/A Run Java_PVR_Flink_Batch PreCommit .github/workflows/beam_PreCommit_Java_PVR_Flink_Batch.yml
PreCommit Java PVR Flink Docker N/A Run Java_PVR_Flink_Docker PreCommit .github/workflows/beam_PreCommit_Java_PVR_Flink_Docker.yml
PreCommit Java RabbitMq IO Direct N/A Run Java_RabbitMq_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_RabbitMq_IO_Direct.yml
PreCommit Java Redis IO Direct N/A Run Java_Redis_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Redis_IO_Direct.yml
PreCommit Java RequestResponse IO Direct N/A Run Java_RequestResponse_IO_Direct PreCommit .github\workflows\beam_RequestResponse_Java_RequestResponse_IO_Direct.yml
PreCommit Java SingleStore IO Direct N/A Run Java_SingleStore_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_SingleStore_IO_Direct.yml
PreCommit Java Snowflake IO Direct N/A Run Java_Snowflake_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Snowflake_IO_Direct.yml
PreCommit Java Solr IO Direct N/A Run Java_Solr_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Solr_IO_Direct.yml
PreCommit Java Spark3 Versions N/A Run Java_Spark3_Versions PreCommit .github/workflows/beam_PreCommit_Java_Spark3_Versions.yml
PreCommit Java Splunk IO Direct N/A Run Java_Splunk_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Splunk_IO_Direct.yml
PreCommit Java Thrift IO Direct N/A Run Java_Thrift_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Thrift_IO_Direct.yml
PreCommit Java Tika IO Direct N/A Run Java_Tika_IO_Direct PreCommit .github/workflows/beam_PreCommit_Java_Tika_IO_Direct.yml
PreCommit Kotlin Examples N/A Run Kotlin_Examples PreCommit .github/workflows/beam_PreCommit_Kotlin_Examples.yml
PreCommit Portable Python ['3.8','3.11'] Run Portable_Python PreCommit .github/workflows/beam_PreCommit_Portable_Python.yml
PreCommit Python ['3.8','3.9','3.10','3.11'] Run Python PreCommit (matrix_element) .github/workflows/beam_PreCommit_Python.yml
PreCommit Python Coverage N/A Run Python_Coverage PreCommit .github/workflows/beam_PreCommit_Python_Coverage.yml
PreCommit Python Dataframes ['3.8','3.9','3.10','3.11'] Run Python_Dataframes PreCommit (matrix_element) .github/workflows/beam_PreCommit_Python_Dataframes.yml
PreCommit Python Docker ['3.8','3.9','3.10','3.11'] Run PythonDocker PreCommit (matrix_element) .github/workflows/beam_PreCommit_PythonDocker.yml
PreCommit Python Docs N/A Run PythonDocs PreCommit .github/workflows/beam_PreCommit_PythonDocs.yml
PreCommit Python Examples ['3.8','3.9','3.10','3.11'] Run Python_Examples PreCommit (matrix_element) .github/workflows/beam_PreCommit_Python_Examples.yml
PreCommit Python Formatter N/A Run PythonFormatter PreCommit .github/workflows/beam_PreCommit_PythonFormatter.yml
PreCommit Python Integration ['3.8','3.11'] Run Python_Integration PreCommit (matrix_element) .github/workflows/beam_PreCommit_Python_Integration.yml
PreCommit Python Lint N/A Run PythonLint PreCommit .github/workflows/beam_PreCommit_PythonLint.yml
PreCommit Python ML ['3.8','3.9','3.10','3.11'] Run Python_ML PreCommit (matrix_element) .github/workflows/beam_PreCommit_Python_ML.yml
PreCommit Python PVR Flink N/A Run Python_PVR_Flink PreCommit .github/workflows/beam_PreCommit_Python_PVR_Flink.yml
PreCommit Python Runners ['3.8','3.9','3.10','3.11'] Run Python_Runners PreCommit (matrix_element) .github/workflows/beam_PreCommit_Python_Runners.yml
PreCommit Python Transforms ['3.8','3.9','3.10','3.11'] Run Python_Transforms PreCommit (matrix_element) .github/workflows/beam_PreCommit_Python_Transforms.yml
PreCommit RAT N/A Run RAT PreCommit .github/workflows/beam_PreCommit_RAT.yml
PreCommit Spotless N/A Run Spotless PreCommit .github/workflows/beam_PreCommit_Spotless.yml
PreCommit SQL N/A Run SQL PreCommit .github/workflows/beam_PreCommit_SQL.yml
PreCommit SQL Java8 N/A Run SQL_Java8 PreCommit .github/workflows/beam_PreCommit_SQL_Java8.yml
PreCommit SQL Java17 N/A Run SQL_Java17 PreCommit .github/workflows/beam_PreCommit_SQL_Java17.yml
PreCommit Typescript N/A Run Typescript PreCommit .github/workflows/beam_PreCommit_Typescript.yml
PreCommit Website N/A Run Website PreCommit .github/workflows/beam_PreCommit_Website.yml
PreCommit Website Stage GCS N/A Run Website_Stage_GCS PreCommit .github/workflows/beam_PreCommit_Website_Stage_GCS.yml
PreCommit Whitespace N/A Run Whitespace PreCommit .github/workflows/beam_PreCommit_Whitespace.yml
PreCommit Xlang Generated Transforms N/A Run Xlang_Generated_Transforms PreCommit .github/workflows/beam_PreCommit_Xlang_Generated_Transforms.yml
PreCommit YAML Xlang Direct N/A Run Yaml_Xlang_Direct PreCommit .github/workflows/beam_PreCommit_Yaml_Xlang_Direct.yml

Additional PreCommit jobs running basic SDK unit test on a matrices of operating systems. These workflows were setup differently and currently do not support trigger phrases

Workflow name Cron Status
Go Tests .github/workflows/go_tests.yml
Java Tests .github/workflows/java_tests.yml
Python Tests .github/workflows/python_tests.yml
TypeScript Tests .github/workflows/typescript_tests.yml

PostCommit Jobs

PostCommit Jobs run in a schedule against master branch and generally do not get triggered in a PR. To manually trigger certain PostCommit job, attach a file named "Trigger file" (listed below) under .github/trigger_files/ folder.

Workflow name Matrix Trigger file Cron Status
PostCommit Go N/A beam_PostCommit_Go.json .github/workflows/beam_PostCommit_Go.yml
PostCommit Go Dataflow ARM N/A beam_PostCommit_Go_Dataflow_ARM.json .github/workflows/beam_PostCommit_Go_Dataflow_ARM.yml
PostCommit Go VR Flink N/A beam_PostCommit_Go_VR_Flink.json .github/workflows/beam_PostCommit_Go_VR_Flink.yml
PostCommit Go VR Samza N/A beam_PostCommit_Go_VR_Samza.json .github/workflows/beam_PostCommit_Go_VR_Samza.yml
PostCommit Go VR Spark N/A beam_PostCommit_Go_VR_Spark.json .github/workflows/beam_PostCommit_Go_VR_Spark.yml
PostCommit Java Avro Versions N/A beam_PostCommit_Java_Avro_Versions.json .github/workflows/beam_PostCommit_Java_Avro_Versions.yml
PostCommit Java BigQueryEarlyRollout N/A beam_PostCommit_Java_BigQueryEarlyRollout.json .github/workflows/beam_PostCommit_Java_BigQueryEarlyRollout.yml
PostCommit Java Dataflow V1 N/A beam_PostCommit_Java_DataflowV1.json .github/workflows/beam_PostCommit_Java_DataflowV1.yml
PostCommit Java Dataflow V2 N/A beam_PostCommit_Java_DataflowV2.json .github/workflows/beam_PostCommit_Java_DataflowV2.yml
PostCommit Java Examples Dataflow ARM ['8','11','17','21'] beam_PostCommit_Java_Examples_Dataflow_ARM.json .github/workflows/beam_PostCommit_Java_Examples_Dataflow_ARM.yml
PostCommit Java Examples Dataflow N/A beam_PostCommit_Java_Examples_Dataflow.json .github/workflows/beam_PostCommit_Java_Examples_Dataflow.yml
PostCommit Java Examples Dataflow Java ['8','17','21'] beam_PostCommit_Java_Examples_Dataflow_Java.json .github/workflows/beam_PostCommit_Java_Examples_Dataflow_Java.yml
PostCommit Java Examples Dataflow V2 N/A beam_PostCommit_Java_Examples_Dataflow_V2.json .github/workflows/beam_PostCommit_Java_Examples_Dataflow_V2.yml
PostCommit Java Examples Dataflow V2 Java ['8','17','21'] beam_PostCommit_Java_Examples_Dataflow_V2_Java.json .github/workflows/beam_PostCommit_Java_Examples_Dataflow_V2_Java.yml
PostCommit Java Examples Direct N/A beam_PostCommit_Java_Examples_Direct.json .github/workflows/beam_PostCommit_Java_Examples_Direct.yml
PostCommit Java Examples Flink N/A beam_PostCommit_Java_Examples_Flink.json .github/workflows/beam_PostCommit_Java_Examples_Flink.yml
PostCommit Java Examples Spark N/A beam_PostCommit_Java_Examples_Spark.json .github/workflows/beam_PostCommit_Java_Examples_Spark.yml
PostCommit Java Hadoop Versions N/A beam_PostCommit_Java_Hadoop_Versions.json .github/workflows/beam_PostCommit_Java_Hadoop_Versions.yml
PostCommit Java IO Performance Tests N/A beam_PostCommit_Java_IO_Performance_Tests.json .github/workflows/beam_PostCommit_Java_IO_Performance_Tests.yml
PostCommit Java InfluxDbIO Integration Test N/A beam_PostCommit_Java_InfluxDbIO_IT.json .github/workflows/beam_PostCommit_Java_InfluxDbIO_IT.yml
PostCommit Java Jpms Dataflow Java11 N/A beam_PostCommit_Java_Jpms_Dataflow_Java11.json .github/workflows/beam_PostCommit_Java_Jpms_Dataflow_Java11.yml
PostCommit Java Jpms Dataflow Java17 N/A beam_PostCommit_Java_Jpms_Dataflow_Java17.json .github/workflows/beam_PostCommit_Java_Jpms_Dataflow_Java17.yml
PostCommit Java Jpms Direct Java11 N/A beam_PostCommit_Java_Jpms_Direct_Java11.json .github/workflows/beam_PostCommit_Java_Jpms_Direct_Java11.yml
PostCommit Java Jpms Direct Java17 N/A beam_PostCommit_Java_Jpms_Direct_Java17.json .github/workflows/beam_PostCommit_Java_Jpms_Direct_Java17.yml
PostCommit Java Jpms Direct Java21 N/A beam_PostCommit_Java_Jpms_Direct_Java21.json .github/workflows/beam_PostCommit_Java_Jpms_Direct_Java21.yml
PostCommit Java Jpms Flink Java11 N/A beam_PostCommit_Java_Jpms_Flink_Java11.json .github/workflows/beam_PostCommit_Java_Jpms_Flink_Java11.yml
PostCommit Java Jpms Spark Java11 N/A beam_PostCommit_Java_Jpms_Spark_Java11.json .github/workflows/beam_PostCommit_Java_Jpms_Spark_Java11.yml
PostCommit Java Nexmark Dataflow N/A beam_PostCommit_Java_Nexmark_Dataflow.json .github/workflows/beam_PostCommit_Java_Nexmark_Dataflow.yml
PostCommit Java Nexmark Dataflow V2 N/A beam_PostCommit_Java_Nexmark_Dataflow_V2.json .github/workflows/beam_PostCommit_Java_Nexmark_Dataflow_V2.yml
PostCommit Java Nexmark Dataflow V2 Java ['11','17'] beam_PostCommit_Java_Nexmark_Dataflow_V2_Java.json .github/workflows/beam_PostCommit_Java_Nexmark_Dataflow_V2_Java.yml
PostCommit Java Nexmark Direct N/A beam_PostCommit_Java_Nexmark_Direct.json .github/workflows/beam_PostCommit_Java_Nexmark_Direct.yml
PostCommit Java Nexmark Flink N/A beam_PostCommit_Java_Nexmark_Flink.json .github/workflows/beam_PostCommit_Java_Nexmark_Flink.yml
PostCommit Java Nexmark Spark N/A beam_PostCommit_Java_Nexmark_Spark.json .github/workflows/beam_PostCommit_Java_Nexmark_Spark.yml
PostCommit Java PVR Flink Streaming N/A beam_PostCommit_Java_PVR_Flink_Streaming.json .github/workflows/beam_PostCommit_Java_PVR_Flink_Streaming.yml
PostCommit Java PVR Samza N/A beam_PostCommit_Java_PVR_Samza.json .github/workflows/beam_PostCommit_Java_PVR_Samza.yml
PostCommit Java SingleStoreIO IT N/A beam_PostCommit_Java_SingleStoreIO_IT.json .github/workflows/beam_PostCommit_Java_SingleStoreIO_IT.yml
PostCommit Java PVR Spark3 Streaming N/A beam_PostCommit_Java_PVR_Spark3_Streaming.json .github/workflows/beam_PostCommit_Java_PVR_Spark3_Streaming.yml
PostCommit Java PVR Spark Batch N/A beam_PostCommit_Java_PVR_Spark_Batch.json .github/workflows/beam_PostCommit_Java_PVR_Spark_Batch.yml
PostCommit Java Sickbay N/A beam_PostCommit_Java_Sickbay.json .github/workflows/beam_PostCommit_Java_Sickbay.yml
PostCommit Java Tpcds Dataflow N/A beam_PostCommit_Java_Tpcds_Dataflow.json .github/workflows/beam_PostCommit_Java_Tpcds_Dataflow.yml
PostCommit Java Tpcds Flink N/A beam_PostCommit_Java_Tpcds_Flink.json .github/workflows/beam_PostCommit_Java_Tpcds_Flink.yml
PostCommit Java Tpcds Spark N/A beam_PostCommit_Java_Tpcds_Spark.json .github/workflows/beam_PostCommit_Java_Tpcds_Spark.yml
PostCommit Java ValidatesRunner Dataflow JavaVersions ['8','21'] beam_PostCommit_Java_ValidatesRunner_Dataflow_JavaVersions.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_Dataflow_JavaVersions.yml
PostCommit Java ValidatesRunner Dataflow Streaming N/A beam_PostCommit_Java_ValidatesRunner_Dataflow_Streaming.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_Dataflow_Streaming.yml
PostCommit Java ValidatesRunner Dataflow V2 Streaming N/A beam_PostCommit_Java_ValidatesRunner_Dataflow_V2_Streaming.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_Dataflow_V2_Streaming.yml
PostCommit Java ValidatesRunner Dataflow V2 N/A beam_PostCommit_Java_ValidatesRunner_Dataflow_V2.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_Dataflow_V2.yml
PostCommit Java ValidatesRunner Dataflow N/A beam_PostCommit_Java_ValidatesRunner_Dataflow.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_Dataflow.yml
PostCommit Java ValidatesRunner Direct JavaVersions ['8','21'] beam_PostCommit_Java_ValidatesRunner_Direct_JavaVersions.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_Direct_JavaVersions.yml
PostCommit Java ValidatesRunner Direct N/A beam_PostCommit_Java_ValidatesRunner_Direct.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_Direct.yml
PostCommit Java ValidatesRunner Flink Java8 N/A beam_PostCommit_Java_ValidatesRunner_Flink_Java8.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_Flink_Java8.yml
PostCommit Java ValidatesRunner Flink N/A beam_PostCommit_Java_ValidatesRunner_Flink.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_Flink.yml
PostCommit Java ValidatesRunner Samza N/A beam_PostCommit_Java_ValidatesRunner_Samza.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_Samza.yml
PostCommit Java ValidatesRunner Spark Java8 N/A beam_PostCommit_Java_ValidatesRunner_Spark_Java8.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_Spark_Java8.yml
PostCommit Java ValidatesRunner Spark N/A beam_PostCommit_Java_ValidatesRunner_Spark.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_Spark.yml
PostCommit Java ValidatesRunner SparkStructuredStreaming N/A beam_PostCommit_Java_ValidatesRunner_SparkStructuredStreaming.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_SparkStructuredStreaming.yml
PostCommit Java ValidatesRunner Twister2 N/A beam_PostCommit_Java_ValidatesRunner_Twister2.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_Twister2.yml
PostCommit Java ValidatesRunner ULR N/A beam_PostCommit_Java_ValidatesRunner_ULR.json .github/workflows/beam_PostCommit_Java_ValidatesRunner_ULR.yml
PostCommit Java N/A beam_PostCommit_Java.json .github/workflows/beam_PostCommit_Java.yml
PostCommit Javadoc N/A beam_PostCommit_Javadoc.json .github/workflows/beam_PostCommit_Javadoc.yml
PostCommit PortableJar Flink N/A beam_PostCommit_PortableJar_Flink.json .github/workflows/beam_PostCommit_PortableJar_Flink.yml
PostCommit PortableJar Spark N/A beam_PostCommit_PortableJar_Spark.json .github/workflows/beam_PostCommit_PortableJar_Spark.yml
PostCommit Python ['3.8','3.9','3.10','3.11'] beam_PostCommit_Python.json .github/workflows/beam_PostCommit_Python.yml
PostCommit Python Arm ['3.8','3.9','3.10','3.11'] beam_PostCommit_Python_Arm.json .github/workflows/beam_PostCommit_Python_Arm.yml
PostCommit Python Dependency N/A beam_PostCommit_Python_Dependency.json .github/workflows/beam_PostCommit_Python_Dependency.yml
PostCommit Python Examples Dataflow N/A beam_PostCommit_Python_Examples_Dataflow.json .github/workflows/beam_PostCommit_Python_Examples_Dataflow.yml
PostCommit Python Examples Direct ['3.8','3.9','3.10','3.11'] beam_PostCommit_Python_Examples_Direct.json .github/workflows/beam_PostCommit_Python_Examples_Direct.yml
PostCommit Python Examples Flink ['3.8','3.11'] beam_PostCommit_Python_Examples_Flink.json .github/workflows/beam_PostCommit_Python_Examples_Flink.yml
PostCommit Python Examples Spark ['3.8','3.11'] beam_PostCommit_Python_Examples_Spark.json .github/workflows/beam_PostCommit_Python_Examples_Spark.yml
PostCommit Python MongoDBIO IT N/A beam_PostCommit_Python_MongoDBIO_IT.json .github/workflows/beam_PostCommit_Python_MongoDBIO_IT.yml
PostCommit Python Nexmark Direct N/A beam_PostCommit_Python_Nexmark_Direct.json .github/workflows/beam_PostCommit_Python_Nexmark_Direct.yml
PostCommit Python ValidatesContainer Dataflow ['3.8','3.9','3.10','3.11'] beam_PostCommit_Python_ValidatesContainer_Dataflow.json .github/workflows/beam_PostCommit_Python_ValidatesContainer_Dataflow.yml
PostCommit Python ValidatesContainer Dataflow With RC ['3.8','3.9','3.10','3.11'] beam_PostCommit_Python_ValidatesContainer_Dataflow_With_RC.json .github/workflows/beam_PostCommit_Python_ValidatesContainer_Dataflow_With_RC.yml
PostCommit Python ValidatesRunner Dataflow ['3.8','3.11'] beam_PostCommit_Python_ValidatesRunner_Dataflow.json .github/workflows/beam_PostCommit_Python_ValidatesRunner_Dataflow.yml
PostCommit Python ValidatesRunner Flink ['3.8','3.11'] beam_PostCommit_Python_ValidatesRunner_Flink.json .github/workflows/beam_PostCommit_Python_ValidatesRunner_Flink.yml
PostCommit Python ValidatesRunner Samza ['3.8','3.11'] beam_PostCommit_Python_ValidatesRunner_Samza.json .github/workflows/beam_PostCommit_Python_ValidatesRunner_Samza.yml
PostCommit Python ValidatesRunner Spark ['3.8','3.9','3.11'] beam_PostCommit_Python_ValidatesRunner_Spark.json .github/workflows/beam_PostCommit_Python_ValidatesRunner_Spark.yml
PostCommit Python Xlang Gcp Dataflow N/A beam_PostCommit_Python_Xlang_Gcp_Dataflow.json .github/workflows/beam_PostCommit_Python_Xlang_Gcp_Dataflow.yml
PostCommit Python Xlang Gcp Direct N/A beam_PostCommit_Python_Xlang_Gcp_Direct.json .github/workflows/beam_PostCommit_Python_Xlang_Gcp_Direct.yml
PostCommit Python Xlang IO Dataflow N/A beam_PostCommit_Python_Xlang_IO_Dataflow.json .github/workflows/beam_PostCommit_Python_Xlang_IO_Dataflow.yml
PostCommit Sickbay Python ['3.8','3.9','3.10','3.11'] beam_PostCommit_Sickbay_Python.json .github/workflows/beam_PostCommit_Sickbay_Python.yml
PostCommit SQL N/A beam_PostCommit_SQL.json .github/workflows/beam_PostCommit_SQL.yml
PostCommit TransformService Direct N/A beam_PostCommit_TransformService_Direct.json .github/workflows/beam_PostCommit_TransformService_Direct.yml
PostCommit Website Test N/A beam_PostCommit_Website_Test.json .github/workflows/beam_PostCommit_Website_Test.yml
PostCommit XVR GoUsingJava Dataflow N/A beam_PostCommit_XVR_GoUsingJava_Dataflow.json .github/workflows/beam_PostCommit_XVR_GoUsingJava_Dataflow.yml
PostCommit XVR Direct N/A beam_PostCommit_XVR_Direct.json .github/workflows/beam_PostCommit_XVR_Direct.yml
PostCommit XVR Flink N/A beam_PostCommit_XVR_Flink.json .github/workflows/beam_PostCommit_XVR_Flink.yml
PostCommit XVR JavaUsingPython Dataflow N/A beam_PostCommit_XVR_JavaUsingPython_Dataflow.json .github/workflows/beam_PostCommit_XVR_JavaUsingPython_Dataflow.yml
PostCommit XVR PythonUsingJava Dataflow N/A beam_PostCommit_XVR_PythonUsingJava_Dataflow.json .github/workflows/beam_PostCommit_XVR_PythonUsingJava_Dataflow.yml
PostCommit XVR PythonUsingJavaSQL Dataflow N/A beam_PostCommit_XVR_PythonUsingJavaSQL_Dataflow.json .github/workflows/beam_PostCommit_XVR_PythonUsingJavaSQL_Dataflow.yml
PostCommit XVR Samza N/A beam_PostCommit_XVR_Samza.json .github/workflows/beam_PostCommit_XVR_Samza.yml
PostCommit XVR Spark3 N/A beam_PostCommit_XVR_Spark3.json .github/workflows/beam_PostCommit_XVR_Spark3.yml
Python Validates Container Dataflow ARM ['3.8','3.9','3.10','3.11'] beam_Python_ValidatesContainer_Dataflow_ARM.json .github/workflows/beam_Python_ValidatesContainer_Dataflow_ARM.yml

PerformanceTests and Benchmark Jobs

Workflow name Matrix Cron Status
CloudML Benchmarks Dataflow N/A .github/workflows/beam_CloudML_Benchmarks_Dataflow.yml
Inference Python Benchmarks Dataflow N/A .github/workflows/beam_Inference_Python_Benchmarks_Dataflow.yml
Java JMH N/A .github/workflows/beam_Java_JMH.yml
Performance Tests AvroIOIT HDFS N/A .github/workflows/beam_PerformanceTests_AvroIOIT_HDFS.yml
Performance Tests AvroIOIT N/A .github/workflows/beam_PerformanceTests_AvroIOIT.yml
Performance Tests BigQueryIO Batch Java Avro N/A .github/workflows/beam_PerformanceTests_BigQueryIO_Batch_Java_Avro.yml
Performance Tests BigQueryIO Batch Java Json N/A .github/workflows/beam_PerformanceTests_BigQueryIO_Batch_Java_Json.yml
Performance Tests BigQueryIO Streaming Java N/A .github/workflows/beam_PerformanceTests_BigQueryIO_Streaming_Java.yml
Performance Tests BigQueryIO Read Python N/A .github/workflows/beam_PerformanceTests_BiqQueryIO_Read_Python.yml
Performance Tests BigQueryIO Write Python Batch N/A .github/workflows/beam_PerformanceTests_BiqQueryIO_Write_Python_Batch.yml
PerformanceTests Cdap N/A .github/workflows/beam_PerformanceTests_Cdap.yml
PerformanceTests Compressed TextIOIT HDFS N/A .github/workflows/beam_PerformanceTests_Compressed_TextIOIT_HDFS.yml
PerformanceTests Compressed TextIOIT N/A .github/workflows/beam_PerformanceTests_Compressed_TextIOIT.yml
PerformanceTests HadoopFormat N/A .github/workflows/beam_PerformanceTests_HadoopFormat.yml
PerformanceTests JDBC N/A .github/workflows/beam_PerformanceTests_JDBC.yml
PerformanceTests Kafka IO N/A .github/workflows/beam_PerformanceTests_Kafka_IO.yml
PerformanceTests ManyFiles TextIOIT HDFS N/A .github/workflows/beam_PerformanceTests_ManyFiles_TextIOIT_HDFS.yml
PerformanceTests ManyFiles TextIOIT N/A .github/workflows/beam_PerformanceTests_ManyFiles_TextIOIT.yml
PerformanceTests MongoDBIO IT N/A .github/workflows/beam_PerformanceTests_MongoDBIO_IT.yml
PerformanceTests ParquetIOIT HDFS N/A .github/workflows/beam_PerformanceTests_ParquetIOIT_HDFS.yml
PerformanceTests ParquetIOIT N/A .github/workflows/beam_PerformanceTests_ParquetIOIT.yml
PerformanceTests PubsubIOIT Python Streaming N/A .github/workflows/beam_PerformanceTests_PubsubIOIT_Python_Streaming.yml
PerformanceTests SingleStoreIO N/A .github/workflows/beam_PerformanceTests_SingleStoreIO.yml
PerformanceTests SpannerIO Read 2GB Python N/A .github/workflows/beam_PerformanceTests_SpannerIO_Read_2GB_Python.yml
PerformanceTests SpannerIO Write 2GB Python Batch N/A .github/workflows/beam_PerformanceTests_SpannerIO_Write_2GB_Python_Batch.yml
PerformanceTests SparkReceiver IO N/A .github/workflows/beam_PerformanceTests_SparkReceiver_IO.yml
PerformanceTests SQLBigQueryIO Batch Java N/A .github/workflows/beam_PerformanceTests_SQLBigQueryIO_Batch_Java.yml
PerformanceTests TextIOIT HDFS N/A .github/workflows/beam_PerformanceTests_TextIOIT_HDFS.yml
PerformanceTests TextIOIT Python N/A .github/workflows/beam_PerformanceTests_TextIOIT_Python.yml
PerformanceTests TextIOIT N/A .github/workflows/beam_PerformanceTests_TextIOIT.yml
PerformanceTests TFRecordIOIT HDFS N/A .github/workflows/beam_PerformanceTests_TFRecordIOIT_HDFS.yml
PerformanceTests TFRecordIOIT N/A .github/workflows/beam_PerformanceTests_TFRecordIOIT.yml
PerformanceTests WordCountIT PythonVersions ['3.8'] .github/workflows/beam_PerformanceTests_WordCountIT_PythonVersions.yml
PerformanceTests XmlIOIT HDFS N/A .github/workflows/beam_PerformanceTests_XmlIOIT_HDFS.yml
PerformanceTests XmlIOIT N/A .github/workflows/beam_PerformanceTests_XmlIOIT.yml
PerformanceTests xlang KafkaIO Python N/A .github/workflows/beam_PerformanceTests_xlang_KafkaIO_Python.yml

LoadTests Jobs

Workflow name Matrix Cron Status
LoadTests Go CoGBK Dataflow Batch N/A .github/workflows/beam_LoadTests_Go_CoGBK_Dataflow_Batch.yml
LoadTests Go CoGBK Flink Batch N/A .github/workflows/beam_LoadTests_Go_CoGBK_Flink_batch.yml
LoadTests Go Combine Dataflow Batch N/A .github/workflows/beam_LoadTests_Go_Combine_Dataflow_Batch.yml
LoadTests Go Combine Flink Batch N/A .github/workflows/beam_LoadTests_Go_Combine_Flink_Batch.yml
LoadTests Go GBK Dataflow Batch N/A .github/workflows/beam_LoadTests_Go_GBK_Dataflow_Batch.yml
LoadTests Go GBK Flink Batch N/A .github/workflows/beam_LoadTests_Go_GBK_Flink_Batch.yml
LoadTests Go ParDo Dataflow Batch N/A .github/workflows/beam_LoadTests_Go_ParDo_Dataflow_Batch.yml
LoadTests Go ParDo Flink Batch N/A .github/workflows/beam_LoadTests_Go_ParDo_Flink_Batch.yml
LoadTests Go SideInput Dataflow Batch N/A .github/workflows/beam_LoadTests_Go_SideInput_Dataflow_Batch.yml
LoadTests Go SideInput Flink Batch N/A .github/workflows/beam_LoadTests_Go_SideInput_Flink_Batch.yml
LoadTests Java CoGBK Dataflow Batch N/A .github/workflows/beam_LoadTests_Java_CoGBK_Dataflow_Batch.yml
LoadTests Java CoGBK Dataflow Streaming N/A .github/workflows/beam_LoadTests_Java_CoGBK_Dataflow_Streaming.yml
LoadTests Java CoGBK Dataflow V2 Batch JavaVersions ['11','17'] .github/workflows/beam_LoadTests_Java_CoGBK_Dataflow_V2_Batch_JavaVersions.yml
LoadTests Java CoGBK Dataflow V2 Streaming JavaVersions ['11','17'] .github/workflows/beam_LoadTests_Java_CoGBK_Dataflow_V2_Streaming_JavaVersions.yml
LoadTests Java CoGBK SparkStructuredStreaming Batch N/A .github/workflows/beam_LoadTests_Java_CoGBK_SparkStructuredStreaming_Batch.yml
LoadTests Java Combine Dataflow Batch N/A .github/workflows/beam_LoadTests_Java_Combine_Dataflow_Batch.yml
LoadTests Java Combine Dataflow Streaming N/A .github/workflows/beam_LoadTests_Java_Combine_Dataflow_Streaming.yml
LoadTests Java Combine SparkStructuredStreaming Batch N/A .github/workflows/beam_LoadTests_Java_Combine_SparkStructuredStreaming_Batch.yml
LoadTests Java GBK Dataflow Batch N/A .github/workflows/beam_LoadTests_Java_GBK_Dataflow_Batch.yml
LoadTests Java GBK Dataflow Streaming N/A .github/workflows/beam_LoadTests_Java_GBK_Dataflow_Streaming.yml
LoadTests Java GBK Dataflow V2 Batch N/A .github/workflows/beam_LoadTests_Java_GBK_Dataflow_V2_Batch.yml
LoadTests Java GBK Dataflow V2 Batch Java17 N/A .github/workflows/beam_LoadTests_Java_GBK_Dataflow_V2_Batch_Java17.yml
LoadTests Java GBK Dataflow V2 Streaming N/A .github/workflows/beam_LoadTests_Java_GBK_Dataflow_V2_Streaming.yml
LoadTests Java GBK Dataflow V2 Streaming Java17 N/A .github/workflows/beam_LoadTests_Java_GBK_Dataflow_V2_Streaming_Java17.yml
LoadTests Java GBK Smoke N/A .github/workflows/beam_LoadTests_Java_GBK_Smoke.yml
LoadTests Java GBK SparkStructuredStreaming Batch N/A .github/workflows/beam_LoadTests_Java_GBK_SparkStructuredStreaming_Batch.yml
LoadTests Java ParDo Dataflow Batch N/A .github/workflows/beam_LoadTests_Java_ParDo_Dataflow_Batch.yml
LoadTests Java ParDo Dataflow Streaming N/A .github/workflows/beam_LoadTests_Java_ParDo_Dataflow_Streaming.yml
LoadTests Java ParDo Dataflow V2 Batch JavaVersions ['11','17'] .github/workflows/beam_LoadTests_Java_ParDo_Dataflow_V2_Batch_JavaVersions.yml
LoadTests Java ParDo Dataflow V2 Streaming JavaVersions ['11','17'] .github/workflows/beam_LoadTests_Java_ParDo_Dataflow_V2_Streaming_JavaVersions.yml
LoadTests Java ParDo SparkStructuredStreaming Batch N/A .github/workflows/beam_LoadTests_Java_ParDo_SparkStructuredStreaming_Batch.yml
LoadTests Java Combine Smoke N/A .github/workflows/beam_Java_LoadTests_Combine_Smoke.yml
LoadTests Python CoGBK Dataflow Batch N/A .github/workflows/beam_LoadTests_Python_CoGBK_Dataflow_Batch.yml
LoadTests Python CoGBK Dataflow Streaming N/A .github/workflows/beam_LoadTests_Python_CoGBK_Dataflow_Streaming.yml
LoadTests Python CoGBK Flink Batch N/A .github/workflows/beam_LoadTests_Python_CoGBK_Flink_Batch.yml
LoadTests Python Combine Dataflow Batch N/A .github/workflows/beam_LoadTests_Python_Combine_Dataflow_Batch.yml
LoadTests Python Combine Dataflow Streaming N/A .github/workflows/beam_LoadTests_Python_Combine_Dataflow_Streaming.yml
LoadTests Python Combine Flink Batch N/A .github/workflows/beam_LoadTests_Python_Combine_Flink_Batch.yml
LoadTests Python Combine Flink Streaming N/A .github/workflows/beam_LoadTests_Python_Combine_Flink_Streaming.yml
LoadTests Python FnApiRunner Microbenchmark N/A .github/workflows/beam_LoadTests_Python_FnApiRunner_Microbenchmark
LoadTests Python GBK Dataflow Batch N/A .github/workflows/beam_LoadTests_Python_GBK_Dataflow_Batch.yml
LoadTests Python GBK Dataflow Streaming N/A .github/workflows/beam_LoadTests_Python_GBK_Dataflow_Streaming.yml
LoadTests Python GBK Flink Batch N/A .github/workflows/beam_LoadTests_Python_GBK_Flink_Batch.yml
LoadTests Python GBK reiterate Dataflow Batch N/A .github/workflows/beam_LoadTests_Python_GBK_reiterate_Dataflow_Batch.yml
LoadTests Python GBK reiterate Dataflow Streaming N/A .github/workflows/beam_LoadTests_Python_GBK_reiterate_Dataflow_Streaming.yml
LoadTests Python ParDo Dataflow Batch N/A .github/workflows/beam_LoadTests_Python_ParDo_Dataflow_Batch.yml
LoadTests Python ParDo Dataflow Streaming N/A .github/workflows/beam_LoadTests_Python_ParDo_Dataflow_Streaming.yml
LoadTests Python ParDo Flink Batch N/A .github/workflows/beam_LoadTests_Python_ParDo_Flink_Batch.yml
LoadTests Python ParDo Flink Streaming N/A .github/workflows/beam_LoadTests_Python_ParDo_Flink_Streaming.yml
LoadTests Python SideInput Dataflow Batch N/A .github/workflows/beam_LoadTests_Python_SideInput_Dataflow_Batch.yml
LoadTests Python Smoke N/A .github/workflows/beam_LoadTests_Python_Smoke.yml

Other Jobs

Workflow name Matrix Cron Status
Cancel Stale Dataflow Jobs N/A .github/workflows/beam_CancelStaleDataflowJobs.yml
Clean Up GCP Resources N/A .github/workflows/beam_CleanUpGCPResources.yml
Clean Up Prebuilt SDK Images N/A .github/workflows/beam_beam_CleanUpPrebuiltSDKImages.yml
Cleanup Dataproc Resources N/A .github/workflows/beam_CleanUpDataprocResources.yml
Community Metrics Prober N/A .github/workflows/beam_Prober_CommunityMetrics.yml
PostRelease Nightly Snapshot N/A .github/workflows/beam_PostRelease_NightlySnapshot.yml
Playground CI Nightly ["java", "go", "python"] .github/workflows/beam_Playground_CI_Nightly.yml
Publish Beam SDK Snapshots N/A .github/workflows/beam_Publish_Beam_SDK_Snapshots.yml
Publish BeamMetrics N/A .github/workflows/beam_Publish_BeamMetrics.yml
Publish Docker Snapshots N/A .github/workflows/beam_Publish_Docker_Snapshots.yml
Publish Website N/A .github/workflows/beam_Publish_Website.yml
Release Nightly Snapshot N/A .github/workflows/beam_Release_NightlySnapshot.yml
Release Nightly Snapshot Python N/A .github/workflows/beam_Release_Python_NightlySnapshot.yml
Rotate IO-Datastores Cluster Credentials N/A .github/workflows/beam_IODatastoresCredentialsRotation.yml
Rotate Metrics Cluster Credentials N/A .github/workflows/beam_MetricsCredentialsRotation.yml