public class TableFunctionConverter extends SqlFunctionConverter
builder, cluster
Constructor and Description |
---|
TableFunctionConverter(org.apache.calcite.plan.RelOptCluster cluster,
org.apache.calcite.rel.RelNode leftRel,
org.apache.calcite.sql.SqlOperatorTable opTable,
org.apache.calcite.sql.validate.SqlNameMatcher nameMatcher) |
Modifier and Type | Method and Description |
---|---|
org.apache.calcite.rex.RexNode |
visitCall(org.apache.calcite.rex.RexCall call) |
convertOperator, hasOverloadedOp, visitOver
apply, apply, mutate, visitArray, visitCorrelVariable, visitDynamicParam, visitFieldAccess, visitFieldCollations, visitInputRef, visitList, visitLiteral, visitLocalRef, visitPatternFieldRef, visitRangeRef, visitSubQuery, visitTableInputRef, visitWindow
public TableFunctionConverter(org.apache.calcite.plan.RelOptCluster cluster, org.apache.calcite.rel.RelNode leftRel, 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 SqlFunctionConverter
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.