Trait

org.apache.spark.sql.catalyst.plans

PlanTest

Related Doc: package plans

Permalink

trait PlanTest extends SparkFunSuite with PlanTestBase

Provides helper methods for comparing plans.

Linear Supertypes
PlanTestBase, PredicateHelper, SparkFunSuite, Logging, BeforeAndAfterAll, SuiteMixin, FunSuite, FunSuiteLike, Documenting, Alerting, Notifying, Informing, TestRegistration, TestSuite, Suite, Serializable, Serializable, Assertions, TripleEquals, TripleEqualsSupport, AnyRef, Any
Known Subclasses
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. PlanTest
  2. PlanTestBase
  3. PredicateHelper
  4. SparkFunSuite
  5. Logging
  6. BeforeAndAfterAll
  7. SuiteMixin
  8. FunSuite
  9. FunSuiteLike
  10. Documenting
  11. Alerting
  12. Notifying
  13. Informing
  14. TestRegistration
  15. TestSuite
  16. Suite
  17. Serializable
  18. Serializable
  19. Assertions
  20. TripleEquals
  21. TripleEqualsSupport
  22. AnyRef
  23. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. class AssertionsHelper extends AnyRef

    Permalink
    Definition Classes
    Assertions
  2. class CheckingEqualizer[L] extends AnyRef

    Permalink
    Definition Classes
    TripleEqualsSupport
  3. class Equalizer[L] extends AnyRef

    Permalink
    Definition Classes
    TripleEqualsSupport
  4. trait NoArgTest extends () ⇒ Outcome with TestData

    Permalink
    Attributes
    protected
    Definition Classes
    TestSuite

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. def !==[T](right: Spread[T]): TripleEqualsInvocationOnSpread[T]

    Permalink
    Definition Classes
    TripleEqualsSupport
  3. def !==(right: Null): TripleEqualsInvocation[Null]

    Permalink
    Definition Classes
    TripleEqualsSupport
  4. def !==[T](right: T): TripleEqualsInvocation[T]

    Permalink
    Definition Classes
    TripleEqualsSupport
  5. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  6. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  7. def ===[T](right: Spread[T]): TripleEqualsInvocationOnSpread[T]

    Permalink
    Definition Classes
    TripleEqualsSupport
  8. def ===(right: Null): TripleEqualsInvocation[Null]

    Permalink
    Definition Classes
    TripleEqualsSupport
  9. def ===[T](right: T): TripleEqualsInvocation[T]

    Permalink
    Definition Classes
    TripleEqualsSupport
  10. def afterAll(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    SparkFunSuite → BeforeAndAfterAll
  11. def alert: Alerter

    Permalink
    Attributes
    protected
    Definition Classes
    FunSuiteLike → Alerting
  12. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  13. macro def assert(condition: Boolean, clue: Any)(implicit prettifier: Prettifier, pos: Position): Assertion

    Permalink
    Definition Classes
    Assertions
  14. macro def assert(condition: Boolean)(implicit prettifier: Prettifier, pos: Position): Assertion

    Permalink
    Definition Classes
    Assertions
  15. macro def assertCompiles(code: String)(implicit pos: Position): Assertion

    Permalink
    Definition Classes
    Assertions
  16. macro def assertDoesNotCompile(code: String)(implicit pos: Position): Assertion

    Permalink
    Definition Classes
    Assertions
  17. def assertResult(expected: Any)(actual: Any)(implicit prettifier: Prettifier, pos: Position): Assertion

    Permalink
    Definition Classes
    Assertions
  18. def assertResult(expected: Any, clue: Any)(actual: Any)(implicit prettifier: Prettifier, pos: Position): Assertion

    Permalink
    Definition Classes
    Assertions
  19. def assertThrows[T <: AnyRef](f: ⇒ Any)(implicit classTag: ClassTag[T], pos: Position): Assertion

    Permalink
    Definition Classes
    Assertions
  20. macro def assertTypeError(code: String)(implicit pos: Position): Assertion

    Permalink
    Definition Classes
    Assertions
  21. val assertionsHelper: AssertionsHelper

    Permalink
    Definition Classes
    Assertions
  22. macro def assume(condition: Boolean, clue: Any)(implicit prettifier: Prettifier, pos: Position): Assertion

    Permalink
    Definition Classes
    Assertions
  23. macro def assume(condition: Boolean)(implicit prettifier: Prettifier, pos: Position): Assertion

    Permalink
    Definition Classes
    Assertions
  24. def beforeAll(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    BeforeAndAfterAll
  25. def canEvaluate(expr: Expression, plan: LogicalPlan): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    PredicateHelper
  26. def canEvaluateWithinJoin(expr: Expression): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    PredicateHelper
  27. def cancel(cause: Throwable)(implicit pos: Position): Nothing

    Permalink
    Definition Classes
    Assertions
  28. def cancel(message: String, cause: Throwable)(implicit pos: Position): Nothing

    Permalink
    Definition Classes
    Assertions
  29. def cancel(message: String)(implicit pos: Position): Nothing

    Permalink
    Definition Classes
    Assertions
  30. def cancel()(implicit pos: Position): Nothing

    Permalink
    Definition Classes
    Assertions
  31. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  32. def compareExpressions(e1: Expression, e2: Expression): Unit

    Permalink

    Fails the test if the two expressions do not match

    Fails the test if the two expressions do not match

    Attributes
    protected
    Definition Classes
    PlanTestBase
  33. def compareJoinOrder(plan1: LogicalPlan, plan2: LogicalPlan): Unit

    Permalink

    Fails the test if the join order in the two plans do not match

    Fails the test if the join order in the two plans do not match

    Attributes
    protected
    Definition Classes
    PlanTestBase
  34. def comparePlans(plan1: LogicalPlan, plan2: LogicalPlan, checkAnalysis: Boolean = true): Unit

    Permalink

    Fails the test if the two plans do not match

    Fails the test if the two plans do not match

    Attributes
    protected
    Definition Classes
    PlanTestBase
  35. def conversionCheckedConstraint[A, B](implicit equivalenceOfA: Equivalence[A], cnv: (B) ⇒ A): CanEqual[A, B]

    Permalink
    Definition Classes
    TripleEquals → TripleEqualsSupport
  36. def convertEquivalenceToAToBConstraint[A, B](equivalenceOfB: Equivalence[B])(implicit ev: <:<[A, B]): CanEqual[A, B]

    Permalink
    Definition Classes
    TripleEquals → TripleEqualsSupport
  37. def convertEquivalenceToAToBConversionConstraint[A, B](equivalenceOfB: Equivalence[B])(implicit ev: (A) ⇒ B): CanEqual[A, B]

    Permalink
    Definition Classes
    TripleEquals → TripleEqualsSupport
  38. def convertEquivalenceToBToAConstraint[A, B](equivalenceOfA: Equivalence[A])(implicit ev: <:<[B, A]): CanEqual[A, B]

    Permalink
    Definition Classes
    TripleEquals → TripleEqualsSupport
  39. def convertEquivalenceToBToAConversionConstraint[A, B](equivalenceOfA: Equivalence[A])(implicit ev: (B) ⇒ A): CanEqual[A, B]

    Permalink
    Definition Classes
    TripleEquals → TripleEqualsSupport
  40. def convertToCheckingEqualizer[T](left: T): CheckingEqualizer[T]

    Permalink
    Definition Classes
    TripleEquals → TripleEqualsSupport
  41. implicit def convertToEqualizer[T](left: T): Equalizer[T]

    Permalink
    Definition Classes
    TripleEquals → TripleEqualsSupport
  42. def defaultEquality[A]: Equality[A]

    Permalink
    Definition Classes
    TripleEqualsSupport
  43. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  44. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  45. final def execute(testName: String, configMap: ConfigMap, color: Boolean, durations: Boolean, shortstacks: Boolean, fullstacks: Boolean, stats: Boolean): Unit

    Permalink
    Definition Classes
    Suite
  46. def expectedTestCount(filter: Filter): Int

    Permalink
    Definition Classes
    Suite
  47. def fail(cause: Throwable)(implicit pos: Position): Nothing

    Permalink
    Definition Classes
    Assertions
  48. def fail(message: String, cause: Throwable)(implicit pos: Position): Nothing

    Permalink
    Definition Classes
    Assertions
  49. def fail(message: String)(implicit pos: Position): Nothing

    Permalink
    Definition Classes
    Assertions
  50. def fail()(implicit pos: Position): Nothing

    Permalink
    Definition Classes
    Assertions
  51. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  52. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  53. final def getTestResourceFile(file: String): File

    Permalink
    Attributes
    protected
    Definition Classes
    SparkFunSuite
  54. final def getTestResourcePath(file: String): String

    Permalink
    Attributes
    protected
    Definition Classes
    SparkFunSuite
  55. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  56. def ignore(testName: String, testTags: Tag*)(testFun: ⇒ Any)(implicit pos: Position): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    FunSuiteLike
  57. def info: Informer

    Permalink
    Attributes
    protected
    Definition Classes
    FunSuiteLike → Informing
  58. def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  59. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  60. def intercept[T <: AnyRef](f: ⇒ Any)(implicit classTag: ClassTag[T], pos: Position): T

    Permalink
    Definition Classes
    Assertions
  61. val invokeBeforeAllAndAfterAllEvenIfNoTestsAreExpected: Boolean

    Permalink
    Definition Classes
    BeforeAndAfterAll
  62. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  63. def isTraceEnabled(): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  64. def log: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  65. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  66. def logDebug(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  67. def logError(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  68. def logError(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  69. def logInfo(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  70. def logInfo(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  71. def logName: String

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  72. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  73. def logTrace(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  74. def logWarning(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  75. def logWarning(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  76. def lowPriorityConversionCheckedConstraint[A, B](implicit equivalenceOfB: Equivalence[B], cnv: (A) ⇒ B): CanEqual[A, B]

    Permalink
    Definition Classes
    TripleEquals → TripleEqualsSupport
  77. def lowPriorityTypeCheckedConstraint[A, B](implicit equivalenceOfB: Equivalence[B], ev: <:<[A, B]): CanEqual[A, B]

    Permalink
    Definition Classes
    TripleEquals → TripleEqualsSupport
  78. def markup: Documenter

    Permalink
    Attributes
    protected
    Definition Classes
    FunSuiteLike → Documenting
  79. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  80. def nestedSuites: IndexedSeq[Suite]

    Permalink
    Definition Classes
    Suite
  81. def normalizeExprIds(plan: LogicalPlan): LogicalPlan

    Permalink

    Since attribute references are given globally unique ids during analysis, we must normalize them to check if two different queries are identical.

    Since attribute references are given globally unique ids during analysis, we must normalize them to check if two different queries are identical.

    Attributes
    protected
    Definition Classes
    PlanTestBase
  82. def normalizePlan(plan: LogicalPlan): LogicalPlan

    Permalink

    Normalizes plans: - Filter the filter conditions that appear in a plan.

    Normalizes plans: - Filter the filter conditions that appear in a plan. For instance, ((expr 1 && expr 2) && expr 3), (expr 1 && expr 2 && expr 3), (expr 3 && (expr 1 && expr 2) etc., will all now be equivalent. - Sample the seed will replaced by 0L. - Join conditions will be resorted by hashCode.

    Attributes
    protected
    Definition Classes
    PlanTestBase
  83. def note: Notifier

    Permalink
    Attributes
    protected
    Definition Classes
    FunSuiteLike → Notifying
  84. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  85. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  86. def pending: Assertion with PendingStatement

    Permalink
    Definition Classes
    Assertions
  87. def pendingUntilFixed(f: ⇒ Unit)(implicit pos: Position): Assertion with PendingStatement

    Permalink
    Definition Classes
    Assertions
  88. final def registerIgnoredTest(testText: String, testTags: Tag*)(testFun: ⇒ Any)(implicit pos: Position): Unit

    Permalink
    Definition Classes
    FunSuiteLike → TestRegistration
  89. final def registerTest(testText: String, testTags: Tag*)(testFun: ⇒ Any)(implicit pos: Position): Unit

    Permalink
    Definition Classes
    FunSuiteLike → TestRegistration
  90. def replaceAlias(condition: Expression, aliases: AttributeMap[Expression]): Expression

    Permalink
    Attributes
    protected
    Definition Classes
    PredicateHelper
  91. def rerunner: Option[String]

    Permalink
    Definition Classes
    Suite
  92. def run(testName: Option[String], args: Args): Status

    Permalink
    Definition Classes
    BeforeAndAfterAll → SuiteMixin
  93. def runNestedSuites(args: Args): Status

    Permalink
    Attributes
    protected
    Definition Classes
    Suite
  94. def runTest(testName: String, args: Args): Status

    Permalink
    Attributes
    protected
    Definition Classes
    FunSuiteLike → TestSuite → Suite
  95. def runTests(testName: Option[String], args: Args): Status

    Permalink
    Attributes
    protected
    Definition Classes
    FunSuiteLike → Suite
  96. lazy val spark: SparkSession

    Permalink
    Definition Classes
    SparkFunSuite
  97. def splitConjunctivePredicates(condition: Expression): Seq[Expression]

    Permalink
    Attributes
    protected
    Definition Classes
    PredicateHelper
  98. def splitDisjunctivePredicates(condition: Expression): Seq[Expression]

    Permalink
    Attributes
    protected
    Definition Classes
    PredicateHelper
  99. final val styleName: String

    Permalink
    Definition Classes
    FunSuiteLike → Suite
  100. final val succeed: Assertion

    Permalink
    Definition Classes
    Assertions
  101. def suiteId: String

    Permalink
    Definition Classes
    Suite
  102. def suiteName: String

    Permalink
    Definition Classes
    Suite
  103. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  104. def tags: Map[String, Set[String]]

    Permalink
    Definition Classes
    FunSuiteLike → Suite
  105. def test(testName: String, testTags: Tag*)(testFun: ⇒ Any)(implicit pos: Position): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    FunSuiteLike
  106. def testDataFor(testName: String, theConfigMap: ConfigMap): TestData

    Permalink
    Definition Classes
    FunSuiteLike → Suite
  107. def testNames: Set[String]

    Permalink
    Definition Classes
    FunSuiteLike → Suite
  108. def testsFor(unit: Unit): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    FunSuiteLike
  109. def toString(): String

    Permalink
    Definition Classes
    FunSuite → AnyRef → Any
  110. def typeCheckedConstraint[A, B](implicit equivalenceOfA: Equivalence[A], ev: <:<[B, A]): CanEqual[A, B]

    Permalink
    Definition Classes
    TripleEquals → TripleEqualsSupport
  111. implicit def unconstrainedEquality[A, B](implicit equalityOfA: Equality[A]): CanEqual[A, B]

    Permalink
    Definition Classes
    TripleEquals → TripleEqualsSupport
  112. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  113. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  114. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  115. def withClue[T](clue: Any)(fun: ⇒ T): T

    Permalink
    Definition Classes
    Assertions
  116. final def withFixture(test: NoArgTest): Outcome

    Permalink

    Log the suite name and the test name before and after each test.

    Log the suite name and the test name before and after each test.

    Subclasses should never override this method. If they wish to run custom code before and after each test, they should mix in the {{org.scalatest.BeforeAndAfter}} trait instead.

    Attributes
    protected
    Definition Classes
    SparkFunSuite → TestSuite
  117. def withSQLConf(pairs: (String, String)*)(f: ⇒ Unit): Unit

    Permalink

    Sets all SQL configurations specified in pairs, calls f, and then restores all SQL configurations.

    Sets all SQL configurations specified in pairs, calls f, and then restores all SQL configurations.

    Attributes
    protected
    Definition Classes
    PlanTestBase

Deprecated Value Members

  1. final def execute: Unit

    Permalink
    Definition Classes
    Suite
    Annotations
    @deprecated
    Deprecated

    The parameterless execute method has been deprecated and will be removed in a future version of ScalaTest. Please invoke execute with empty parens instead: execute().

  2. def trap[T](f: ⇒ T): Throwable

    Permalink
    Definition Classes
    Assertions
    Annotations
    @deprecated
    Deprecated

    The trap method is no longer needed for demos in the REPL, which now abreviates stack traces, and will be removed in a future version of ScalaTest

Inherited from PlanTestBase

Inherited from PredicateHelper

Inherited from SparkFunSuite

Inherited from Logging

Inherited from BeforeAndAfterAll

Inherited from SuiteMixin

Inherited from FunSuite

Inherited from FunSuiteLike

Inherited from Documenting

Inherited from Alerting

Inherited from Notifying

Inherited from Informing

Inherited from TestRegistration

Inherited from TestSuite

Inherited from Suite

Inherited from Serializable

Inherited from Serializable

Inherited from Assertions

Inherited from TripleEquals

Inherited from TripleEqualsSupport

Inherited from AnyRef

Inherited from Any

Ungrouped