Class

org.apache.spark.sql

SnappyDDLParser

Related Doc: package sql

Permalink

abstract class SnappyDDLParser extends SnappyBaseParser with Logging

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

Instance Constructors

  1. new SnappyDDLParser(session: SnappySession)

    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. final type ColumnDirectionMap = Seq[(String, Option[SortDirection])]

    Permalink
  4. sealed trait NTimes extends AnyRef

    Permalink
    Definition Classes
    RuleDSLCombinators
  5. final type TableEnd = (Option[String], Option[Map[String, String]], Array[String], Option[BucketSpec], Option[LogicalPlan])

    Permalink
  6. class TracingBubbleException extends RuntimeException with NoStackTrace

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

    Permalink
    Definition Classes
    RuleDSLCombinators
  8. class __SubParserInput extends ParserInput

    Permalink
    Attributes
    protected
    Definition Classes
    Parser

Abstract Value Members

  1. abstract def expression: Rule1[Expression]

    Permalink
    Attributes
    protected
  2. abstract def input: ParserInput

    Permalink
    Definition Classes
    Parser
  3. abstract def newInstance(): SnappyDDLParser

    Permalink
    Attributes
    protected
  4. abstract def parseSQL[T](sqlText: String, parseRule: ⇒ Try[T]): T

    Permalink
    Attributes
    protected
  5. abstract def partitionSpec: Rule1[Map[String, Option[String]]]

    Permalink
    Attributes
    protected
  6. abstract def query: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  7. abstract def start: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser

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. final def ADD: Rule0

    Permalink
  6. final def ALL: Rule0

    Permalink
  7. final def ALTER: Rule0

    Permalink
  8. final def ANALYZE: Rule0

    Permalink
  9. final def AND: Rule0

    Permalink
  10. final def ANTI: Rule0

    Permalink
  11. def ANY: Rule0

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

    Permalink
    Definition Classes
    SnappyBaseParser
  13. final def AS: Rule0

    Permalink
  14. final def ASC: Rule0

    Permalink
  15. final def AUTHORIZATION: Rule0

    Permalink
  16. final def BETWEEN: Rule0

    Permalink
  17. final def BIGINT: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  18. final def BINARY: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  19. final def BLOB: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  20. final def BOOLEAN: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  21. final def BUCKETS: Rule0

    Permalink
  22. final def BY: Rule0

    Permalink
  23. final def BYTE: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  24. final def CACHE: Rule0

    Permalink
  25. final def CALL: Rule0

    Permalink
  26. final def CASCADE: Rule0

    Permalink
  27. final def CASE: Rule0

    Permalink
  28. final def CAST: Rule0

    Permalink
  29. final def CHAR: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  30. final def CHECK: Rule0

    Permalink
  31. final def CLEAR: Rule0

    Permalink
  32. final def CLOB: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  33. final def CLUSTER: Rule0

    Permalink
  34. final def CLUSTERED: Rule0

    Permalink
  35. final def CODEGEN: Rule0

    Permalink
  36. final def COLUMN: Rule0

    Permalink
  37. final def COLUMNS: Rule0

    Permalink
  38. final def COMMENT: Rule0

    Permalink
  39. final def COMPUTE: Rule0

    Permalink
  40. final def CONSTRAINT: Rule0

    Permalink
  41. final def CREATE: Rule0

    Permalink
  42. final def CROSS: Rule0

    Permalink
  43. final def CUBE: Rule0

    Permalink
  44. final def CURRENT: Rule0

    Permalink
  45. final def CURRENT_DATE: Rule0

    Permalink
  46. final def CURRENT_TIMESTAMP: Rule0

    Permalink
  47. final def CURRENT_USER: Rule0

    Permalink
  48. final def DATABASE: Rule0

    Permalink
  49. final def DATABASES: Rule0

    Permalink
  50. final def DATE: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  51. final def DAY: Rule0

    Permalink
  52. final def DECIMAL: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  53. final def DELETE: Rule0

    Permalink
  54. final def DEPLOY: Rule0

    Permalink
  55. final def DESC: Rule0

    Permalink
  56. final def DESCRIBE: Rule0

    Permalink
  57. final def DISABLE: Rule0

    Permalink
  58. final def DISKSTORE: Rule0

    Permalink
  59. final def DISTINCT: Rule0

    Permalink
  60. final def DISTRIBUTE: Rule0

    Permalink
  61. final def DOUBLE: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  62. final def DROP: Rule0

    Permalink
  63. final def DURATION: Rule0

    Permalink
  64. final def ELSE: Rule0

    Permalink
  65. final def ENABLE: Rule0

    Permalink
  66. final def END: Rule0

    Permalink
  67. def EOI: Char

    Permalink
    Definition Classes
    RuleDSLBasics
  68. final def EXCEPT: Rule0

    Permalink
  69. final def EXEC: Rule0

    Permalink
  70. final def EXECUTE: Rule0

    Permalink
  71. final def EXISTS: Rule0

    Permalink
  72. final def EXPLAIN: Rule0

    Permalink
  73. final def EXTENDED: Rule0

    Permalink
  74. final def EXTERNAL: Rule0

    Permalink
  75. final def ExtTableIdentifier: Rule1[TableIdentifier]

    Permalink
  76. final def FALSE: Rule0

    Permalink
  77. final def FETCH: Rule0

    Permalink
  78. final def FIRST: Rule0

    Permalink
  79. final def FLOAT: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  80. final def FN: Rule0

    Permalink
  81. final def FOLLOWING: Rule0

    Permalink
  82. final def FOR: Rule0

    Permalink
  83. final def FOREIGN: Rule0

    Permalink
  84. final def FORMAT: Rule0

    Permalink
  85. final def FORMATTED: Rule0

    Permalink
  86. final def FROM: Rule0

    Permalink
  87. final def FULL: Rule0

    Permalink
  88. final def FUNCTION: Rule0

    Permalink
  89. final def FUNCTIONS: Rule0

    Permalink
  90. final def GLOBAL: Rule0

    Permalink
  91. final def GRANT: Rule0

    Permalink
  92. final def GROUP: Rule0

    Permalink
  93. final def GROUPING: Rule0

    Permalink
  94. final def HASH: Rule0

    Permalink
  95. final def HAVING: Rule0

    Permalink
  96. final def HOUR: Rule0

    Permalink
  97. final def IF: Rule0

    Permalink
  98. final def IN: Rule0

    Permalink
  99. final def INDEX: Rule0

    Permalink
  100. final def INIT: Rule0

    Permalink
  101. final def INNER: Rule0

    Permalink
  102. final def INSERT: Rule0

    Permalink
  103. final def INT: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  104. final def INTEGER: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  105. final def INTERSECT: Rule0

    Permalink
  106. final def INTERVAL: Rule0

    Permalink
  107. final def INTO: Rule0

    Permalink
  108. final def IS: Rule0

    Permalink
  109. final def JAR: Rule0

    Permalink
  110. final def JARS: Rule0

    Permalink
  111. final def JOIN: Rule0

    Permalink
  112. final def LAST: Rule0

    Permalink
  113. final def LATERAL: Rule0

    Permalink
  114. final def LAZY: Rule0

    Permalink
  115. final def LDAPGROUP: Rule0

    Permalink
  116. final def LEFT: Rule0

    Permalink
  117. final def LEVEL: Rule0

    Permalink
  118. final def LIKE: Rule0

    Permalink
  119. final def LIMIT: Rule0

    Permalink
  120. final def LIST: Rule0

    Permalink
  121. final def LOAD: Rule0

    Permalink
  122. final def LOCATION: Rule0

    Permalink
  123. final def LONG: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  124. final def MAP: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  125. def MATCH: Rule0

    Permalink
    Definition Classes
    RuleDSLBasics
  126. final def MEMBERS: Rule0

    Permalink
  127. final def MICROS: Rule0

    Permalink
  128. final def MICROSECOND: Rule0

    Permalink
  129. final def MILLIS: Rule0

    Permalink
  130. final def MILLISECOND: Rule0

    Permalink
  131. final def MINS: Rule0

    Permalink
  132. final def MINUS: Rule0

    Permalink
  133. final def MINUTE: Rule0

    Permalink
  134. def MISMATCH[I <: HList, O <: HList]: Rule[I, O]

    Permalink
    Definition Classes
    RuleDSLBasics
  135. def MISMATCH0: Rule0

    Permalink
    Definition Classes
    RuleDSLBasics
  136. final def MONTH: Rule0

    Permalink
  137. final def MSCK: Rule0

    Permalink
  138. final def NATURAL: Rule0

    Permalink
  139. final def NOT: Rule0

    Permalink
  140. final def NULL: Rule0

    Permalink
  141. final def NULLS: Rule0

    Permalink
  142. final def NUMERIC: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  143. final def OF: Rule0

    Permalink
  144. final def ON: Rule0

    Permalink
  145. final def ONLY: Rule0

    Permalink
  146. final def OPTIONS: Rule0

    Permalink
  147. final def OR: Rule0

    Permalink
  148. final def ORDER: Rule0

    Permalink
  149. final def OUT: Rule0

    Permalink
  150. final def OUTER: Rule0

    Permalink
  151. final def OVER: Rule0

    Permalink
  152. final def OVERWRITE: Rule0

    Permalink
  153. final def PACKAGE: Rule0

    Permalink
  154. final def PACKAGES: Rule0

    Permalink
  155. final def PARTITION: Rule0

    Permalink
  156. final def PARTITIONED: Rule0

    Permalink
  157. final def PATH: Rule0

    Permalink
  158. final def PERCENT: Rule0

    Permalink
  159. final def PIVOT: Rule0

    Permalink
  160. final def POLICY: Rule0

    Permalink
  161. final def PRECEDING: Rule0

    Permalink
  162. final def PRECISION: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  163. final def PRIMARY: Rule0

    Permalink
  164. final def PRIVILEGE: Rule0

    Permalink
  165. final def PURGE: Rule0

    Permalink
  166. final def PUT: Rule0

    Permalink
  167. final def RANGE: Rule0

    Permalink
  168. final def REAL: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  169. final def REFRESH: Rule0

    Permalink
  170. final def REGEXP: Rule0

    Permalink
  171. final def RENAME: Rule0

    Permalink
  172. final def REPLACE: Rule0

    Permalink
  173. final def REPOS: Rule0

    Permalink
  174. final def RESET: Rule0

    Permalink
  175. final def RESTRICT: Rule0

    Permalink
  176. final def RETURNS: Rule0

    Permalink
  177. final def REVOKE: Rule0

    Permalink
  178. final def RIGHT: Rule0

    Permalink
  179. final def RLIKE: Rule0

    Permalink
  180. final def ROLLUP: Rule0

    Permalink
  181. final def ROW: Rule0

    Permalink
  182. final def ROWS: Rule0

    Permalink
  183. final def SCALA: Rule0

    Permalink
  184. final def SCHEMA: Rule0

    Permalink
  185. final def SCHEMAS: Rule0

    Permalink
  186. final def SECOND: Rule0

    Permalink
  187. final def SECS: Rule0

    Permalink
  188. final def SECURITY: Rule0

    Permalink
  189. final def SELECT: Rule0

    Permalink
  190. final def SEMI: Rule0

    Permalink
  191. final def SERDE: Rule0

    Permalink
  192. final def SERDEPROPERTIES: Rule0

    Permalink
  193. final def SET: Rule0

    Permalink
  194. final def SETS: Rule0

    Permalink
  195. final def SHORT: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  196. final def SHOW: Rule0

    Permalink
  197. final def SKEWED: Rule0

    Permalink
  198. final def SLIDE: Rule0

    Permalink
  199. final def SMALLINT: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  200. final def SORT: Rule0

    Permalink
  201. final def SORTED: Rule0

    Permalink
  202. final def START: Rule0

    Permalink
  203. final def STATISTICS: Rule0

    Permalink
  204. final def STOP: Rule0

    Permalink
  205. final def STORED: Rule0

    Permalink
  206. final def STREAM: Rule0

    Permalink
  207. final def STREAMING: Rule0

    Permalink
  208. final def STRING: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  209. final def STRUCT: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  210. final def TABLE: Rule0

    Permalink
  211. final def TABLES: Rule0

    Permalink
  212. final def TABLESAMPLE: Rule0

    Permalink
  213. final def TBLPROPERTIES: Rule0

    Permalink
  214. final def TEMPORARY: Rule0

    Permalink
  215. final def THEN: Rule0

    Permalink
  216. final def TIMESTAMP: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  217. final def TINYINT: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  218. final def TO: Rule0

    Permalink
  219. final def TRIGGER: Rule0

    Permalink
  220. final def TRUE: Rule0

    Permalink
  221. final def TRUNCATE: Rule0

    Permalink
  222. final def UNBOUNDED: Rule0

    Permalink
  223. final def UNCACHE: Rule0

    Permalink
  224. final def UNDEPLOY: Rule0

    Permalink
  225. final def UNION: Rule0

    Permalink
  226. final def UNIQUE: Rule0

    Permalink
  227. final def UNSET: Rule0

    Permalink
  228. final def UPDATE: Rule0

    Permalink
  229. final def USE: Rule0

    Permalink
  230. final def USER: Rule0

    Permalink
  231. final def USING: Rule0

    Permalink
  232. final def VALUES: Rule0

    Permalink
  233. final def VARBINARY: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  234. final def VARCHAR: Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  235. final def VIEW: Rule0

    Permalink
  236. final def VIEWS: Rule0

    Permalink
  237. final def WEEK: Rule0

    Permalink
  238. final def WHEN: Rule0

    Permalink
  239. final def WHERE: Rule0

    Permalink
  240. final def WINDOW: Rule0

    Permalink
  241. final def WITH: Rule0

    Permalink
  242. final def YEAR: Rule0

    Permalink
  243. def __advance(): Boolean

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

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

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

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

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

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

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

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

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

    Permalink
    Definition Classes
    Parser
  253. def __inErrorAnalysis: Boolean

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

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

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

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

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

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

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

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

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

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

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

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

    Permalink
    Definition Classes
    Parser
  266. def __saveState: Mark

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

    Permalink
    Definition Classes
    Parser
  268. final def allowDDL: Rule0

    Permalink
    Attributes
    protected
  269. def alterTable: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  270. def alterTableOrView: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  271. def alterTableToggleRowLevelSecurity: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  272. def alterView: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  273. def anyOf(chars: String): Rule0

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

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  275. final def asInstanceOf[T0]: T0

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

    Permalink
    Definition Classes
    RuleDSLCombinators
    Annotations
    @compileTimeOnly( ... )
  277. final def beforeDDLEnd: Rule0

    Permalink
    Attributes
    protected
  278. final def booleanLiteral: Rule1[Boolean]

    Permalink
    Attributes
    protected
  279. final def bucketSpec: Rule1[BucketSpec]

    Permalink
    Attributes
    protected
  280. def cache: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  281. final def canAlter(id: TableIdentifier, op: String, allBuiltins: Boolean = false): TableIdentifier

    Permalink
    Attributes
    protected
  282. 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( ... )
  283. var caseSensitive: Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  284. implicit def ch(c: Char): Rule0

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  288. def checkExists(resource: FunctionResource): Unit

    Permalink
    Attributes
    protected
  289. def clearQueryHints(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  290. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  291. def codeChunk: Rule1[String]

    Permalink
    Attributes
    protected
  292. final def colsWithDirection: Rule1[ColumnDirectionMap]

    Permalink
    Attributes
    protected
  293. def column: Rule1[StructField]

    Permalink
    Attributes
    protected
  294. final def columnCharType: Rule1[DataType]

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  295. final def columnDataType: Rule1[DataType]

    Permalink
    Definition Classes
    SnappyBaseParser
  296. final def commaSep: Rule0

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  297. final def commentBody: Rule0

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  298. final def commentBodyOrHint: Rule0

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  299. def copyStateFrom(other: Parser, offset: Int): Unit

    Permalink
    Definition Classes
    Parser
  300. def createFunction: Rule1[LogicalPlan]

    Permalink

    Create a CreateFunctionCommand command.

    Create a CreateFunctionCommand command.

    For example:

    CREATE [TEMPORARY] FUNCTION [db_name.]function_name AS class_name RETURNS ReturnType
     USING JAR 'file_uri';
    Attributes
    protected
  301. def createHiveTable: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  302. def createIndex: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  303. def createPolicy: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  304. def createSchema: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  305. def createStream: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  306. def createTable: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  307. def createTableLike: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  308. def createTempViewUsing: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  309. def createView: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  310. def cursor: Int

    Permalink
    Definition Classes
    Parser
  311. def cursorChar: Char

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

    Permalink
    Definition Classes
    SnappyBaseParser
  313. def ddl: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  314. final def ddlEnd: Rule1[TableEnd]

    Permalink
    Attributes
    protected
  315. def delegateToSpark: Rule1[LogicalPlan]

    Permalink

    Handle other statements not appropriate for SnappyData's builtin sources but used by hive/file based sources in Spark.

    Handle other statements not appropriate for SnappyData's builtin sources but used by hive/file based sources in Spark. This rule should always be at the end of the "start" rule so that this is used as the last fallback and not before any of the SnappyData customizations.

    Attributes
    protected
  316. final def delimiter: Rule0

    Permalink

    All recognized delimiters including whitespace.

    All recognized delimiters including whitespace.

    Definition Classes
    SnappyBaseParser
  317. def deployPackages: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  318. def describe: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  319. final def digits: Rule1[String]

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  320. def drop[T](implicit h: HListable[T]): PopRule[Out]

    Permalink
    Definition Classes
    RuleDSLActions
    Annotations
    @compileTimeOnly( ... )
  321. def dropFunction: Rule1[LogicalPlan]

    Permalink

    Create a DropFunctionCommand command.

    Create a DropFunctionCommand command.

    For example:

    DROP [TEMPORARY] FUNCTION [IF EXISTS] function;
    Attributes
    protected
  322. def dropIndex: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  323. def dropPolicy: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  324. def dropSchema: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  325. def dropTable: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  326. def dropView: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  327. final def durationUnit: Rule1[Duration]

    Permalink
    Attributes
    protected
  328. final def eq(arg0: AnyRef): Boolean

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

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

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  335. def formatError(error: ParseError, formatter: ErrorFormatter): String

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

    Permalink
    Definition Classes
    SnappyBaseParser
  337. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  338. final def globalOrTemporary: Rule1[Boolean]

    Permalink
    Attributes
    protected
  339. def grantRevokeExternal: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  340. def grantRevokeIntp: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  341. def handleQueryHint(hint: String, hintValue: String): Unit

    Permalink

    Handle query hints including plan-level like joinType that are marked to be handled later.

    Handle query hints including plan-level like joinType that are marked to be handled later.

    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  342. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  343. final def hexLiteral: Rule1[Array[Byte]]

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  344. final def identifier: Rule1[String]

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  345. final def identifierExt: Rule1[String]

    Permalink

    allow for first character of unquoted identifier to be a numeric

    allow for first character of unquoted identifier to be a numeric

    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  346. final def identifierList: Rule1[Seq[String]]

    Permalink
    Attributes
    protected
  347. final def identifierWithComment: Rule1[(String, Option[String])]

    Permalink
    Attributes
    protected
  348. final def ifExists: Rule1[Boolean]

    Permalink
    Attributes
    protected
  349. final def ifNotExists: Rule1[Boolean]

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

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

    Permalink
    Definition Classes
    RuleDSLBasics
    Annotations
    @compileTimeOnly( ... )
  352. def initializeLogIfNecessary(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  353. implicit def int2NTimes(i: Int): NTimes

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

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  355. def interpretCode: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  356. final def intervalUnit(k: Keyword): Rule0

    Permalink
    Attributes
    protected
  357. final def intervalUnit(k: String): Rule0

    Permalink

    the string passed in *SHOULD* be lower case

    the string passed in *SHOULD* be lower case

    Attributes
    protected
  358. final def isDebugEnabled: Boolean

    Permalink
    Definition Classes
    Logging
  359. final def isInfoEnabled: Boolean

    Permalink
    Definition Classes
    Logging
  360. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  361. final def isTraceEnabled: Boolean

    Permalink
    Definition Classes
    Logging
  362. final def keyword(k: Keyword): Rule0

    Permalink
    Definition Classes
    SnappyBaseParser
  363. def lastChar: Char

    Permalink
    Definition Classes
    Parser
  364. final var levelFlags: Int

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  365. final def lineCommentOrHint: Rule0

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  366. def log: Logger

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

    Permalink
    Definition Classes
    Logging
  368. def logDebug(msg: ⇒ String): Unit

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

    Permalink
    Definition Classes
    Logging
  370. def logError(msg: ⇒ String): Unit

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

    Permalink
    Definition Classes
    Logging
  372. def logInfo(msg: ⇒ String): Unit

    Permalink
    Definition Classes
    Logging
  373. def logName: String

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

    Permalink
    Definition Classes
    Logging
  375. def logTrace(msg: ⇒ String): Unit

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

    Permalink
    Definition Classes
    Logging
  377. def logWarning(msg: ⇒ String): Unit

    Permalink
    Definition Classes
    Logging
  378. final var log_: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  379. final def mapType: Rule1[DataType]

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

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

    Permalink
    Definition Classes
    AnyRef
  382. 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
    Definition Classes
    SnappyBaseParser
  383. def noneOf(chars: String): Rule0

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

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

    Permalink
    Definition Classes
    AnyRef
  386. final def numericLiteral: Rule1[String]

    Permalink
    Attributes
    protected
  387. 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( ... )
  388. final def option: Rule1[(String, String)]

    Permalink
    Attributes
    protected
  389. final def optionKey: Rule1[String]

    Permalink
    Attributes
    protected
  390. 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( ... )
  391. final def options: Rule1[Map[String, String]]

    Permalink
    Attributes
    protected
  392. final def packageIdentifier: Rule1[TableIdentifier]

    Permalink
    Definition Classes
    SnappyBaseParser
  393. final def packageIdentifierPart: Rule1[String]

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  394. def passThrough: Rule1[LogicalPlan]

    Permalink

    Commands like GRANT/REVOKE/CREATE DISKSTORE/CALL on a table that are passed through as is to the SnappyData store layer (only for column and row tables).

    Commands like GRANT/REVOKE/CREATE DISKSTORE/CALL on a table that are passed through as is to the SnappyData store layer (only for column and row tables).

    Example:

    GRANT SELECT ON table TO user1, user2;
    GRANT INSERT ON table TO ldapGroup: group1;
    CREATE DISKSTORE diskstore_name ('dir1' 10240)
    DROP DISKSTORE diskstore_name
    CALL SYSCS_UTIL.SYSCS_SET_RUNTIMESTATISTICS(1)
    Attributes
    protected
  395. final def policyFor: Rule1[String]

    Permalink
    Attributes
    protected
  396. final def policyTo: Rule1[Seq[String]]

    Permalink
    Attributes
    protected
  397. implicit def predicate(p: CharPredicate): Rule0

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

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  399. def push[T](value: T)(implicit h: HListable[T]): RuleN[Out]

    Permalink
    Definition Classes
    RuleDSLActions
    Annotations
    @compileTimeOnly( ... )
  400. final def qualifiedName: Rule1[String]

    Permalink
    Attributes
    protected
  401. final def questionMark: Rule0

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  402. def quiet[I <: HList, O <: HList](r: Rule[I, O]): Rule[I, O]

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

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  404. final def quotedUppercaseId(id: IdentifierWithDatabase): String

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  405. implicit def range2NTimes(range: Range): NTimes

    Permalink
    Definition Classes
    RuleDSLCombinators
    Annotations
    @compileTimeOnly( ... )
  406. def refreshTable: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  407. def reset: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  408. def resetLogger(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  409. final def resourceType: Rule1[FunctionResource]

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

    Permalink
    Definition Classes
    Parser
  411. 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( ... )
  412. implicit def rule2WithSeparatedBy[I <: HList, O <: HList](r: Rule[I, O] with Repeated): WithSeparatedBy[I, O]

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  416. def set: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  417. final def sortDirection: Rule1[SortDirection]

    Permalink
    Attributes
    protected
  418. final lazy val sparkParser: SparkSqlParser

    Permalink

    spark parser used for hive DDLs that are not relevant to SnappyData's builtin sources

    spark parser used for hive DDLs that are not relevant to SnappyData's builtin sources

    Attributes
    protected
  419. final def sql: Rule1[LogicalPlan]

    Permalink
    Definition Classes
    SnappyBaseParser
  420. implicit def str(s: String): Rule0

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

    Permalink
    Definition Classes
    RuleDSLBasics
    Annotations
    @compileTimeOnly( ... )
  422. def streamContext: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  423. 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
    Definition Classes
    SnappyBaseParser
  424. final def stringLiteral: Rule1[String]

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  425. final def structField: Rule1[StructField]

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  426. final def structType: Rule1[DataType]

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  427. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  428. final def tableEnd: Rule2[StringBuilder, TableEnd]

    Permalink
    Attributes
    protected
  429. final def tableEnd1: Rule[::[StringBuilder, HNil], ::[StringBuilder, ::[TableEnd, HNil]]]

    Permalink
    Attributes
    protected
  430. final def tableIdentifier: Rule1[TableIdentifier]

    Permalink
    Definition Classes
    SnappyBaseParser
  431. final def tableSchema: Rule1[Seq[StructField]]

    Permalink
    Attributes
    protected
  432. final def tableSchemaOpt: Rule1[Option[Seq[StructField]]]

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  435. def truncateTable: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  436. def uncache: Rule1[LogicalPlan]

    Permalink
    Attributes
    protected
  437. final def unquotedIdentifier: Rule1[String]

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  438. def valueMap[T](m: Map[String, T], ignoreCase: Boolean)(implicit h: HListable[T]): RuleN[Out]

    Permalink
    Definition Classes
    RuleDSLBasics
    Annotations
    @compileTimeOnly( ... )
  439. implicit def valueMap[T](m: Map[String, T])(implicit h: HListable[T]): RuleN[Out]

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

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

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

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

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

    Permalink

    The recognized whitespace characters and comments.

    The recognized whitespace characters and comments.

    Attributes
    protected
    Definition Classes
    SnappyBaseParser
  445. 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 Logging

Inherited from SnappyBaseParser

Inherited from Parser

Inherited from RuleDSL

Inherited from RuleDSLActions

Inherited from RuleDSLCombinators

Inherited from RuleDSLBasics

Inherited from AnyRef

Inherited from Any

Ungrouped