You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@spark.apache.org by sr...@apache.org on 2020/11/27 16:26:55 UTC

[spark] branch master updated (35ded12 -> 13fd272)

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

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


    from 35ded12  [SPARK-33141][SQL] Capture SQL configs when creating permanent views
     add 13fd272  Spelling r common dev mlib external project streaming resource managers python

No new revisions were added by this update.

Summary of changes:
 R/CRAN_RELEASE.md                                  |  2 +-
 R/install-dev.bat                                  |  2 +-
 R/pkg/R/DataFrame.R                                |  6 +++---
 R/pkg/R/RDD.R                                      |  4 ++--
 R/pkg/R/SQLContext.R                               |  2 +-
 R/pkg/R/WindowSpec.R                               |  4 ++--
 R/pkg/R/column.R                                   | 16 ++++++++--------
 R/pkg/R/context.R                                  |  4 ++--
 R/pkg/R/deserialize.R                              |  2 +-
 R/pkg/R/functions.R                                |  4 ++--
 R/pkg/R/install.R                                  |  2 +-
 R/pkg/R/mllib_fpm.R                                |  2 +-
 R/pkg/R/mllib_tree.R                               |  4 ++--
 R/pkg/R/mllib_utils.R                              |  2 +-
 R/pkg/R/pairRDD.R                                  |  4 ++--
 R/pkg/R/streaming.R                                |  2 +-
 R/pkg/R/types.R                                    |  2 +-
 R/pkg/R/utils.R                                    |  2 +-
 R/pkg/inst/worker/daemon.R                         |  4 ++--
 R/pkg/inst/worker/worker.R                         |  8 ++++----
 R/pkg/tests/fulltests/test_Serde.R                 |  2 +-
 R/pkg/tests/fulltests/test_jvm_api.R               |  6 +++---
 R/pkg/tests/fulltests/test_sparkSQL.R              |  6 +++---
 R/pkg/tests/fulltests/test_utils.R                 |  2 +-
 R/pkg/vignettes/sparkr-vignettes.Rmd               |  2 +-
 .../apache/spark/util/kvstore/LevelDBTypeInfo.java |  2 +-
 .../spark/network/client/TransportClient.java      |  2 +-
 .../apache/spark/network/crypto/AuthEngine.java    |  2 +-
 .../spark/network/crypto/AuthEngineSuite.java      | 10 +++++-----
 .../network/protocol/MessageWithHeaderSuite.java   |  4 ++--
 .../apache/spark/network/sasl/SparkSaslSuite.java  | 16 ++++++++--------
 .../server/OneForOneStreamManagerSuite.java        |  2 +-
 .../network/util/TransportFrameDecoderSuite.java   |  2 +-
 .../spark/network/shuffle/SimpleDownloadFile.java  |  2 +-
 .../org/apache/spark/unsafe/types/UTF8String.java  | 10 +++++-----
 .../types/UTF8StringPropertyCheckSuite.scala       |  6 +++---
 dev/appveyor-guide.md                              | 12 ++++++------
 dev/create-release/known_translations              |  2 +-
 dev/create-release/release-build.sh                |  2 +-
 dev/create-release/releaseutils.py                 |  6 +++---
 dev/create-release/translate-contributors.py       | 22 +++++++++++-----------
 dev/github_jira_sync.py                            | 10 +++++-----
 dev/run-tests-jenkins.py                           | 18 +++++++++---------
 dev/run-tests.py                                   |  6 +++---
 dev/tests/pr_merge_ability.sh                      |  2 +-
 dev/tests/pr_public_classes.sh                     |  2 +-
 project/MimaExcludes.scala                         |  2 +-
 project/SparkBuild.scala                           |  6 +++---
 python/docs/source/_static/css/pyspark.css         |  2 +-
 .../docs/source/_templates/autosummary/class.rst   |  2 +-
 python/docs/source/development/debugging.rst       |  2 +-
 python/docs/source/development/testing.rst         |  2 +-
 python/docs/source/getting_started/install.rst     |  6 +++---
 .../docs/source/getting_started/quickstart.ipynb   |  4 ++--
 python/docs/source/index.rst                       |  2 +-
 python/pyspark/__init__.pyi                        |  2 +-
 python/pyspark/cloudpickle/cloudpickle.py          | 10 +++++-----
 python/pyspark/cloudpickle/cloudpickle_fast.py     | 10 +++++-----
 python/pyspark/context.py                          |  4 ++--
 python/pyspark/java_gateway.py                     |  2 +-
 python/pyspark/ml/feature.py                       |  2 +-
 python/pyspark/ml/regression.py                    |  2 +-
 python/pyspark/ml/regression.pyi                   |  2 +-
 python/pyspark/ml/tests/test_algorithms.py         |  2 +-
 python/pyspark/ml/tests/test_image.py              |  2 +-
 python/pyspark/mllib/clustering.py                 |  2 +-
 python/pyspark/mllib/evaluation.py                 |  4 ++--
 python/pyspark/mllib/regression.py                 |  2 +-
 python/pyspark/mllib/stat/_statistics.py           |  2 +-
 .../mllib/tests/test_streaming_algorithms.py       |  2 +-
 python/pyspark/rdd.py                              |  4 ++--
 python/pyspark/resource/requests.py                |  4 ++--
 python/pyspark/shuffle.py                          |  2 +-
 python/pyspark/sql/column.py                       |  2 +-
 python/pyspark/sql/dataframe.py                    |  2 +-
 python/pyspark/sql/functions.py                    | 14 +++++++-------
 .../pyspark/sql/pandas/_typing/protocols/frame.pyi |  2 +-
 .../sql/pandas/_typing/protocols/series.pyi        |  2 +-
 python/pyspark/sql/pandas/functions.py             |  4 ++--
 .../pyspark/sql/tests/test_pandas_grouped_map.py   |  2 +-
 python/pyspark/sql/tests/test_udf.py               |  4 ++--
 python/pyspark/sql/utils.py                        |  6 +++---
 python/pyspark/streaming/context.py                |  2 +-
 python/pyspark/tests/test_context.py               |  4 ++--
 python/pyspark/worker.py                           |  2 +-
 python/test_support/userlibrary.py                 |  2 +-
 .../scala/org/apache/spark/deploy/k8s/Config.scala |  2 +-
 .../k8s/ExecutorPodsSnapshotsStoreImpl.scala       |  4 ++--
 .../deploy/k8s/KubernetesVolumeUtilsSuite.scala    |  4 ++--
 .../features/MountVolumesFeatureStepSuite.scala    |  2 +-
 .../org/apache/spark/deploy/mesos/config.scala     |  2 +-
 .../cluster/mesos/MesosSchedulerUtils.scala        |  2 +-
 .../apache/spark/deploy/yarn/YarnAllocator.scala   |  2 +-
 .../org/apache/hadoop/net/ServerSocketUtil.java    |  2 +-
 .../network/yarn/YarnShuffleServiceSuite.scala     |  2 +-
 .../spark/streaming/api/python/PythonDStream.scala |  2 +-
 .../apache/spark/streaming/dstream/DStream.scala   |  4 ++--
 .../apache/spark/streaming/util/HdfsUtils.scala    |  2 +-
 .../org/apache/spark/streaming/JavaAPISuite.java   |  2 +-
 .../apache/spark/streaming/MapWithStateSuite.scala |  6 +++---
 .../spark/streaming/rdd/MapWithStateRDDSuite.scala |  6 +++---
 101 files changed, 208 insertions(+), 208 deletions(-)


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@spark.apache.org
For additional commands, e-mail: commits-help@spark.apache.org