[beam] branch asf-site updated: Publishing website 2022/03/22 00:03:26 at commit 555cc26

2022-03-21 Thread git-site-role
This is an automated email from the ASF dual-hosted git repository.

git-site-role pushed a commit to branch asf-site
in repository https://gitbox.apache.org/repos/asf/beam.git


The following commit(s) were added to refs/heads/asf-site by this push:
 new 12a4dec  Publishing website 2022/03/22 00:03:26 at commit 555cc26
12a4dec is described below

commit 12a4decf3e0f27450a1633fd55e79f35f8bf032e
Author: jenkins 
AuthorDate: Tue Mar 22 00:03:27 2022 +

Publishing website 2022/03/22 00:03:26 at commit 555cc26
---
 website/generated-content/documentation/runners/flink/index.html | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/website/generated-content/documentation/runners/flink/index.html 
b/website/generated-content/documentation/runners/flink/index.html
index fd065e9..5e742a7 100644
--- a/website/generated-content/documentation/runners/flink/index.html
+++ b/website/generated-content/documentation/runners/flink/index.html
@@ -103,7 +103,7 @@ and will not work on remote clusters.
 See here for 
details.Additional information 
and caveatsMonitoring your jobYou can 
monitor a running Flink job using the Flink JobManager Dashboard or its Rest 
interfaces. By default, this is available at port 8081 of the 
JobManager node. If you have a Flink installation on your local machine that 
would be http://localhost:8081PubSubIO rely on their checkpoints to be 
acknowledged which can only be done when checkpointing is enabled for the 
FlinkRunner. To enable checkpointing, please set checkpointingIntervalcheckpointing_interval to the desired 
checkpointing interval in milliseconds.Pipeline options for the Flink 
RunnerWh [...]
 https://beam.apache.org/releases/javadoc/2.37.0/index.html?org/apache/beam/runners/flink/FlinkPipelineOptions.html>FlinkPipelineOptions
-reference class:allowNonRestoredStateFlag 
indicating whether non restored state is allowed if the savepoint contains 
state for an operator that is no longer part of the pipeline.Default: 
falseautoBalanceWriteFilesShardingEnabledFlag
 indicating whether auto-balance sharding for WriteFiles transform should be 
enabled. This might prove  [...]
+reference class:allowNonRestoredStateFlag 
indicating whether non restored state is allowed if the savepoint contains 
state for an operator that is no longer part of the pipeline.Default: 
falseautoBalanceWriteFilesShardingEnabledFlag
 indicating whether auto-balance sharding for WriteFiles transform should be 
enabled. This might prove  [...]
 https://beam.apache.org/releases/javadoc/2.37.0/index.html?org/apache/beam/sdk/options/PipelineOptions.html>PipelineOptions
 reference.Flink Version 
CompatibilityThe Flink cluster version has to match the minor version 
used by the FlinkRunner.
 The minor version is the first two numbers in the version string, e.g. in 
1.13.0 the


[beam] branch master updated (d352d60 -> 0a68801)

2022-03-21 Thread iemejia
This is an automated email from the ASF dual-hosted git repository.

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


from d352d60  [BEAM-14071] Enabling Flink on Dataproc for Interactive Beam 
(#17044)
 add 7257e37  [BEAM-4106] Remove filesToStage from Flink pipeline option 
list.
 add 0a68801  Merge pull request #17143: [BEAM-4106] Remove filesToStage 
from Flink pipeline option list.

No new revisions were added by this update.

Summary of changes:
 website/www/site/layouts/shortcodes/flink_java_pipeline_options.html | 5 -
 .../www/site/layouts/shortcodes/flink_python_pipeline_options.html   | 5 -
 2 files changed, 10 deletions(-)


[beam] branch master updated: [BEAM-14071] Enabling Flink on Dataproc for Interactive Beam (#17044)

2022-03-21 Thread ningk
This is an automated email from the ASF dual-hosted git repository.

ningk 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 d352d60  [BEAM-14071] Enabling Flink on Dataproc for Interactive Beam 
(#17044)
d352d60 is described below

commit d352d6086b64bf4390fe8fb551a80892090f6be0
Author: Victor 
AuthorDate: Mon Mar 21 16:44:11 2022 -0400

[BEAM-14071] Enabling Flink on Dataproc for Interactive Beam (#17044)
---
 .../runners/interactive/cache_manager.py   |  9 +-
 .../dataproc/dataproc_cluster_manager.py   | 12 +++-
 .../runners/interactive/interactive_beam.py| 19 -
 .../runners/interactive/interactive_environment.py |  6 ++--
 .../runners/interactive/interactive_runner.py  |  5 +++-
 .../runners/interactive/interactive_runner_test.py | 32 --
 6 files changed, 60 insertions(+), 23 deletions(-)

diff --git a/sdks/python/apache_beam/runners/interactive/cache_manager.py 
b/sdks/python/apache_beam/runners/interactive/cache_manager.py
index 300f3a3..1960733 100644
--- a/sdks/python/apache_beam/runners/interactive/cache_manager.py
+++ b/sdks/python/apache_beam/runners/interactive/cache_manager.py
@@ -190,7 +190,14 @@ class FileBasedCacheManager(CacheManager):
 
   def size(self, *labels):
 if self.exists(*labels):
-  return sum(os.path.getsize(path) for path in self._match(*labels))
+  matched_path = self._match(*labels)
+  # if any matched path has a gs:// prefix, it must be cached on GCS
+  if 'gs://' in matched_path[0]:
+from apache_beam.io.gcp import gcsio
+return sum(
+sum(gcsio.GcsIO().list_prefix(path).values())
+for path in matched_path)
+  return sum(os.path.getsize(path) for path in matched_path)
 return 0
 
   def exists(self, *labels):
diff --git 
a/sdks/python/apache_beam/runners/interactive/dataproc/dataproc_cluster_manager.py
 
b/sdks/python/apache_beam/runners/interactive/dataproc/dataproc_cluster_manager.py
index 4a9c688..8bb8e24 100644
--- 
a/sdks/python/apache_beam/runners/interactive/dataproc/dataproc_cluster_manager.py
+++ 
b/sdks/python/apache_beam/runners/interactive/dataproc/dataproc_cluster_manager.py
@@ -27,7 +27,6 @@ from typing import Tuple
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.runners.interactive import interactive_environment as ie
 from apache_beam.runners.interactive.utils import progress_indicated
-from apache_beam.version import __version__ as beam_version
 
 try:
   from google.cloud import dataproc_v1
@@ -67,9 +66,6 @@ class DataprocClusterManager:
   required for creating and deleting Dataproc clusters for use
   under Interactive Beam.
   """
-  IMAGE_VERSION = '2.0.31-debian10'
-  STAGING_LOG_NAME = 'dataproc-startup-script_output'
-
   def __init__(self, cluster_metadata: MasterURLIdentifier) -> None:
 """Initializes the DataprocClusterManager with properties required
 to interface with the Dataproc ClusterControllerClient.
@@ -162,13 +158,13 @@ class DataprocClusterManager:
 'cluster_name': self.cluster_metadata.cluster_name,
 'config': {
 'software_config': {
-'image_version': self.IMAGE_VERSION,
+'image_version': ie.current_env().clusters.
+DATAPROC_IMAGE_VERSION,
 'optional_components': ['DOCKER', 'FLINK']
 },
 'gce_cluster_config': {
 'metadata': {
-'flink-start-yarn-session': 'true',
-'PIP_PACKAGES': 'apache-beam[gcp]=={}'.format(beam_version)
+'flink-start-yarn-session': 'true'
 },
 'service_account_scopes': [
 'https://www.googleapis.com/auth/cloud-platform'
@@ -310,7 +306,7 @@ class DataprocClusterManager:
 """Returns the master_url of the current cluster."""
 startup_logs = []
 for file in self._fs._list(staging_bucket):
-  if self.STAGING_LOG_NAME in file.path:
+  if ie.current_env().clusters.DATAPROC_STAGING_LOG_NAME in file.path:
 startup_logs.append(file.path)
 
 for log in startup_logs:
diff --git a/sdks/python/apache_beam/runners/interactive/interactive_beam.py 
b/sdks/python/apache_beam/runners/interactive/interactive_beam.py
index 6098b07..6fa1f8a 100644
--- a/sdks/python/apache_beam/runners/interactive/interactive_beam.py
+++ b/sdks/python/apache_beam/runners/interactive/interactive_beam.py
@@ -37,7 +37,6 @@ from datetime import timedelta
 from typing import DefaultDict
 from typing import Dict
 from typing import List
-from typing import Mapping
 from typing import Optional
 
 import pandas as pd
@@ -45,8 +44,6 @@ import pandas as pd
 import apache_beam as beam
 from apache_beam.dataframe.frame_base import DeferredBase
 from apache_beam.runners.interactive import 

[beam] branch master updated: [BEAM-14124] Add display data to BQ storage reads.

2022-03-21 Thread ibzib
This is an automated email from the ASF dual-hosted git repository.

ibzib 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 ce71caf  [BEAM-14124] Add display data to BQ storage reads.
 new 57c8647  Merge pull request #17115 from ibzib/bq-display-data
ce71caf is described below

commit ce71cafc4801474ba7791a194200e4599b0b9e33
Author: Kyle Weaver 
AuthorDate: Thu Mar 17 13:12:35 2022 -0700

[BEAM-14124] Add display data to BQ storage reads.

Add display data for "Selected fields" and "Projection pushdown
applied". I also want to add one for "Number of fields pushed down", but
that will be a little more involved so I'll do it in a separate PR.
---
 .../beam/sdk/io/gcp/bigquery/BigQueryIO.java   | 26 ++-
 .../gcp/bigquery/BigQueryStorageTableSource.java   | 52 +-
 .../io/gcp/bigquery/BigQueryIOStorageReadTest.java |  5 +++
 3 files changed, 70 insertions(+), 13 deletions(-)

diff --git 
a/sdks/java/io/google-cloud-platform/src/main/java/org/apache/beam/sdk/io/gcp/bigquery/BigQueryIO.java
 
b/sdks/java/io/google-cloud-platform/src/main/java/org/apache/beam/sdk/io/gcp/bigquery/BigQueryIO.java
index 9786d90..c510db7 100644
--- 
a/sdks/java/io/google-cloud-platform/src/main/java/org/apache/beam/sdk/io/gcp/bigquery/BigQueryIO.java
+++ 
b/sdks/java/io/google-cloud-platform/src/main/java/org/apache/beam/sdk/io/gcp/bigquery/BigQueryIO.java
@@ -590,6 +590,7 @@ public class BigQueryIO {
 .setMethod(TypedRead.Method.DEFAULT)
 .setUseAvroLogicalTypes(false)
 .setFormat(DataFormat.AVRO)
+.setProjectionPushdownApplied(false)
 .build();
   }
 
@@ -805,6 +806,8 @@ public class BigQueryIO {
   abstract Builder setFromBeamRowFn(FromBeamRowFunction fromRowFn);
 
   abstract Builder setUseAvroLogicalTypes(Boolean useAvroLogicalTypes);
+
+  abstract Builder setProjectionPushdownApplied(boolean 
projectionPushdownApplied);
 }
 
 abstract @Nullable ValueProvider getJsonTableRef();
@@ -853,6 +856,8 @@ public class BigQueryIO {
 
 abstract Boolean getUseAvroLogicalTypes();
 
+abstract boolean getProjectionPushdownApplied();
+
 /**
  * An enumeration type for the priority of a query.
  *
@@ -1229,7 +1234,8 @@ public class BigQueryIO {
 getRowRestriction(),
 getParseFn(),
 outputCoder,
-getBigQueryServices(;
+getBigQueryServices(),
+getProjectionPushdownApplied(;
   }
 
   checkArgument(
@@ -1430,6 +1436,10 @@ public class BigQueryIO {
   DisplayData.item("table", 
BigQueryHelpers.displayTable(getTableProvider()))
   .withLabel("Table"))
   .addIfNotNull(DisplayData.item("query", 
getQuery()).withLabel("Query"))
+  .addIfNotDefault(
+  DisplayData.item("projectionPushdownApplied", 
getProjectionPushdownApplied())
+  .withLabel("Projection Pushdown Applied"),
+  false)
   .addIfNotNull(
   DisplayData.item("flattenResults", getFlattenResults())
   .withLabel("Flatten Query Results"))
@@ -1438,6 +1448,13 @@ public class BigQueryIO {
   .withLabel("Use Legacy SQL Dialect"))
   .addIfNotDefault(
   DisplayData.item("validation", 
getValidate()).withLabel("Validation Enabled"), true);
+
+  ValueProvider> selectedFieldsProvider = getSelectedFields();
+  if (selectedFieldsProvider != null && 
selectedFieldsProvider.isAccessible()) {
+builder.add(
+DisplayData.item("selectedFields", String.join(", ", 
selectedFieldsProvider.get()))
+.withLabel("Selected Fields"));
+  }
 }
 
 /** Ensures that methods of the from() / fromQuery() family are called at 
most once. */
@@ -1623,6 +1640,11 @@ public class BigQueryIO {
   return toBuilder().setUseAvroLogicalTypes(true).build();
 }
 
+@VisibleForTesting
+TypedRead withProjectionPushdownApplied() {
+  return toBuilder().setProjectionPushdownApplied(true).build();
+}
+
 @Override
 public boolean supportsProjectionPushdown() {
   // We can't do projection pushdown when a query is set. The query may 
project certain fields
@@ -1643,7 +1665,7 @@ public class BigQueryIO {
   outputFields.keySet());
   ImmutableList fields =
   ImmutableList.copyOf(fieldAccessDescriptor.fieldNamesAccessed());
-  return withSelectedFields(fields);
+  return withSelectedFields(fields).withProjectionPushdownApplied();
 }
   }
 
diff --git 
a/sdks/java/io/google-cloud-platform/src/main/java/org/apache/beam/sdk/io/gcp/bigquery/BigQueryStorageTableSource.java
 

[beam] branch pr-bot-state updated: Updating config from bot

2022-03-21 Thread github-bot
This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a commit to branch pr-bot-state
in repository https://gitbox.apache.org/repos/asf/beam.git


The following commit(s) were added to refs/heads/pr-bot-state by this push:
 new adb6b21  Updating config from bot
adb6b21 is described below

commit adb6b212cd4ab0717ff54487d5c7106742929ea8
Author: github-actions 
AuthorDate: Mon Mar 21 17:46:45 2022 +

Updating config from bot


[beam] branch pr-bot-state updated: Updating config from bot

2022-03-21 Thread github-bot
This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a commit to branch pr-bot-state
in repository https://gitbox.apache.org/repos/asf/beam.git


The following commit(s) were added to refs/heads/pr-bot-state by this push:
 new 4356fe1  Updating config from bot
4356fe1 is described below

commit 4356fe17d5f21100f784e0c0ea7106a192acfef8
Author: github-actions 
AuthorDate: Mon Mar 21 17:43:43 2022 +

Updating config from bot


[beam] branch pr-bot-state updated: Updating config from bot

2022-03-21 Thread github-bot
This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a commit to branch pr-bot-state
in repository https://gitbox.apache.org/repos/asf/beam.git


The following commit(s) were added to refs/heads/pr-bot-state by this push:
 new 5f12696  Updating config from bot
5f12696 is described below

commit 5f1269647beff1451ac06ae322a22a35075683c3
Author: github-actions 
AuthorDate: Mon Mar 21 17:31:17 2022 +

Updating config from bot


[beam] 01/01: Revert "[BEAM-14112] Avoid storing a generator in _CustomBigQuerySource (#17100)"

2022-03-21 Thread chamikara
This is an automated email from the ASF dual-hosted git repository.

chamikara pushed a commit to branch revert-17100-cyang/rfbq-interactive-fix
in repository https://gitbox.apache.org/repos/asf/beam.git

commit 3ccd12e69bda2816929a54cf3639738c82733782
Author: Chamikara Jayalath 
AuthorDate: Mon Mar 21 10:20:13 2022 -0700

Revert "[BEAM-14112] Avoid storing a generator in _CustomBigQuerySource 
(#17100)"

This reverts commit 62a661071b7db15e71d236abe68e15582e8997c9.
---
 sdks/python/apache_beam/io/gcp/bigquery.py | 38 +-
 .../apache_beam/io/gcp/bigquery_read_it_test.py| 12 ---
 2 files changed, 22 insertions(+), 28 deletions(-)

diff --git a/sdks/python/apache_beam/io/gcp/bigquery.py 
b/sdks/python/apache_beam/io/gcp/bigquery.py
index fc0f4b7..0503de8 100644
--- a/sdks/python/apache_beam/io/gcp/bigquery.py
+++ b/sdks/python/apache_beam/io/gcp/bigquery.py
@@ -705,7 +705,7 @@ class _CustomBigQuerySource(BoundedSource):
 self.flatten_results = flatten_results
 self.coder = coder or _JsonToDictCoder
 self.kms_key = kms_key
-self.export_result = None
+self.split_result = None
 self.options = pipeline_options
 self.bq_io_metadata = None  # Populate in setup, as it may make an RPC
 self.bigquery_job_labels = bigquery_job_labels or {}
@@ -789,26 +789,19 @@ class _CustomBigQuerySource(BoundedSource):
   project = self.project
 return project
 
-  def _create_source(self, path, bq):
+  def _create_source(self, path, schema):
 if not self.use_json_exports:
   return create_avro_source(path)
 else:
-  if isinstance(self.table_reference, vp.ValueProvider):
-table_ref = bigquery_tools.parse_table_reference(
-self.table_reference.get(), project=self.project)
-  else:
-table_ref = self.table_reference
-  table = bq.get_table(
-  table_ref.projectId, table_ref.datasetId, table_ref.tableId)
   return TextSource(
   path,
   min_bundle_size=0,
   compression_type=CompressionTypes.UNCOMPRESSED,
   strip_trailing_newlines=True,
-  coder=self.coder(table.schema))
+  coder=self.coder(schema))
 
   def split(self, desired_bundle_size, start_position=None, 
stop_position=None):
-if self.export_result is None:
+if self.split_result is None:
   bq = bigquery_tools.BigQueryWrapper(
   temp_dataset_id=(
   self.temp_dataset.datasetId if self.temp_dataset else None))
@@ -820,13 +813,16 @@ class _CustomBigQuerySource(BoundedSource):
   if not self.table_reference.projectId:
 self.table_reference.projectId = self._get_project()
 
-  self.export_result = self._export_files(bq)
+  schema, metadata_list = self._export_files(bq)
+  # Sources to be created lazily within a generator as they're output.
+  self.split_result = (
+  self._create_source(metadata.path, schema)
+  for metadata in metadata_list)
 
   if self.query is not None:
 bq.clean_up_temporary_dataset(self._get_project())
 
-for metadata in self.export_result:
-  source = self._create_source(metadata.path, bq)
+for source in self.split_result:
   yield SourceBundle(
   weight=1.0, source=source, start_position=None, stop_position=None)
 
@@ -878,7 +874,7 @@ class _CustomBigQuerySource(BoundedSource):
 """Runs a BigQuery export job.
 
 Returns:
-  a list of FileMetadata instances
+  bigquery.TableSchema instance, a list of FileMetadata instances
 """
 job_labels = self._get_bq_metadata().add_additional_bq_job_labels(
 self.bigquery_job_labels)
@@ -908,7 +904,17 @@ class _CustomBigQuerySource(BoundedSource):
job_labels=job_labels,
use_avro_logical_types=True)
 bq.wait_for_bq_job(job_ref)
-return FileSystems.match([gcs_location])[0].metadata_list
+metadata_list = FileSystems.match([gcs_location])[0].metadata_list
+
+if isinstance(self.table_reference, vp.ValueProvider):
+  table_ref = bigquery_tools.parse_table_reference(
+  self.table_reference.get(), project=self.project)
+else:
+  table_ref = self.table_reference
+table = bq.get_table(
+table_ref.projectId, table_ref.datasetId, table_ref.tableId)
+
+return table.schema, metadata_list
 
 
 class _CustomBigQueryStorageSource(BoundedSource):
diff --git a/sdks/python/apache_beam/io/gcp/bigquery_read_it_test.py 
b/sdks/python/apache_beam/io/gcp/bigquery_read_it_test.py
index e47754d..9101039 100644
--- a/sdks/python/apache_beam/io/gcp/bigquery_read_it_test.py
+++ b/sdks/python/apache_beam/io/gcp/bigquery_read_it_test.py
@@ -37,8 +37,6 @@ from apache_beam.io.gcp import bigquery_tools
 from apache_beam.io.gcp.bigquery_tools import BigQueryWrapper
 from apache_beam.io.gcp.internal.clients import bigquery
 from apache_beam.options.value_provider import 

[beam] branch revert-17100-cyang/rfbq-interactive-fix created (now 3ccd12e)

2022-03-21 Thread chamikara
This is an automated email from the ASF dual-hosted git repository.

chamikara pushed a change to branch revert-17100-cyang/rfbq-interactive-fix
in repository https://gitbox.apache.org/repos/asf/beam.git.


  at 3ccd12e  Revert "[BEAM-14112] Avoid storing a generator in 
_CustomBigQuerySource (#17100)"

This branch includes the following new commits:

 new 3ccd12e  Revert "[BEAM-14112] Avoid storing a generator in 
_CustomBigQuerySource (#17100)"

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



[beam] branch master updated: Don't print in task configuration.

2022-03-21 Thread ibzib
This is an automated email from the ASF dual-hosted git repository.

ibzib 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 a8f405b  Don't print in task configuration.
 new 83131fb  Merge pull request #17139 from ibzib/no-print
a8f405b is described below

commit a8f405bc382a2f5fece186f806a81f0108491578
Author: Kyle Weaver 
AuthorDate: Mon Mar 21 09:30:43 2022 -0700

Don't print in task configuration.

This will print every time any Gradle command is run, which is way too 
spammy.
---
 playground/frontend/build.gradle | 1 -
 1 file changed, 1 deletion(-)

diff --git a/playground/frontend/build.gradle b/playground/frontend/build.gradle
index 5a4eeef..48a8cf3 100644
--- a/playground/frontend/build.gradle
+++ b/playground/frontend/build.gradle
@@ -141,7 +141,6 @@ docker {
   project.docker_image_default_repo_root)
   files "./build/"
   tags containerImageTags()
-  println("container:" +  name)
   buildArgs(['FLUTTER_VERSION': 
project.rootProject.hasProperty(["flutter-version"]) ?
 project.rootProject["flutter-version"] :
 "2.5.2-stable" ])


[beam] branch master updated (6d0d346 -> ef09c02)

2022-03-21 Thread pabloem
This is an automated email from the ASF dual-hosted git repository.

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


from 6d0d346  [BEAM-14136] Clean up staticcheck and linter warnings in the 
Go SDK (#17137)
 add ef09c02  Merge pull request #17063 from [BEAM-12164] Fix flaky tests

No new revisions were added by this update.

Summary of changes:
 .../SpannerChangeStreamErrorTest.java  | 117 -
 1 file changed, 67 insertions(+), 50 deletions(-)


[beam] branch master updated (48a8a73 -> 6d0d346)

2022-03-21 Thread lostluck
This is an automated email from the ASF dual-hosted git repository.

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


from 48a8a73  fixes static checks and go lint issues (#17138)
 add 6d0d346  [BEAM-14136] Clean up staticcheck and linter warnings in the 
Go SDK (#17137)

No new revisions were added by this update.

Summary of changes:
 sdks/go/pkg/beam/core/runtime/exec/sideinput.go |  2 +-
 .../go/pkg/beam/core/runtime/exec/sideinput_test.go | 16 
 .../beam/core/runtime/xlangx/expansionx/download.go |  4 ++--
 sdks/go/pkg/beam/options/gcpopts/options_test.go| 21 +++--
 sdks/go/pkg/beam/provision/provision_test.go|  2 +-
 sdks/go/pkg/beam/runners/dataflow/dataflow_test.go  | 13 +++--
 sdks/go/pkg/beam/transforms/sql/sqlx/sqlx.go|  2 ++
 7 files changed, 32 insertions(+), 28 deletions(-)


[beam] branch master updated (f7de08e -> 48a8a73)

2022-03-21 Thread lostluck
This is an automated email from the ASF dual-hosted git repository.

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


from f7de08e  Merge pull request #17118: [adhoc] Move aws IT tests to 
testing package according to best practices
 add 48a8a73  fixes static checks and go lint issues (#17138)

No new revisions were added by this update.

Summary of changes:
 sdks/go/test/integration/io/xlang/debezium/debezium.go | 2 ++
 sdks/go/test/integration/io/xlang/jdbc/jdbc.go | 1 -
 sdks/go/test/integration/primitives/cogbk.go   | 1 +
 sdks/go/test/integration/primitives/window_panes.go| 2 ++
 4 files changed, 5 insertions(+), 1 deletion(-)


[beam] branch pr-bot-state updated: Updating config from bot

2022-03-21 Thread github-bot
This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a commit to branch pr-bot-state
in repository https://gitbox.apache.org/repos/asf/beam.git


The following commit(s) were added to refs/heads/pr-bot-state by this push:
 new b763cba  Updating config from bot
b763cba is described below

commit b763cbacc6502f3259006459f6e7f0238efb6b60
Author: github-actions 
AuthorDate: Mon Mar 21 16:14:12 2022 +

Updating config from bot
---
 scripts/ci/pr-bot/state/pr-state/pr-17137.json | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/scripts/ci/pr-bot/state/pr-state/pr-17137.json 
b/scripts/ci/pr-bot/state/pr-state/pr-17137.json
index 242a48d..37f7ab4 100644
--- a/scripts/ci/pr-bot/state/pr-state/pr-17137.json
+++ b/scripts/ci/pr-bot/state/pr-state/pr-17137.json
@@ -2,7 +2,7 @@
   "commentedAboutFailingChecks": true,
   "reviewersAssignedForLabels": {},
   "nextAction": "Author",
-  "stopReviewerNotifications": false,
+  "stopReviewerNotifications": true,
   "remindAfterTestsPass": [],
   "committerAssigned": false
 }
\ No newline at end of file


[beam] branch pr-bot-state updated: Updating config from bot

2022-03-21 Thread github-bot
This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a commit to branch pr-bot-state
in repository https://gitbox.apache.org/repos/asf/beam.git


The following commit(s) were added to refs/heads/pr-bot-state by this push:
 new 9c06980  Updating config from bot
9c06980 is described below

commit 9c069808c8b5fae2ac57792eceab544990ea78cd
Author: github-actions 
AuthorDate: Mon Mar 21 16:09:16 2022 +

Updating config from bot
---
 scripts/ci/pr-bot/state/pr-state/pr-17137.json | 8 
 1 file changed, 8 insertions(+)

diff --git a/scripts/ci/pr-bot/state/pr-state/pr-17137.json 
b/scripts/ci/pr-bot/state/pr-state/pr-17137.json
new file mode 100644
index 000..242a48d
--- /dev/null
+++ b/scripts/ci/pr-bot/state/pr-state/pr-17137.json
@@ -0,0 +1,8 @@
+{
+  "commentedAboutFailingChecks": true,
+  "reviewersAssignedForLabels": {},
+  "nextAction": "Author",
+  "stopReviewerNotifications": false,
+  "remindAfterTestsPass": [],
+  "committerAssigned": false
+}
\ No newline at end of file


[beam] 01/01: Merge pull request #17118: [adhoc] Move aws IT tests to testing package according to best practices

2022-03-21 Thread aromanenko
This is an automated email from the ASF dual-hosted git repository.

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

commit f7de08eb86b77794195e74f90763703ce7cb88d7
Merge: 096aeef ca2d91e
Author: Alexey Romanenko <33895511+aromanenko-...@users.noreply.github.com>
AuthorDate: Mon Mar 21 13:59:16 2022 +0100

Merge pull request #17118: [adhoc] Move aws IT tests to testing package 
according to best practices

 .../org/apache/beam/sdk/io/aws2/ITEnvironment.java |  2 +-
 .../io/aws2/dynamodb/{ => testing}/DynamoDBIOIT.java   |  5 +++--
 .../sdk/io/aws2/kinesis/{ => testing}/KinesisIOIT.java |  6 --
 .../sdk/io/aws2/s3/{ => testing}/S3FileSystemIT.java   |  4 ++--
 .../beam/sdk/io/aws2/sns/{ => testing}/SnsIOIT.java| 18 +-
 .../beam/sdk/io/aws2/sqs/{ => testing}/SqsIOIT.java| 17 -
 6 files changed, 43 insertions(+), 9 deletions(-)


[beam] branch master updated (096aeef -> f7de08e)

2022-03-21 Thread aromanenko
This is an automated email from the ASF dual-hosted git repository.

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


from 096aeef  [BEAM-14122] Upgrade pip-licenses dependency (#17132)
 add ca2d91e  [adhoc] Move aws IT tests to testing package according to 
best practices
 new f7de08e  Merge pull request #17118: [adhoc] Move aws IT tests to 
testing package according to best practices

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


Summary of changes:
 .../org/apache/beam/sdk/io/aws2/ITEnvironment.java |  2 +-
 .../io/aws2/dynamodb/{ => testing}/DynamoDBIOIT.java   |  5 +++--
 .../sdk/io/aws2/kinesis/{ => testing}/KinesisIOIT.java |  6 --
 .../sdk/io/aws2/s3/{ => testing}/S3FileSystemIT.java   |  4 ++--
 .../beam/sdk/io/aws2/sns/{ => testing}/SnsIOIT.java| 18 +-
 .../beam/sdk/io/aws2/sqs/{ => testing}/SqsIOIT.java| 17 -
 6 files changed, 43 insertions(+), 9 deletions(-)
 rename 
sdks/java/io/amazon-web-services2/src/test/java/org/apache/beam/sdk/io/aws2/dynamodb/{
 => testing}/DynamoDBIOIT.java (97%)
 rename 
sdks/java/io/amazon-web-services2/src/test/java/org/apache/beam/sdk/io/aws2/kinesis/{
 => testing}/KinesisIOIT.java (96%)
 rename 
sdks/java/io/amazon-web-services2/src/test/java/org/apache/beam/sdk/io/aws2/s3/{
 => testing}/S3FileSystemIT.java (97%)
 rename 
sdks/java/io/amazon-web-services2/src/test/java/org/apache/beam/sdk/io/aws2/sns/{
 => testing}/SnsIOIT.java (90%)
 rename 
sdks/java/io/amazon-web-services2/src/test/java/org/apache/beam/sdk/io/aws2/sqs/{
 => testing}/SqsIOIT.java (87%)