You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@beam.apache.org by gi...@apache.org on 2021/04/30 02:47:31 UTC

[beam] tag nightly-master updated (2f02771 -> 0302dcd)

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

github-bot pushed a change to tag nightly-master
in repository https://gitbox.apache.org/repos/asf/beam.git.


*** WARNING: tag nightly-master was modified! ***

    from 2f02771  (commit)
      to 0302dcd  (commit)
    from 2f02771  Merge pull request #14491 from ihji/BEAM-12140
     add 7b51b51  [BEAM-7372] cleanup following codes from apache_beam/runners/dataflow and apache_beam/runners/interactive * usage of future package * usage of past package * unnecessary builtins import
     add 35881d7  [BEAM-7372] cleanup py2 codepath from runners/dataflow and runners/interactive #14564
     add 50fcf55  Merge pull request #14639: [BEAM-10277][BEAM-12198] Populate encoding positions to all matching schemas
     add 1a5f90e  Revert "[BEAM-3713] Moving integration tests from nose to pytest (#14481)"
     add 87e1164  Merge pull request #14676: Revert "[BEAM-3713] Moving integration tests from nose to pytest (#14481)"
     add b87f1f0  [BEAM-12247] Reduce memory/string creations in InMemoryTimerInternals
     add be906f3  [BEAM-12248] Reduce ArrayList allocation in Row/RowUtils
     add 7418c84  Merge pull request #14672: [BEAM-12248][BEAM-12247] Reduce String and ArrayList object creations
     add e9df62b  Moving to 2.31.0-SNAPSHOT on master branch.
     add cdef5bb  [BEAM-12238] Make StateBackedIterable Serializable. (#14660)
     add e284374  [BEAM-9615] Use UUIDs in Go SDK Schemas (#14665)
     add 3eb3dc9  [BEAM-12174] Propertly close ExecutableStageContext in DoFnOp#close (#14659)
     add 400b1d7  [BEAM-12118] Fix race introduced in QueeuingBeamFnDataClient triggering failed precondition. (#14668)
     add 8867610  [BEAM-9547] WontImplement a few more DeferredGroupBy operations (#14675)
     add a60546e  [BEAM-12227] Update ExternalWorkerServiceTest
     add f5cf55d  Merge pull request #14677 from [BEAM-12227] Update ExternalWorkerServiceTest
     add f3fab5c  [BEAM-8706] Bump antlr4 to 4.9.2
     add 0ec9084  Merge pull request #14669 from [BEAM-8706] Bump antlr4 to 4.9.2
     add 9c5f08f  Fix kenn at apache email address in blog author list
     add 21fca9c  Add Beam 2.29.0 release blog post
     add 99cb746  Merge pull request #14562: Add Beam 2.29.0 release blog post
     add bb3a769  Update website for 2.29.0 release
     add fd33f16  Merge pull request #14556: Update website for 2.29.0 release
     add b6ee454  [BEAM-12222] Update Dataflow container for side input changes
     add ce4c192  Merge pull request #14687: [BEAM-12222] Update Dataflow container for side input changes
     add 637cf50  Increase timeout of Dataflow V1 streaming ValidatesRunner
     add f716b2f  Merge pull request #14688: [BEAM-12250] Increase timeout of Dataflow V1 streaming ValidatesRunner
     add 22e3ce3  [BEAM-12158] Regen go protos & rename internal proto package (#14612)
     add 17fef39  bugfix for cut_release_branch.sh
     add a2849e0  Merge pull request #14682 from ihji/bugfix_cut_release_branch_script
     add 5ecbe17  Update golock instructions (#14678)
     add a5296ff  adding 2.31.0 section to CHANGES.md
     add 0302dcd  Merge pull request #14681 from ihji/changes_2_31_0

No new revisions were added by this update.

Summary of changes:
 ...Java_ValidatesRunner_Dataflow_Streaming.groovy} |    2 +-
 .test-infra/jenkins/job_PostCommit_Python.groovy   |    2 +-
 ...ommit_Python_ValidatesContainer_Dataflow.groovy |    2 +-
 ...stCommit_Python_ValidatesRunner_Dataflow.groovy |    2 +-
 ...ommit_Python_ValidatesRunner_Dataflow_V2.groovy |    2 +-
 ..._PostCommit_Python_ValidatesRunner_Flink.groovy |    4 -
 CHANGES.md                                         |   31 +
 .../org/apache/beam/gradle/BeamModulePlugin.groovy |    7 +-
 gradle.properties                                  |    4 +-
 model/pipeline/src/main/proto/schema.proto         |    4 +
 release/src/main/scripts/cut_release_branch.sh     |    5 +-
 .../beam/runners/core/InMemoryTimerInternals.java  |   46 +-
 runners/google-cloud-dataflow-java/build.gradle    |    2 +-
 .../util/RowCoderCloudObjectTranslator.java        |    6 +
 .../util/SchemaCoderCloudObjectTranslator.java     |    6 +
 .../portability/ExternalWorkerServiceTest.java     |    4 +-
 .../apache/beam/runners/samza/runtime/DoFnOp.java  |    7 +-
 sdks/go/README.md                                  |    3 +-
 sdks/go/gogradle.lock                              |    7 +
 sdks/go/pkg/beam/core/core.go                      |    2 +-
 .../pkg/beam/core/runtime/graphx/schema/schema.go  |   20 +-
 sdks/go/pkg/beam/core/runtime/graphx/v1/gen.go     |    2 +-
 sdks/go/pkg/beam/core/runtime/graphx/v1/v1.pb.go   | 1954 ++++++++---
 sdks/go/pkg/beam/core/runtime/graphx/v1/v1.proto   |    4 +-
 .../model/fnexecution_v1/beam_provision_api.pb.go  |    4 +-
 .../beam/model/pipeline_v1/beam_runner_api.pb.go   | 3595 +++++++++++---------
 sdks/go/pkg/beam/model/pipeline_v1/metrics.pb.go   |  855 ++---
 sdks/go/pkg/beam/model/pipeline_v1/schema.pb.go    |  401 +--
 .../java/org/apache/beam/sdk/coders/RowCoder.java  |    7 +
 .../apache/beam/sdk/coders/RowCoderGenerator.java  |    9 +-
 .../java/org/apache/beam/sdk/schemas/Schema.java   |    8 +
 .../org/apache/beam/sdk/schemas/SchemaCoder.java   |    6 +
 .../apache/beam/sdk/schemas/SchemaTranslation.java |    2 +-
 .../main/java/org/apache/beam/sdk/values/Row.java  |   84 +-
 .../java/org/apache/beam/sdk/values/RowUtils.java  |   13 +
 .../impl/transform/BeamSqlOutputToConsoleFn.java   |    2 +-
 .../apache/beam/sdk/extensions/sql/TestUtils.java  |    6 +-
 .../fn/harness/data/QueueingBeamFnDataClient.java  |   14 +-
 .../beam/fn/harness/state/StateBackedIterable.java |   11 +-
 .../fn/harness/state/StateBackedIterableTest.java  |   34 +
 sdks/python/apache_beam/dataframe/frames.py        |   10 +-
 .../examples/complete/autocomplete_test.py         |    4 +-
 .../examples/complete/game/game_stats_it_test.py   |    6 +-
 .../complete/game/hourly_team_score_it_test.py     |    6 +-
 .../examples/complete/game/leader_board_it_test.py |    6 +-
 .../examples/complete/game/user_score_it_test.py   |    6 +-
 .../complete/juliaset/juliaset/juliaset_test_it.py |    4 +-
 .../cookbook/bigquery_tornadoes_it_test.py         |    4 +-
 .../cookbook/datastore_wordcount_it_test.py        |    4 +-
 .../apache_beam/examples/fastavro_it_test.py       |    8 +-
 .../streaming_wordcount_debugging_it_test.py       |    4 +-
 .../examples/streaming_wordcount_it_test.py        |    4 +-
 .../apache_beam/examples/wordcount_it_test.py      |   11 +-
 sdks/python/apache_beam/io/fileio_test.py          |    4 +-
 .../io/gcp/big_query_query_to_table_it_test.py     |   14 +-
 .../apache_beam/io/gcp/bigquery_file_loads_test.py |    8 +-
 .../apache_beam/io/gcp/bigquery_io_read_it_test.py |    6 +-
 .../apache_beam/io/gcp/bigquery_read_it_test.py    |   12 +-
 sdks/python/apache_beam/io/gcp/bigquery_test.py    |   12 +-
 .../apache_beam/io/gcp/bigquery_write_it_test.py   |   12 +-
 .../gcp/datastore/v1new/datastore_write_it_test.py |    4 +-
 .../apache_beam/io/gcp/dicomio_integration_test.py |    6 +-
 .../io/gcp/experimental/spannerio_read_it_test.py  |    6 +-
 .../io/gcp/experimental/spannerio_write_it_test.py |    8 +-
 .../apache_beam/io/gcp/gcsio_integration_test.py   |   14 +-
 .../apache_beam/io/gcp/pubsub_integration_test.py  |    6 +-
 sdks/python/apache_beam/io/parquetio_it_test.py    |    4 +-
 sdks/python/apache_beam/metrics/metric_test.py     |    4 +-
 .../python/apache_beam/ml/gcp/cloud_dlp_it_test.py |    6 +-
 .../ml/gcp/naturallanguageml_test_it.py            |    4 +-
 .../ml/gcp/videointelligenceml_test_it.py          |    4 +-
 sdks/python/apache_beam/ml/gcp/visionml_test_it.py |    4 +-
 sdks/python/apache_beam/pipeline_test.py           |    9 +-
 .../apache_beam/runners/dataflow/__init__.py       |    2 -
 .../dataflow/dataflow_exercise_metrics_pipeline.py |    2 -
 .../dataflow_exercise_metrics_pipeline_test.py     |    9 +-
 ...dataflow_exercise_streaming_metrics_pipeline.py |    2 -
 ...low_exercise_streaming_metrics_pipeline_test.py |    8 +-
 .../runners/dataflow/dataflow_metrics.py           |    6 +-
 .../runners/dataflow/dataflow_metrics_test.py      |    3 -
 .../runners/dataflow/dataflow_runner.py            |   10 +-
 .../runners/dataflow/dataflow_runner_test.py       |    4 -
 .../runners/dataflow/internal/__init__.py          |    1 -
 .../runners/dataflow/internal/apiclient.py         |    7 +-
 .../runners/dataflow/internal/apiclient_test.py    |    2 -
 .../runners/dataflow/internal/clients/__init__.py  |    1 -
 .../internal/clients/cloudbuild/__init__.py        |    2 -
 .../dataflow/internal/clients/dataflow/__init__.py |    2 -
 .../clients/dataflow/dataflow_v1b3_client.py       |    2 -
 .../clients/dataflow/dataflow_v1b3_messages.py     |    2 -
 .../internal/clients/dataflow/message_matchers.py  |    5 +-
 .../clients/dataflow/message_matchers_test.py      |    2 -
 .../apache_beam/runners/dataflow/internal/names.py |    5 -
 .../runners/dataflow/native_io/__init__.py         |    1 -
 .../runners/dataflow/native_io/iobase.py           |    3 -
 .../runners/dataflow/native_io/iobase_test.py      |    2 -
 .../runners/dataflow/ptransform_overrides.py       |    2 -
 .../runners/dataflow/template_runner_test.py       |    2 -
 .../runners/dataflow/test_dataflow_runner.py       |    3 -
 .../runners/interactive/augmented_pipeline.py      |    2 -
 .../runners/interactive/augmented_pipeline_test.py |    2 -
 .../runners/interactive/background_caching_job.py  |    2 -
 .../interactive/background_caching_job_test.py     |    2 -
 .../runners/interactive/cache_manager.py           |    4 -
 .../runners/interactive/cache_manager_test.py      |    4 -
 .../runners/interactive/caching/__init__.py        |    2 -
 .../runners/interactive/caching/cacheable.py       |    2 -
 .../runners/interactive/caching/read_cache.py      |    2 -
 .../runners/interactive/caching/read_cache_test.py |    2 -
 .../runners/interactive/caching/streaming_cache.py |    2 -
 .../interactive/caching/streaming_cache_test.py    |    2 -
 .../runners/interactive/caching/write_cache.py     |    2 -
 .../interactive/caching/write_cache_test.py        |    2 -
 .../runners/interactive/display/display_manager.py |    4 -
 .../display/interactive_pipeline_graph.py          |    4 -
 .../interactive/display/pcoll_visualization.py     |    3 -
 .../display/pcoll_visualization_test.py            |    2 -
 .../runners/interactive/display/pipeline_graph.py  |    4 -
 .../interactive/display/pipeline_graph_renderer.py |    8 +-
 .../interactive/display/pipeline_graph_test.py     |    2 -
 .../runners/interactive/interactive_beam.py        |    2 -
 .../runners/interactive/interactive_beam_test.py   |    2 -
 .../runners/interactive/interactive_environment.py |    2 -
 .../interactive/interactive_environment_test.py    |    2 -
 .../runners/interactive/interactive_runner.py      |    4 -
 .../runners/interactive/interactive_runner_test.py |    4 -
 .../messaging/interactive_environment_inspector.py |    2 -
 .../interactive_environment_inspector_test.py      |    2 -
 .../runners/interactive/options/capture_control.py |    2 -
 .../interactive/options/capture_control_test.py    |    2 -
 .../interactive/options/capture_limiters.py        |    2 -
 .../interactive/options/capture_limiters_test.py   |    2 -
 .../interactive/options/interactive_options.py     |    2 -
 .../runners/interactive/pipeline_fragment.py       |    2 -
 .../runners/interactive/pipeline_fragment_test.py  |    2 -
 .../runners/interactive/pipeline_instrument.py     |    2 -
 .../interactive/pipeline_instrument_test.py        |    2 -
 .../runners/interactive/recording_manager.py       |    2 -
 .../runners/interactive/recording_manager_test.py  |    2 -
 .../testing/integration/notebook_executor.py       |    2 -
 .../interactive/testing/integration/screen_diff.py |    2 -
 .../integration/tests/init_square_cube_test.py     |    2 -
 .../interactive/testing/test_cache_manager.py      |    2 -
 .../interactive/user_pipeline_tracker_test.py      |    2 -
 .../apache_beam/runners/interactive/utils.py       |    2 -
 .../apache_beam/runners/interactive/utils_test.py  |    2 -
 .../portability/fn_api_runner/fn_runner_test.py    |    4 +-
 .../portability/fn_api_runner/translations_test.py |    6 +-
 sdks/python/apache_beam/testing/test_pipeline.py   |   13 +-
 .../apache_beam/testing/test_stream_it_test.py     |    8 +-
 .../transforms/combinefn_lifecycle_test.py         |    4 +-
 .../apache_beam/transforms/dofn_lifecycle_test.py  |    4 +-
 .../apache_beam/transforms/external_it_test.py     |    4 +-
 .../apache_beam/transforms/ptransform_test.py      |   26 +-
 .../apache_beam/transforms/sideinputs_test.py      |   29 +-
 sdks/python/apache_beam/transforms/util_test.py    |    4 +-
 sdks/python/apache_beam/version.py                 |    2 +-
 sdks/python/conftest.py                            |    7 -
 sdks/python/container/run_validatescontainer.sh    |   17 +-
 sdks/python/pytest.ini                             |    5 -
 sdks/python/scripts/run_integration_test.sh        |   39 +-
 sdks/python/test-suites/dataflow/common.gradle     |   52 +-
 sdks/python/test-suites/direct/common.gradle       |   76 +-
 sdks/python/test-suites/portable/common.gradle     |   19 +-
 website/www/site/config.toml                       |    2 +-
 website/www/site/content/en/blog/beam-2.29.0.md    |   84 +
 .../www/site/content/en/get-started/downloads.md   |    8 +
 website/www/site/data/authors.yml                  |    2 +-
 website/www/site/static/.htaccess                  |    2 +-
 169 files changed, 4776 insertions(+), 3249 deletions(-)
 rename .test-infra/jenkins/{job_PostCommit_Java_ValidatesRunner_Dataflow_streaming.groovy => job_PostCommit_Java_ValidatesRunner_Dataflow_Streaming.groovy} (99%)
 create mode 100644 website/www/site/content/en/blog/beam-2.29.0.md