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/03/12 04:37:38 UTC

[beam] tag nightly-master updated (48f9f66 -> 2da7448)

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 48f9f66  (commit)
      to 2da7448  (commit)
    from 48f9f66  Merge pull request #14141 from [BEAM-10861] Add RunnerImplementedSource  and RunnerImplementedSink to Pubsub
     add 51bb63f  [BEAM-11952] Clean up merged window result in MergingViaWindowFnRunner to avoid accumulating unnecessary state
     add 06ce34e  Merge pull request #14182 from [BEAM-11952] Clean up merged window result in MergingViaWindowFnRunner to avoid accumulating unnecessary state
     add 45d9a85  Allow submitting dataflow jobs with merging window fn in python sdk
     add 6ae62a8  Address comment
     add e3367a1  Remove CustomWindowTypeWindowFn from dataflow_runner_test as well
     add f801170  Merge pull request #14179 from y1chi/allow_merge_window_fn
     add fe8ddfc  [BEAM-7372] remove usage of future package from coders and dataframe (#14163)
     add 2591d51  Parallelize python validate container tests in beam_PostCommit_Py_Val… (#14145)
     add 7af083a  Update Java beam-master container image tag (#14191)
     add 3006e90  [BEAM-8288] remove py2 codepath from interactive Beam (#14172)
     add 8714557  [BEAM-11958] Don't use new Jackson APIs to avoid classpath issues when parsing AWS configuration
     add 10f5cbc  Merge pull request #14199: [BEAM-11958] Don't use new Jackson APIs to avoid classpath issues when parsing AWS configuration
     add 0316e1c  [BEAM-10961] enable strict dependency checking for sdks/java/io/debezium
     add 0ab3036  Merge pull request #14194 from sonam-vend/sdks-io-debezium
     add 13b38e1  [BEAM-10961] Enable strict dependency checking on Google Cloud Dataflow runner
     add b675eb5  Merge pull request #13660 from sonam-vend/runner-google-cloud-dataflow
     add f0d1aef  [BEAM-11962] Disable failing test (#14202)
     add 9be70c9  [BEAM-11719] Allow encoding protos and dataclasses as deterministically.
     add 5659a52  Better type inference for GroupBy.
     add 5cb7674  Add support for named tuples.
     add 5595ec6  Named tuple pickling fix for Python 3.6.
     add 0de5f01  Merge pull request #14180 [BEAM-11719] Allow encoding protos and dataclasses as deterministically.
     add e3f20b9  Include Cron run in postcommit health dashboard
     add b56c3e2  Merge pull request #14201: Include Cron run in postcommit health dashboard
     add 18ad33a  [BEAM-9372] remove python version check whether python 3.6 above or not
     add 08bd566  Merge pull request #14184 from [BEAM-9372] remove python version check whether python 3.6 above or not
     add a6b3820  GroupIntoBatches test uses stateful ParDo
     add 59906f6  Always use portable job submission for Dataflow runner v2
     add 8ccfa53  Merge pull request #14074: Always use portable job submission for Dataflow V2
     add 6290aee  [BEAM-11715] [BEAM-11694] Re-enable (conditional) combiner packing. (#14193)
     add b8b5b58  Moving to 2.30.0-SNAPSHOT on master branch.
     add 2da7448  [BEAM-11887] Change SortingFlinkCombineRunner usage to only for Sessions (#14120)

No new revisions were added by this update.

Summary of changes:
 ...ommit_Python_ValidatesContainer_Dataflow.groovy |   8 +-
 .../grafana/dashboards/post-commit_tests.json      |   2 +-
 .../org/apache/beam/gradle/BeamModulePlugin.groovy |   2 +-
 .../apache/beam/gradle/GrpcVendoring_1_26_0.groovy |   1 +
 .../examples/cookbook/MapClassIntegrationIT.java   |   2 +
 gradle.properties                                  |   4 +-
 .../FlinkMergingNonShuffleReduceFunction.java      |   4 +-
 .../functions/FlinkPartialReduceFunction.java      |   9 +-
 .../translation/functions/FlinkReduceFunction.java |   9 +-
 runners/google-cloud-dataflow-java/build.gradle    |  49 +++----
 .../examples-streaming/build.gradle                |   2 +-
 .../examples/build.gradle                          |   2 +-
 .../beam/runners/dataflow/DataflowRunner.java      |  95 ++++++++----
 .../beam/runners/dataflow/DataflowRunnerTest.java  |   3 +-
 .../google-cloud-dataflow-java/worker/build.gradle |  14 +-
 .../worker/legacy-worker/build.gradle              |  17 ++-
 sdks/go/pkg/beam/core/core.go                      |   2 +-
 .../beam/fn/harness/WindowMergingFnRunner.java     |   9 +-
 .../beam/fn/harness/WindowMergingFnRunnerTest.java |  22 +++
 .../apache/beam/sdk/io/aws/options/AwsModule.java  |  11 +-
 .../apache/beam/sdk/io/aws2/options/AwsModule.java |  10 +-
 sdks/java/io/debezium/build.gradle                 |   3 +-
 sdks/python/apache_beam/coders/__init__.py         |   2 -
 sdks/python/apache_beam/coders/avro_record.py      |   2 -
 sdks/python/apache_beam/coders/coder_impl.pxd      |  14 +-
 sdks/python/apache_beam/coders/coder_impl.py       | 160 +++++++++++++--------
 sdks/python/apache_beam/coders/coders.py           |   9 +-
 sdks/python/apache_beam/coders/coders_test.py      |   2 -
 .../apache_beam/coders/coders_test_common.py       |  36 +++++
 sdks/python/apache_beam/coders/fast_coders_test.py |   2 -
 sdks/python/apache_beam/coders/observable.py       |   2 -
 sdks/python/apache_beam/coders/observable_test.py  |   2 -
 sdks/python/apache_beam/coders/row_coder.py        |   2 -
 sdks/python/apache_beam/coders/row_coder_test.py   |   2 -
 sdks/python/apache_beam/coders/slow_coders_test.py |   2 -
 sdks/python/apache_beam/coders/slow_stream.py      |   2 -
 .../apache_beam/coders/standard_coders_test.py     |   3 -
 sdks/python/apache_beam/coders/stream_test.py      |   3 -
 sdks/python/apache_beam/coders/typecoders.py       |   2 -
 sdks/python/apache_beam/coders/typecoders_test.py  |   2 -
 sdks/python/apache_beam/dataframe/__init__.py      |   2 -
 sdks/python/apache_beam/dataframe/convert.py       |   2 -
 sdks/python/apache_beam/dataframe/convert_test.py  |   2 -
 sdks/python/apache_beam/dataframe/doctests.py      |   4 -
 sdks/python/apache_beam/dataframe/doctests_test.py |   2 -
 sdks/python/apache_beam/dataframe/expressions.py   |   2 -
 .../apache_beam/dataframe/expressions_test.py      |   2 -
 sdks/python/apache_beam/dataframe/frame_base.py    |   2 -
 .../apache_beam/dataframe/frame_base_test.py       |   2 -
 sdks/python/apache_beam/dataframe/frames.py        |   2 -
 sdks/python/apache_beam/dataframe/frames_test.py   |   2 -
 sdks/python/apache_beam/dataframe/io.py            |   2 -
 sdks/python/apache_beam/dataframe/io_test.py       |   3 -
 .../apache_beam/dataframe/pandas_docs_test.py      |   3 -
 .../apache_beam/dataframe/pandas_doctests_test.py  |   2 -
 sdks/python/apache_beam/dataframe/partitionings.py |   2 -
 .../apache_beam/dataframe/partitionings_test.py    |   2 -
 sdks/python/apache_beam/dataframe/schemas.py       |   2 -
 sdks/python/apache_beam/dataframe/schemas_test.py  |   3 -
 sdks/python/apache_beam/dataframe/transforms.py    |   2 -
 .../apache_beam/dataframe/transforms_test.py       |   3 -
 .../runners/dataflow/dataflow_runner.py            |  29 +---
 .../runners/dataflow/dataflow_runner_test.py       |  37 -----
 .../interactive/background_caching_job_test.py     |   8 +-
 .../display/pcoll_visualization_test.py            |  10 +-
 .../interactive/display/pipeline_graph_test.py     |   8 +-
 .../runners/interactive/interactive_beam.py        |  25 +---
 .../runners/interactive/interactive_beam_test.py   |   8 +-
 .../runners/interactive/interactive_environment.py |   6 -
 .../interactive/interactive_environment_test.py    |   8 +-
 .../runners/interactive/interactive_runner_test.py |   8 +-
 .../interactive_environment_inspector_test.py      |   8 +-
 .../interactive/options/capture_control_test.py    |   8 +-
 .../runners/interactive/pipeline_fragment_test.py  |   8 +-
 .../runners/interactive/pipeline_instrument.py     |   4 +-
 .../runners/interactive/recording_manager_test.py  |   8 +-
 .../interactive/testing/integration/screen_diff.py |  11 +-
 .../apache_beam/runners/interactive/utils_test.py  |   8 +-
 .../runners/portability/fn_api_runner/fn_runner.py |   1 +
 .../runners/portability/portable_runner.py         |   6 +-
 .../testing/test_stream_service_test.py            |   8 +-
 sdks/python/apache_beam/transforms/core.py         |  18 ++-
 .../apache_beam/utils/interactive_utils_test.py    |   8 +-
 sdks/python/apache_beam/version.py                 |   2 +-
 sdks/python/container/run_validatescontainer.sh    |  56 ++++----
 sdks/python/test-suites/dataflow/build.gradle      |   6 +
 sdks/python/test-suites/dataflow/common.gradle     |  16 +++
 sdks/python/test-suites/gradle.properties          |   1 +
 88 files changed, 423 insertions(+), 478 deletions(-)