Packages

  • package root
    Definition Classes
    root
  • package org
    Definition Classes
    root
  • package apache
    Definition Classes
    org
  • package spark

    Core Spark functionality.

    Core Spark functionality. org.apache.spark.SparkContext serves as the main entry point to Spark, while org.apache.spark.rdd.RDD is the data type representing a distributed collection, and provides most parallel operations.

    In addition, org.apache.spark.rdd.PairRDDFunctions contains operations available only on RDDs of key-value pairs, such as groupByKey and join; org.apache.spark.rdd.DoubleRDDFunctions contains operations available only on RDDs of Doubles; and org.apache.spark.rdd.SequenceFileRDDFunctions contains operations available on RDDs that can be saved as SequenceFiles. These operations are automatically available on any RDD of the right type (e.g. RDD[(Int, Int)] through implicit conversions.

    Java programmers should reference the org.apache.spark.api.java package for Spark programming APIs in Java.

    Classes and methods marked with Experimental are user-facing features which have not been officially adopted by the Spark project. These are subject to change or removal in minor releases.

    Classes and methods marked with Developer API are intended for advanced users want to extend Spark through lower level interfaces. These are subject to changes or removal in minor releases.

    Definition Classes
    apache
  • package sql

    Allows the execution of relational queries, including those expressed in SQL using Spark.

    Allows the execution of relational queries, including those expressed in SQL using Spark.

    Definition Classes
    spark
  • package errors
    Definition Classes
    sql
  • QueryCompilationErrors
  • QueryExecutionErrors
  • QueryParsingErrors
o

org.apache.spark.sql.errors

QueryParsingErrors

object QueryParsingErrors

Object for grouping all error messages of the query parsing. Currently it includes all ParseException.

Source
QueryParsingErrors.scala
Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. QueryParsingErrors
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. def addCatalogInCacheTableAsSelectNotAllowedError(quoted: String, ctx: CacheTableContext): Throwable
  5. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  6. def cannotCleanReservedNamespacePropertyError(property: String, ctx: ParserRuleContext, msg: String): Throwable
  7. def cannotCleanReservedTablePropertyError(property: String, ctx: ParserRuleContext, msg: String): Throwable
  8. def cannotParseIntervalValueError(value: String, ctx: TypeConstructorContext): Throwable
  9. def cannotParseValueTypeError(valueType: String, value: String, ctx: TypeConstructorContext): Throwable
  10. def cannotResolveWindowReferenceError(name: String, ctx: WindowClauseContext): Throwable
  11. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()
  12. def columnAliasInOperationNotAllowedError(op: String, ctx: TableAliasContext): Throwable
  13. def combinationQueryResultClausesUnsupportedError(ctx: QueryOrganizationContext): Throwable
  14. def computeStatisticsNotExpectedError(ctx: IdentifierContext): Throwable
  15. def createTempTableNotSpecifyProviderError(ctx: CreateTableContext): Throwable
  16. def dataTypeUnsupportedError(dataType: String, ctx: PrimitiveDataTypeContext): Throwable
  17. def descColumnForPartitionUnsupportedError(ctx: DescribeRelationContext): Throwable
  18. def directoryPathAndOptionsPathBothSpecifiedError(ctx: InsertOverwriteDirContext): Throwable
  19. def distributeByUnsupportedError(ctx: QueryOrganizationContext): Throwable
  20. def duplicateClausesError(clauseName: String, ctx: ParserRuleContext): Throwable
  21. def duplicateCteDefinitionNamesError(duplicateNames: String, ctx: CtesContext): Throwable
  22. def duplicateKeysError(key: String, ctx: ParserRuleContext): Throwable
  23. def duplicatedTablePathsFoundError(pathOne: String, pathTwo: String, ctx: ParserRuleContext): Throwable
  24. def emptyInputForTableSampleError(ctx: ParserRuleContext): Throwable
  25. def emptyPartitionKeyError(key: String, ctx: PartitionSpecContext): Throwable
  26. def emptySourceForMergeError(ctx: MergeIntoTableContext): Throwable
  27. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  28. def equals(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  29. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  30. def fromOrInNotAllowedInShowDatabasesError(ctx: ShowNamespacesContext): Throwable
  31. def fromToIntervalUnsupportedError(from: String, to: String, ctx: ParserRuleContext): Throwable
  32. def functionNameUnsupportedError(functionName: String, ctx: ParserRuleContext): Throwable
  33. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  34. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  35. def incompletePartitionSpecificationError(key: String, ctx: DescribeRelationContext): Throwable
  36. def insertOverwriteDirectoryUnsupportedError(ctx: InsertIntoContext): Throwable
  37. def insertedValueNumberNotMatchFieldNumberError(ctx: NotMatchedClauseContext): Throwable
  38. def intervalValueOutOfRangeError(ctx: IntervalContext): Throwable
  39. def invalidBucketsNumberError(describe: String, ctx: ApplyTransformContext): Throwable
  40. def invalidByteLengthLiteralError(bytesStr: String, ctx: SampleByBytesContext): Throwable
  41. def invalidEscapeStringError(ctx: PredicateContext): Throwable
  42. def invalidFromToUnitValueError(ctx: IntervalValueContext): Throwable
  43. def invalidGroupingSetError(element: String, ctx: GroupingAnalyticsContext): Throwable
  44. def invalidInsertIntoError(ctx: InsertIntoContext): Throwable
  45. def invalidIntervalFormError(value: String, ctx: MultiUnitsIntervalContext): Throwable
  46. def invalidIntervalLiteralError(ctx: IntervalContext): Throwable
  47. def invalidLateralJoinRelationError(ctx: RelationPrimaryContext): Throwable
  48. def invalidNumericLiteralRangeError(rawStrippedQualifier: String, minValue: BigDecimal, maxValue: BigDecimal, typeName: String, ctx: NumberContext): Throwable
  49. def invalidPropertyKeyForSetQuotedConfigurationError(keyCandidate: String, valueStr: String, ctx: SetQuotedConfigurationContext): Throwable
  50. def invalidPropertyValueForSetQuotedConfigurationError(valueCandidate: String, keyStr: String, ctx: SetQuotedConfigurationContext): Throwable
  51. def invalidTimeZoneDisplacementValueError(ctx: SetTimeZoneContext): Throwable
  52. def invalidTransformArgumentError(ctx: TransformArgumentContext): Throwable
  53. def invalidWindowReferenceError(name: String, ctx: WindowClauseContext): Throwable
  54. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  55. def joinCriteriaUnimplementedError(join: JoinCriteriaContext, ctx: RelationContext): Throwable
  56. def lateralJoinWithNaturalJoinUnsupportedError(ctx: ParserRuleContext): Throwable
  57. def lateralJoinWithUsingJoinUnsupportedError(ctx: ParserRuleContext): Throwable
  58. def lateralWithPivotInFromClauseNotAllowedError(ctx: FromClauseContext): Throwable
  59. def literalValueTypeUnsupportedError(valueType: String, ctx: TypeConstructorContext): Throwable
  60. def mergeStatementWithoutWhenClauseError(ctx: MergeIntoTableContext): Throwable
  61. def mixedIntervalUnitsError(literal: String, ctx: ParserRuleContext): Throwable
  62. def moreThanOneFromToUnitInIntervalLiteralError(ctx: ParserRuleContext): Throwable
  63. def naturalCrossJoinUnsupportedError(ctx: RelationContext): Throwable
  64. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  65. def nonLastMatchedClauseOmitConditionError(ctx: MergeIntoTableContext): Throwable
  66. def nonLastNotMatchedClauseOmitConditionError(ctx: MergeIntoTableContext): Throwable
  67. def notEnoughArgumentsForTransformError(name: String, ctx: ApplyTransformContext): Throwable
  68. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  69. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  70. def operationInHiveStyleCommandUnsupportedError(operation: String, command: String, ctx: StatementContext, msgOpt: Option[String] = None): Throwable
  71. def operationNotAllowedError(message: String, ctx: ParserRuleContext): Throwable
  72. def parsingValueTypeError(e: IllegalArgumentException, valueType: String, ctx: TypeConstructorContext): Throwable
  73. def partitionTransformNotExpectedError(name: String, describe: String, ctx: ApplyTransformContext): Throwable
  74. def propertiesAndDbPropertiesBothSpecifiedError(ctx: CreateNamespaceContext): Throwable
  75. def repetitiveWindowDefinitionError(name: String, ctx: WindowClauseContext): Throwable
  76. def rowFormatNotUsedWithStoredAsError(ctx: CreateTableLikeContext): Throwable
  77. def showFunctionsUnsupportedError(identifier: String, ctx: IdentifierContext): Throwable
  78. def sqlStatementUnsupportedError(sqlText: String, position: Origin): Throwable
  79. def storedAsAndStoredByBothSpecifiedError(ctx: CreateFileFormatContext): Throwable
  80. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  81. def tableSampleByBytesUnsupportedError(msg: String, ctx: SampleMethodContext): Throwable
  82. def toString(): String
    Definition Classes
    AnyRef → Any
  83. def tooManyArgumentsForTransformError(name: String, ctx: ApplyTransformContext): Throwable
  84. def transformNotSupportQuantifierError(ctx: ParserRuleContext): Throwable
  85. def transformWithSerdeUnsupportedError(ctx: ParserRuleContext): Throwable
  86. def trimOptionUnsupportedError(trimOption: Int, ctx: TrimContext): Throwable
  87. def unexpectedFomatForSetConfigurationError(ctx: SetConfigurationContext): Throwable
  88. def unexpectedFormatForResetConfigurationError(ctx: ResetConfigurationContext): Throwable
  89. def unquotedIdentifierError(ident: String, ctx: ErrorIdentContext): Throwable
  90. def unrecognizedMatchedActionError(ctx: MatchedClauseContext): Throwable
  91. def unrecognizedNotMatchedActionError(ctx: NotMatchedClauseContext): Throwable
  92. def unsupportedLateralJoinTypeError(ctx: ParserRuleContext, joinType: String): Throwable
  93. def unsupportedLocalFileSchemeError(ctx: InsertOverwriteDirContext): Throwable
  94. def useDefinedRecordReaderOrWriterClassesError(ctx: ParserRuleContext): Throwable
  95. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  96. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  97. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()

Inherited from AnyRef

Inherited from Any

Ungrouped