You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@spark.apache.org by we...@apache.org on 2020/01/13 14:56:09 UTC

[spark] branch master updated (f77dcfc -> b389b8c)

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

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


    from f77dcfc  [SPARK-30351][ML][PYSPARK] BisectingKMeans support instance weighting
     add b389b8c  [SPARK-30188][SQL] Resolve the failed unit tests when enable AQE

No new revisions were added by this update.

Summary of changes:
 R/pkg/tests/fulltests/test_mllib_recommendation.R  |  3 +-
 .../apache/spark/ml/recommendation/ALSSuite.scala  |  7 +-
 python/pyspark/sql/column.py                       |  3 +-
 python/pyspark/sql/dataframe.py                    | 12 ++--
 .../sql/tests/test_pandas_udf_grouped_agg.py       | 26 +++----
 python/pyspark/sql/udf.py                          |  3 +-
 python/pyspark/sql/window.py                       | 16 ++---
 .../apache/spark/sql/execution/CacheManager.scala  | 21 ++++--
 .../execution/adaptive/AdaptiveSparkPlanExec.scala |  6 +-
 .../adaptive/AdaptiveSparkPlanHelper.scala         | 12 +++-
 .../adaptive/DemoteBroadcastHashJoin.scala         |  3 +-
 .../adaptive/InsertAdaptiveSparkPlan.scala         | 21 +++++-
 .../adaptive/OptimizeLocalShuffleReader.scala      |  7 +-
 .../test/resources/sql-tests/inputs/explain.sql    |  3 +
 .../org/apache/spark/sql/CachedTableSuite.scala    | 18 +++--
 .../org/apache/spark/sql/ConfigBehaviorSuite.scala |  6 +-
 .../apache/spark/sql/DataFrameAggregateSuite.scala | 19 +++--
 .../org/apache/spark/sql/DataFrameJoinSuite.scala  |  7 +-
 .../org/apache/spark/sql/DataFrameSuite.scala      | 27 ++++---
 .../spark/sql/DataFrameWindowFunctionsSuite.scala  |  7 +-
 .../org/apache/spark/sql/DatasetCacheSuite.scala   |  9 ++-
 .../scala/org/apache/spark/sql/DatasetSuite.scala  |  7 +-
 .../spark/sql/DynamicPartitionPruningSuite.scala   | 10 ++-
 .../scala/org/apache/spark/sql/ExplainSuite.scala  | 12 ++++
 .../spark/sql/FileBasedDataSourceSuite.scala       | 13 ++--
 .../scala/org/apache/spark/sql/JoinHintSuite.scala | 13 ++--
 .../scala/org/apache/spark/sql/JoinSuite.scala     | 11 +--
 .../scala/org/apache/spark/sql/SQLQuerySuite.scala |  7 +-
 .../org/apache/spark/sql/SQLQueryTestSuite.scala   |  5 +-
 .../spark/sql/SparkSessionExtensionSuite.scala     |  3 +
 .../scala/org/apache/spark/sql/SubquerySuite.scala | 11 +--
 .../spark/sql/connector/DataSourceV2Suite.scala    | 13 ++--
 .../sql/execution/BroadcastExchangeSuite.scala     | 13 ++--
 .../DeprecatedWholeStageCodegenSuite.scala         | 25 ++++---
 .../execution/LogicalPlanTagInSparkPlanSuite.scala | 14 ++++
 .../apache/spark/sql/execution/PlannerSuite.scala  | 82 ++++++++++++----------
 .../WholeStageCodegenSparkSubmitSuite.scala        |  1 +
 .../sql/execution/WholeStageCodegenSuite.scala     | 13 ++++
 .../execution/datasources/SchemaPruningSuite.scala |  6 +-
 .../datasources/orc/OrcV2SchemaPruningSuite.scala  |  5 +-
 .../parquet/ParquetSchemaPruningSuite.scala        |  5 +-
 .../spark/sql/execution/debug/DebuggingSuite.scala | 15 ++++
 .../sql/execution/joins/BroadcastJoinSuite.scala   | 12 ++--
 .../sql/execution/metric/SQLMetricsSuite.scala     | 13 ++++
 .../python/BatchEvalPythonExecSuite.scala          |  7 +-
 .../execution/ui/SQLAppStatusListenerSuite.scala   | 10 ++-
 .../sql/internal/ExecutorSideSQLConfSuite.scala    |  4 +-
 .../spark/sql/util/DataFrameCallbackSuite.scala    |  8 ++-
 .../sql/hive/execution/HiveExplainSuite.scala      | 28 ++++----
 .../spark/sql/hive/execution/HiveUDAFSuite.scala   | 10 +--
 .../hive/execution/ObjectHashAggregateSuite.scala  | 10 +--
 .../spark/sql/hive/execution/SQLMetricsSuite.scala | 14 ++++
 52 files changed, 430 insertions(+), 206 deletions(-)


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