@Internal public class FlinkTimestampDynamicFunction extends org.apache.calcite.sql.fun.SqlAbstractTimeFunction
SqlStdOperatorTable
) in Flink, the difference from the
parent SqlAbstractTimeFunction
is this function class be aware of whether it is used in
batch mode, if true it will act totally same as the parent SqlAbstractTimeFunction
, but
will be a non-deterministic function if not in batch mode.Modifier and Type | Field and Description |
---|---|
protected boolean |
isBatchMode |
Constructor and Description |
---|
FlinkTimestampDynamicFunction(String functionName,
org.apache.calcite.sql.type.SqlTypeName returnTypeName,
boolean isBatchMode) |
Modifier and Type | Method and Description |
---|---|
boolean |
equals(@Nullable Object obj) |
int |
hashCode() |
boolean |
isDeterministic() |
boolean |
isDynamicFunction() |
getMonotonicity, getSyntax, inferReturnType
deriveType, getFunctionType, getNameAsId, getParamNames, getParamTypes, getSqlIdentifier, isQuantifierAllowed, unparse, validateCall, validateQuantifier
acceptCall, acceptCall, adjustType, allowsFraming, argumentMustBeScalar, checkOperandCount, checkOperandTypes, constructArgNameList, constructArgTypeList, constructOperandList, createCall, createCall, createCall, createCall, createCall, createCall, createCall, getAllowedSignatures, getAllowedSignatures, getKind, getLeftPrec, getMonotonicity, getName, getOperandCountRange, getOperandTypeChecker, getOperandTypeInference, getReturnTypeInference, getRightPrec, getSignatureTemplate, getStrongPolicyInference, inferReturnType, isAggregator, isGroup, isGroupAuxiliary, isName, isSymmetrical, leftPrec, not, preValidateCall, requiresDecimalExpansion, requiresOrder, requiresOver, reverse, rewriteCall, rightPrec, toString, unparseListClause, unparseListClause, validateOperands, validRexOperands
public FlinkTimestampDynamicFunction(String functionName, org.apache.calcite.sql.type.SqlTypeName returnTypeName, boolean isBatchMode)
public boolean isDynamicFunction()
isDynamicFunction
in class org.apache.calcite.sql.fun.SqlAbstractTimeFunction
public boolean isDeterministic()
isDeterministic
in class org.apache.calcite.sql.SqlOperator
public boolean equals(@Nullable Object obj)
equals
in class org.apache.calcite.sql.SqlOperator
public int hashCode()
hashCode
in class org.apache.calcite.sql.SqlOperator
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.