Skip to content

Commit

Permalink
address comment
Browse files Browse the repository at this point in the history
  • Loading branch information
mgaido91 committed May 27, 2018
1 parent e2132c9 commit 68e398d
Showing 1 changed file with 1 addition and 3 deletions.
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

0 comments on commit 68e398d

Please sign in to comment.