public class HiveQl
extends Object
Modifier and Type | Class and Description |
---|---|
static class |
HiveQl.Token$
Extractor for matching Hive's AST Tokens.
|
static class |
HiveQl.TransformableNode
A set of implicit transformations that allow Hive ASTNodes to be rewritten by transformations
similar to
catalyst.trees.TreeNode . |
Constructor and Description |
---|
HiveQl() |
Modifier and Type | Method and Description |
---|---|
static scala.util.matching.Regex |
allJoinTokens() |
static scala.util.matching.Regex |
AND() |
static scala.util.matching.Regex |
ARRAY() |
static scala.util.matching.Regex |
AVG() |
static scala.util.matching.Regex |
BETWEEN() |
static scala.util.matching.Regex |
CASE() |
static scala.util.matching.Regex |
COALESCE() |
static scala.util.matching.Regex |
COUNT() |
static org.apache.spark.sql.catalyst.plans.logical.LogicalPlan |
createPlan(String sql)
Creates LogicalPlan for a given HiveQL string.
|
static org.apache.spark.sql.catalyst.plans.logical.Subquery |
createPlanForView(org.apache.hadoop.hive.ql.metadata.Table view,
scala.Option<String> alias) |
static scala.util.matching.Regex |
destinationToken() |
static scala.util.matching.Regex |
DIV() |
static scala.collection.mutable.StringBuilder |
dumpTree(org.apache.hadoop.hive.ql.lib.Node node,
scala.collection.mutable.StringBuilder builder,
int indent) |
static scala.util.matching.Regex |
errorRegEx() |
static scala.util.matching.Regex |
explode() |
static scala.util.matching.Regex |
FALSE() |
static org.apache.hadoop.hive.ql.parse.ASTNode |
getAst(String sql)
Returns the AST for the given SQL string.
|
static org.apache.hadoop.hive.ql.lib.Node |
getClause(String clauseName,
scala.collection.Seq<org.apache.hadoop.hive.ql.lib.Node> nodeList) |
static scala.Option<org.apache.hadoop.hive.ql.lib.Node> |
getClauseOption(String clauseName,
scala.collection.Seq<org.apache.hadoop.hive.ql.lib.Node> nodeList) |
static scala.util.matching.Regex |
IN() |
static scala.util.matching.Regex |
laterViewToken() |
static scala.util.matching.Regex |
LIKE() |
static scala.util.matching.Regex |
LOWER() |
static scala.util.matching.Regex |
MAX() |
static scala.util.matching.Regex |
MIN() |
static org.apache.spark.sql.catalyst.expressions.Generator |
nodesToGenerator(scala.collection.Seq<org.apache.hadoop.hive.ql.lib.Node> nodes) |
static org.apache.spark.sql.catalyst.plans.logical.LogicalPlan |
nodeToRelation(org.apache.hadoop.hive.ql.lib.Node node) |
static org.apache.spark.sql.catalyst.expressions.SortOrder |
nodeToSortOrder(org.apache.hadoop.hive.ql.lib.Node node) |
static scala.util.matching.Regex |
NOT() |
static scala.collection.Seq<Object> |
numericAstTypes() |
static scala.util.matching.Regex |
OR() |
static scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> |
parseDdl(String ddl) |
static org.apache.spark.sql.catalyst.plans.logical.LogicalPlan |
parseSql(String sql)
Returns a LogicalPlan for a given HiveQL string.
|
static scala.util.matching.Regex |
RAND() |
static scala.util.matching.Regex |
REGEXP() |
static scala.util.matching.Regex |
RLIKE() |
static scala.util.matching.Regex |
SQRT() |
static scala.util.matching.Regex |
SUBSTR() |
static scala.util.matching.Regex |
SUM() |
static scala.util.matching.Regex |
TRUE() |
static scala.util.matching.Regex |
UPPER() |
static scala.util.matching.Regex |
WHEN() |
public static org.apache.hadoop.hive.ql.parse.ASTNode getAst(String sql)
public static org.apache.spark.sql.catalyst.plans.logical.LogicalPlan parseSql(String sql)
public static scala.util.matching.Regex errorRegEx()
public static org.apache.spark.sql.catalyst.plans.logical.LogicalPlan createPlan(String sql)
public static org.apache.spark.sql.catalyst.plans.logical.Subquery createPlanForView(org.apache.hadoop.hive.ql.metadata.Table view, scala.Option<String> alias)
public static scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> parseDdl(String ddl)
public static org.apache.hadoop.hive.ql.lib.Node getClause(String clauseName, scala.collection.Seq<org.apache.hadoop.hive.ql.lib.Node> nodeList)
public static scala.Option<org.apache.hadoop.hive.ql.lib.Node> getClauseOption(String clauseName, scala.collection.Seq<org.apache.hadoop.hive.ql.lib.Node> nodeList)
public static scala.util.matching.Regex allJoinTokens()
public static scala.util.matching.Regex laterViewToken()
public static org.apache.spark.sql.catalyst.plans.logical.LogicalPlan nodeToRelation(org.apache.hadoop.hive.ql.lib.Node node)
public static org.apache.spark.sql.catalyst.expressions.SortOrder nodeToSortOrder(org.apache.hadoop.hive.ql.lib.Node node)
public static scala.util.matching.Regex destinationToken()
public static scala.collection.Seq<Object> numericAstTypes()
public static scala.util.matching.Regex ARRAY()
public static scala.util.matching.Regex COALESCE()
public static scala.util.matching.Regex COUNT()
public static scala.util.matching.Regex AVG()
public static scala.util.matching.Regex SUM()
public static scala.util.matching.Regex MAX()
public static scala.util.matching.Regex MIN()
public static scala.util.matching.Regex UPPER()
public static scala.util.matching.Regex LOWER()
public static scala.util.matching.Regex RAND()
public static scala.util.matching.Regex AND()
public static scala.util.matching.Regex OR()
public static scala.util.matching.Regex NOT()
public static scala.util.matching.Regex TRUE()
public static scala.util.matching.Regex FALSE()
public static scala.util.matching.Regex LIKE()
public static scala.util.matching.Regex RLIKE()
public static scala.util.matching.Regex REGEXP()
public static scala.util.matching.Regex IN()
public static scala.util.matching.Regex DIV()
public static scala.util.matching.Regex BETWEEN()
public static scala.util.matching.Regex WHEN()
public static scala.util.matching.Regex CASE()
public static scala.util.matching.Regex SUBSTR()
public static scala.util.matching.Regex SQRT()
public static scala.util.matching.Regex explode()
public static org.apache.spark.sql.catalyst.expressions.Generator nodesToGenerator(scala.collection.Seq<org.apache.hadoop.hive.ql.lib.Node> nodes)
public static scala.collection.mutable.StringBuilder dumpTree(org.apache.hadoop.hive.ql.lib.Node node, scala.collection.mutable.StringBuilder builder, int indent)