You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@beam.apache.org by bh...@apache.org on 2022/06/16 20:36:57 UTC

[beam] branch master updated: Update remaining references to Jira to GH (#21834)

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

bhulette pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/beam.git


The following commit(s) were added to refs/heads/master by this push:
     new 1dff59b4ff2 Update remaining references to Jira to GH (#21834)
1dff59b4ff2 is described below

commit 1dff59b4ff26310f88f927edfcf44709ed6ea9c2
Author: Danny McCormick <da...@google.com>
AuthorDate: Thu Jun 16 16:36:52 2022 -0400

    Update remaining references to Jira to GH (#21834)
    
    * Update remaining references to Jira to GH
    
    * Switch to links
    
    * Spotless apply
    
    * Link format
    
    * Undo vscode changes
    
    * Remove one more extraneous vscode reference
    
    * Fix broken links
    
    * Fix broken links
    
    * Fix spacing
---
 .test-infra/jenkins/build.gradle                   |  2 +-
 .../job_LoadTests_Combine_Flink_Python.groovy      |  2 +-
 .../jenkins/job_LoadTests_Combine_Python.groovy    |  2 +-
 .../jenkins/job_LoadTests_GBK_Flink_Go.groovy      |  2 +-
 .../jenkins/job_LoadTests_GBK_Flink_Python.groovy  |  2 +-
 .../jenkins/job_LoadTests_GBK_Python.groovy        |  4 ++--
 .../job_LoadTests_GBK_Python_reiterate.groovy      |  2 +-
 .../jenkins/job_LoadTests_ParDo_Python.groovy      |  2 +-
 .../jenkins/job_LoadTests_SideInput_Python.groovy  |  2 +-
 .../job_LoadTests_coGBK_Flink_Python.groovy        |  2 +-
 .../job_PerformanceTests_FileBasedIO_IT.groovy     |  2 +-
 .../jenkins/job_PerformanceTests_KafkaIO_IT.groovy |  6 +++---
 ..._PortableValidatesRunner_Flink_Streaming.groovy |  2 +-
 ...mit_Python_Chicago_Taxi_Example_Dataflow.groovy |  2 +-
 ...Commit_Python_Chicago_Taxi_Example_Flink.groovy |  2 +-
 .test-infra/jenkins/metrics_report/tox.ini         |  2 +-
 build.gradle.kts                                   |  6 +++---
 .../org/apache/beam/gradle/BeamModulePlugin.groovy |  2 +-
 .../examples/complete/game/StatefulTeamScore.java  |  4 +++-
 .../apache/beam/examples/snippets/Snippets.java    |  4 +++-
 .../transforms/python/elementwise/pardo-py.ipynb   |  2 +-
 .../beam/model/pipeline/v1/beam_runner_api.proto   |  8 ++++----
 .../apache/beam/model/pipeline/v1/metrics.proto    |  6 +++---
 .../src/main/scripts/build_release_candidate.sh    |  2 +-
 release/src/main/scripts/run_rc_validation.sh      |  4 ++--
 scripts/ci/pr-bot/processNewPrs.ts                 |  2 +-
 .../src/apache_beam/proto/beam_runner_api.ts       |  6 +++---
 .../dsls/dataframes/differences-from-pandas.md     |  2 +-
 .../en/documentation/patterns/ai-platform.md       |  2 +-
 .../content/en/documentation/programming-guide.md  | 24 +++++++++++-----------
 30 files changed, 58 insertions(+), 54 deletions(-)

diff --git a/.test-infra/jenkins/build.gradle b/.test-infra/jenkins/build.gradle
index 8fe40ea62fb..37c9c4d8d6a 100644
--- a/.test-infra/jenkins/build.gradle
+++ b/.test-infra/jenkins/build.gradle
@@ -22,7 +22,7 @@ plugins {
 applyGroovyNature()
 applyPythonNature()
 
-// TODO(BEAM-9980): Don't hardcode this version, take the value provided by Python nature.
+// TODO(https://github.com/apache/beam/issues/20209): Don't hardcode this version, take the value provided by Python nature.
 pythonVersion = '3.8'
 
 task generateMetricsReport {
diff --git a/.test-infra/jenkins/job_LoadTests_Combine_Flink_Python.groovy b/.test-infra/jenkins/job_LoadTests_Combine_Flink_Python.groovy
index f2b5441a074..50863a0ddf1 100644
--- a/.test-infra/jenkins/job_LoadTests_Combine_Flink_Python.groovy
+++ b/.test-infra/jenkins/job_LoadTests_Combine_Flink_Python.groovy
@@ -28,7 +28,7 @@ import static LoadTestsBuilder.DOCKER_BEAM_SDK_IMAGE
 
 String now = new Date().format("MMddHHmmss", TimeZone.getTimeZone('UTC'))
 
-// TODO(BEAM-10852): Skipping some cases because they are too slow.
+// TODO(https://github.com/apache/beam/issues/20402): Skipping some cases because they are too slow.
 def TESTS_TO_SKIP = [
   'load-tests-python-flink-streaming-combine-1',
 ]
diff --git a/.test-infra/jenkins/job_LoadTests_Combine_Python.groovy b/.test-infra/jenkins/job_LoadTests_Combine_Python.groovy
index f9554e79a11..1416db226e3 100644
--- a/.test-infra/jenkins/job_LoadTests_Combine_Python.groovy
+++ b/.test-infra/jenkins/job_LoadTests_Combine_Python.groovy
@@ -100,7 +100,7 @@ def loadTestConfigurations = { datasetName, mode ->
 
 def addStreamingOptions(test){
   test.pipelineOptions << [streaming: null,
-    // TODO(BEAM-11779) remove shuffle_mode=appliance with runner v2 once issue is resolved.
+    // TODO(https://github.com/apache/beam/issues/20806) remove shuffle_mode=appliance with runner v2 once issue is resolved.
     experiments: "use_runner_v2, shuffle_mode=appliance"
   ]
 }
diff --git a/.test-infra/jenkins/job_LoadTests_GBK_Flink_Go.groovy b/.test-infra/jenkins/job_LoadTests_GBK_Flink_Go.groovy
index 729b998b7de..9df5f03b98b 100644
--- a/.test-infra/jenkins/job_LoadTests_GBK_Flink_Go.groovy
+++ b/.test-infra/jenkins/job_LoadTests_GBK_Flink_Go.groovy
@@ -27,7 +27,7 @@ import static LoadTestsBuilder.DOCKER_CONTAINER_REGISTRY
 
 String now = new Date().format('MMddHHmmss', TimeZone.getTimeZone('UTC'))
 
-// TODO(BEAM-9761): Skipping some cases because they are too slow or have memory errors.
+// TODO(https://github.com/apache/beam/issues/20146): Skipping some cases because they are too slow or have memory errors.
 def TESTS_TO_SKIP = [
   'load-tests-go-flink-batch-gbk-7',
 ]
diff --git a/.test-infra/jenkins/job_LoadTests_GBK_Flink_Python.groovy b/.test-infra/jenkins/job_LoadTests_GBK_Flink_Python.groovy
index 1b7c1f9a807..be395c829e4 100644
--- a/.test-infra/jenkins/job_LoadTests_GBK_Flink_Python.groovy
+++ b/.test-infra/jenkins/job_LoadTests_GBK_Flink_Python.groovy
@@ -168,4 +168,4 @@ PhraseTriggeringPostCommitBuilder.postCommitJob(
       loadTest(delegate, CommonTestProperties.TriggeringContext.PR)
     }
 
-// TODO(BEAM-9761) Re-enable auto builds after these tests pass.
+// TODO(https://github.com/apache/beam/issues/20146) Re-enable auto builds after these tests pass.
diff --git a/.test-infra/jenkins/job_LoadTests_GBK_Python.groovy b/.test-infra/jenkins/job_LoadTests_GBK_Python.groovy
index 58a0697e729..623a245f4d9 100644
--- a/.test-infra/jenkins/job_LoadTests_GBK_Python.groovy
+++ b/.test-infra/jenkins/job_LoadTests_GBK_Python.groovy
@@ -22,7 +22,7 @@ import InfluxDBCredentialsHelper
 
 def now = new Date().format("MMddHHmmss", TimeZone.getTimeZone('UTC'))
 
-// TODO(BEAM-10774): Skipping some cases because they are too slow.
+// TODO(https://github.com/apache/beam/issues/20403): Skipping some cases because they are too slow.
 def TESTS_TO_SKIP = [
   'load-tests-python-dataflow-streaming-gbk-1',
   'load-tests-python-dataflow-streaming-gbk-2',
@@ -156,7 +156,7 @@ def addStreamingOptions(test) {
     // Use the new Dataflow runner, which offers improved efficiency of Dataflow jobs.
     // See https://cloud.google.com/dataflow/docs/guides/deploying-a-pipeline#dataflow-runner-v2
     // for more details.
-    // TODO(BEAM-11779) remove shuffle_mode=appliance with runner v2 once issue is resolved.
+    // TODO(https://github.com/apache/beam/issues/20806) remove shuffle_mode=appliance with runner v2 once issue is resolved.
     experiments: 'use_runner_v2, shuffle_mode=appliance',
   ]
 }
diff --git a/.test-infra/jenkins/job_LoadTests_GBK_Python_reiterate.groovy b/.test-infra/jenkins/job_LoadTests_GBK_Python_reiterate.groovy
index c980cf070fb..764bd605e72 100644
--- a/.test-infra/jenkins/job_LoadTests_GBK_Python_reiterate.groovy
+++ b/.test-infra/jenkins/job_LoadTests_GBK_Python_reiterate.groovy
@@ -86,7 +86,7 @@ def addStreamingOptions(test) {
     // Use the new Dataflow runner, which offers improved efficiency of Dataflow jobs.
     // See https://cloud.google.com/dataflow/docs/guides/deploying-a-pipeline#dataflow-runner-v2
     // for more details.
-    // TODO(BEAM-11779) remove shuffle_mode=appliance with runner v2 once issue is resolved.
+    // TODO(https://github.com/apache/beam/issues/20806) remove shuffle_mode=appliance with runner v2 once issue is resolved.
     experiments: 'use_runner_v2, shuffle_mode=appliance',
   ]
 }
diff --git a/.test-infra/jenkins/job_LoadTests_ParDo_Python.groovy b/.test-infra/jenkins/job_LoadTests_ParDo_Python.groovy
index 82def0f5ab5..8d5d96560d5 100644
--- a/.test-infra/jenkins/job_LoadTests_ParDo_Python.groovy
+++ b/.test-infra/jenkins/job_LoadTests_ParDo_Python.groovy
@@ -131,7 +131,7 @@ def addStreamingOptions(test) {
     // Use the new Dataflow runner, which offers improved efficiency of Dataflow jobs.
     // See https://cloud.google.com/dataflow/docs/guides/deploying-a-pipeline#dataflow-runner-v2
     // for more details.
-    // TODO(BEAM-11779) remove shuffle_mode=appliance with runner v2 once issue is resolved.
+    // TODO(https://github.com/apache/beam/issues/20806) remove shuffle_mode=appliance with runner v2 once issue is resolved.
     experiments: 'use_runner_v2, shuffle_mode=appliance',
   ]
 }
diff --git a/.test-infra/jenkins/job_LoadTests_SideInput_Python.groovy b/.test-infra/jenkins/job_LoadTests_SideInput_Python.groovy
index 5261e5f677f..e587a81bc98 100644
--- a/.test-infra/jenkins/job_LoadTests_SideInput_Python.groovy
+++ b/.test-infra/jenkins/job_LoadTests_SideInput_Python.groovy
@@ -39,7 +39,7 @@ def fromTemplate = { mode, name, id, datasetName, testSpecificOptions ->
       influx_measurement   : "python_${mode}_sideinput_${id}",
       num_workers          : 10,
       autoscaling_algorithm: 'NONE',
-      // TODO(BEAM-11779) remove shuffle_mode=appliance with runner v2 once issue is resolved.
+      // TODO(https://github.com/apache/beam/issues/20806) remove shuffle_mode=appliance with runner v2 once issue is resolved.
       experiments          : 'use_runner_v2, shuffle_mode=appliance',
     ] << testSpecificOptions
   ]
diff --git a/.test-infra/jenkins/job_LoadTests_coGBK_Flink_Python.groovy b/.test-infra/jenkins/job_LoadTests_coGBK_Flink_Python.groovy
index 68dd2113e7a..3e7dbaa706a 100644
--- a/.test-infra/jenkins/job_LoadTests_coGBK_Flink_Python.groovy
+++ b/.test-infra/jenkins/job_LoadTests_coGBK_Flink_Python.groovy
@@ -152,4 +152,4 @@ PhraseTriggeringPostCommitBuilder.postCommitJob(
       loadTest(delegate, CommonTestProperties.TriggeringContext.PR)
     }
 
-// TODO(BEAM-9761) Re-enable auto builds after these tests pass.
+// TODO(https://github.com/apache/beam/issues/20146) Re-enable auto builds after these tests pass.
diff --git a/.test-infra/jenkins/job_PerformanceTests_FileBasedIO_IT.groovy b/.test-infra/jenkins/job_PerformanceTests_FileBasedIO_IT.groovy
index bb815b3325c..28bdda5993f 100644
--- a/.test-infra/jenkins/job_PerformanceTests_FileBasedIO_IT.groovy
+++ b/.test-infra/jenkins/job_PerformanceTests_FileBasedIO_IT.groovy
@@ -327,7 +327,7 @@ jobs.findAll {
     'beam_PerformanceTests_TextIOIT_HDFS',
     'beam_PerformanceTests_Compressed_TextIOIT_HDFS',
     'beam_PerformanceTests_ManyFiles_TextIOIT_HDFS',
-    // TODO(BEAM-3945) TFRecord performance test is failing only when running on hdfs.
+    // TODO(https://github.com/apache/beam/issues/18796) TFRecord performance test is failing only when running on hdfs.
     // We need to fix this before enabling this job on jenkins.
     //'beam_PerformanceTests_TFRecordIOIT_HDFS',
     'beam_PerformanceTests_AvroIOIT_HDFS',
diff --git a/.test-infra/jenkins/job_PerformanceTests_KafkaIO_IT.groovy b/.test-infra/jenkins/job_PerformanceTests_KafkaIO_IT.groovy
index a71bc9056dd..7646a3c2889 100644
--- a/.test-infra/jenkins/job_PerformanceTests_KafkaIO_IT.groovy
+++ b/.test-infra/jenkins/job_PerformanceTests_KafkaIO_IT.groovy
@@ -24,7 +24,7 @@ String jobName = "beam_PerformanceTests_Kafka_IO"
 
 job(jobName) {
   common.setTopLevelMainJobProperties(delegate)
-  // TODO(BEAM-9482): Re-enable once fixed.
+  // TODO(https://github.com/apache/beam/issues/20333): Re-enable once fixed.
   // common.setAutoJob(delegate, 'H H/6 * * *')
   //  common.enablePhraseTriggeringFromPullRequest(
   //      delegate,
@@ -75,7 +75,7 @@ job(jobName) {
     kafkaTopic                   : 'beam-runnerv2',
     bigQueryTable                : 'kafkaioit_results_sdf_wrapper',
     influxMeasurement            : 'kafkaioit_results_sdf_wrapper',
-    // TODO(BEAM-11779) remove shuffle_mode=appliance with runner v2 once issue is resolved.
+    // TODO(https://github.com/apache/beam/issues/20806) remove shuffle_mode=appliance with runner v2 once issue is resolved.
     experiments                  : 'use_runner_v2,shuffle_mode=appliance,use_unified_worker',
   ]
 
@@ -90,7 +90,7 @@ job(jobName) {
     kafkaTopic                   : 'beam-sdf',
     bigQueryTable                : 'kafkaioit_results_runner_v2',
     influxMeasurement            : 'kafkaioit_results_runner_v2',
-    // TODO(BEAM-11779) remove shuffle_mode=appliance with runner v2 once issue is resolved.
+    // TODO(https://github.com/apache/beam/issues/20806) remove shuffle_mode=appliance with runner v2 once issue is resolved.
     experiments                  : 'use_runner_v2,shuffle_mode=appliance,use_unified_worker',
   ]
 
diff --git a/.test-infra/jenkins/job_PostCommit_Java_PortableValidatesRunner_Flink_Streaming.groovy b/.test-infra/jenkins/job_PostCommit_Java_PortableValidatesRunner_Flink_Streaming.groovy
index a35746a0cd3..fb3e24867f8 100644
--- a/.test-infra/jenkins/job_PostCommit_Java_PortableValidatesRunner_Flink_Streaming.groovy
+++ b/.test-infra/jenkins/job_PostCommit_Java_PortableValidatesRunner_Flink_Streaming.groovy
@@ -40,7 +40,7 @@ PostcommitJobBuilder.postCommitJob('beam_PostCommit_Java_PVR_Flink_Streaming',
           tasks(":runners:flink:${CommonTestProperties.getFlinkVersion()}:job-server:validatesPortableRunnerStreaming")
           commonJobProperties.setGradleSwitches(delegate)
         }
-        // TODO(BEAM-10940): Enable this test suite once we have support.
+        // TODO(https://github.com/apache/beam/issues/20668): Enable this test suite once we have support.
         //gradle {
         //  rootBuildScriptDir(commonJobProperties.checkoutDir)
         //  tasks(":runners:flink:${CommonTestProperties.getFlinkVersion()}:job-server:validatesPortableRunnerStreamingCheckpoint")
diff --git a/.test-infra/jenkins/job_PostCommit_Python_Chicago_Taxi_Example_Dataflow.groovy b/.test-infra/jenkins/job_PostCommit_Python_Chicago_Taxi_Example_Dataflow.groovy
index 50104892153..0fe9504e8a6 100644
--- a/.test-infra/jenkins/job_PostCommit_Python_Chicago_Taxi_Example_Dataflow.groovy
+++ b/.test-infra/jenkins/job_PostCommit_Python_Chicago_Taxi_Example_Dataflow.groovy
@@ -53,7 +53,7 @@ PhraseTriggeringPostCommitBuilder.postCommitJob(
       chicagoTaxiJob(delegate)
     }
 
-// TODO(BEAM-9154): Chicago Taxi Example doesn't work in Python 3.
+// TODO(https://github.com/apache/beam/issues/19973): Chicago Taxi Example doesn't work in Python 3.
 // Uncomment below once it is fixed.
 //
 // CronJobBuilder.cronJob(
diff --git a/.test-infra/jenkins/job_PostCommit_Python_Chicago_Taxi_Example_Flink.groovy b/.test-infra/jenkins/job_PostCommit_Python_Chicago_Taxi_Example_Flink.groovy
index 54f8cd94914..2874fc3bad3 100644
--- a/.test-infra/jenkins/job_PostCommit_Python_Chicago_Taxi_Example_Flink.groovy
+++ b/.test-infra/jenkins/job_PostCommit_Python_Chicago_Taxi_Example_Flink.groovy
@@ -67,7 +67,7 @@ PhraseTriggeringPostCommitBuilder.postCommitJob(
       chicagoTaxiJob(delegate)
     }
 
-// TODO(BEAM-9154): Chicago Taxi Example doesn't work in Python 3.
+// TODO(https://github.com/apache/beam/issues/19973): Chicago Taxi Example doesn't work in Python 3.
 // Uncomment below once it is fixed.
 //
 // CronJobBuilder.cronJob(
diff --git a/.test-infra/jenkins/metrics_report/tox.ini b/.test-infra/jenkins/metrics_report/tox.ini
index aee2a776890..6ea39e0ab39 100644
--- a/.test-infra/jenkins/metrics_report/tox.ini
+++ b/.test-infra/jenkins/metrics_report/tox.ini
@@ -14,7 +14,7 @@
 ;    See the License for the specific language governing permissions and
 ;    limitations under the License.
 ;
-; TODO(BEAM-9980): Don't hardcode Py3.8 version.
+; TODO(https://github.com/apache/beam/issues/20209): Don't hardcode Py3.8 version.
 [tox]
 skipsdist = True
 envlist = py38-test,py38-generate-report
diff --git a/build.gradle.kts b/build.gradle.kts
index e4c9fe4e84f..581f4f06f09 100644
--- a/build.gradle.kts
+++ b/build.gradle.kts
@@ -297,7 +297,7 @@ tasks.register("pythonDockerBuildPreCommit") {
 }
 
 tasks.register("pythonLintPreCommit") {
-  // TODO(BEAM-9980): Find a better way to specify lint and formatter tasks without hardcoding py version.
+  // TODO(https://github.com/apache/beam/issues/20209): Find a better way to specify lint and formatter tasks without hardcoding py version.
   dependsOn(":sdks:python:test-suites:tox:py37:lint")
 }
 
@@ -379,14 +379,14 @@ tasks.register("runBeamDependencyCheck") {
 }
 
 tasks.register("whitespacePreCommit") {
-  // TODO(BEAM-9980): Find a better way to specify the tasks without hardcoding py version.
+  // TODO(https://github.com/apache/beam/issues/20209): Find a better way to specify the tasks without hardcoding py version.
   dependsOn(":sdks:python:test-suites:tox:py38:archiveFilesToLint")
   dependsOn(":sdks:python:test-suites:tox:py38:unpackFilesToLint")
   dependsOn(":sdks:python:test-suites:tox:py38:whitespacelint")
 }
 
 tasks.register("typescriptPreCommit") {
-  // TODO(BEAM-9980): Find a better way to specify the tasks without hardcoding py version.
+  // TODO(https://github.com/apache/beam/issues/20209): Find a better way to specify the tasks without hardcoding py version.
   dependsOn(":sdks:python:test-suites:tox:py38:eslint")
   dependsOn(":sdks:python:test-suites:tox:py38:jest")
 }
diff --git a/buildSrc/src/main/groovy/org/apache/beam/gradle/BeamModulePlugin.groovy b/buildSrc/src/main/groovy/org/apache/beam/gradle/BeamModulePlugin.groovy
index e7cecf81ccf..d7fa19fe9cd 100644
--- a/buildSrc/src/main/groovy/org/apache/beam/gradle/BeamModulePlugin.groovy
+++ b/buildSrc/src/main/groovy/org/apache/beam/gradle/BeamModulePlugin.groovy
@@ -1169,7 +1169,7 @@ class BeamModulePlugin implements Plugin<Project> {
         options.errorprone.disableWarningsInGeneratedCode = true
         options.errorprone.excludedPaths = '(.*/)?(build/generated-src|build/generated.*avro-java|build/generated)/.*'
 
-        // TODO(BEAM-11936): Enable errorprone checks
+        // TODO(https://github.com/apache/beam/issues/20955): Enable errorprone checks
         options.errorprone.errorproneArgs.add("-Xep:AutoValueImmutableFields:OFF")
         options.errorprone.errorproneArgs.add("-Xep:AutoValueSubclassLeaked:OFF")
         options.errorprone.errorproneArgs.add("-Xep:BadImport:OFF")
diff --git a/examples/java/src/main/java/org/apache/beam/examples/complete/game/StatefulTeamScore.java b/examples/java/src/main/java/org/apache/beam/examples/complete/game/StatefulTeamScore.java
index 8fe87c454d2..5e70d85ec69 100644
--- a/examples/java/src/main/java/org/apache/beam/examples/complete/game/StatefulTeamScore.java
+++ b/examples/java/src/main/java/org/apache/beam/examples/complete/game/StatefulTeamScore.java
@@ -78,7 +78,9 @@ import org.joda.time.Instant;
  */
 @SuppressWarnings({
   "nullness", // TODO(https://github.com/apache/beam/issues/20497)
-  "unused" // TODO(BEAM-13271): Remove when new version of errorprone is released (2.11.0)
+  // TODO(https://github.com/apache/beam/issues/21230): Remove when new version of
+  // errorprone is released (2.11.0)
+  "unused"
 })
 public class StatefulTeamScore extends LeaderBoard {
 
diff --git a/examples/java/src/main/java/org/apache/beam/examples/snippets/Snippets.java b/examples/java/src/main/java/org/apache/beam/examples/snippets/Snippets.java
index 2091d572bf5..274f48f11bb 100644
--- a/examples/java/src/main/java/org/apache/beam/examples/snippets/Snippets.java
+++ b/examples/java/src/main/java/org/apache/beam/examples/snippets/Snippets.java
@@ -118,7 +118,9 @@ import org.slf4j.LoggerFactory;
 @SuppressWarnings({
   "rawtypes", // TODO(https://github.com/apache/beam/issues/20447)
   "nullness", // TODO(https://github.com/apache/beam/issues/20497)
-  "unused" // TODO(BEAM-13271): Remove when new version of errorprone is released (2.11.0)
+  // TODO(https://github.com/apache/beam/issues/21230): Remove when new version of
+  // errorprone is released (2.11.0)
+  "unused"
 })
 public class Snippets {
 
diff --git a/examples/notebooks/documentation/transforms/python/elementwise/pardo-py.ipynb b/examples/notebooks/documentation/transforms/python/elementwise/pardo-py.ipynb
index f4984dc36b9..6a0a8a91809 100644
--- a/examples/notebooks/documentation/transforms/python/elementwise/pardo-py.ipynb
+++ b/examples/notebooks/documentation/transforms/python/elementwise/pardo-py.ipynb
@@ -365,7 +365,7 @@
     "\n",
     "> *Known issues:*\n",
     ">\n",
-    "> * [[BEAM-7340]](https://github.com/apache/beam/issues/19394)\n",
+    "> * [[Issue 19394]](https://github.com/apache/beam/issues/19394)\n",
     ">   `DoFn.teardown()` metrics are lost."
    ]
   },
diff --git a/model/pipeline/src/main/proto/org/apache/beam/model/pipeline/v1/beam_runner_api.proto b/model/pipeline/src/main/proto/org/apache/beam/model/pipeline/v1/beam_runner_api.proto
index a19229a7857..56541f7a74c 100644
--- a/model/pipeline/src/main/proto/org/apache/beam/model/pipeline/v1/beam_runner_api.proto
+++ b/model/pipeline/src/main/proto/org/apache/beam/model/pipeline/v1/beam_runner_api.proto
@@ -471,7 +471,7 @@ message StandardUserStateTypes {
     // StateKey.MultimapKeysUserState or StateKey.MultimapUserState.
     MULTIMAP = 1 [(beam_urn) = "beam:user_state:multimap:v1"];
 
-    // TODO(BEAM-10650): Add protocol to support OrderedListState
+    // TODO(https://github.com/apache/beam/issues/20486): Add protocol to support OrderedListState
   }
 }
 
@@ -1024,11 +1024,11 @@ message StandardCoders {
     //
     // Schema types are mapped to coders as follows:
     //   AtomicType:
-    //     BYTE:      not yet a standard coder (BEAM-7996)
-    //     INT16:     not yet a standard coder (BEAM-7996)
+    //     BYTE:      not yet a standard coder (https://github.com/apache/beam/issues/19815)
+    //     INT16:     not yet a standard coder (https://github.com/apache/beam/issues/19815)
     //     INT32:     beam:coder:varint:v1
     //     INT64:     beam:coder:varint:v1
-    //     FLOAT:     not yet a standard coder (BEAM-7996)
+    //     FLOAT:     not yet a standard coder (https://github.com/apache/beam/issues/19815)
     //     DOUBLE:    beam:coder:double:v1
     //     STRING:    beam:coder:string_utf8:v1
     //     BOOLEAN:   beam:coder:bool:v1
diff --git a/model/pipeline/src/main/proto/org/apache/beam/model/pipeline/v1/metrics.proto b/model/pipeline/src/main/proto/org/apache/beam/model/pipeline/v1/metrics.proto
index dd1c1428180..40956ddf856 100644
--- a/model/pipeline/src/main/proto/org/apache/beam/model/pipeline/v1/metrics.proto
+++ b/model/pipeline/src/main/proto/org/apache/beam/model/pipeline/v1/metrics.proto
@@ -191,7 +191,7 @@ message MonitoringInfoSpecs {
     // which does not fit into a typical metric format. See MonitoringTableData
     // for more details.
     //
-    // TODO(BEAM-9617): Support monitored state.
+    // TODO(https://github.com/apache/beam/issues/20122): Support monitored state.
     //
     // USER_MONITORING_TABLE = XX [(monitoring_info_spec) = {
     //   urn: "beam:metric:user:v1",
@@ -561,7 +561,7 @@ message MonitoringInfoTypeUrns {
     // which does not fit into a typical metric format. See MonitoringTableData
     // for more details.
     //
-    // TODO(BEAM-9617): Support monitored state.
+    // TODO(https://github.com/apache/beam/issues/20122): Support monitored state.
     //
     // Encoding: MonitoringTableData proto encoded as bytes
     // MONITORING_TABLE_TYPE = XX [(org.apache.beam.model.pipeline.v1.beam_urn) =
@@ -587,7 +587,7 @@ message MonitoringInfoTypeUrns {
 // to aggregate these metrics in custom ways. Engines can use custom aggregation
 // functions for specific URNs by inspecting the column values.
 //
-// TODO(BEAM-9617): Support monitored state.
+// TODO(https://github.com/apache/beam/issues/20122): Support monitored state.
 //
 // message MonitoringTableData {
 //   message MonitoringColumnValue {
diff --git a/release/src/main/scripts/build_release_candidate.sh b/release/src/main/scripts/build_release_candidate.sh
index a380d692a79..8fe434edb97 100755
--- a/release/src/main/scripts/build_release_candidate.sh
+++ b/release/src/main/scripts/build_release_candidate.sh
@@ -363,7 +363,7 @@ if [[ $confirmation = "y" ]]; then
   git clone --branch "${RC_TAG}" --depth 1 ${GIT_REPO_URL}
   cd ${BEAM_ROOT_DIR}
   RELEASE_COMMIT=$(git rev-list -n 1 "tags/${RC_TAG}")
-  # TODO(BEAM-9980): Don't hardcode py version in this file.
+  # TODO(https://github.com/apache/beam/issues/20209): Don't hardcode py version in this file.
   cd sdks/python && pip install -r build-requirements.txt && tox -e py38-docs
   GENERATED_PYDOC=~/${LOCAL_WEBSITE_UPDATE_DIR}/${LOCAL_PYTHON_DOC}/${BEAM_ROOT_DIR}/sdks/python/target/docs/_build
   rm -rf ${GENERATED_PYDOC}/.doctrees
diff --git a/release/src/main/scripts/run_rc_validation.sh b/release/src/main/scripts/run_rc_validation.sh
index a39fbea23ec..35b45b7fd46 100755
--- a/release/src/main/scripts/run_rc_validation.sh
+++ b/release/src/main/scripts/run_rc_validation.sh
@@ -98,7 +98,7 @@ echo "All environment and workflow configurations from RC_VALIDATE_CONFIGS:"
 for i in "${RC_VALIDATE_CONFIGS[@]}"; do
   echo "$i = ${!i}"
 done
-echo "TODO(BEAM-13054): parts of this script launch background processes with gnome-terminal,"
+echo "TODO(https://github.com/apache/beam/issues/21237): parts of this script launch background processes with gnome-terminal,"
 echo "It may not work well over ssh or within a tmux session. Using 'ssh -Y' may help."
 echo "[Confirmation Required] Would you like to proceed with current settings? [y|N]"
 read confirmation
@@ -229,7 +229,7 @@ else
   echo "* Skipping Python Quickstart and MobileGame. Hub is required."
 fi
 
-# TODO(BEAM-13220) Run the remaining tests on Jenkins.
+# TODO(https://github.com/apache/beam/issues/21193) Run the remaining tests on Jenkins.
 echo ""
 echo "====================Starting Python Leaderboard & GameStates Validations==============="
 if [[ ("$python_leaderboard_direct" = true \
diff --git a/scripts/ci/pr-bot/processNewPrs.ts b/scripts/ci/pr-bot/processNewPrs.ts
index 6b112c3dbb1..02b07e3e6e3 100644
--- a/scripts/ci/pr-bot/processNewPrs.ts
+++ b/scripts/ci/pr-bot/processNewPrs.ts
@@ -191,7 +191,7 @@ async function processPull(
       return;
     }
 
-    // TODO(BEAM-13925) - also check if the author is a committer, if they are don't auto-assign a committer
+    // TODO(https://github.com/apache/beam/issues/21417) - also check if the author is a committer, if they are don't auto-assign a committer
     for (const approver of approvers) {
       const labelOfReviewer = prState.getLabelForReviewer(approver);
       if (labelOfReviewer) {
diff --git a/sdks/typescript/src/apache_beam/proto/beam_runner_api.ts b/sdks/typescript/src/apache_beam/proto/beam_runner_api.ts
index 7911b9d7aba..e1b4d95ce07 100644
--- a/sdks/typescript/src/apache_beam/proto/beam_runner_api.ts
+++ b/sdks/typescript/src/apache_beam/proto/beam_runner_api.ts
@@ -1564,11 +1564,11 @@ export enum StandardCoders_Enum {
      *
      * Schema types are mapped to coders as follows:
      *   AtomicType:
-     *     BYTE:      not yet a standard coder (BEAM-7996)
-     *     INT16:     not yet a standard coder (BEAM-7996)
+     *     BYTE:      not yet a standard coder (https://github.com/apache/beam/issues/19815)
+     *     INT16:     not yet a standard coder (https://github.com/apache/beam/issues/19815)
      *     INT32:     beam:coder:varint:v1
      *     INT64:     beam:coder:varint:v1
-     *     FLOAT:     not yet a standard coder (BEAM-7996)
+     *     FLOAT:     not yet a standard coder (https://github.com/apache/beam/issues/19815)
      *     DOUBLE:    beam:coder:double:v1
      *     STRING:    beam:coder:string_utf8:v1
      *     BOOLEAN:   beam:coder:bool:v1
diff --git a/website/www/site/content/en/documentation/dsls/dataframes/differences-from-pandas.md b/website/www/site/content/en/documentation/dsls/dataframes/differences-from-pandas.md
index c143d717f36..4586750dd29 100644
--- a/website/www/site/content/en/documentation/dsls/dataframes/differences-from-pandas.md
+++ b/website/www/site/content/en/documentation/dsls/dataframes/differences-from-pandas.md
@@ -62,7 +62,7 @@ Examples:
 
 Beam DataFrame operations are deferred, but the schemas of the resulting DataFrames are not, meaning that result columns must be computable without access to the data. Some DataFrame operations can’t support this usage, so they can’t be implemented. These operations raise a [WontImplementError](https://beam.apache.org/releases/pydoc/{{< param release_latest >}}/apache_beam.dataframe.frame_base.html#apache_beam.dataframe.frame_base.WontImplementError).
 
-<!-- TODO(BEAM-12169): Document the use of categorical columns as a workaround -->
+<!-- TODO(https://github.com/apache/beam/issues/20958): Document the use of categorical columns as a workaround -->
 Currently there’s no workaround for this issue. But in the future, Beam Dataframe may support non-deferred column operations on categorical columns. This work is being tracked in [Issue 20958](https://github.com/apache/beam/issues/20958).
 
 ### Operations that produce non-deferred values or plots
diff --git a/website/www/site/content/en/documentation/patterns/ai-platform.md b/website/www/site/content/en/documentation/patterns/ai-platform.md
index 4decd7f3707..f9df11266b8 100644
--- a/website/www/site/content/en/documentation/patterns/ai-platform.md
+++ b/website/www/site/content/en/documentation/patterns/ai-platform.md
@@ -212,5 +212,5 @@ with beam.Pipeline() as p:
 {{< /highlight >}}
 
 {{< highlight java >}}
-// Getting predictions is not yet available for Java. [BEAM-9501]
+// Getting predictions is not yet available for Java. [https://github.com/apache/beam/issues/20001]
 {{< /highlight >}}
diff --git a/website/www/site/content/en/documentation/programming-guide.md b/website/www/site/content/en/documentation/programming-guide.md
index d4b822d0f27..680d91bdae5 100644
--- a/website/www/site/content/en/documentation/programming-guide.md
+++ b/website/www/site/content/en/documentation/programming-guide.md
@@ -5436,7 +5436,7 @@ _ = (p | 'Read per user' >> ReadPerUser()
 {{< /highlight >}}
 
 {{< highlight go >}}
-This is not supported yet, see BEAM-10660.
+This is not supported yet, see https://github.com/apache/beam/issues/20510.
 {{< /highlight >}}
 
 #### CombiningState
@@ -5468,7 +5468,7 @@ _ = (p | 'Read per user' >> ReadPerUser()
 {{< /highlight >}}
 
 {{< highlight go >}}
-This is not supported yet, see BEAM-10660.
+This is not supported yet, see https://github.com/apache/beam/issues/20510.
 {{< /highlight >}}
 
 #### BagState
@@ -5514,7 +5514,7 @@ _ = (p | 'Read per user' >> ReadPerUser()
 {{< /highlight >}}
 
 {{< highlight go >}}
-This is not supported yet, see BEAM-10660.
+This is not supported yet, see https://github.com/apache/beam/issues/20510.
 {{< /highlight >}}
 
 ### 11.2. Deferred state reads {#deferred-state-reads}
@@ -5543,11 +5543,11 @@ perUser.apply(ParDo.of(new DoFn<KV<String, ValueT>, OutputT>() {
 {{< /highlight >}}
 
 {{< highlight py >}}
-This is not supported yet, see BEAM-11506.
+This is not supported yet, see https://github.com/apache/beam/issues/20739.
 {{< /highlight >}}
 
 {{< highlight go >}}
-This is not supported yet, see BEAM-10660.
+This is not supported yet, see https://github.com/apache/beam/issues/20510.
 {{< /highlight >}}
 
 If however there are code paths in which the states are not fetched, then annotating with @AlwaysFetched will add
@@ -5637,7 +5637,7 @@ _ = (p | 'Read per user' >> ReadPerUser()
 {{< /highlight >}}
 
 {{< highlight go >}}
-This is not supported yet, see BEAM-10660.
+This is not supported yet, see https://github.com/apache/beam/issues/20510.
 {{< /highlight >}}
 
 #### 11.3.2. Processing-time timers {#processing-time-timers}
@@ -5689,7 +5689,7 @@ _ = (p | 'Read per user' >> ReadPerUser()
 {{< /highlight >}}
 
 {{< highlight go >}}
-This is not supported yet, see BEAM-10660.
+This is not supported yet, see https://github.com/apache/beam/issues/20510.
 {{< /highlight >}}
 
 #### 11.3.3. Dynamic timer tags {#dynamic-timer-tags}
@@ -5750,7 +5750,7 @@ _ = (p | 'Read per user' >> ReadPerUser()
 {{< /highlight >}}
 
 {{< highlight go >}}
-This is not supported yet, see BEAM-10660.
+This is not supported yet, see https://github.com/apache/beam/issues/20510.
 {{< /highlight >}}
 
 #### 11.3.4. Timer output timestamps {#timer-output-timestamps}
@@ -5857,11 +5857,11 @@ perUser.apply(ParDo.of(new DoFn<KV<String, ValueT>, OutputT>() {
 {{< /highlight >}}
 
 {{< highlight py >}}
-Timer output timestamps is not yet supported in Python SDK. See BEAM-11507.
+Timer output timestamps is not yet supported in Python SDK. See https://github.com/apache/beam/issues/20705.
 {{< /highlight >}}
 
 {{< highlight go >}}
-This is not supported yet, see BEAM-10660.
+This is not supported yet, see https://github.com/apache/beam/issues/20510.
 {{< /highlight >}}
 
 ### 11.4. Garbage collecting state {#garbage-collecting-state}
@@ -5907,7 +5907,7 @@ _ = (p | 'Read per user' >> ReadPerUser()
 {{< /highlight >}}
 
 {{< highlight go >}}
-This is not supported yet, see BEAM-10660.
+This is not supported yet, see https://github.com/apache/beam/issues/20510.
 {{< /highlight >}}
 
 This `ParDo` stores state per day. Once the pipeline is done processing data for a given day, all the state for that
@@ -5991,7 +5991,7 @@ _ = (p | 'Read per user' >> ReadPerUser()
 {{< /highlight >}}
 
 {{< highlight go >}}
-This is not supported yet, see BEAM-10660.
+This is not supported yet, see https://github.com/apache/beam/issues/20510.
 {{< /highlight >}}
 
 ### 11.5. State and timers examples {#state-timers-examples}