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/16 03:00:41 UTC

[beam] tag nightly-master updated (88d687b -> 56d7e1b)

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 88d687b  (commit)
      to 56d7e1b  (commit)
    from 88d687b  Merge pull request #14228: [BEAM-7092] Fix artifact names for Spark separated modules + upgrade to Spark 3.1.1
     add b2ce15e  [BEAM-8221] Fix NPE while reading from non-existent Kafka topic
     add 08a9d54  Merge pull request #14217: [BEAM-8221] Fix NPE while reading from non-existent Kafka topic
     add 15ef51f  [BEAM-11963] Fix KafkaTableProviderIT (#14205)
     add 0ad65c6  [BEAM-9547] Implement count() on deferred DataFrame, Series (#14178)
     add 91c8160  [BEAM-8787] Don't recommend './gradlew check' to new contributors.
     add ee83d09  [BEAM-8787] Add instructions for cloning the Beam repo.
     add 7a72101  [BEAM-8787] cd into the newly created beam repo.
     add ad01046  Merge pull request #14225 from ibzib/BEAM-8787
     add 8aa0df4  Update partitioning ordering
     add cfa75ae  Update PartitioningSession
     add 573fa43  Explicitly define the requires/preserves semantics
     add a524931  Reverse comparison detecting when elementwise expressions need Index
     add fe198bb  Bulk update preserves=
     add f2ba501  nunique update
     add 61d7572  TODO updates
     add bdc9ade  Strong preservation assertion for PartitioningSession
     add db9355a  Update stage fusion logic
     add 3e24899  Actually run index partitioning checks
     add f0a9c73  Fix Index[i,j] subpartitioing
     add be6d5f6  Fix output_partitioning, add tests
     add a1d8b85  fix callable, add test
     add fb5be4b  Bulk rename Nothing() to Arbitrary()
     add a273061  Allow preserves=Arbitrary, bulk replace preserves=Index() with preserves=Arbitrary()
     add 1b3e231  Fix pd.concat(keys=) partitioning
     add ba61708  [BEAM-11881] Fix partitioning ordering for DataFrames (#14135)
     add b8066d5  Few small updates to the release guide
     add 5a9bb83  Merge pull request #14230: Few small updates to the release guide
     add 8d0b19f  [BEAM-11972] Close all opened channels/readers on ParquetIO
     add 916c156  Merge pull request #14229: [BEAM-11972] Close all opened channels/readers on ParquetIO
     add 23ba50b  [BEAM-10943] Add builtin functions in the Calcite planner.
     add 3a9591f  Merge pull request #14222 from ibzib/BEAM-10943-builtins
     add 7f3d8dc  add environment caching to custom container instructions
     add f600108  Merge pull request #14234 from emilymye/editflinkdocs
     add fdb0fd7  Limits Dataflow GCR container image overriding to external Apache Beam container images
     add baecb10  Merge pull request #14224: [BEAM-11613] Limits Dataflow GCR container image overriding
     add a4f0bc9  [BEAM-5628] remove vcfio.py and concerning resources (#14185)
     add f515758  Removes non-interactive from SVN commands
     add 56d7e1b  Merge pull request #14231: Removes non-interactive from SVN commands

No new revisions were added by this update.

Summary of changes:
 .../src/main/scripts/build_release_candidate.sh    |     4 +-
 .../beam/sdk/extensions/sql/SqlTransform.java      |     1 -
 .../beam/sdk/extensions/sql/impl/BeamSqlEnv.java   |    37 +-
 .../extensions/sql/impl/CalciteQueryPlanner.java   |    15 +
 .../meta/provider/kafka/KafkaTableProviderIT.java  |    27 +-
 .../beam/sdk/io/kafka/KafkaUnboundedSource.java    |     7 +-
 .../org/apache/beam/sdk/io/kafka/KafkaIOTest.java  |    26 +
 .../org/apache/beam/sdk/io/parquet/ParquetIO.java  |   199 +-
 .../src/test/resources/log4j-test.properties       |     9 +-
 sdks/python/apache_beam/dataframe/expressions.py   |   116 +-
 .../apache_beam/dataframe/expressions_test.py      |    68 +
 sdks/python/apache_beam/dataframe/frame_base.py    |    18 +-
 sdks/python/apache_beam/dataframe/frames.py        |   196 +-
 sdks/python/apache_beam/dataframe/frames_test.py   |     6 +
 .../apache_beam/dataframe/pandas_doctests_test.py  |     3 -
 .../dataframe/pandas_top_level_functions.py        |    14 +-
 sdks/python/apache_beam/dataframe/partitionings.py |    60 +-
 .../apache_beam/dataframe/partitionings_test.py    |    16 +-
 sdks/python/apache_beam/dataframe/transforms.py    |    67 +-
 sdks/python/apache_beam/io/vcfio.py                |   511 -
 sdks/python/apache_beam/io/vcfio_test.py           |   635 --
 .../runners/dataflow/internal/apiclient.py         |    23 +-
 .../runners/dataflow/internal/apiclient_test.py    |   146 +-
 .../apache_beam/testing/data/vcf/valid-4.0.vcf     |    23 -
 .../apache_beam/testing/data/vcf/valid-4.0.vcf.bz2 |   Bin 781 -> 0 bytes
 .../apache_beam/testing/data/vcf/valid-4.0.vcf.gz  |   Bin 727 -> 0 bytes
 .../testing/data/vcf/valid-4.1-large.vcf           | 10000 -------------------
 .../testing/data/vcf/valid-4.1-large.vcf.gz        |   Bin 156715 -> 0 bytes
 .../apache_beam/testing/data/vcf/valid-4.2.vcf     |    42 -
 .../apache_beam/testing/data/vcf/valid-4.2.vcf.gz  |   Bin 1240 -> 0 bytes
 sdks/python/apache_beam/transforms/environments.py |    11 +-
 sdks/python/scripts/run_pylint.sh                  |     1 -
 website/www/site/content/en/contribute/_index.md   |    13 +-
 .../site/content/en/contribute/release-guide.md    |    55 +-
 .../en/documentation/runtime/environments.md       |     4 +
 website/www/site/data/io_matrix.yaml               |     6 -
 36 files changed, 728 insertions(+), 11631 deletions(-)
 copy {runners/samza => sdks/java/io/parquet}/src/test/resources/log4j-test.properties (81%)
 delete mode 100644 sdks/python/apache_beam/io/vcfio.py
 delete mode 100644 sdks/python/apache_beam/io/vcfio_test.py
 delete mode 100644 sdks/python/apache_beam/testing/data/vcf/valid-4.0.vcf
 delete mode 100644 sdks/python/apache_beam/testing/data/vcf/valid-4.0.vcf.bz2
 delete mode 100644 sdks/python/apache_beam/testing/data/vcf/valid-4.0.vcf.gz
 delete mode 100644 sdks/python/apache_beam/testing/data/vcf/valid-4.1-large.vcf
 delete mode 100644 sdks/python/apache_beam/testing/data/vcf/valid-4.1-large.vcf.gz
 delete mode 100644 sdks/python/apache_beam/testing/data/vcf/valid-4.2.vcf
 delete mode 100644 sdks/python/apache_beam/testing/data/vcf/valid-4.2.vcf.gz