public class SqlFunctionConverter
extends org.apache.calcite.rex.RexShuttle
Modifier and Type | Field and Description |
---|---|
protected org.apache.calcite.rex.RexBuilder |
builder |
protected org.apache.calcite.plan.RelOptCluster |
cluster |
Constructor and Description |
---|
SqlFunctionConverter(org.apache.calcite.plan.RelOptCluster cluster,
org.apache.calcite.sql.SqlOperatorTable opTable,
org.apache.calcite.sql.validate.SqlNameMatcher nameMatcher) |
Modifier and Type | Method and Description |
---|---|
org.apache.calcite.sql.SqlOperator |
convertOperator(org.apache.calcite.sql.SqlOperator operator) |
boolean |
hasOverloadedOp(org.apache.calcite.sql.SqlOperator operator,
org.apache.calcite.sql.SqlFunctionCategory functionType) |
org.apache.calcite.rex.RexNode |
visitCall(org.apache.calcite.rex.RexCall call) |
org.apache.calcite.rex.RexNode |
visitOver(org.apache.calcite.rex.RexOver over) |
apply, apply, mutate, visitArray, visitCorrelVariable, visitDynamicParam, visitFieldAccess, visitFieldCollations, visitInputRef, visitList, visitLiteral, visitLocalRef, visitPatternFieldRef, visitRangeRef, visitSubQuery, visitTableInputRef, visitWindow
protected final org.apache.calcite.plan.RelOptCluster cluster
protected final org.apache.calcite.rex.RexBuilder builder
public SqlFunctionConverter(org.apache.calcite.plan.RelOptCluster cluster, org.apache.calcite.sql.SqlOperatorTable opTable, org.apache.calcite.sql.validate.SqlNameMatcher nameMatcher)
public org.apache.calcite.rex.RexNode visitCall(org.apache.calcite.rex.RexCall call)
visitCall
in interface org.apache.calcite.rex.RexVisitor<org.apache.calcite.rex.RexNode>
visitCall
in class org.apache.calcite.rex.RexShuttle
public org.apache.calcite.rex.RexNode visitOver(org.apache.calcite.rex.RexOver over)
visitOver
in interface org.apache.calcite.rex.RexVisitor<org.apache.calcite.rex.RexNode>
visitOver
in class org.apache.calcite.rex.RexShuttle
public org.apache.calcite.sql.SqlOperator convertOperator(org.apache.calcite.sql.SqlOperator operator)
public boolean hasOverloadedOp(org.apache.calcite.sql.SqlOperator operator, org.apache.calcite.sql.SqlFunctionCategory functionType)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.