Class

org.apache.spark.sql

SnappyBaseParser

Related Doc: package sql

Permalink

abstract class SnappyBaseParser extends Parser

Base parsing facilities for all SnappyData SQL parsers.

Linear Supertypes
Parser, RuleDSL, RuleDSLActions, RuleDSLCombinators, RuleDSLBasics, AnyRef, Any
Known Subclasses
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. SnappyBaseParser
  2. Parser
  3. RuleDSL
  4. RuleDSLActions
  5. RuleDSLCombinators
  6. RuleDSLBasics
  7. AnyRef
  8. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new SnappyBaseParser(session: SparkSession)

    Permalink

Type Members

  1. sealed trait ActionOperator[I <: HList, O <: HList, Ops] extends AnyRef

    Permalink
    Definition Classes
    RuleDSLActions
  2. sealed trait CharRangeSupport extends AnyRef

    Permalink
    Definition Classes
    RuleDSLBasics
  3. sealed trait NTimes extends AnyRef

    Permalink
    Definition Classes
    RuleDSLCombinators
  4. class TracingBubbleException extends RuntimeException with NoStackTrace

    Permalink
    Definition Classes
    Parser
  5. trait WithSeparatedBy[I <: HList, O <: HList] extends AnyRef

    Permalink
    Definition Classes
    RuleDSLCombinators
  6. class __SubParserInput extends ParserInput

    Permalink
    Attributes
    protected
    Definition Classes
    Parser

Abstract Value Members

  1. abstract def input: ParserInput

    Permalink
    Definition Classes
    Parser
  2. abstract def start: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected

Concrete Value Members

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

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. def &(r: Rule[_, _]): Rule0

    Permalink
    Definition Classes
    RuleDSLCombinators
    Annotations
    @compileTimeOnly( ... )
  4. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  5. def ANY: Rule0

    Permalink
    Definition Classes
    RuleDSLBasics
    Annotations
    @compileTimeOnly( ... )
  6. final def ARRAY: Rule0

    Permalink
  7. final def BIGINT: Rule0

    Permalink
  8. final def BINARY: Rule0

    Permalink
  9. final def BLOB: Rule0

    Permalink
  10. final def BOOLEAN: Rule0

    Permalink
  11. final def BYTE: Rule0

    Permalink
  12. final def CHAR: Rule0

    Permalink
  13. final def CLOB: Rule0

    Permalink
  14. final def DATE: Rule0

    Permalink
  15. final def DECIMAL: Rule0

    Permalink
  16. final def DOUBLE: Rule0

    Permalink
  17. def EOI: Char

    Permalink
    Definition Classes
    RuleDSLBasics
  18. final def FLOAT: Rule0

    Permalink
  19. final def INT: Rule0

    Permalink
  20. final def INTEGER: Rule0

    Permalink
  21. final def LONG: Rule0

    Permalink
  22. final def MAP: Rule0

    Permalink
  23. def MATCH: Rule0

    Permalink
    Definition Classes
    RuleDSLBasics
  24. def MISMATCH[I <: HList, O <: HList]: Rule[I, O]

    Permalink
    Definition Classes
    RuleDSLBasics
  25. def MISMATCH0: Rule0

    Permalink
    Definition Classes
    RuleDSLBasics
  26. final def NUMERIC: Rule0

    Permalink
  27. final def REAL: Rule0

    Permalink
  28. final def SHORT: Rule0

    Permalink
  29. final def SMALLINT: Rule0

    Permalink
  30. final def STRING: Rule0

    Permalink
  31. final def STRUCT: Rule0

    Permalink
  32. final def TIMESTAMP: Rule0

    Permalink
  33. final def TINYINT: Rule0

    Permalink
  34. final def VARBINARY: Rule0

    Permalink
  35. final def VARCHAR: Rule0

    Permalink
  36. def __advance(): Boolean

    Permalink
    Definition Classes
    Parser
  37. def __bubbleUp(prefix: List[NonTerminal], terminal: Terminal): Nothing

    Permalink
    Definition Classes
    Parser
  38. def __bubbleUp(terminal: Terminal): Nothing

    Permalink
    Definition Classes
    Parser
  39. def __enterAtomic(start: Int): Boolean

    Permalink
    Definition Classes
    Parser
  40. def __enterNotPredicate(): AnyRef

    Permalink
    Definition Classes
    Parser
  41. def __enterQuiet(): Int

    Permalink
    Definition Classes
    Parser
  42. def __exitAtomic(saved: Boolean): Unit

    Permalink
    Definition Classes
    Parser
  43. def __exitNotPredicate(saved: AnyRef): Unit

    Permalink
    Definition Classes
    Parser
  44. def __exitQuiet(saved: Int): Unit

    Permalink
    Definition Classes
    Parser
  45. def __hardFail(expected: String): Nothing

    Permalink
    Definition Classes
    Parser
  46. def __inErrorAnalysis: Boolean

    Permalink
    Definition Classes
    Parser
  47. final def __matchAnyOf(string: String, ix: Int): Boolean

    Permalink
    Definition Classes
    Parser
    Annotations
    @tailrec()
  48. final def __matchIgnoreCaseString(string: String, ix: Int): Boolean

    Permalink
    Definition Classes
    Parser
    Annotations
    @tailrec()
  49. final def __matchIgnoreCaseStringWrapped(string: String, ix: Int): Boolean

    Permalink
    Definition Classes
    Parser
    Annotations
    @tailrec()
  50. def __matchMap(m: Map[String, Any]): Boolean

    Permalink
    Definition Classes
    Parser
  51. def __matchMapWrapped(m: Map[String, Any]): Boolean

    Permalink
    Definition Classes
    Parser
  52. final def __matchNoneOf(string: String, ix: Int): Boolean

    Permalink
    Definition Classes
    Parser
    Annotations
    @tailrec()
  53. final def __matchString(string: String, ix: Int): Boolean

    Permalink
    Definition Classes
    Parser
    Annotations
    @tailrec()
  54. final def __matchStringWrapped(string: String, ix: Int): Boolean

    Permalink
    Definition Classes
    Parser
    Annotations
    @tailrec()
  55. def __push(value: Any): Boolean

    Permalink
    Definition Classes
    Parser
  56. def __registerMismatch(): Boolean

    Permalink
    Definition Classes
    Parser
  57. def __restoreState(mark: Mark): Unit

    Permalink
    Definition Classes
    Parser
  58. def __run[L <: HList](rule: ⇒ RuleN[L])(implicit scheme: DeliveryScheme[L]): Result

    Permalink
    Definition Classes
    Parser
  59. def __saveState: Mark

    Permalink
    Definition Classes
    Parser
  60. def __updateMaxCursor(): Boolean

    Permalink
    Definition Classes
    Parser
  61. def anyOf(chars: String): Rule0

    Permalink
    Definition Classes
    RuleDSLBasics
    Annotations
    @compileTimeOnly( ... )
  62. final def arrayType: Rule1[DataType]

    Permalink
    Attributes
    protected
  63. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  64. def atomic[I <: HList, O <: HList](r: Rule[I, O]): Rule[I, O]

    Permalink
    Definition Classes
    RuleDSLCombinators
    Annotations
    @compileTimeOnly( ... )
  65. def capture[I <: HList, O <: HList](r: Rule[I, O])(implicit p: Prepend[O, ::[String, HNil]]): Rule[I, Out]

    Permalink
    Definition Classes
    RuleDSLActions
    Annotations
    @compileTimeOnly( ... )
  66. var caseSensitive: Boolean

    Permalink
    Attributes
    protected
  67. implicit def ch(c: Char): Rule0

    Permalink
    Definition Classes
    RuleDSLBasics
    Annotations
    @compileTimeOnly( ... )
  68. def charAt(offset: Int): Char

    Permalink
    Definition Classes
    Parser
  69. def charAtRC(offset: Int): Char

    Permalink
    Definition Classes
    Parser
  70. final def charType: Rule1[DataType]

    Permalink
    Attributes
    protected
  71. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  72. final def columnCharType: Rule1[DataType]

    Permalink
    Attributes
    protected
  73. final def columnDataType: Rule1[DataType]

    Permalink
  74. final def commaSep: Rule0

    Permalink
    Attributes
    protected
  75. final def commentBody: Rule0

    Permalink
    Attributes
    protected
  76. final def commentBodyOrHint: Rule0

    Permalink
    Attributes
    protected
  77. def copyStateFrom(other: Parser, offset: Int): Unit

    Permalink
    Definition Classes
    Parser
  78. def cursor: Int

    Permalink
    Definition Classes
    Parser
  79. def cursorChar: Char

    Permalink
    Definition Classes
    Parser
  80. final def dataType: Rule1[DataType]

    Permalink
  81. final def delimiter: Rule0

    Permalink

    All recognized delimiters including whitespace.

  82. final def digits: Rule1[String]

    Permalink
    Attributes
    protected
  83. def drop[T](implicit h: HListable[T]): PopRule[Out]

    Permalink
    Definition Classes
    RuleDSLActions
    Annotations
    @compileTimeOnly( ... )
  84. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  86. def errorTraceCollectionLimit: Int

    Permalink
    Definition Classes
    Parser
  87. def fail(expected: String): Rule0

    Permalink
    Definition Classes
    RuleDSLBasics
  88. def failX[I <: HList, O <: HList](expected: String): Rule[I, O]

    Permalink
    Definition Classes
    RuleDSLBasics
  89. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  90. final def fixedDecimalType: Rule1[DataType]

    Permalink
    Attributes
    protected
  91. def formatError(error: ParseError, formatter: ErrorFormatter): String

    Permalink
    Definition Classes
    Parser
  92. final def functionIdentifier: Rule1[FunctionIdentifier]

    Permalink
  93. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  94. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  95. final def identifier: Rule1[String]

    Permalink
    Attributes
    protected
  96. def ignoreCase(s: String): Rule0

    Permalink
    Definition Classes
    RuleDSLBasics
    Annotations
    @compileTimeOnly( ... )
  97. def ignoreCase(c: Char): Rule0

    Permalink
    Definition Classes
    RuleDSLBasics
    Annotations
    @compileTimeOnly( ... )
  98. implicit def int2NTimes(i: Int): NTimes

    Permalink
    Definition Classes
    RuleDSLCombinators
    Annotations
    @compileTimeOnly( ... )
  99. final def integral: Rule1[String]

    Permalink
    Attributes
    protected
  100. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  101. final def keyword(k: Keyword): Rule0

    Permalink
  102. def lastChar: Char

    Permalink
    Definition Classes
    Parser
  103. final def lineCommentOrHint: Rule0

    Permalink
    Attributes
    protected
  104. final def mapType: Rule1[DataType]

    Permalink
    Attributes
    protected
  105. macro def namedRule[I <: HList, O <: HList](name: String)(r: Rule[I, O]): Rule[I, O]

    Permalink
    Definition Classes
    Parser
  106. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  107. final def newDataType(t: Keyword): Rule0

    Permalink

    Used for DataTypes.

    Used for DataTypes. Not reserved and otherwise identical to "keyword" apart from the name so as to appear properly in error messages related to incorrect DataType definition.

    Attributes
    protected
  108. def noneOf(chars: String): Rule0

    Permalink
    Definition Classes
    RuleDSLBasics
    Annotations
    @compileTimeOnly( ... )
  109. final def notify(): Unit

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

    Permalink
    Definition Classes
    AnyRef
  111. def oneOrMore[I <: HList, O <: HList](r: Rule[I, O])(implicit l: Lifter[Seq, I, O]): Rule[In, StrictOut] with Repeated

    Permalink
    Definition Classes
    RuleDSLCombinators
    Annotations
    @compileTimeOnly( ... )
  112. def optional[I <: HList, O <: HList](r: Rule[I, O])(implicit l: Lifter[Option, I, O]): Rule[In, OptionalOut]

    Permalink
    Definition Classes
    RuleDSLCombinators
    Annotations
    @compileTimeOnly( ... )
  113. implicit def predicate(p: CharPredicate): Rule0

    Permalink
    Definition Classes
    RuleDSLBasics
    Annotations
    @compileTimeOnly( ... )
  114. final def primitiveType: Rule1[DataType]

    Permalink
    Attributes
    protected
  115. def push[T](value: T)(implicit h: HListable[T]): RuleN[Out]

    Permalink
    Definition Classes
    RuleDSLActions
    Annotations
    @compileTimeOnly( ... )
  116. final def questionMark: Rule0

    Permalink
    Attributes
    protected
  117. def quiet[I <: HList, O <: HList](r: Rule[I, O]): Rule[I, O]

    Permalink
    Definition Classes
    RuleDSLCombinators
    Annotations
    @compileTimeOnly( ... )
  118. final def quotedIdentifier: Rule1[String]

    Permalink
    Attributes
    protected
  119. implicit def range2NTimes(range: Range): NTimes

    Permalink
    Definition Classes
    RuleDSLCombinators
    Annotations
    @compileTimeOnly( ... )
  120. def reset(): Unit

    Permalink
    Attributes
    protected
  121. macro def rule[I <: HList, O <: HList](r: Rule[I, O]): Rule[I, O]

    Permalink
    Definition Classes
    Parser
  122. implicit def rule2ActionOperator[I <: HList, O <: HList](r: Rule[I, O])(implicit ops: ActionOps[I, O]): ActionOperator[I, O, Out]

    Permalink
    Definition Classes
    RuleDSLActions
    Annotations
    @compileTimeOnly( ... )
  123. implicit def rule2WithSeparatedBy[I <: HList, O <: HList](r: Rule[I, O] with Repeated): WithSeparatedBy[I, O]

    Permalink
    Definition Classes
    RuleDSLCombinators
    Annotations
    @compileTimeOnly( ... )
  124. def run[T](arg: T)(implicit rr: RunResult[T]): Out

    Permalink
    Definition Classes
    RuleDSLActions
    Annotations
    @compileTimeOnly( ... )
  125. def runSubParser[I <: HList, O <: HList](f: (ParserInput) ⇒ Rule[I, O]): Rule[I, O]

    Permalink
    Definition Classes
    RuleDSLCombinators
    Annotations
    @compileTimeOnly( ... )
  126. final def scientificNotation: Rule0

    Permalink
    Attributes
    protected
  127. final def sql: Rule1[LogicalPlan]

    Permalink
  128. implicit def str(s: String): Rule0

    Permalink
    Definition Classes
    RuleDSLBasics
    Annotations
    @compileTimeOnly( ... )
  129. implicit def str2CharRangeSupport(s: String): CharRangeSupport

    Permalink
    Definition Classes
    RuleDSLBasics
    Annotations
    @compileTimeOnly( ... )
  130. final def strictIdentifier: Rule1[String]

    Permalink

    A strictIdentifier is more restricted than an identifier in that neither any of the SQL reserved keywords nor non-reserved keywords will be interpreted as a strictIdentifier.

    A strictIdentifier is more restricted than an identifier in that neither any of the SQL reserved keywords nor non-reserved keywords will be interpreted as a strictIdentifier.

    Attributes
    protected
  131. final def stringLiteral: Rule1[String]

    Permalink
    Attributes
    protected
  132. final def structField: Rule1[StructField]

    Permalink
    Attributes
    protected
  133. final def structType: Rule1[DataType]

    Permalink
    Attributes
    protected
  134. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  135. final def tableIdentifier: Rule1[TableIdentifier]

    Permalink
  136. def test(condition: Boolean): Rule0

    Permalink
    Definition Classes
    RuleDSLActions
    Annotations
    @compileTimeOnly( ... )
  137. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  138. final def unquotedIdentifier: Rule1[String]

    Permalink
    Attributes
    protected
  139. implicit def valueMap[T](m: Map[String, T])(implicit h: HListable[T]): RuleN[Out]

    Permalink
    Definition Classes
    RuleDSLBasics
    Annotations
    @compileTimeOnly( ... )
  140. def valueStack: ValueStack

    Permalink
    Definition Classes
    Parser
  141. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  144. final def ws: Rule0

    Permalink

    The recognized whitespace characters and comments.

    The recognized whitespace characters and comments.

    Attributes
    protected
  145. def zeroOrMore[I <: HList, O <: HList](r: Rule[I, O])(implicit l: Lifter[Seq, I, O]): Rule[In, OptionalOut] with Repeated

    Permalink
    Definition Classes
    RuleDSLCombinators
    Annotations
    @compileTimeOnly( ... )

Inherited from Parser

Inherited from RuleDSL

Inherited from RuleDSLActions

Inherited from RuleDSLCombinators

Inherited from RuleDSLBasics

Inherited from AnyRef

Inherited from Any

Ungrouped