@Deprecated public class HiveTableSqlFunction extends org.apache.flink.table.planner.functions.utils.TableSqlFunction
TableSqlFunction
. Override getFunction to clone function and invoke HiveGenericUDTF#setArgumentTypesAndConstants
. Override SqlReturnTypeInference to invoke HiveGenericUDTF#getHiveResultType
instead of HiveGenericUDTF#getResultType(Object[],
Class[])
.Modifier and Type | Class and Description |
---|---|
static class |
HiveTableSqlFunction.HiveOperandTypeChecker
Deprecated.
TODO hack code, should modify calcite getRowType to pass operand types
|
Constructor and Description |
---|
HiveTableSqlFunction(FunctionIdentifier identifier,
TableFunction hiveUdtf,
DataType implicitResultType,
org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory,
org.apache.flink.table.planner.plan.schema.FlinkTableFunction functionImpl,
HiveTableSqlFunction.HiveOperandTypeChecker operandTypeChecker)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
org.apache.calcite.rel.type.RelDataType |
getRowType(org.apache.calcite.rel.type.RelDataTypeFactory typeFactory,
List<org.apache.calcite.sql.SqlNode> operandList)
Deprecated.
|
TableFunction |
makeFunction(Object[] constantArguments,
LogicalType[] argTypes)
Deprecated.
|
static HiveTableSqlFunction.HiveOperandTypeChecker |
operandTypeChecker(String name,
TableFunction udtf)
Deprecated.
|
$lessinit$greater$default$7, getImplicitResultType, inferOperandTypesInternal, isDeterministic, toString, udtf
getElementType, getFunction
deriveType, getFunctionType, getNameAsId, getParamTypes, getSqlIdentifier, getSyntax, isQuantifierAllowed, unparse, validateCall, validateQuantifier
acceptCall, acceptCall, adjustType, allowsFraming, argumentMustBeScalar, checkOperandCount, checkOperandTypes, constructArgNameList, constructArgTypeList, constructOperandList, createCall, createCall, createCall, createCall, equals, getAllowedSignatures, getAllowedSignatures, getKind, getLeftPrec, getMonotonicity, getMonotonicity, getName, getOperandCountRange, getOperandTypeChecker, getOperandTypeInference, getReturnTypeInference, getRightPrec, getSignatureTemplate, hashCode, inferReturnType, inferReturnType, isAggregator, isDynamicFunction, isGroup, isGroupAuxiliary, isName, leftPrec, preValidateCall, requiresDecimalExpansion, requiresOrder, requiresOver, rewriteCall, rightPrec, unparseListClause, unparseListClause, validateOperands, validRexOperands
public HiveTableSqlFunction(FunctionIdentifier identifier, TableFunction hiveUdtf, DataType implicitResultType, org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory, org.apache.flink.table.planner.plan.schema.FlinkTableFunction functionImpl, HiveTableSqlFunction.HiveOperandTypeChecker operandTypeChecker)
public TableFunction makeFunction(Object[] constantArguments, LogicalType[] argTypes)
makeFunction
in class org.apache.flink.table.planner.functions.utils.TableSqlFunction
public org.apache.calcite.rel.type.RelDataType getRowType(org.apache.calcite.rel.type.RelDataTypeFactory typeFactory, List<org.apache.calcite.sql.SqlNode> operandList)
getRowType
in class org.apache.flink.table.planner.functions.utils.TableSqlFunction
public static HiveTableSqlFunction.HiveOperandTypeChecker operandTypeChecker(String name, TableFunction udtf)
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.