Skip to content
Closed
Changes from 1 commit
Commits
File filter

Filter by extension

Filter by extension

Conversations
Failed to load comments.
Loading
Jump to
Jump to file
Failed to load files.
Loading
Diff view
Diff view
Prev Previous commit
address comment
  • Loading branch information
mgaido91 committed May 27, 2018
commit 68e398dcc60d1cd3f4871369149f23f607789a4e
Original file line number Diff line number Diff line change
Expand Up @@ -17,8 +17,6 @@

package org.apache.spark.sql

import org.scalatest.Assertion

import org.apache.spark.api.python.PythonEvalType
import org.apache.spark.sql.catalyst.expressions.PythonUDF
import org.apache.spark.sql.catalyst.plans.logical.AnalysisBarrier
Expand All @@ -32,7 +30,7 @@ class GroupedDatasetSuite extends QueryTest with SharedSQLContext {
private val scalaUDF = udf((x: Long) => { x + 1 })
private lazy val datasetWithUDF = spark.range(1).toDF("s").select($"s", scalaUDF($"s"))

private def assertContainsAnalysisBarrier(ds: Dataset[_], atLevel: Int = 1): Assertion = {
private def assertContainsAnalysisBarrier(ds: Dataset[_], atLevel: Int = 1): Unit = {
assert(atLevel >= 0)
var children = Seq(ds.queryExecution.logical)
(1 to atLevel).foreach { _ =>
Expand Down