Skip to content

Commit 0a8e096

Browse files
committed
Update comments.
1 parent ea7d5a6 commit 0a8e096

File tree

2 files changed

+3
-2
lines changed

2 files changed

+3
-2
lines changed

sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/optimizer/Optimizer.scala

Lines changed: 2 additions & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -532,7 +532,8 @@ object CombineFilters extends Rule[LogicalPlan] {
532532
case Filter(Not(AtLeastNNulls(1, e1)), Filter(Not(AtLeastNNulls(1, e2)), grandChild)) =>
533533
// If we are combining two expressions Not(AtLeastNNulls(1, e1)) and
534534
// Not(AtLeastNNulls(1, e2))
535-
// (this is used to make sure there is no null in the result of e1 and e2), we can
535+
// (this is used to make sure there is no null in the result of e1 and e2 and
536+
// they are added by FilterNullsInJoinKey optimziation rule), we can
536537
// just create a Not(AtLeastNNulls(1, (e1 ++ e2).distinct)).
537538
Filter(Not(AtLeastNNulls(1, (e1 ++ e2).distinct)), grandChild)
538539
case ff @ Filter(fc, nf @ Filter(nc, grandChild)) => Filter(And(nc, fc), grandChild)

sql/core/src/test/scala/org/apache/spark/sql/optimizer/FilterNullsInJoinKeySuite.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -27,7 +27,7 @@ import org.apache.spark.sql.catalyst.plans.logical.{Filter, LocalRelation, Logic
2727
import org.apache.spark.sql.catalyst.rules.RuleExecutor
2828
import org.apache.spark.sql.test.TestSQLContext
2929

30-
/** This is the test suite for FilterNullsInJoinKey optimziation rule. */
30+
/** This is the test suite for FilterNullsInJoinKey optimization rule. */
3131
class FilterNullsInJoinKeySuite extends PlanTest {
3232

3333
// We add predicate pushdown rules at here to make sure we do not

0 commit comments

Comments
 (0)