Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abbrev - Variable in enum org.apache.calcite.sql.fun.SqlLibrary
-
Abbreviation for the library used in SQL reference.
- abs(byte) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ABS
operator applied to byte values. - abs(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ABS
operator applied to double values. - abs(float) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ABS
operator applied to float values. - abs(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ABS
operator applied to int values. - abs(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ABS
operator applied to long values. - abs(short) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ABS
operator applied to short values. - abs(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ABS
operator applied to BigDecimal values. - ABS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ABS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
ABS(numeric)
function. - ABSENT_ON_NULL - Enum constant in enum org.apache.calcite.sql.SqlJsonConstructorNullClause
- absentOverClause() - Method in interface org.apache.calcite.runtime.CalciteResource
- ABSTRACT_ENUMERABLE_CTOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ABSTRACT_FACTORY_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Provide an interface for creating families of related or dependent objects without specifying their concrete classes.
- AbstractConverter - Class in org.apache.calcite.plan.volcano
-
Converts a relational expression to any given output convention.
- AbstractConverter(RelOptCluster, RelSubset, RelTraitDef, RelTraitSet) - Constructor for class org.apache.calcite.plan.volcano.AbstractConverter
- AbstractConverter.ExpandConversionRule - Class in org.apache.calcite.plan.volcano
-
Rule that converts an
AbstractConverter
into a chain of converters from the source relation to the target traits. - AbstractConverter.ExpandConversionRule.Config - Interface in org.apache.calcite.plan.volcano
-
Rule configuration.
- AbstractEnumerable<T> - Class in org.apache.calcite.linq4j
-
Abstract implementation of the
Enumerable
interface that implements the extension methods. - AbstractEnumerable() - Constructor for class org.apache.calcite.linq4j.AbstractEnumerable
- AbstractEnumerable2<T> - Class in org.apache.calcite.linq4j
-
Abstract implementation of the
Enumerable
interface that implements the extension methods. - AbstractEnumerable2() - Constructor for class org.apache.calcite.linq4j.AbstractEnumerable2
- AbstractFlatList() - Constructor for class org.apache.calcite.runtime.FlatLists.AbstractFlatList
- AbstractJoinExtractFilterRule - Class in org.apache.calcite.rel.rules
- AbstractJoinExtractFilterRule(AbstractJoinExtractFilterRule.Config) - Constructor for class org.apache.calcite.rel.rules.AbstractJoinExtractFilterRule
-
Creates an AbstractJoinExtractFilterRule.
- AbstractJoinExtractFilterRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AbstractMapping() - Constructor for class org.apache.calcite.util.mapping.Mappings.AbstractMapping
- AbstractModifiableTable - Class in org.apache.calcite.test
-
Abstract base class for implementations of
ModifiableTable
. - AbstractModifiableTable(String) - Constructor for class org.apache.calcite.test.AbstractModifiableTable
- AbstractModifiableView - Class in org.apache.calcite.test
-
Abstract base class for implementations of
ModifiableView
. - AbstractModifiableView() - Constructor for class org.apache.calcite.test.AbstractModifiableView
- AbstractNode - Class in org.apache.calcite.linq4j.tree
-
Abstract implementation of
Node
. - AbstractPreparingTable() - Constructor for class org.apache.calcite.prepare.Prepare.AbstractPreparingTable
- AbstractQueryable<T> - Class in org.apache.calcite.linq4j
-
Abstract implementation of the
Queryable
interface that implements the extension methods. - AbstractQueryable() - Constructor for class org.apache.calcite.linq4j.AbstractQueryable
- AbstractQueryableTable - Class in org.apache.calcite.adapter.java
-
Abstract base class for implementing
Table
. - AbstractQueryableTable(Type) - Constructor for class org.apache.calcite.adapter.java.AbstractQueryableTable
- AbstractRange(long, long) - Constructor for class org.apache.calcite.runtime.SpaceFillingCurve2D.AbstractRange
- AbstractRelNode - Class in org.apache.calcite.rel
-
Base class for every relational expression (
RelNode
). - AbstractRelNode(RelOptCluster, RelTraitSet) - Constructor for class org.apache.calcite.rel.AbstractRelNode
-
Creates an
AbstractRelNode
. - AbstractRelOptPlanner - Class in org.apache.calcite.plan
-
Abstract base for implementations of the
RelOptPlanner
interface. - AbstractRelOptPlanner(RelOptCostFactory, Context) - Constructor for class org.apache.calcite.plan.AbstractRelOptPlanner
-
Creates an AbstractRelOptPlanner.
- AbstractSchema - Class in org.apache.calcite.schema.impl
-
Abstract implementation of
Schema
. - AbstractSchema() - Constructor for class org.apache.calcite.schema.impl.AbstractSchema
- AbstractSchema.Factory - Class in org.apache.calcite.schema.impl
-
Schema factory that creates an
AbstractSchema
. - AbstractSourceMapping - Class in org.apache.calcite.util.mapping
-
Simple implementation of
Mappings.TargetMapping
where the number of sources and targets are specified as constructor parameters, and you just need to implement one method. - AbstractSourceMapping(int, int) - Constructor for class org.apache.calcite.util.mapping.AbstractSourceMapping
- AbstractSqlTester - Class in org.apache.calcite.sql.test
-
Abstract implementation of
SqlTester
that talks to a mock catalog. - AbstractSqlTester() - Constructor for class org.apache.calcite.sql.test.AbstractSqlTester
- AbstractSqlType - Class in org.apache.calcite.sql.type
-
Abstract base class for SQL implementations of
RelDataType
. - AbstractSqlType(SqlTypeName, boolean, List<? extends RelDataTypeField>) - Constructor for class org.apache.calcite.sql.type.AbstractSqlType
-
Creates an AbstractSqlType.
- AbstractSumSplitter() - Constructor for class org.apache.calcite.sql.SqlSplittableAggFunction.AbstractSumSplitter
- AbstractTable - Class in org.apache.calcite.schema.impl
-
Abstract base class for implementing
Table
. - AbstractTable() - Constructor for class org.apache.calcite.schema.impl.AbstractTable
- AbstractTableQueryable<T> - Class in org.apache.calcite.schema.impl
-
Abstract implementation of
Queryable
forQueryableTable
. - AbstractTableQueryable(QueryProvider, SchemaPlus, QueryableTable, String) - Constructor for class org.apache.calcite.schema.impl.AbstractTableQueryable
- AbstractTargetMapping - Class in org.apache.calcite.util.mapping
-
Simple implementation of
Mappings.TargetMapping
where the number of sources and targets are specified as constructor parameters, and you just need to implement one method. - AbstractTargetMapping(int, int) - Constructor for class org.apache.calcite.util.mapping.AbstractTargetMapping
- AbstractTypeCoercion - Class in org.apache.calcite.sql.validate.implicit
-
Base class for all the type coercion rules.
- AbstractUnifyRule(SubstitutionVisitor.Operand, SubstitutionVisitor.Operand, int) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.AbstractUnifyRule
- accAdvance(AggAddContext, Expression, Expression) - Static method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- ACCEL_ONLY_TABLE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
An accel-only table.
- accept(int, K, V) - Method in interface org.apache.calcite.util.Pair.PairWithOrdinalConsumer
-
Performs this operation on the given arguments.
- accept(int, T, U) - Method in interface org.apache.calcite.runtime.PairList.IndexedBiConsumer
-
Performs this operation on the given arguments.
- accept(E) - Method in class org.apache.calcite.util.MonotonicSupplier
- accept(PreparedStatement) - Method in interface org.apache.calcite.test.CalciteAssert.PreparedStatementConsumer
- accept(UnaryOperator<E>) - Method in class org.apache.calcite.util.Holder
-
Applies a transform to the value.
- accept(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.AbstractNode
- accept(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.ClassDeclaration
- accept(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.ConstructorDeclaration
- accept(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.FieldDeclaration
- accept(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.MethodDeclaration
- accept(ExpressionWriter) - Method in interface org.apache.calcite.linq4j.tree.Node
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.AbstractNode
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.BinaryExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.BlockStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ClassDeclaration
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ConditionalStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ConstantExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ConstructorDeclaration
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.DeclarationStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.DefaultExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.DynamicExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.Expression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.FieldDeclaration
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ForEachStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ForStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.FunctionExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.GotoStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.IndexExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.InvocationExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.LabelStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.LambdaExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ListInitExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.MemberDeclaration
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.MemberExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.MemberInitExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.MethodCallExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.MethodDeclaration
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.NewArrayExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.NewExpression
- accept(Shuttle) - Method in interface org.apache.calcite.linq4j.tree.Node
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ParameterExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.Statement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.SwitchStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.TernaryExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ThrowStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.TryStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.TypeBinaryExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.UnaryExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.WhileStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.BinaryExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.BlockStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ClassDeclaration
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ConditionalExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ConditionalStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ConstantExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ConstructorDeclaration
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.DeclarationStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.DefaultExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.DynamicExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.FieldDeclaration
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ForEachStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ForStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.FunctionExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.GotoStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.IndexExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.InvocationExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.LabelStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.LambdaExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ListInitExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.MemberExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.MemberInitExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.MethodCallExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.MethodDeclaration
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.NewArrayExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.NewExpression
- accept(Visitor<R>) - Method in interface org.apache.calcite.linq4j.tree.Node
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ParameterExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.SwitchStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.TernaryExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ThrowStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.TryStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.TypeBinaryExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.UnaryExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.WhileStatement
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonColumn
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonCustomSchema
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonCustomTable
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonFunction
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonJdbcSchema
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonLattice
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonMapSchema
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonMaterialization
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonMeasure
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonSchema
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonTable
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonTile
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonType
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonView
- accept(RelShuttle) - Method in class org.apache.calcite.rel.AbstractRelNode
- accept(RelShuttle) - Method in class org.apache.calcite.rel.core.TableScan
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalAggregate
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalAsofJoin
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalCalc
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalCorrelate
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalExchange
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalFilter
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalIntersect
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalJoin
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalMatch
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalMinus
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalProject
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalSort
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalTableModify
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalUnion
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalValues
- accept(RelShuttle) - Method in interface org.apache.calcite.rel.RelNode
-
Accepts a visit from a shuttle.
- accept(RelShuttle) - Method in class org.apache.calcite.test.SqlToRelTestBase.CustomCorrelate
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexCall
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexCorrelVariable
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexDynamicParam
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexFieldAccess
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexInputRef
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexLambda
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexLambdaRef
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexLiteral
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexLocalRef
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexNode
-
Accepts a visitor with a payload, dispatching to the right overloaded
RexBiVisitor.visitInputRef(RexInputRef, Object)
visitXxx} method. - accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexOver
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexPatternFieldRef
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexRangeRef
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexSubQuery
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexTableInputRef
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexWindowBound
-
Transforms the bound via
RexBiVisitor
. - accept(RexShuttle) - Method in class org.apache.calcite.rel.AbstractRelNode
- accept(RexShuttle) - Method in class org.apache.calcite.rel.core.Calc
- accept(RexShuttle) - Method in class org.apache.calcite.rel.core.Filter
- accept(RexShuttle) - Method in class org.apache.calcite.rel.core.Join
- accept(RexShuttle) - Method in class org.apache.calcite.rel.core.Project
- accept(RexShuttle) - Method in class org.apache.calcite.rel.core.Snapshot
- accept(RexShuttle) - Method in class org.apache.calcite.rel.core.Sort
- accept(RexShuttle) - Method in class org.apache.calcite.rel.core.TableFunctionScan
- accept(RexShuttle) - Method in interface org.apache.calcite.rel.RelNode
-
Accepts a visit from a shuttle.
- accept(RexShuttle) - Method in class org.apache.calcite.rel.rules.MultiJoin
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexCall
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexCorrelVariable
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexDynamicParam
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexFieldAccess
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexInputRef
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexLambda
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexLambdaRef
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexLiteral
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexLocalRef
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexNode
-
Accepts a visitor, dispatching to the right overloaded
visitXxx
method. - accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexOver
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexPatternFieldRef
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexRangeRef
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexSubQuery
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexTableInputRef
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexWindowBound
-
Transforms the bound via
RexVisitor
. - accept(StringAndPos, SqlValidator, SqlNode) - Method in interface org.apache.calcite.sql.test.SqlTester.ValidatedNodeConsumer
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlCall
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlDynamicParam
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlIdentifier
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlLiteral
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlNode
-
Accepts a generic visitor.
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlNodeList
- accept2(ExpressionWriter, boolean) - Method in class org.apache.calcite.linq4j.tree.DeclarationStatement
- acceptCall(SqlVisitor<R>, SqlCall) - Method in class org.apache.calcite.sql.SqlOperator
-
Accepts a
SqlVisitor
, visiting each operand of a call. - acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.fun.SqlConvertFunction
- acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.fun.SqlDotOperator
- acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.SqlAsOperator
- acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.SqlMatchRecognize.SqlMatchRecognizeOperator
- acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.SqlOperator
-
Accepts a
SqlVisitor
, directing anSqlBasicVisitor.ArgHandler
to visit an operand of a call. - acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.SqlOverOperator
-
Accepts a
SqlVisitor
, and tells it to visit each child. - acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.SqlSelectOperator
- acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.SqlSnapshot.SqlSnapshotOperator
- ACCESS - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- accessNotAllowed(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- accessors(Expression, List<Integer>) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
- accessors(Expression, List<Integer>) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- AccessSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Access database. - AccessSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.AccessSqlDialect
-
Creates an AccessSqlDialect.
- accessValue(RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Retrieves the primitive value of a numeric node.
- AccumOperation - Class in org.apache.calcite.runtime
-
Used at run time by the ST_Accum function.
- AccumOperation() - Constructor for class org.apache.calcite.runtime.AccumOperation
- accumulate(Iterable<TSource>, TAccumulate) - Method in class org.apache.calcite.adapter.enumerable.BasicLazyAccumulator
- accumulate(Iterable<TSource>, TAccumulate) - Method in class org.apache.calcite.adapter.enumerable.SourceSorter
- accumulate(Iterable<TSource>, TOrigAccumulate) - Method in interface org.apache.calcite.adapter.enumerable.LazyAggregateLambdaFactory.LazyAccumulator
- accumulator() - Method in interface org.apache.calcite.adapter.enumerable.AggResetContext
-
Returns accumulator variables that should be reset.
- accumulator() - Method in class org.apache.calcite.adapter.enumerable.impl.AggResetContextImpl
- accumulatorAdder - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- accumulatorAdder() - Method in interface org.apache.calcite.adapter.enumerable.AggregateLambdaFactory
- accumulatorAdder() - Method in class org.apache.calcite.adapter.enumerable.BasicAggregateLambdaFactory
- accumulatorAdder() - Method in class org.apache.calcite.adapter.enumerable.LazyAggregateLambdaFactory
- accumulatorInitializer() - Method in interface org.apache.calcite.adapter.enumerable.AggregateLambdaFactory
- accumulatorInitializer() - Method in class org.apache.calcite.adapter.enumerable.BasicAggregateLambdaFactory
- accumulatorInitializer() - Method in class org.apache.calcite.adapter.enumerable.LazyAggregateLambdaFactory
- accumulatorType - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- acos(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ACOS
operator applied to double values. - acos(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ACOS
operator applied to BigDecimal values. - ACOS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ACOS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
ACOS(numeric)
function. - acosd(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ACOSD
operator applied to double values. - acosd(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ACOSD
operator applied to BigDecimal values. - ACOSD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ACOSD - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
ACOSD(numeric)
function; returns the inverse cosine ofvalue
in degrees. - acosh(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ACOSH
operator applied to double values. - acosh(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ACOSH
operator applied to BigDecimal values. - ACOSH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ACOSH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
ACOSH(numeric)
function; returns the inverse hyperbolic cosine ofvalue
. - ACTIVE - Enum constant in enum org.apache.calcite.rel.metadata.NullSentinel
-
Placeholder that means that a request for metadata is already active, therefore this request forms a cycle.
- actualFunctionsToReduce() - Method in interface org.apache.calcite.rel.rules.AggregateReduceFunctionsRule.Config
-
Returns the validated set of functions to reduce, or the default set if not specified.
- adapt(List<T1>, Function1<T1, R>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Deprecated.
- adapt(DoubleFunction1<T1>) - Static method in class org.apache.calcite.linq4j.function.Functions
- adapt(FloatFunction1<T1>) - Static method in class org.apache.calcite.linq4j.function.Functions
- adapt(IntegerFunction1<T1>) - Static method in class org.apache.calcite.linq4j.function.Functions
- adapt(LongFunction1<T1>) - Static method in class org.apache.calcite.linq4j.function.Functions
- adapt(T[], Function1<T, R>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Deprecated.Use
Lists.transform(java.util.List<F>, com.google.common.base.Function<? super F, ? extends T>)
andArrays.asList(Object[])
- ADAPTER_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Convert the interface of a class into another interface clients expect.
- adaptTo(RelNode, List<Integer>, int, int, int) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Creates an equivalent AggregateCall that is adapted to a new input types and/or number of columns in GROUP BY.
- add(double, double) - Method in class org.apache.calcite.interpreter.AggregateNode.DoubleSum
- add(int, int) - Method in class org.apache.calcite.interpreter.AggregateNode.IntSum
- add(int, int, int) - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter1
- add(int, Integer) - Method in class org.apache.calcite.util.ImmutableIntList
- add(int, E) - Method in class org.apache.calcite.util.CastingList
- add(int, E) - Method in class org.apache.calcite.util.ChunkList
- add(int, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIdentifier
-
Returns an identifier that is the same as this except with a component added at a given position.
- add(int, SqlNode) - Method in class org.apache.calcite.sql.SqlNodeList
- add(int, T, U) - Method in interface org.apache.calcite.runtime.PairList
-
Adds a pair to this list at a given position.
- add(long, int) - Static method in class org.apache.calcite.util.Smalls.MyStaticSumFunction
- add(long, int) - Method in class org.apache.calcite.util.Smalls.MySumFunction
- add(long, int, int, int) - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter2
- add(long, int, String) - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter2
- add(long, int, String, String) - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter1
- add(long, long) - Method in class org.apache.calcite.interpreter.AggregateNode.LongSum
- add(short, int) - Method in class org.apache.calcite.util.Smalls.SumFunctionBadIAdd
- add(E) - Method in class org.apache.calcite.linq4j.MemoryFactory
- add(Integer) - Method in class org.apache.calcite.util.ImmutableIntList
- add(E) - Method in class org.apache.calcite.util.ChunkList
- add(E) - Method in class org.apache.calcite.util.Closer
-
Registers a resource.
- add(E) - Method in class org.apache.calcite.util.EquivalenceSet
-
Adds an element, and returns the element (which is its own parent).
- add(E) - Method in class org.apache.calcite.util.ImmutableNullableList.Builder
-
Adds
element
to theImmutableNullableList
. - add(E) - Method in class org.apache.calcite.util.ImmutableNullableSet.Builder
-
Adds
element
to theImmutableNullableSet
. - add(E) - Method in class org.apache.calcite.util.PartiallyOrderedSet
-
Adds an element to this lattice.
- add(E...) - Method in class org.apache.calcite.util.ImmutableNullableList.Builder
-
Adds each element of
elements
to theImmutableNullableList
. - add(E...) - Method in class org.apache.calcite.util.ImmutableNullableSet.Builder
-
Adds each element of
elements
to theImmutableNullableSet
. - add(String, String) - Method in class org.apache.calcite.adapter.mongodb.MongoRel.Implementor
- add(Double, Double) - Static method in class org.apache.calcite.util.NumberUtil
-
Returns the sum of two numbers, or null if either is null.
- add(Boolean, Boolean) - Method in class org.apache.calcite.interpreter.AggregateNode.MaxBoolean
- add(Boolean, Boolean) - Method in class org.apache.calcite.interpreter.AggregateNode.MinBoolean
- add(Class<?>, String) - Method in class org.apache.calcite.schema.impl.ReflectiveFunctionBase.ParameterListBuilder
- add(Class<?>, String, boolean) - Method in class org.apache.calcite.schema.impl.ReflectiveFunctionBase.ParameterListBuilder
- add(Integer, Integer) - Method in class org.apache.calcite.util.Smalls.MySum3
- add(String) - Method in class org.apache.calcite.util.NameSet
- add(String, Predicate<MemoryFactory.Memory<E>>) - Method in class org.apache.calcite.runtime.Matcher.Builder
-
Associates a predicate with a symbol.
- add(String, TimeUnit, int, TimeUnit, int) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Adds a field with an interval type.
- add(String, TimeUnit, int, TimeUnit, int) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- add(String, Lattice) - Method in interface org.apache.calcite.schema.SchemaPlus
-
Adds a lattice to this schema.
- add(String, RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Adds a field with given name and type.
- add(String, RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- add(String, RelProtoDataType) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Defines a type within this schema.
- add(String, RelProtoDataType) - Method in interface org.apache.calcite.schema.SchemaPlus
-
Adds a type to this schema.
- add(String, Function) - Method in interface org.apache.calcite.schema.SchemaPlus
-
Adds a function to this schema.
- add(String, Schema) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
-
Adds a child schema of this schema.
- add(String, Schema) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds a child schema of this schema.
- add(String, Schema) - Method in interface org.apache.calcite.schema.SchemaPlus
-
Adds a schema as a sub-schema of this schema, and returns the wrapped object.
- add(String, Schema) - Static method in class org.apache.calcite.test.ConnectionFactories
-
Returns a post-processor that adds
Schema
and sets it as default. - add(String, Table) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Defines a table within this schema.
- add(String, Table) - Method in interface org.apache.calcite.schema.SchemaPlus
-
Adds a table to this schema.
- add(String, Table, ImmutableList<String>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Defines a table within this schema.
- add(String, SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Adds a field with a type created using
RelDataTypeFactory.createSqlType(org.apache.calcite.sql.type.SqlTypeName)
. - add(String, SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- add(String, SqlTypeName, int) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Adds a field with a type created using
RelDataTypeFactory.createSqlType(org.apache.calcite.sql.type.SqlTypeName, int)
. - add(String, SqlTypeName, int) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- add(String, SqlTypeName, int, int) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Adds a field with a type created using
RelDataTypeFactory.createSqlType(org.apache.calcite.sql.type.SqlTypeName, int, int)
. - add(String, SqlTypeName, int, int) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- add(BigDecimal, BigDecimal) - Method in class org.apache.calcite.interpreter.AggregateNode.BigDecimalSum
- add(Map<String, String>, List<String>) - Method in class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
-
Adds newly projected fields and restricted predicates.
- add(Consumer<T>) - Method in enum org.apache.calcite.runtime.Hook
-
Deprecated.this installs a global hook (cross-thread), so it might have greater impact than expected. Use with caution. Prefer thread-local hooks.
- add(Function<T, R>) - Method in enum org.apache.calcite.runtime.Hook
-
Deprecated.Use
Hook.add(Consumer)
. - add(Predicate<Puffin.Line<G, F>>, Consumer<Puffin.Line<G, F>>) - Method in interface org.apache.calcite.util.Puffin.Builder
-
Adds a predicate and action to be invoked on each line of a source.
- add(List<Geometry>, Geometry) - Method in class org.apache.calcite.runtime.AccumOperation
- add(List<Geometry>, Geometry) - Method in class org.apache.calcite.runtime.CollectOperation
- add(List<Geometry>, Geometry) - Method in class org.apache.calcite.runtime.UnionOperation
- add(Expression) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- add(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic addition operation that does not have overflow checking.
- add(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic addition operation that does not have overflow checking.
- add(Statement) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- add(RelDataTypeField) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Adds a field.
- add(RelDataTypeField) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- add(Table) - Method in class org.apache.calcite.schema.impl.StarTable
- add(SqlNode) - Method in class org.apache.calcite.sql.SqlNodeList
- add(SqlAbstractParserImpl) - Method in class org.apache.calcite.sql.parser.Span
-
Adds the position of the last token emitted by a parser to the list, and returns this Span.
- add(SqlParserPos) - Method in class org.apache.calcite.sql.parser.Span
-
Adds a position to the list, and returns this Span.
- add(SqlNode) - Method in class org.apache.calcite.sql.parser.Span
-
Adds a node's position to the list, and returns this Span.
- add(SqlOperator) - Method in class org.apache.calcite.sql.util.ListSqlOperatorTable
-
Deprecated.Use
SqlOperatorTables.of(java.lang.Iterable<? extends org.apache.calcite.sql.SqlOperator>)
, which creates an immutable table. - add(SqlOperatorTable) - Method in class org.apache.calcite.sql.util.ChainedSqlOperatorTable
-
Deprecated.
- add(CalciteAssert.SchemaSpec) - Static method in class org.apache.calcite.test.ConnectionFactories
-
Returns a post-processor that adds a
CalciteAssert.SchemaSpec
(set of schemes) to a connection. - add(T, T) - Method in class org.apache.calcite.interpreter.AggregateNode.NumericComparison
- add(T, U) - Method in interface org.apache.calcite.runtime.PairList
-
Adds a pair to this list.
- add(T, U) - Method in class org.apache.calcite.runtime.PairList.Builder
-
Adds a pair to the list under construction.
- Add - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An addition operation, such as a + b, without overflow checking, for numeric operands.
- ADD_MONTHS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ADD_MONTHS
function (Oracle, Spark). - ADD_MONTHS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ADD_MONTHS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ADD_MONTHS(start_date, num_months)" function (SPARK) Returns the date that is num_months after start_date.
- ADD_MONTHS_INT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- add2(PairList<RexNode, String>, int, List<RelDataTypeField>) - Static method in class org.apache.calcite.rex.RexInputRef
-
Adds to a PairList a reference to a given field in a list of fields.
- addAggCall(AggregateCall, int, boolean, List<AggregateCall>, Map<AggregateCall, RexNode>, List<RelDataType>) - Method in class org.apache.calcite.rex.RexBuilder
-
Deprecated.
- addAggCall(AggregateCall, int, List<AggregateCall>, Map<AggregateCall, RexNode>, List<RelDataType>) - Method in class org.apache.calcite.rex.RexBuilder
-
Deprecated.
- addAggCall(AggregateCall, int, List<AggregateCall>, Map<AggregateCall, RexNode>, IntPredicate) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a reference to an aggregate call, checking for repeated calls.
- addAggregateFunctions(Map<String, String>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- addAlias(String, String) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Defines an alias for an existing frame.
- addAlias(SqlNode, String) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Converts an expression "expr" into "expr AS alias".
- addAlias(SqlOperator, SqlOperator) - Method in class org.apache.calcite.sql2rel.ReflectiveConvertletTable
-
Registers that one operator is an alias for another.
- addAll(int, Collection<? extends Integer>) - Method in class org.apache.calcite.util.ImmutableIntList
- addAll(int, Collection<? extends SqlNode>) - Method in class org.apache.calcite.sql.SqlNodeList
- addAll(int, PairList<T, U>) - Method in interface org.apache.calcite.runtime.PairList
-
Adds to this list, at a given index, the contents of another PairList.
- addAll(Iterable<? extends E>) - Method in class org.apache.calcite.util.ImmutableNullableList.Builder
-
Adds each element of
elements
to theImmutableNullableList
. - addAll(Iterable<? extends E>) - Method in class org.apache.calcite.util.ImmutableNullableSet.Builder
-
Adds each element of
elements
to theImmutableNullableSet
. - addAll(Iterable<? extends Map.Entry<String, RelDataType>>) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Adds all fields in a collection.
- addAll(Iterable<? extends Map.Entry<String, RelDataType>>) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- addAll(Iterable<? extends SqlNode>) - Method in class org.apache.calcite.sql.parser.Span
-
Adds the positions of a collection of nodes to the list, and returns this Span.
- addAll(Iterable<Integer>) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Sets all bits in a given list of bits.
- addAll(Collection<? extends Integer>) - Method in class org.apache.calcite.util.ImmutableIntList
- addAll(Collection<? extends SqlNode>) - Method in class org.apache.calcite.sql.SqlNodeList
- addAll(Iterator<? extends E>) - Method in class org.apache.calcite.util.ImmutableNullableList.Builder
-
Adds each element of
elements
to theImmutableNullableList
. - addAll(Iterator<? extends E>) - Method in class org.apache.calcite.util.ImmutableNullableSet.Builder
-
Adds each element of
elements
to theImmutableNullableSet
. - addAll(TimeFrameSet) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Adds all time frames in
timeFrameSet
to thisBuilder
. - addAll(PairList<T, U>) - Method in interface org.apache.calcite.runtime.PairList
-
Adds to this list the contents of another PairList.
- addAll(ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Sets all bits in a given bit set.
- addAll(ImmutableIntList) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Sets all bits in a given list of
int
s. - addAssign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an addition assignment operation that does not have overflow checking.
- addAssign(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an addition assignment operation that does not have overflow checking.
- addAssign(Expression, Expression, Method, LambdaExpression, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an addition assignment operation that does not have overflow checking.
- AddAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An addition compound assignment operation, such as (a += b), without overflow checking, for numeric operands.
- addAssignChecked(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an addition assignment operation that has overflow checking.
- addAssignChecked(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an addition assignment operation that has overflow checking.
- addAssignChecked(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an addition assignment operation that has overflow checking.
- AddAssignChecked - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An addition compound assignment operation, such as (a += b), with overflow checking, for numeric operands.
- addCarets() - Method in class org.apache.calcite.sql.parser.StringAndPos
- addCarets(String, int, int, int, int) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Converts a string to a string with one or two carets in it.
- addCharsetAndCollation(RelDataType, RelDataTypeFactory) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Adds collation and charset to a character type, returns other types unchanged.
- addChecked(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic addition operation that has overflow checking.
- addChecked(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic addition operation that has overflow checking.
- AddChecked - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An addition operation, such as (a + b), with overflow checking, for numeric operands.
- addChild(SqlValidatorNamespace, String, boolean) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- addChild(SqlValidatorNamespace, String, boolean) - Method in class org.apache.calcite.sql.validate.ParameterScope
- addChild(SqlValidatorNamespace, String, boolean) - Method in class org.apache.calcite.sql.validate.JoinScope
- addChild(SqlValidatorNamespace, String, boolean) - Method in class org.apache.calcite.sql.validate.ListScope
- addChild(SqlValidatorNamespace, String, boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Registers a relation in this scope.
- addColumn(String, RelDataType) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- addColumn(String, RelDataType, boolean) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- addColumnNames(SqlValidatorNamespace, List<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- addCommonRelSubExprInstruction() - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to attempt to match instances of
CommonRelSubExprRule
, but only in cases where vertices have more than one parent. - addCondition(RexNode) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Sets the condition of the program.
- addConvertedNonCorrSubqs(Map<SqlNode, RexNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Adds to the current map of non-correlated converted sub-queries the elements from another map that contains non-correlated sub-queries that have been converted by another SqlToRelConverter.
- addConverters(boolean) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to attempt to match instances of
ConverterRule
, but only where a conversion is actually required. - addCore(String) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Defines a core time frame.
- addDate(int, int, TimeFrame) - Method in class org.apache.calcite.rel.type.TimeFrameSet
- addDiffMask(String) - Method in class org.apache.calcite.test.DiffTestCase
-
Adds a diff mask.
- addDimension(Lattice.Column) - Method in class org.apache.calcite.materialize.Lattice.TileBuilder
- addDivision(String, Number, String) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Defines a time frame such that each base frame consists of
count
instances of the new frame. - addedDeclarations - Variable in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
The list of new final static fields to be added to the current class.
- addEdge(V, V) - Method in class org.apache.calcite.util.graph.AttributedDirectedGraph
-
Deprecated.
- addEdge(V, V) - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- addEdge(V, V) - Method in interface org.apache.calcite.util.graph.DirectedGraph
-
Adds an edge to this graph.
- addEdge(V, V, Object...) - Method in class org.apache.calcite.util.graph.AttributedDirectedGraph
- addEpsilon(double) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Add an epsilon to the value passed in.
- addEquivalenceClass(RexTableInputRef, RexTableInputRef) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule.EquivalenceClasses
- addExpr(RexNode) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Adds an expression to the list of common expressions, and returns a reference to the expression.
- addExpressionForReuse(DeclarationStatement) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- addFile(String) - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- addFunctions(SchemaPlus, String, List<String>, String, String, boolean) - Static method in class org.apache.calcite.model.ModelHandler
-
Creates and validates a
ScalarFunctionImpl
, and adds it to a schema. - addGroupBegin() - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to begin a group of rules.
- addGroupBy(List<String>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- addGroupEnd() - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to end a group of rules, firing the group collectively.
- addIdentity() - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Adds a project item for every input field.
- addIf(SqlNode) - Method in class org.apache.calcite.sql.parser.Span
-
Adds a node's position to the list if the node is not null, and returns this Span.
- addIgnorePattern(String) - Method in class org.apache.calcite.test.DiffTestCase
- addImplicitFuncNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- addImplicitFuncNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit function names to a builder.
- addImplicitFunctionsToBuilder(ImmutableList.Builder<Function>, String, boolean) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- addImplicitFunctionsToBuilder(ImmutableList.Builder<Function>, String, boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit functions to a builder.
- addImplicitSubSchemaToBuilder(ImmutableSortedMap.Builder<String, CalciteSchema>) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- addImplicitSubSchemaToBuilder(ImmutableSortedMap.Builder<String, CalciteSchema>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit sub-schemas to a builder.
- addImplicitTablesBasedOnNullaryFunctionsToBuilder(ImmutableSortedMap.Builder<String, Table>) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- addImplicitTablesBasedOnNullaryFunctionsToBuilder(ImmutableSortedMap.Builder<String, Table>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit table functions to a builder.
- addImplicitTableToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- addImplicitTableToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit tables to a builder.
- addImplicitTypeNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- addImplicitTypeNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit type names to a builder.
- addLattice(RelOptLattice) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- addLattice(RelOptLattice) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Defines a lattice.
- addLattice(RelOptLattice) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- addListener(RelOptListener) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- addListener(RelOptListener) - Method in class org.apache.calcite.plan.MulticastRelOptListener
-
Adds a listener which will receive multicast events.
- addListener(RelOptListener) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Adds a listener to this planner.
- addMatch(VolcanoRuleMatch) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Add a RuleMatch into the queue.
- addMatchLimit(int) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to limit the number of pattern matches for subsequent instructions.
- addMatchOrder(HepMatchOrder) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to change the order of pattern matching for subsequent instructions.
- addMaterialization(RelOptMaterialization) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- addMaterialization(RelOptMaterialization) - Method in class org.apache.calcite.plan.hep.HepPlanner
- addMaterialization(RelOptMaterialization) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Defines a pair of relational expressions that are equivalent.
- addMaterialization(RelOptMaterialization) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- addMeasure(Lattice.Measure) - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Adds a measure, if it does not already exist.
- addMeasure(Lattice.Measure) - Method in class org.apache.calcite.materialize.Lattice.TileBuilder
- addMethod - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- addMethodParameters(Method) - Method in class org.apache.calcite.schema.impl.ReflectiveFunctionBase.ParameterListBuilder
- addMonotonic(String) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- addMultiple(String, Number, String) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Defines a time frame that consists of
count
instances of a base frame. - addOrder(List<String>) - Method in class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
- addOrderByFields(List<String>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- addOrderItem(List<SqlNode>, RelFieldCollation) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- addPatternVar(String) - Method in class org.apache.calcite.sql.validate.MatchRecognizeScope
- AddPointOperation - Class in org.apache.calcite.runtime
-
Geometry editor operation that adds a point to a geometry.
- AddPointOperation(Geometry, int) - Constructor for class org.apache.calcite.runtime.AddPointOperation
- addPredicates(List<String>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
-
Adds new restricted predicates.
- addProject(int, int, String) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Adds a projection based upon the
index
th expression at a given position. - addProject(int, String) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Adds a projection based upon the
index
th expression. - addProject(int, RexNode, String) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Adds a project expression to the program at a given position.
- addProject(RexNode, String) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Adds a project expression to the program.
- addQuery(RelNode) - Method in class org.apache.calcite.materialize.LatticeSuggester
-
Adds a query.
- addQuotient(String, String, String) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Defines a time frame that is the number of a minor unit within a major frame.
- addRelBuilderConfigTransform(UnaryOperator<RelBuilder.Config>) - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Adds a transform to
SqlToRelConverter.Config.getRelBuilderConfigTransform()
. - addRelTraitDef(RelTraitDef) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- addRelTraitDef(RelTraitDef) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Registers a rel trait definition.
- addRelTraitDef(RelTraitDef) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- addRemovableOuterJoinFactor(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Adds a join factor to the set of factors that can be removed because the factor is the null-generating factor in an outer join, its join keys are unique, and the factor is not projected in the query.
- addRemovableSelfJoinPair(int, int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Adds to a map that keeps track of removable self-join pairs.
- addRollup(String, String) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Defines a rollup from one frame to another.
- addRule(RelOptRule) - Method in interface org.apache.calcite.jdbc.CalcitePrepare.SparkHandler.RuleSetBuilder
- addRule(RelOptRule) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- addRule(RelOptRule) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Registers a rule.
- addRule(RelOptRule) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- addRule(RelOptRule) - Method in class org.apache.calcite.test.MockRelOptPlanner
- addRuleByDescription(String) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to attempt to match a specific rule identified by its unique description.
- addRuleClass(Class<R>) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to attempt to match any rules of a given class.
- addRuleCollection(Collection<RelOptRule>) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to attempt to match any rules in a given collection.
- addRuleInstance(RelOptRule) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to attempt to match a specific rule object.
- addSchema(SchemaPlus, CalciteAssert.SchemaSpec...) - Static method in class org.apache.calcite.test.CalciteAssert
-
Adds a schema specification (or specifications) to the root schema, returning the last one created.
- addSelect(List<SqlNode>, SqlNode, RelDataType) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- addSelect(List<SqlNode>, SqlNode, RelDataType) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- addSelectFields(Map<String, String>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
-
Adds new projected fields.
- addSelectFields(Map<String, String>) - Method in class org.apache.calcite.adapter.innodb.InnodbRel.Implementor
- addStatement(String) - Method in class org.apache.calcite.adapter.pig.PigRel.Implementor
- addStatement(CalciteConnection, Meta.StatementHandle) - Method in interface org.apache.calcite.server.CalciteServer
- addSubprogram(HepProgram) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to execute a subprogram.
- addTable(String) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockSchema
- addThread(Function<T, R>) - Method in enum org.apache.calcite.runtime.Hook
-
Deprecated.
- addThread(Consumer<T>) - Method in enum org.apache.calcite.runtime.Hook
-
Adds a handler for this thread.
- addTile(Lattice.Tile) - Method in class org.apache.calcite.materialize.Lattice.Builder
- addTimestamp(long, long, TimeFrame) - Method in class org.apache.calcite.rel.type.TimeFrameSet
- addToSelectList(List<SqlNode>, Set<String>, List<Map.Entry<String, RelDataType>>, SqlNode, SelectScope, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Adds an expression to a select list, ensuring that its alias does not clash with any existing expressions on the list.
- addTrait(T, RelTrait) - Static method in class org.apache.calcite.plan.RelOptUtil
- addType(String, RelProtoDataType) - Static method in class org.apache.calcite.test.ConnectionFactories
-
Returns a post-processor that adds a type.
- addVertex(V) - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- addVertex(V) - Method in interface org.apache.calcite.util.graph.DirectedGraph
-
Adds a vertex to this graph.
- addWindowName(String) - Method in class org.apache.calcite.sql.validate.SelectScope
- addWrap(Object) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- AddZTransformer - Class in org.apache.calcite.runtime
-
Operation that adds a z value to a geometry.
- AddZTransformer(double) - Constructor for class org.apache.calcite.runtime.AddZTransformer
- adjacents(Iterable<? extends T>) - Static method in class org.apache.calcite.util.Pair
-
Returns an iterator that iterates over (i, i + 1) pairs in an iterable.
- adjustInputRef(SqlToRelConverter.Blackboard, RexInputRef) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Adjusts the type of a reference to an input field to account for nulls introduced by outer joins; and adjusts the offset to match the physical implementation.
- adjustKeys(List<Integer>, int) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Adjusts key values in a list by some fixed amount.
- adjustType(SqlValidator, SqlCall, RelDataType) - Method in class org.apache.calcite.sql.SqlBinaryOperator
- adjustType(SqlValidator, SqlCall, RelDataType) - Method in class org.apache.calcite.sql.SqlOperator
-
Validates and determines coercibility and resulting collation name of binary operator if needed.
- adjustType(SqlValidator, SqlCall, RelDataType) - Method in class org.apache.calcite.sql.SqlPostfixOperator
- adjustType(SqlValidator, SqlCall, RelDataType) - Method in class org.apache.calcite.sql.SqlPrefixOperator
- adjustTypeForArrayConstructor(RelDataType, SqlOperatorBinding) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
When the array element does not equal the array component type, make explicit casting.
- adjustTypeForArrayFunctions(RelDataType, SqlOperatorBinding, int...) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Adjusts the types of specified operands in an array operation to match a given target type.
- adjustTypeForMapConstructor(Pair<RelDataType, RelDataType>, SqlOperatorBinding) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
When the map key or value does not equal the map component key type or value type, make explicit casting.
- ADMIN - Enum constant in enum org.apache.calcite.chinook.EnvironmentFairy.User
- adoptConvention(Convention) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns new RelBuilder that adopts the convention provided.
- after - Variable in class org.apache.calcite.rel.core.Match
- after - Variable in class org.apache.calcite.rel.mutable.MutableMatch
- after() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- after(Consumer<Puffin.Context<G, F>>) - Method in interface org.apache.calcite.util.Puffin.Builder
-
Adds an action to be called after all sources.
- afterSource(Consumer<Puffin.Context<G, F>>) - Method in interface org.apache.calcite.util.Puffin.Builder
-
Adds an action to be called after each source.
- afterTableFunction(SqlToRelConverter.Blackboard, SqlCall, LogicalTableFunctionScan) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- agg - Variable in class org.apache.calcite.materialize.Lattice.Measure
- agg - Variable in class org.apache.calcite.model.JsonMeasure
-
The name of an aggregate function.
- AGG_FIRST - Static variable in interface org.apache.calcite.rel.rules.AggregateUnionAggregateRule.Config
- AGG_INDEX - Enum constant in enum org.apache.calcite.adapter.enumerable.WinAggImplementor.SeekType
-
The index of row that is aggregated.
- AGG_LAMBDA_FACTORY_ACC_ADDER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AGG_LAMBDA_FACTORY_ACC_INITIALIZER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AGG_LAMBDA_FACTORY_ACC_RESULT_SELECTOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AGG_LAMBDA_FACTORY_ACC_SINGLE_GROUP_RESULT_SELECTOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AGG_M2M - Enum constant in enum org.apache.calcite.sql.SqlKind
-
AGG_M2M
(aggregate measure to measure) internal aggregate function. - AGG_M2M - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
AGG_M2M
aggregate function takes a measure as its argument and returns a measure. - AGG_M2V - Enum constant in enum org.apache.calcite.sql.SqlKind
-
AGG_M2V
(aggregate measure to value) internal aggregate function. - AGG_M2V - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
AGG_M2V
aggregate function takes a measure as its argument and returns value. - AGG_SECOND - Static variable in interface org.apache.calcite.rel.rules.AggregateUnionAggregateRule.Config
- AGG_SUM - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy for SUM aggregate function inferred from the operand type, and nullable if the call occurs within a "GROUP BY ()" query.
- AGG_SUM_EMPTY_IS_ZERO - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy for $SUM0 aggregate function inferred from the operand type.
- AggAddContext - Interface in org.apache.calcite.adapter.enumerable
-
Information for a call to
AggImplementor.implementAdd(AggContext, AggAddContext)
. - AggAddContextImpl - Class in org.apache.calcite.adapter.enumerable.impl
-
Implementation of
AggAddContext
. - AggAddContextImpl(BlockBuilder, List<Expression>) - Constructor for class org.apache.calcite.adapter.enumerable.impl.AggAddContextImpl
- AggCallBinding(RelDataTypeFactory, SqlAggFunction, List<RelDataType>, int, boolean) - Constructor for class org.apache.calcite.rel.core.Aggregate.AggCallBinding
-
Deprecated.
- AggCallBinding(RelDataTypeFactory, SqlAggFunction, List<RelDataType>, List<RelDataType>, int, boolean) - Constructor for class org.apache.calcite.rel.core.Aggregate.AggCallBinding
-
Creates an AggCallBinding.
- aggCalls - Variable in class org.apache.calcite.rel.core.Aggregate
- aggCalls - Variable in class org.apache.calcite.rel.core.Window.Group
-
List of
Window.RexWinAggCall
objects, each of which is a call to aSqlAggFunction
. - aggCalls - Variable in class org.apache.calcite.rel.mutable.MutableAggregate
- AggContext - Interface in org.apache.calcite.adapter.enumerable
-
Information on the aggregate calculation context.
- aggIdx - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- AggImplementor - Interface in org.apache.calcite.adapter.enumerable
-
Implements an aggregate function by generating expressions to initialize, add to, and get a result from, an accumulator.
- AggImpState - Class in org.apache.calcite.adapter.enumerable
-
Represents internal state when implementing aggregate functions.
- AggImpState(int, AggregateCall, boolean) - Constructor for class org.apache.calcite.adapter.enumerable.AggImpState
- aggList - Variable in class org.apache.calcite.sql.SqlPivot
- aggregate(TAccumulate, Function2<TAccumulate, T, TAccumulate>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- aggregate(TAccumulate, Function2<TAccumulate, TSource, TAccumulate>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Applies an accumulator function over a sequence.
- aggregate(List<Map.Entry<String, Class>>, List<String>) - Method in class org.apache.calcite.adapter.mongodb.MongoTable.MongoQueryable
-
Called via code-generation.
- aggregate(Enumerable<TSource>, Function2<TSource, TSource, TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Applies an accumulator function over a sequence.
- aggregate(Enumerable<TSource>, TAccumulate, Function2<TAccumulate, TSource, TAccumulate>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Applies an accumulator function over a sequence.
- aggregate(Enumerable<TSource>, TAccumulate, Function2<TAccumulate, TSource, TAccumulate>, Function1<TAccumulate, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Applies an accumulator function over a sequence.
- aggregate(Function2<T, T, T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- aggregate(Function2<TSource, TSource, TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Applies an accumulator function over a sequence.
- aggregate(Queryable<T>, FunctionExpression<Function2<T, T, T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Applies an accumulator function over a sequence.
- aggregate(Queryable<T>, FunctionExpression<Function2<T, T, T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- aggregate(Queryable<T>, FunctionExpression<Function2<T, T, T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Applies an accumulator function over a sequence.
- aggregate(Queryable<T>, TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Applies an accumulator function over a sequence.
- aggregate(Queryable<T>, TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Applies an accumulator function over a sequence.
- aggregate(Queryable<T>, TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- aggregate(Queryable<T>, TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>, FunctionExpression<Function1<TAccumulate, TResult>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Applies an accumulator function over a sequence.
- aggregate(Queryable<T>, TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>, FunctionExpression<Function1<TAccumulate, TResult>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Applies an accumulator function over a sequence.
- aggregate(Queryable<T>, TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>, FunctionExpression<Function1<TAccumulate, TResult>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- aggregate(FunctionExpression<Function2<T, T, T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- aggregate(FunctionExpression<Function2<T, T, T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Applies an accumulator function over a sequence.
- aggregate(RelBuilder.GroupKey, Iterable<? extends RelBuilder.AggCall>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
Aggregate
with multiple calls. - aggregate(RelBuilder.GroupKey, List<AggregateCall>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
Aggregate
with an array ofAggregateCall
s. - aggregate(RelBuilder.GroupKey, RelBuilder.AggCall...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
Aggregate
with an array of calls. - aggregate(TAccumulate, Function2<TAccumulate, T, TAccumulate>, Function1<TAccumulate, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- aggregate(TAccumulate, Function2<TAccumulate, TSource, TAccumulate>, Function1<TAccumulate, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Applies an accumulator function over a sequence.
- aggregate(TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- aggregate(TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>, FunctionExpression<Function1<TAccumulate, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- aggregate(TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Applies an accumulator function over a sequence.
- aggregate(TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>, FunctionExpression<Function1<TAccumulate, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Applies an accumulator function over a sequence.
- Aggregate - Class in org.apache.calcite.rel.core
-
Relational operator that eliminates duplicates and computes totals.
- Aggregate(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.rel.core.Aggregate
-
Creates an Aggregate.
- Aggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.rel.core.Aggregate
-
Deprecated.
- Aggregate(RelOptCluster, RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.rel.core.Aggregate
-
Deprecated.
- Aggregate(RelInput) - Constructor for class org.apache.calcite.rel.core.Aggregate
-
Creates an Aggregate by parsing serialized output.
- AGGREGATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AGGREGATE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- AGGREGATE - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
Aggregate
nodes. - AGGREGATE - Static variable in class org.apache.calcite.rel.rules.materialize.MaterializedViewRules
-
Rule that matches
Aggregate
. - AGGREGATE - Static variable in class org.apache.calcite.rel.rules.MeasureRules
- AGGREGATE - Static variable in interface org.apache.calcite.rel.rules.PruneEmptyRules.RemoveEmptySingleRule.RemoveEmptySingleRuleConfig
- AGGREGATE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "AGGREGATE(m)" aggregate function; aggregates a measure column according to the measure's rollup strategy.
- AGGREGATE - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category consisting of all built-in aggregate functions.
- AGGREGATE_ANY_PULL_UP_CONSTANTS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
More general form of
CoreRules.AGGREGATE_PROJECT_PULL_UP_CONSTANTS
that matches any relational expression. - AGGREGATE_CASE_TO_FILTER - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that converts CASE-style filtered aggregates into true filtered aggregates.
- AGGREGATE_EXPAND_DISTINCT_AGGREGATES - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that expands distinct aggregates (such as
COUNT(DISTINCT x)
) from aAggregate
. - AGGREGATE_EXPAND_DISTINCT_AGGREGATES_TO_JOIN - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.AGGREGATE_EXPAND_DISTINCT_AGGREGATES
but generates a Join. - AGGREGATE_EXPAND_WITHIN_DISTINCT - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that rewrites a
LogicalAggregate
that containsWITHIN DISTINCT
aggregate functions to one that does not. - AGGREGATE_FACTORY - Static variable in class org.apache.calcite.adapter.jdbc.JdbcRules
- AGGREGATE_FILTER_TRANSPOSE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- AGGREGATE_FILTER_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_FN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
AGGREGATE
aggregate function. - AGGREGATE_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts an
Aggregate
to empty if its child is empty. - AGGREGATE_JOIN_JOIN_REMOVE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_JOIN_REMOVE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_JOIN_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_JOIN_TRANSPOSE_EXTENDED - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.AGGREGATE_JOIN_TRANSPOSE
, but extended to push down aggregate functions. - AGGREGATE_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_PROJECT - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- AGGREGATE_PROJECT_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_PROJECT_PULL_UP_CONSTANTS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that removes constant keys from an
Aggregate
. - AGGREGATE_PROJECT_STAR_TABLE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Variant of
CoreRules.AGGREGATE_STAR_TABLE
that accepts aProject
between theAggregate
and itsStarTable.StarTableScan
input. - AGGREGATE_REDUCE_FUNCTIONS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that reduces aggregate functions in an
Aggregate
to simpler forms. - AGGREGATE_REMOVE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that removes an
Aggregate
if it computes no aggregate functions (that is, it is implementingSELECT DISTINCT
), or all the aggregate functions are splittable, and the underlying relational expression is already distinct. - AGGREGATE_STAR_TABLE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that matches an
Aggregate
on aStarTable.StarTableScan
. - AGGREGATE_UNION_AGGREGATE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_UNION_AGGREGATE_FIRST - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.AGGREGATE_UNION_AGGREGATE
, but matches anAggregate
only as the left input of theUnion
. - AGGREGATE_UNION_AGGREGATE_SECOND - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.AGGREGATE_UNION_AGGREGATE
, but matches anAggregate
only as the right input of theUnion
. - AGGREGATE_UNION_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_VALUES - Static variable in class org.apache.calcite.rel.rules.CoreRules
- Aggregate.AggCallBinding - Class in org.apache.calcite.rel.core
-
Implementation of the
SqlOperatorBinding
interface for anaggregate call
applied to a set of operands in the context of aLogicalAggregate
. - Aggregate.Group - Enum in org.apache.calcite.rel.core
-
Describes the kind of roll-up.
- Aggregate.PercentileDiscAggCallBinding - Class in org.apache.calcite.rel.core
-
Used for PERCENTILE_DISC return type inference.
- AGGREGATE2 - Static variable in class org.apache.calcite.rel.rules.MeasureRules
- aggregateCall - Variable in class org.apache.calcite.sql.validate.SqlValidatorUtil.FlatAggregate
- aggregateCall(AggregateCall) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to an aggregate function as a copy of an
AggregateCall
. - aggregateCall(AggregateCall, Mapping) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to an aggregate function as a copy of an
AggregateCall
, applying a mapping. - aggregateCall(SqlParserPos, SqlAggFunction, boolean, boolean, boolean, RexNode, ImmutableList<RexNode>, ImmutableList<RexNode>, String, ImmutableList<RexNode>, ImmutableList<RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to an aggregate function with all applicable operands.
- aggregateCall(SqlParserPos, SqlAggFunction, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to an aggregate function.
- aggregateCall(SqlParserPos, SqlAggFunction, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to an aggregate function.
- aggregateCall(SqlAggFunction, boolean, boolean, boolean, RexNode, ImmutableList<RexNode>, ImmutableList<RexNode>, String, ImmutableList<RexNode>, ImmutableList<RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to an aggregate function with all applicable operands.
- aggregateCall(SqlAggFunction, boolean, boolean, RexNode, String, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Deprecated.
- aggregateCall(SqlAggFunction, boolean, boolean, RexNode, String, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Deprecated.
- aggregateCall(SqlAggFunction, boolean, RexNode, String, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Deprecated.
- aggregateCall(SqlAggFunction, boolean, RexNode, String, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Deprecated.
- aggregateCall(SqlAggFunction, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to an aggregate function.
- aggregateCall(SqlAggFunction, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to an aggregate function.
- AggregateCall - Class in org.apache.calcite.rel.core
-
Call to an aggregate function within an
Aggregate
. - AggregateCall(SqlAggFunction, boolean, List<Integer>, RelDataType, String) - Constructor for class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- aggregateCalls - Variable in class org.apache.calcite.rel.core.Match
- aggregateCallsPreVar - Variable in class org.apache.calcite.rel.core.Match
- AggregateCaseToFilterRule - Class in org.apache.calcite.rel.rules
-
Rule that converts CASE-style filtered aggregates into true filtered aggregates.
- AggregateCaseToFilterRule(AggregateCaseToFilterRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateCaseToFilterRule
-
Creates an AggregateCaseToFilterRule.
- AggregateCaseToFilterRule(RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.AggregateCaseToFilterRule
-
Deprecated.
- AggregateCaseToFilterRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateExpandDistinctAggregatesRule - Class in org.apache.calcite.rel.rules
-
Planner rule that expands distinct aggregates (such as
COUNT(DISTINCT x)
) from aAggregate
. - AggregateExpandDistinctAggregatesRule(Class<? extends Aggregate>, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
-
Deprecated.
- AggregateExpandDistinctAggregatesRule(Class<? extends LogicalAggregate>, boolean, RelFactories.JoinFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
-
Deprecated.
- AggregateExpandDistinctAggregatesRule(Class<? extends LogicalAggregate>, RelFactories.JoinFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
-
Deprecated.
- AggregateExpandDistinctAggregatesRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateExpandWithinDistinctRule - Class in org.apache.calcite.rel.rules
-
Planner rule that rewrites an
Aggregate
that containsWITHIN DISTINCT
aggregate functions. - AggregateExpandWithinDistinctRule(AggregateExpandWithinDistinctRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateExpandWithinDistinctRule
-
Creates an AggregateExpandWithinDistinctRule.
- AggregateExpandWithinDistinctRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateExtractProjectRule - Class in org.apache.calcite.rel.rules
- AggregateExtractProjectRule(Class<? extends Aggregate>, Class<? extends RelNode>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateExtractProjectRule
-
Deprecated.
- AggregateExtractProjectRule(RelOptRuleOperand, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateExtractProjectRule
-
Deprecated.
- AggregateExtractProjectRule(AggregateExtractProjectRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateExtractProjectRule
-
Creates an AggregateExtractProjectRule.
- AggregateExtractProjectRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- aggregateFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- AggregateFilterTransposeRule - Class in org.apache.calcite.rel.rules
- AggregateFilterTransposeRule(RelOptRuleOperand, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateFilterTransposeRule
-
Deprecated.
- AggregateFilterTransposeRule(AggregateFilterTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateFilterTransposeRule
-
Creates an AggregateFilterTransposeRule.
- AggregateFilterTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateFunction - Interface in org.apache.calcite.schema
-
Function that combines several values into a scalar result.
- AggregateFunctionImpl - Class in org.apache.calcite.schema.impl
-
Implementation of
AggregateFunction
via user-defined class. - aggregateIllegalInClause(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- aggregateIllegalInOrderBy() - Method in interface org.apache.calcite.runtime.CalciteResource
- aggregateInFilterIllegal() - Method in interface org.apache.calcite.runtime.CalciteResource
- aggregateInWithinDistinctIllegal() - Method in interface org.apache.calcite.runtime.CalciteResource
- aggregateInWithinGroupIllegal() - Method in interface org.apache.calcite.runtime.CalciteResource
- AggregateJoinJoinRemoveRule - Class in org.apache.calcite.rel.rules
- AggregateJoinJoinRemoveRule(Class<? extends Aggregate>, Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinJoinRemoveRule
-
Deprecated.
- AggregateJoinJoinRemoveRule(AggregateJoinJoinRemoveRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinJoinRemoveRule
-
Creates an AggregateJoinJoinRemoveRule.
- AggregateJoinJoinRemoveRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateJoinRemoveRule - Class in org.apache.calcite.rel.rules
- AggregateJoinRemoveRule(Class<? extends Aggregate>, Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinRemoveRule
-
Deprecated.
- AggregateJoinRemoveRule(AggregateJoinRemoveRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinRemoveRule
-
Creates an AggregateJoinRemoveRule.
- AggregateJoinRemoveRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateJoinTransposeRule - Class in org.apache.calcite.rel.rules
- AggregateJoinTransposeRule(Class<? extends Aggregate>, Class<? extends Join>, RelBuilderFactory, boolean) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Deprecated.
- AggregateJoinTransposeRule(Class<? extends Aggregate>, RelFactories.AggregateFactory, Class<? extends Join>, RelFactories.JoinFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Deprecated.
- AggregateJoinTransposeRule(Class<? extends Aggregate>, RelFactories.AggregateFactory, Class<? extends Join>, RelFactories.JoinFactory, boolean) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Deprecated.
- AggregateJoinTransposeRule(Class<? extends Aggregate>, RelFactories.AggregateFactory, Class<? extends Join>, RelFactories.JoinFactory, RelFactories.ProjectFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Deprecated.
- AggregateJoinTransposeRule(Class<? extends Aggregate>, RelFactories.AggregateFactory, Class<? extends Join>, RelFactories.JoinFactory, RelFactories.ProjectFactory, boolean) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Deprecated.
- AggregateJoinTransposeRule(AggregateJoinTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Creates an AggregateJoinTransposeRule.
- AggregateJoinTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateLambdaFactory<TSource,
TOrigAccumulate, TAccumulate, TResult, TKey> - Interface in org.apache.calcite.adapter.enumerable -
Generates lambda functions used in
EnumerableAggregate
. - AggregateMeasure2Rule(MeasureRules.AggregateMeasure2RuleConfig) - Constructor for class org.apache.calcite.rel.rules.MeasureRules.AggregateMeasure2Rule
-
Creates an AggregateMeasure2Rule.
- AggregateMeasureRule(MeasureRules.AggregateMeasureRuleConfig) - Constructor for class org.apache.calcite.rel.rules.MeasureRules.AggregateMeasureRule
-
Creates a AggregateMeasureRule.
- AggregateMergeRule - Class in org.apache.calcite.rel.rules
- AggregateMergeRule(RelOptRuleOperand, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateMergeRule
-
Deprecated.
- AggregateMergeRule(AggregateMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateMergeRule
-
Creates an AggregateMergeRule.
- AggregateMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- aggregateMissingWithinGroupClause(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- AggregateNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements an
Aggregate
. - AggregateNode(Compiler, Aggregate) - Constructor for class org.apache.calcite.interpreter.AggregateNode
- AggregateNode.BigDecimalSum - Class in org.apache.calcite.interpreter
-
Implementation of
SUM
over BigDecimal values as a user-defined aggregate. - AggregateNode.DoubleSum - Class in org.apache.calcite.interpreter
-
Implementation of
SUM
over DOUBLE values as a user-defined aggregate. - AggregateNode.IntSum - Class in org.apache.calcite.interpreter
-
Implementation of
SUM
over INTEGER values as a user-defined aggregate. - AggregateNode.LongSum - Class in org.apache.calcite.interpreter
-
Implementation of
SUM
over BIGINT values as a user-defined aggregate. - AggregateNode.MaxBigDecimal - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the maximum ofBigDecimal
values as a user-defined aggregate. - AggregateNode.MaxBoolean - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the maximum ofboolean
values as a user-defined aggregate. - AggregateNode.MaxDouble - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the maximum ofdouble
andreal
values as a user-defined aggregate. - AggregateNode.MaxFloat - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the maximum offloat
values as a user-defined aggregate. - AggregateNode.MaxInt - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the maximum ofinteger
values as a user-defined aggregate. - AggregateNode.MaxLong - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the maximum oflong
values as a user-defined aggregate. - AggregateNode.MinBigDecimal - Class in org.apache.calcite.interpreter
-
Implementation of
MIN
function to calculate the minimum ofBigDecimal
values as a user-defined aggregate. - AggregateNode.MinBoolean - Class in org.apache.calcite.interpreter
-
Implementation of
MIN
function to calculate the minimum ofboolean
values as a user-defined aggregate. - AggregateNode.MinDouble - Class in org.apache.calcite.interpreter
-
Implementation of
MIN
function to calculate the minimum ofdouble
andreal
values as a user-defined aggregate. - AggregateNode.MinFloat - Class in org.apache.calcite.interpreter
-
Implementation of
MIN
function to calculate the minimum offloat
values as a user-defined aggregate. - AggregateNode.MinInt - Class in org.apache.calcite.interpreter
-
Implementation of
MIN
function to calculate the minimum ofinteger
values as a user-defined aggregate. - AggregateNode.MinLong - Class in org.apache.calcite.interpreter
-
Implementation of
MIN
function to calculate the minimum oflong
values as a user-defined aggregate. - AggregateNode.NumericComparison<T> - Class in org.apache.calcite.interpreter
-
Common implementation of comparison aggregate methods over numeric values as a user-defined aggregate.
- AggregateProjectConstantToDummyJoinRule - Class in org.apache.calcite.rel.rules
- AggregateProjectConstantToDummyJoinRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateProjectMergeRule - Class in org.apache.calcite.rel.rules
- AggregateProjectMergeRule(Class<? extends Aggregate>, Class<? extends Project>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateProjectMergeRule
-
Deprecated.
- AggregateProjectMergeRule(AggregateProjectMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateProjectMergeRule
-
Creates an AggregateProjectMergeRule.
- AggregateProjectMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- aggregateProjectPullUpConstantsRule() - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule.Config
-
Instance of rule to pull up constants into aggregate.
- AggregateProjectPullUpConstantsRule - Class in org.apache.calcite.rel.rules
-
Planner rule that removes constant keys from an
Aggregate
. - AggregateProjectPullUpConstantsRule(Class<? extends Aggregate>, Class<? extends RelNode>, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.AggregateProjectPullUpConstantsRule
-
Deprecated.
- AggregateProjectPullUpConstantsRule(AggregateProjectPullUpConstantsRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateProjectPullUpConstantsRule
-
Creates an AggregateProjectPullUpConstantsRule.
- AggregateProjectPullUpConstantsRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateProjectStarTableRule - Class in org.apache.calcite.rel.rules
-
Variant of
AggregateStarTableRule
that accepts aProject
between theAggregate
and itsStarTable.StarTableScan
input. - AggregateProjectStarTableRule(AggregateProjectStarTableRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateProjectStarTableRule
-
Creates an AggregateProjectStarTableRule.
- AggregateProjectStarTableRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateReduceFunctionsRule - Class in org.apache.calcite.rel.rules
-
Planner rule that reduces aggregate functions in
Aggregate
s to simpler forms. - AggregateReduceFunctionsRule(Class<? extends Aggregate>, RelBuilderFactory, EnumSet<SqlKind>) - Constructor for class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Deprecated.
- AggregateReduceFunctionsRule(RelOptRuleOperand, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Deprecated.
- AggregateReduceFunctionsRule(AggregateReduceFunctionsRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Creates an AggregateReduceFunctionsRule.
- AggregateReduceFunctionsRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateRemoveRule - Class in org.apache.calcite.rel.rules
-
Planner rule that removes a
Aggregate
if it computes no aggregate functions (that is, it is implementingSELECT DISTINCT
), or all the aggregate functions are splittable, and the underlying relational expression is already distinct. - AggregateRemoveRule(Class<? extends Aggregate>) - Constructor for class org.apache.calcite.rel.rules.AggregateRemoveRule
-
Deprecated.
- AggregateRemoveRule(Class<? extends Aggregate>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateRemoveRule
-
Deprecated.
- AggregateRemoveRule(AggregateRemoveRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateRemoveRule
-
Creates an AggregateRemoveRule.
- AggregateRemoveRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- aggregateRex(RelBuilder.GroupKey, boolean, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
- aggregateRex(RelBuilder.GroupKey, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
- AggregateStarTableRule - Class in org.apache.calcite.rel.rules
-
Planner rule that matches an
Aggregate
on top of aStarTable.StarTableScan
. - AggregateStarTableRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.AggregateStarTableRule
-
Deprecated.
- AggregateStarTableRule(AggregateStarTableRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateStarTableRule
-
Creates an AggregateStarTableRule.
- AggregateStarTableRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateUnionAggregateRule - Class in org.apache.calcite.rel.rules
- AggregateUnionAggregateRule(Class<? extends Aggregate>, Class<? extends Union>, Class<? extends RelNode>, Class<? extends RelNode>, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.AggregateUnionAggregateRule
-
Deprecated.
- AggregateUnionAggregateRule(Class<? extends Aggregate>, RelFactories.AggregateFactory, Class<? extends Union>, RelFactories.SetOpFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateUnionAggregateRule
-
Deprecated.
- AggregateUnionAggregateRule(AggregateUnionAggregateRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateUnionAggregateRule
-
Creates an AggregateUnionAggregateRule.
- AggregateUnionAggregateRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateUnionTransposeRule - Class in org.apache.calcite.rel.rules
- AggregateUnionTransposeRule(Class<? extends Aggregate>, Class<? extends Union>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateUnionTransposeRule
-
Deprecated.
- AggregateUnionTransposeRule(Class<? extends Aggregate>, RelFactories.AggregateFactory, Class<? extends Union>, RelFactories.SetOpFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateUnionTransposeRule
-
Deprecated.
- AggregateUnionTransposeRule(AggregateUnionTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateUnionTransposeRule
-
Creates an AggregateUnionTransposeRule.
- AggregateUnionTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- aggregateUnique() - Method in interface org.apache.calcite.tools.RelBuilder.Config
-
Whether to create an Aggregate even if we know that the input is already unique; default false.
- AggregateValuesRule - Class in org.apache.calcite.rel.rules
- AggregateValuesRule(AggregateValuesRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateValuesRule
-
Creates an AggregateValuesRule.
- AggregateValuesRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateValuesRule
-
Deprecated.
- AggregateValuesRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregatingScope - Interface in org.apache.calcite.sql.validate
-
An extension to the
SqlValidatorScope
interface which indicates that the scope is aggregating. - AggregatingSelectScope - Class in org.apache.calcite.sql.validate
-
Scope for resolving identifiers within a SELECT statement that has a GROUP BY clause.
- AggregatingSelectScope.Resolved - Class in org.apache.calcite.sql.validate
-
Information about an aggregating scope that can only be determined after validation has occurred.
- aggregation() - Method in interface org.apache.calcite.adapter.enumerable.AggContext
-
Returns the aggregation being implemented.
- aggregation() - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase.AggContextImpl
- AggResetContext - Interface in org.apache.calcite.adapter.enumerable
-
Information for a call to
AggImplementor.implementReset(AggContext, AggResetContext)
. - AggResetContextImpl - Class in org.apache.calcite.adapter.enumerable.impl
-
Implementation of
AggResetContext
. - AggResetContextImpl(BlockBuilder, List<Expression>) - Constructor for class org.apache.calcite.adapter.enumerable.impl.AggResetContextImpl
-
Creates aggregate reset context.
- AggResultContext - Interface in org.apache.calcite.adapter.enumerable
-
Information for a call to
AggImplementor.implementResult(AggContext, AggResultContext)
- AggResultContextImpl - Class in org.apache.calcite.adapter.enumerable.impl
-
Implementation of
AggResultContext
. - AggResultContextImpl(BlockBuilder, AggregateCall, List<Expression>, ParameterExpression, PhysType) - Constructor for class org.apache.calcite.adapter.enumerable.impl.AggResultContextImpl
-
Creates aggregate result context.
- aid - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Author
- algorithm - Variable in class org.apache.calcite.materialize.Lattice
- algorithm - Variable in class org.apache.calcite.model.JsonLattice
-
Whether to use an optimization algorithm to suggest and populate an initial set of tiles.
- algorithm(boolean) - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Sets the "algorithm" attribute (default false).
- algorithmMaxMillis - Variable in class org.apache.calcite.materialize.Lattice
- algorithmMaxMillis - Variable in class org.apache.calcite.model.JsonLattice
-
Maximum time (in milliseconds) to run the algorithm.
- algorithmMaxMillis(long) - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Sets the "algorithmMaxMillis" attribute (default -1).
- alias - Variable in class org.apache.calcite.materialize.Lattice.Column
-
Alias of the column, unique within the lattice.
- alias - Variable in class org.apache.calcite.materialize.LatticeNode
- alias - Variable in class org.apache.calcite.materialize.LatticeTable
- alias(String) - Method in interface org.apache.calcite.tools.RelBuilder.GroupKey
-
Assigns an alias to this group key.
- alias(RexNode, String) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns an expression wrapped in an alias.
- alias(SqlNode) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
- alias(SqlNode, int) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Derives an alias for a node, and invents a mangled identifier if it cannot.
- ALIAS - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
An alias.
- aliasContext(Map<String, RelDataType>, boolean) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- AliasContext(SqlDialect, Map<String, RelDataType>, boolean) - Constructor for class org.apache.calcite.rel.rel2sql.SqlImplementor.AliasContext
-
Creates an AliasContext; use
SqlImplementor.aliasContext(Map, boolean)
. - aliasListDegree(int, String, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- aliasListDuplicate(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- aliasMustBeSimpleIdentifier() - Method in interface org.apache.calcite.runtime.CalciteResource
- AliasNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for an
AS t(c1, c2, ...)
clause. - AliasNamespace(SqlValidatorImpl, SqlCall, SqlNode) - Constructor for class org.apache.calcite.sql.validate.AliasNamespace
-
Creates an AliasNamespace.
- aliasSet - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor
- aliasValue(SqlNodeList) - Static method in class org.apache.calcite.sql.SqlUnpivot
-
Computes an alias.
- all - Variable in class org.apache.calcite.rel.core.RepeatUnion
-
Whether duplicates are considered.
- all - Variable in class org.apache.calcite.rel.core.SetOp
- all - Variable in class org.apache.calcite.rel.mutable.MutableSetOp
- all() - Static method in class org.apache.calcite.adapter.druid.Granularities
-
Returns a Granularity that causes all rows to be rolled up into one.
- all() - Method in class org.apache.calcite.util.PrecedenceClimbingParser
-
Returns a list of all tokens.
- all() - Method in interface org.apache.calcite.util.RangeSets.Consumer
- all() - Method in interface org.apache.calcite.util.RangeSets.Handler
- all(List<? extends E>, Predicate1<E>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns whether
predicate
is true for all elements oflist
. - all(List<? extends E>, Predicate1<E>) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether
predicate
is true for all elements oflist
. - all(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Determines whether all elements of a sequence satisfy a condition.
- all(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- all(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Determines whether all elements of a sequence satisfy a condition.
- all(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Determines whether all the elements of a sequence satisfy a condition.
- all(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Determines whether all the elements of a sequence satisfy a condition.
- all(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- all(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- all(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Determines whether all the elements of a sequence satisfy a condition.
- all(RexNode, SqlOperator, Function<RelBuilder, RelNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an ALL predicate.
- all(SqlKind) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Returns the operator for
ALL comparisonKind
. - ALL - Enum constant in enum org.apache.calcite.adapter.druid.Granularity.Type
- ALL - Enum constant in enum org.apache.calcite.adapter.enumerable.NullPolicy
-
Returns null if and only if all of the arguments are null; If all of the arguments are false return false otherwise true.
- ALL - Enum constant in enum org.apache.calcite.rel.type.RelDataTypeComparability
- ALL - Enum constant in enum org.apache.calcite.sql.ddl.SqlCreateTableLike.LikeOption
- ALL - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
A collection of operators that could be used in all libraries; does not include STANDARD and SPATIAL.
- ALL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ALL
quantification operator. - ALL - Enum constant in enum org.apache.calcite.sql.SqlSelectKeyword
- ALL - Static variable in class org.apache.calcite.sql.SqlAccessType
- ALL_ATTRIBUTES - Enum constant in enum org.apache.calcite.sql.SqlExplainLevel
-
Display all attributes, including cost.
- ALL_EQ - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ALL_GE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ALL_GT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ALL_LE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ALL_LOWER - Enum constant in enum org.apache.calcite.util.format.postgresql.CapitalizationEnum
- ALL_LT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
< ALL
operator. - ALL_NE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ALL_PIG_OPT_RULES - Static variable in class org.apache.calcite.adapter.pig.PigRules
- ALL_PIG_REL_FACTORIES - Static variable in class org.apache.calcite.adapter.pig.PigRelFactories
- ALL_PREDICATES - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ALL_ROWS - Enum constant in enum org.apache.calcite.sql.SqlMatchRecognize.RowsPerMatchOption
- ALL_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- ALL_UPPER - Enum constant in enum org.apache.calcite.util.format.postgresql.CapitalizationEnum
- allAssignable(boolean, Class<?>[], Class<?>[]) - Static method in class org.apache.calcite.linq4j.tree.Types
- allContain(Collection<ImmutableBitSet>, int) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Checks if all bit sets contain a particular bit.
- allCorrelateVariables - Variable in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- allLiterals(List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether every expression in a list is a literal.
- allMatch(BiPredicate<T, U>) - Method in interface org.apache.calcite.runtime.PairList
-
Returns whether the predicate is true for all pairs in this list.
- allMatch(IntPredicate) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns whether a given predicate evaluates to true for all bits in this set.
- allMethodsDeterministic(Class) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Checks if all the methods in given class are deterministic (i.e.
- allNullable(List<RelDataType>) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether all of array of types are nullable.
- ALLOW_INFINITE_COST_CONVERTERS - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether the optimizer will consider adding converters of infinite cost in order to convert a relational expression from one calling convention to another.
- ALLOW_SPATIAL_FUNCTIONS - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeSchemaFactory
- allowableDifferenceTypes() - Method in enum org.apache.calcite.sql.type.SqlTypeFamily
-
For this type family, returns the allow types of the difference between two values of this family.
- allowAliasUnnestItems() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowAliasUnnestItems() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether directly alias array items in UNNEST.
- allowAliasUnnestItems() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowAliasUnnestItems() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowBangEqual() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
-
Deprecated.
- allowCharLiteralAlias() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowCharLiteralAlias() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether this dialect allows character literals as column aliases.
- allowCharLiteralAlias() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowCharLiteralAlias() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowedRules - Variable in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- allowExplicitRowValueConstructor() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowExplicitRowValueConstructor() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow SQL syntax "
ROW(expr1, expr2, expr3)
". - allowExplicitRowValueConstructor() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowExplicitRowValueConstructor() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowExtend() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowExtend() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow mixing table columns with extended columns in
INSERT
(orUPSERT
). - allowExtend() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowExtend() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowExtendedTrim() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowExtendedTrim() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether TRIM should support more than one trim character.
- allowExtendedTrim() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowExtendedTrim() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowGeometry() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowGeometry() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow geo-spatial extensions, including the GEOMETRY type.
- allowGeometry() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowGeometry() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowHyphenInUnquotedTableName() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowHyphenInUnquotedTableName() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow hyphens in an unquoted table name.
- allowHyphenInUnquotedTableName() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowHyphenInUnquotedTableName() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowInfiniteCostConverters() - Method in interface org.apache.calcite.util.SaffronProperties
-
Deprecated.The boolean property "saffron.opt.allowInfiniteCostConverters" determines whether the optimizer will consider adding converters of infinite cost in order to convert a relational expression from one calling convention to another.
- allowLenientCoercion() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowLenientCoercion() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow lenient type coercions.
- allowLenientCoercion() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowLenientCoercion() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowNiladicParentheses() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowNiladicParentheses() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow parentheses to be specified in calls to niladic functions and procedures (that is, functions and procedures with no parameters).
- allowNiladicParentheses() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowNiladicParentheses() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowPartial(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets whether to allow partial width windows; default true.
- allowPluralTimeUnits() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowPluralTimeUnits() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether interval literals should allow plural time units such as "YEARS" and "DAYS" in interval literals.
- allowPluralTimeUnits() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowPluralTimeUnits() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowQualifyingCommonColumn() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowQualifyingCommonColumn() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow a qualified common column in a query that has a NATURAL join or a join with a USING clause.
- allowQualifyingCommonColumn() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowQualifyingCommonColumn() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowsAccess(SqlAccessEnum) - Method in class org.apache.calcite.sql.SqlAccessType
- allowsAs() - Method in class org.apache.calcite.sql.dialect.HiveSqlDialect
- allowsAs() - Method in class org.apache.calcite.sql.dialect.OracleSqlDialect
- allowsAs() - Method in class org.apache.calcite.sql.dialect.SparkSqlDialect
- allowsAs() - Method in class org.apache.calcite.sql.SqlDialect
- allowsFilter() - Method in class org.apache.calcite.sql.fun.SqlAbstractGroupFunction
- allowsFilter() - Method in class org.apache.calcite.sql.fun.SqlSingleValueAggFunction
- allowsFilter() - Method in class org.apache.calcite.sql.SqlAggFunction
-
Whether this aggregate function allows a
FILTER (WHERE ...)
clause. - allowsFraming() - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- allowsFraming() - Method in class org.apache.calcite.sql.fun.SqlLeadLagAggFunction
- allowsFraming() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether this is a window function that allows framing (i.e.
- allowsFraming() - Method in class org.apache.calcite.sql.SqlRankFunction
- allowsIdentifier(String[], int[][]) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Returns whether the reported ParseException tokenImage allows SQL identifier.
- allowsNoPrecNoScale() - Method in enum org.apache.calcite.sql.type.SqlTypeName
- allowsNullTreatment() - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- allowsNullTreatment() - Method in class org.apache.calcite.sql.fun.SqlFirstLastValueAggFunction
- allowsNullTreatment() - Method in class org.apache.calcite.sql.fun.SqlLeadLagAggFunction
- allowsNullTreatment() - Method in class org.apache.calcite.sql.fun.SqlNthValueAggFunction
- allowsNullTreatment() - Method in class org.apache.calcite.sql.SqlAggFunction
-
Returns whether this aggregate function allows specifying null treatment (
RESPECT NULLS
orIGNORE NULLS
). - allowsPrec() - Method in enum org.apache.calcite.sql.type.SqlTypeName
- allowsPrecNoScale() - Method in enum org.apache.calcite.sql.type.SqlTypeName
- allowsPrecScale(boolean, boolean) - Method in enum org.apache.calcite.sql.type.SqlTypeName
-
Returns whether this type can be specified with a given combination of precision and scale.
- allowsScale() - Method in enum org.apache.calcite.sql.type.SqlTypeName
- allowsSeparator() - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
-
Returns whether this aggregate function allows '
SEPARATOR string
' among its arguments. - AllPrivate() - Constructor for class org.apache.calcite.test.schemata.catchall.CatchallSchema.AllPrivate
- allPrivates - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- allRows - Variable in class org.apache.calcite.rel.core.Match
- allRows - Variable in class org.apache.calcite.rel.mutable.MutableMatch
- allSimple() - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns whether there are any composite traits in this set.
- allStrong(List<RexNode>) - Static method in class org.apache.calcite.plan.Strong
-
Returns whether all expressions in a list are strong.
- allTypeInfo() - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- ALTER_INDEX - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ALTER INDEX
DDL statement. - ALTER_MATERIALIZED_VIEW - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ALTER MATERIALIZED VIEW
DDL statement. - ALTER_SEQUENCE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ALTER SEQUENCE
DDL statement. - ALTER_SESSION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ALTER SESSION
DDL statement. - ALTER_TABLE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ALTER TABLE
DDL statement. - ALTER_VIEW - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ALTER VIEW
DDL statement. - ALWAYS - Enum constant in enum org.apache.calcite.rex.RexDigestIncludeType
- alwaysUseParentheses() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether expressions should always be included in parentheses.
- am_pm - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- AM_PM - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- ambiguousSortOrderInJsonArrayAggFunc() - Method in interface org.apache.calcite.runtime.CalciteResource
- amend(String, String) - Method in class org.apache.calcite.test.DiffRepository
- ampm - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- AMPM - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- AmPmCompiledPattern - Class in org.apache.calcite.util.format.postgresql.format.compiled
-
The date/time format compiled component for AM/PM (first or second half of day).
- AmPmCompiledPattern(Set<PatternModifier>, boolean, boolean) - Constructor for class org.apache.calcite.util.format.postgresql.format.compiled.AmPmCompiledPattern
- AmPmFormatPattern - Class in org.apache.calcite.util.format.postgresql.format
-
The date/time format component for AM/PM (first or second half of day).
- AmPmFormatPattern(String) - Constructor for class org.apache.calcite.util.format.postgresql.format.AmPmFormatPattern
- analyze(RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil.InputFinder
-
Returns an input finder that has analyzed a given expression.
- analyze(RexNode) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- analyze(SqlValidatorUtil.GroupAnalyzer) - Method in class org.apache.calcite.sql.validate.AggregatingSelectScope
- analyze(SqlValidatorUtil.GroupAnalyzer) - Method in class org.apache.calcite.sql.validate.DelegatingScope
-
Analyzes expressions in this scope and populates a
GroupAnalyzer
. - analyzeCondition() - Method in class org.apache.calcite.rel.core.Join
-
Analyzes the join condition.
- analyzeGroupItem(SqlValidatorScope, SqlValidatorUtil.GroupAnalyzer, ImmutableList.Builder<ImmutableList<ImmutableBitSet>>, SqlNode) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Analyzes an expression in a GROUP BY clause.
- analyzeSimpleEquiJoin(LogicalJoin, int[]) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- analyzeView(CalciteConnection, CalciteSchema, List<String>, String, List<String>, boolean) - Static method in class org.apache.calcite.schema.Schemas
-
Analyzes a view.
- analyzeView(CalcitePrepare.Context, String, boolean) - Method in interface org.apache.calcite.jdbc.CalcitePrepare
-
Analyzes a view.
- analyzeView(CalcitePrepare.Context, String, boolean) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- AnalyzeViewResult(CalcitePrepareImpl, SqlValidator, String, SqlNode, RelDataType, RelRoot, Table, ImmutableList<String>, RexNode, ImmutableIntList, boolean) - Constructor for class org.apache.calcite.jdbc.CalcitePrepare.AnalyzeViewResult
- ANCHOR_END - Enum constant in enum org.apache.calcite.runtime.Pattern.Op
-
Anchor for end "$".
- ANCHOR_START - Enum constant in enum org.apache.calcite.runtime.Pattern.Op
-
Anchor for start "^".
- and(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an AND.
- and(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise AND operation.
- and(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise AND operation.
- and(HintPredicate...) - Static method in class org.apache.calcite.rel.hint.HintPredicates
-
Returns a composed hint predicate that represents a short-circuiting logical AND of an array of hint predicates
hintPredicates
. - and(RexNode...) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- and(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an AND.
- and(SqlOperandTypeChecker) - Method in interface org.apache.calcite.sql.type.SqlOperandTypeChecker
-
Composes this with another checker using AND.
- and(SqlOperandTypeChecker...) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a checker that passes if all of the rules pass.
- and(SqlSingleOperandTypeChecker) - Method in interface org.apache.calcite.sql.type.SqlSingleOperandTypeChecker
-
Composes this with another single-operand checker using AND.
- and(SqlSingleOperandTypeChecker...) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a single-operand checker that passes if all of the rules pass.
- And - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise or logical AND operation, such as
a & b
in Java. - AND - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- AND - Enum constant in enum org.apache.calcite.rel.hint.CompositeHintPredicate.Composition
- AND - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Logical "AND" operator.
- AND - Enum constant in enum org.apache.calcite.sql.type.CompositeOperandTypeChecker.Composition
- AND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Logical
AND
operator. - AND_CHAIN - Enum constant in enum org.apache.calcite.sql.babel.postgresql.AndChain
- AND_NO_CHAIN - Enum constant in enum org.apache.calcite.sql.babel.postgresql.AndChain
- andAlso(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a conditional AND operation that evaluates the second operand only if the first operand evaluates to true.
- andAlso(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a conditional AND operation that evaluates the second operand only if the first operand is resolved to true.
- AndAlso - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A conditional AND operation that evaluates the second operand only if the first operand evaluates to true.
- andAssign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise AND assignment operation.
- andAssign(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise AND assignment operation.
- andAssign(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise AND assignment operation.
- AndAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise or logical AND compound assignment operation, such as (a &= b) in C#.
- AndChain - Enum in org.apache.calcite.sql.babel.postgresql
-
Defines the keywords that can occur immediately after the "ROLLBACK" or "COMMIT" keywords.
- andExpressions(SqlNode, SqlNode) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns the AND of two expressions.
- andJoinFilters(RexBuilder, RexNode, RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Ands two sets of join filters together, either of which can be null.
- andNot(RexBuilder, RexNode, Iterable<? extends RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Creates the expression
e1 AND NOT notTerm1 AND NOT notTerm2 ...
. - andNot(RexBuilder, RexNode, RexNode...) - Static method in class org.apache.calcite.rex.RexUtil
-
Creates the expression
e1 AND NOT notTerm1 AND NOT notTerm2 ...
. - andThen(Consumer<R>) - Method in interface org.apache.calcite.util.RangeSets.Handler
-
Creates a Consumer that sends output to a given sink.
- andThen(UnaryOperator<SqlOperatorBinding>, SqlReturnTypeInference) - Static method in class org.apache.calcite.sql.type.ReturnTypes
-
Returns a return-type inference that first transforms a binding and then applies an inference.
- andThen(UnaryOperator<X>, UnaryOperator<X>) - Static method in class org.apache.calcite.util.Util
-
Returns an operator that applies
op1
and thenop2
. - andThen(SqlTypeTransform) - Method in interface org.apache.calcite.sql.type.SqlReturnTypeInference
-
Returns a return-type inference that applies this rule then a transform.
- ANON_FIELDS - Static variable in class org.apache.calcite.rel.core.Project.Flags
-
Deprecated.
- ANONYMOUS_ROW - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
Similar to
SqlStdOperatorTable.ROW
, but does not print "ROW". - ANONYMOUS_ROW_NO_PARENTHESES - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
Similar to
SqlInternalOperators.ANONYMOUS_ROW
, but does not print "ROW" or parentheses. - AnotherTableMacroFunctionWithNamedParameters() - Constructor for class org.apache.calcite.util.Smalls.AnotherTableMacroFunctionWithNamedParameters
- AnsiSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for an unknown ANSI compatible database. - AnsiSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.AnsiSqlDialect
-
Creates an AnsiSqlDialect.
- ANTI - Enum constant in enum org.apache.calcite.linq4j.JoinType
-
Anti-join (also known as Anti-semi-join).
- ANTI - Enum constant in enum org.apache.calcite.rel.core.JoinRelType
-
Anti-join (also known as Anti-semi-join).
- ANTI_JOIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- antiJoin(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an anti-join.
- antiJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns elements of
outer
for which there is NOT a member ofinner
with a matching key. - antiJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- antiJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, EqualityComparer<TKey>, Predicate2<TSource, TInner>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- antiJoin(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an anti-join.
- any() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- any() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Determines whether a sequence contains any elements.
- any() - Static method in class org.apache.calcite.plan.RelOptRule
-
Deprecated.
- any() - Static method in class org.apache.calcite.sql.type.SqlOperandCountRanges
- any(Class<? extends MutableRel>) - Static method in class org.apache.calcite.plan.SubstitutionVisitor.AbstractUnifyRule
-
Creates an operand that doesn't check inputs.
- any(Enumerable) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Determines whether a sequence contains any elements.
- any(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Determines whether any element of a sequence satisfies a condition.
- any(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- any(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Determines whether any element of a sequence satisfies a condition.
- any(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Determines whether a sequence contains any elements.
- any(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Determines whether a sequence contains any elements.
- any(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- any(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Determines whether any element of a sequence satisfies a condition.
- any(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Determines whether any element of a sequence satisfies a condition.
- any(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- any(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- any(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Determines whether any element of a sequence satisfies a condition.
- ANY - Enum constant in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Consumer has no preferred representation.
- ANY - Enum constant in enum org.apache.calcite.adapter.enumerable.NullPolicy
-
If any of the arguments are null, return null.
- ANY - Enum constant in enum org.apache.calcite.plan.RelOptRuleOperandChildPolicy
-
Signifies that operand can have any number of children.
- ANY - Enum constant in enum org.apache.calcite.plan.Strong.Policy
-
This kind of expression is null if and only if at least one of its arguments is null.
- ANY - Enum constant in enum org.apache.calcite.rel.RelDistribution.Type
-
Not a valid distribution, but indicates that a consumer will accept any distribution.
- ANY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- ANY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- ANY - Static variable in class org.apache.calcite.rel.RelDistributions
- ANY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_ANY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_COMPARABLE - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy used by
ARG_MIN(value, comp)
and similar functions, where the first operand can have any type and the second must be comparable. - ANY_IGNORE - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_ITEM - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ANY_NULLABLE - Static variable in class org.apache.calcite.sql.type.InferTypes
-
Operand type-inference strategy where an unknown operand type is assumed to be nullable ANY.
- ANY_NUMERIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_NUMERIC_ANY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_PARAMETER_CHECKER - Static variable in class org.apache.calcite.sql.test.SqlTests
-
Checker that allows any number or type of parameters.
- ANY_RESULT_CHECKER - Static variable in class org.apache.calcite.sql.test.SqlTests
-
Checker that allows any result.
- ANY_STRING_OPTIONAL_STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_STRING_STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_TYPE_CHECKER - Static variable in class org.apache.calcite.sql.test.SqlTests
-
Checker which allows any type.
- ANY_VALUE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ANY_VALUE
aggregate function. - ANY_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
ANY_VALUE
aggregate function. - anyContain(Iterable<? extends RexNode>) - Method in class org.apache.calcite.rex.RexUtil.RexFinder
-
Returns whether any of the given expressions contain what this RexFinder seeks.
- anyInputs() - Method in interface org.apache.calcite.plan.RelRule.OperandDetailBuilder
-
Indicates that this operand takes any number or type of inputs.
- anyMatch(BiPredicate<T, U>) - Method in interface org.apache.calcite.runtime.PairList
-
Returns whether the predicate is true for at least one pair in this list.
- anyMatch(IntPredicate) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns whether a given predicate evaluates to true for any bit in this set.
- append(char) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Appends a character, without any quoting.
- append(int) - Method in class org.apache.calcite.util.ImmutableIntList
-
Returns a copy of this list with one element added.
- append(long) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Appends a number, per
StringBuilder.append(long)
. - append(ImmutableList<E>, E) - Static method in class org.apache.calcite.runtime.FlatLists
-
Returns a list that consists of a given list plus an element, guaranteed to be an
ImmutableList
. - append(Integer) - Method in class org.apache.calcite.util.ImmutableIntList
- append(String) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Appends a string, without any quoting.
- append(StringBuilder, int, Object) - Method in class org.apache.calcite.util.JsonBuilder
-
Appends a JSON object to a string builder.
- append(String, BlockStatement) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Appends a block to a list of statements and returns an expression (possibly a variable) that represents the result of the newly added block.
- append(String, BlockStatement, boolean) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Appends an expression to a list of statements, optionally optimizing it to a variable if it is used more than once.
- append(String, Expression) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Appends an expression to a list of statements, and returns an expression (possibly a variable) that represents the result of the newly added block.
- append(String, Expression, boolean) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Appends an expression to a list of statements, optionally optimizing if the expression is used more than once.
- append(List<E>, E) - Static method in class org.apache.calcite.runtime.FlatLists
-
Returns a list that consists of a given list plus an element.
- append(Map<K, V>, K, V) - Static method in class org.apache.calcite.runtime.FlatLists
-
Returns a map that consists of a given map plus an (key, value), guaranteed to be an
ImmutableMap
. - append(Expression) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- append(SqlString) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Appends a hygienic SQL string.
- append(Mappings.TargetMapping, Mappings.TargetMapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Creates a mapping by appending two mappings.
- append(Source) - Method in interface org.apache.calcite.util.Source
-
Returns a source whose path concatenates this with a child.
- append(T) - Method in interface org.apache.calcite.linq4j.tree.Expressions.FluentList
- append(T) - Method in class org.apache.calcite.runtime.FlatLists.AbstractFlatList
-
Returns a list that consists of a this list's elements plus a given element.
- append(T) - Method in class org.apache.calcite.runtime.FlatLists.Flat1List
- append(T) - Method in class org.apache.calcite.runtime.FlatLists.Flat2List
- append(T) - Method in class org.apache.calcite.runtime.FlatLists.Flat3List
- append(T) - Method in class org.apache.calcite.runtime.FlatLists.Flat4List
- append(T) - Method in class org.apache.calcite.runtime.FlatLists.Flat5List
- append(T) - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- appendAll(Iterable<Integer>) - Method in class org.apache.calcite.util.ImmutableIntList
-
Returns a copy of this list with all of the given integers added.
- appendAll(Iterable<T>) - Method in interface org.apache.calcite.linq4j.tree.Expressions.FluentList
- appendAll(T...) - Method in interface org.apache.calcite.linq4j.tree.Expressions.FluentList
- appendIf(boolean, T) - Method in interface org.apache.calcite.linq4j.tree.Expressions.FluentList
- appendIfNotNull(T) - Method in interface org.apache.calcite.linq4j.tree.Expressions.FluentList
- appendIfNotNull(String, Expression) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Appends an expression to a list of statements if it is not null, and returns the expression.
- appendOperands(StringBuilder) - Method in class org.apache.calcite.rex.RexCall
-
Appends call operands without parenthesis.
- appendSearchString(String, SplunkTableScan, LogicalProject, LogicalProject, RelDataType, RelDataType) - Method in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
-
Appends a search string.
- appendURLEncodedArgs(StringBuilder, CharSequence...) - Static method in class org.apache.calcite.runtime.HttpUtils
- appendURLEncodedArgs(StringBuilder, Map<String, String>) - Static method in class org.apache.calcite.runtime.HttpUtils
- apply() - Method in interface org.apache.calcite.linq4j.function.Function0
- apply(T) - Method in class org.apache.calcite.runtime.PredicateImpl
-
Deprecated.
- apply(String, int, int) - Method in interface org.apache.calcite.sql.validate.SqlValidatorUtil.Suggester
- apply(Class<? extends RelNode>) - Method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
-
Deprecated.
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.plan.volcano.VolcanoRelMetadataProvider
-
Deprecated.
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.rel.metadata.CachingRelMetadataProvider
-
Deprecated.
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.rel.metadata.ChainedRelMetadataProvider
-
Deprecated.
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
-
Deprecated.
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
-
Deprecated.
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in interface org.apache.calcite.rel.metadata.RelMetadataProvider
-
Deprecated.Use
RelMetadataQuery
. - apply(String) - Method in class org.apache.calcite.adapter.os.PsTableFunction.LineParser
- apply(String, Locale) - Method in enum org.apache.calcite.util.format.postgresql.CapitalizationEnum
-
Applies the casing style to a string.
- apply(Connection) - Method in interface org.apache.calcite.test.CalciteAssert.ConnectionPostProcessor
- apply(List<T>) - Method in class org.apache.calcite.rex.RexShuttle
-
Applies this shuttle to each expression in a list and returns the resulting list.
- apply(List<?>) - Method in class org.apache.calcite.util.Smalls.SimpleTableMacro
- apply(List<? extends Object>) - Method in class org.apache.calcite.schema.impl.MaterializedViewTable.MaterializedViewTableMacro
- apply(List<? extends Object>) - Method in class org.apache.calcite.schema.impl.TableMacroImpl
-
Applies arguments to yield a table.
- apply(List<? extends Object>) - Method in class org.apache.calcite.schema.impl.ViewTableMacro
- apply(List<? extends Object>) - Method in interface org.apache.calcite.schema.TableMacro
-
Applies arguments to yield a table.
- apply(List<RelHint>, RelNode) - Method in class org.apache.calcite.rel.hint.HintStrategyTable
-
Applies this
HintStrategyTable
hint strategies to the given relational expression and thehints
. - apply(List<T1>, Function1<T1, R>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Creates a copy of a list, applying a function to each element.
- apply(RelOptCluster, RelOptSchema, SchemaPlus) - Method in interface org.apache.calcite.tools.Frameworks.PlannerAction
- apply(RelOptCluster, RelOptSchema, SchemaPlus, CalciteServerStatement) - Method in interface org.apache.calcite.tools.Frameworks.BasePrepareAction
- apply(RelOptRuleCall, Project, Aggregate, StarTable.StarTableScan) - Method in class org.apache.calcite.rel.rules.AggregateStarTableRule
- apply(RelOptRuleCall, Aggregate, Project) - Static method in class org.apache.calcite.rel.rules.AggregateProjectMergeRule
- apply(RelOptRuleCall, Filter, TableScan) - Method in class org.apache.calcite.rel.rules.FilterTableScanRule
- apply(RelOptRuleCall, Filter, TableScan) - Method in class org.apache.calcite.rel.rules.MaterializedViewFilterScanRule
- apply(RelOptRuleCall, Project, TableScan) - Method in class org.apache.calcite.rel.rules.ProjectTableScanRule
- apply(RelOptRuleCall, LogicalProject, LogicalFilter, LogicalValues) - Method in class org.apache.calcite.rel.rules.ValuesReduceRule
-
Does the work.
- apply(SubstitutionVisitor.UnifyRuleCall) - Method in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRule
-
Applies this rule to a particular node in a query.
- apply(Join, JoinRelType, RexNode) - Method in interface org.apache.calcite.rel.rules.FilterJoinRule.Predicate
- apply(RelHint, RelNode) - Method in class org.apache.calcite.rel.hint.CompositeHintPredicate
- apply(RelHint, RelNode) - Method in interface org.apache.calcite.rel.hint.HintPredicate
-
Decides if the given
hint
can be applied to the relational expressionrel
. - apply(RelHint, RelNode) - Method in class org.apache.calcite.rel.hint.NodeTypeHintPredicate
- apply(RelDataTypeField) - Method in class org.apache.calcite.rel.type.RelDataTypeField.ToFieldIndex
-
Deprecated.
- apply(RelDataTypeField) - Method in class org.apache.calcite.rel.type.RelDataTypeField.ToFieldName
-
Deprecated.
- apply(RexNode) - Method in class org.apache.calcite.rex.RexShuttle
-
Applies this shuttle to an expression, or returns null if the expression is null.
- apply(RexSubQuery, Set<CorrelationId>, RelOptUtil.Logic, RelBuilder, int, int, int) - Method in class org.apache.calcite.rel.rules.SubQueryRemoveRule
- apply(RexVisitor<Void>, List<? extends RexNode>, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a visitor to a list of expressions and, if specified, a single expression.
- apply(RexVisitor<Void>, RexNode[], RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a visitor to an array of expressions and, if specified, a single expression.
- apply(RexVisitor<T>, T[]) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a shuttle to an array of expressions.
- apply(StringAndPos, SqlValidator, SqlNode) - Method in interface org.apache.calcite.sql.test.SqlTester.ValidatedNodeFunction
- apply(SqlOperatorBinding) - Method in interface org.apache.calcite.sql.type.SqlTypeTransform
-
Creates an operand type transform.
- apply(Mapping, BitSet) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Applies a mapping to a BitSet.
- apply(Mapping, List<T>) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Applies a mapping to a list.
- apply(Mapping, ImmutableBitSet) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Applies a mapping to an
ImmutableBitSet
. - apply(Mappings.TargetMapping) - Method in interface org.apache.calcite.plan.RelTrait
-
Applies a mapping to this trait.
- apply(Mappings.TargetMapping) - Method in class org.apache.calcite.plan.RelTraitSet
-
Applies a mapping to this traitSet.
- apply(Mappings.TargetMapping) - Method in class org.apache.calcite.rel.RelCollationImpl
-
Applies mapping to a given collation.
- apply(Mappings.TargetMapping) - Method in interface org.apache.calcite.rel.RelDistribution
-
Applies mapping to this distribution trait.
- apply(Mappings.TargetMapping, int) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Applies a mapping to an optional integer, returning an optional result.
- apply(Mappings.TargetMapping, Iterable<? extends RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a mapping to an iterable over expressions.
- apply(Mappings.TargetMapping, List<RelCollation>) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a mapping to a collation list.
- apply(Mappings.TargetMapping, RelCollation) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a mapping to a collation.
- apply(Mappings.TargetMapping, RelFieldCollation) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a mapping to a field collation.
- apply(Mappings.TargetMapping, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a mapping to an expression.
- apply(PrecedenceClimbingParser, PrecedenceClimbingParser.SpecialOp) - Method in interface org.apache.calcite.util.PrecedenceClimbingParser.Special
-
Given an occurrence of this operator, identifies the range of tokens to be collapsed into a call of this operator, and the arguments to that call.
- apply(T0) - Method in interface org.apache.calcite.linq4j.function.DoubleFunction1
- apply(T0) - Method in interface org.apache.calcite.linq4j.function.FloatFunction1
- apply(T0) - Method in interface org.apache.calcite.linq4j.function.Function1
- apply(T0) - Method in interface org.apache.calcite.linq4j.function.IntegerFunction1
- apply(T0) - Method in interface org.apache.calcite.linq4j.function.LongFunction1
- apply(T0) - Method in interface org.apache.calcite.linq4j.function.Predicate1
- apply(T0, T1) - Method in interface org.apache.calcite.linq4j.function.Function2
- apply(T0, T1) - Method in interface org.apache.calcite.linq4j.function.Predicate2
- apply2(Mapping, Iterable<ImmutableBitSet>) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Applies a mapping to a collection of
ImmutableBitSet
s. - apply2(Mapping, List<Integer>) - Static method in class org.apache.calcite.util.mapping.Mappings
- apply3(Mapping, List<T>) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Creates a view of a list, permuting according to a mapping.
- applyFields(Mappings.TargetMapping, List<RelFieldCollation>) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a mapping to a list of field collations.
- applyNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- applyResultSelector(Function2<K, Enumerable<V>, TResult>) - Method in interface org.apache.calcite.linq4j.Lookup
-
Applies a transform function to each key and its associated values and returns the results.
- applySettings(Socket) - Method in class org.apache.calcite.runtime.SocketFactoryImpl
-
Applies the current settings to the given socket.
- applyTimeExtract(String, String, TimeZone) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- applyTimestampCeil(String, String, String, TimeZone) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- applyTimestampFloor(String, String, String, TimeZone) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- APPROX_COUNT_DISTINCT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
APPROX_COUNT_DISTINCT
aggregate function. - APPROX_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- approximate(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
-
Returns a copy of this AggCall that may return approximate results if
approximate
is true. - APPROXIMATE_DECIMAL - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether approximate results from aggregate functions on DECIMAL types are acceptable.
- APPROXIMATE_DISTINCT_COUNT - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether approximate results from
COUNT(DISTINCT ...)
aggregate functions are acceptable. - APPROXIMATE_NUMERIC - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- APPROXIMATE_TOP_N - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether approximate results from "Top N" queries (
ORDER BY aggFun DESC LIMIT n
) are acceptable. - approximateDecimal() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.APPROXIMATE_DECIMAL
. - approximateDecimal() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- approximateDistinctCount() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.APPROXIMATE_DISTINCT_COUNT
. - approximateDistinctCount() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- approximateTopN() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.APPROXIMATE_TOP_N
. - approximateTopN() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- ARBITRARY - Enum constant in enum org.apache.calcite.plan.hep.HepMatchOrder
-
Match in arbitrary order.
- ARCHIVE - Enum constant in enum org.apache.calcite.sql.ddl.SqlDdlNodes.FileType
- areCharacterSetsMismatched(RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Determines whether two types both have different character sets.
- areColumnsDefinitelyUnique(RelMetadataQuery, RelNode, List<RexInputRef>) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
- areColumnsDefinitelyUnique(RelMetadataQuery, RelNode, ImmutableBitSet) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Returns true if the columns represented in a bit mask are definitely known to form a unique column set.
- areColumnsDefinitelyUniqueWhenNullsFiltered(RelMetadataQuery, RelNode, List<RexInputRef>) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
- areColumnsDefinitelyUniqueWhenNullsFiltered(RelMetadataQuery, RelNode, ImmutableBitSet) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Returns true if the columns represented in a bit mask are definitely known to form a unique column set, when nulls have been filtered from the columns.
- areColumnsUnique(RelSubset, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Converter, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Aggregate, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Calc, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Correlate, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Exchange, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Filter, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Intersect, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Join, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Minus, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Project, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(SetOp, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Sort, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(TableModify, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(TableScan, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Values, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(RelMetadataQuery, RelNode, List<RexInputRef>) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
- areColumnsUnique(RelNode, RelMetadataQuery, ImmutableBitSet, boolean) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ColumnUniqueness.Handler
- areColumnsUnique(RelNode, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
-
Catch-all implementation for
BuiltInMetadata.ColumnUniqueness.areColumnsUnique(ImmutableBitSet, boolean)
, invoked using reflection, for any relational expression not handled by a more specific method. - areColumnsUnique(RelNode, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.ColumnUniqueness.areColumnsUnique(ImmutableBitSet, boolean)
statistic. - areColumnsUnique(RelNode, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.ColumnUniqueness.areColumnsUnique(ImmutableBitSet, boolean)
statistic. - areColumnsUnique(ImmutableBitSet, boolean) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ColumnUniqueness
-
Determines whether a specified set of columns from a specified relational expression are unique.
- areColumnsUniqueWhenNullsFiltered(RelMetadataQuery, RelNode, List<RexInputRef>) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
- areEquivalent(E, E) - Method in class org.apache.calcite.util.EquivalenceSet
-
Returns whether two elements are in the same equivalence class.
- areRowsUnique(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns whether the rows of a given relational expression are distinct.
- areRowsUnique(RelNode, boolean) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns whether the rows of a given relational expression are distinct, optionally ignoring NULL values.
- areRowTypesEqual(RelDataType, RelDataType, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
- areSameFamily(Iterable<RelDataType>) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether all types in a collection have the same family, as determined by
SqlTypeUtil.isSameFamily(RelDataType, RelDataType)
. - ARG_MAX - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ARG_MAX
aggregate function. - ARG_MAX - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
ARG_MAX
aggregate function. - ARG_MIN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ARG_MIN
aggregate function. - ARG_MIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
ARG_MIN
aggregate function. - ARG0 - Enum constant in enum org.apache.calcite.adapter.enumerable.NullPolicy
-
If the first argument is null, return null.
- ARG0 - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of the operand #0 (0-based).
- ARG0_ARRAY_NULLABLE_VARYING - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that determines the return type based on the first argument.
- ARG0_EXCEPT_DATE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that returns the type of the first operand, unless it is a DATE, in which case the return type is TIMESTAMP.
- ARG0_EXCEPT_DATE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.ARG0_EXCEPT_DATE
but returns with nullability if any of the operands is nullable by usingSqlTypeTransforms.TO_NULLABLE
. - ARG0_EXCEPT_INTEGER - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that returns the type of the first operand, unless it is an integer type, in which case the return type is DOUBLE.
- ARG0_EXCEPT_INTEGER_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.ARG0_EXCEPT_INTEGER
but returns with nullability if any of the operands is nullable by usingSqlTypeTransforms.TO_NULLABLE
. - ARG0_FORCE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of the operand #0 (0-based), with nulls always allowed.
- ARG0_INTERVAL - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- ARG0_INTERVAL_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- ARG0_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of the operand #0 (0-based).
- ARG0_NULLABLE - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy where a derived type is transformed into the same type, but nullable if and only if the type of a call's operand #0 (0-based) is nullable.
- ARG0_NULLABLE_IF_ARG0_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of the operand #0 (0-based).
- ARG0_NULLABLE_IF_EMPTY - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of the operand #0 (0-based), and nullable if the call occurs within a "GROUP BY ()" query.
- ARG0_NULLABLE_VARYING - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is VARYING the type of the first argument.
- ARG0_OR_EXACT_NO_SCALE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is
ReturnTypes.DECIMAL_SCALE0
with a fallback toReturnTypes.ARG0
This rule is used for floor, ceiling. - ARG0_OR_INTEGER - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- ARG0_TABLE_FUNCTION_WINDOWING - Static variable in class org.apache.calcite.sql.SqlWindowTableFunction
-
Type-inference strategy whereby the row type of a table function call is a ROW, which is combined from the row type of operand #0 (which is a TABLE) and two additional fields.
- ARG1 - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of the operand #1 (0-based).
- ARG1_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of the operand #1 (0-based).
- ARG2 - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of operand #2 (0-based).
- ARG2_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of operand #2 (0-based).
- argBitSet() - Method in class org.apache.calcite.materialize.Lattice.Measure
-
Returns the set of distinct argument ordinals.
- ArgHandlerImpl() - Constructor for class org.apache.calcite.sql.util.SqlBasicVisitor.ArgHandlerImpl
- argOrdinals() - Method in class org.apache.calcite.materialize.Lattice.Measure
-
Returns a list of argument ordinals.
- args - Variable in class org.apache.calcite.materialize.Lattice.Measure
- args - Variable in class org.apache.calcite.model.JsonMeasure
-
Arguments to the measure.
- args - Variable in class org.apache.calcite.util.javac.JaninoCompiler
- args - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Call
- argTypes - Variable in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
-
Deprecated.
- ARGUMENT_ASSIGNMENT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Argument assignment operator,
=>
. - ARGUMENT_ASSIGNMENT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
ARGUMENT_ASSIGNMENT
operator (=<
) assigns an argument to a function call to a particular named parameter. - argumentMustBeBooleanLiteral(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- argumentMustBeLiteral(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- argumentMustBeMeasure(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- argumentMustBeNumericLiteralInRange(String, int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- argumentMustBePositiveInteger(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.fun.SqlCursorConstructor
- argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.fun.SqlInOperator
- argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.fun.SqlMultisetQueryConstructor
- argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether the
ordinal
th argument to this operator must be scalar (as opposed to a query). - argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.SqlSelectOperator
- argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.SqlSetSemanticsTableOperator
- argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.SqlUnnestOperator
- argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.SqlWindowTableFunction
-
Returns whether the
ordinal
th argument to this operator must be scalar (as opposed to a query). - argumentMustBeScalar(int) - Method in class org.apache.calcite.test.MockSqlOperatorTable.InvalidTableFunction
- argumentMustBeScalar(int) - Method in class org.apache.calcite.test.MockSqlOperatorTable.ScoreTableFunction
- argumentMustBeScalar(int) - Method in class org.apache.calcite.test.MockSqlOperatorTable.SimilarlityTableFunction
- argumentMustBeScalar(int) - Method in class org.apache.calcite.test.MockSqlOperatorTable.TopNTableFunction
- argumentMustBeValidPrecision(String, int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- argumentMustHaveScaleZero(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- argumentMustNotBeNull(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- arguments - Variable in class org.apache.calcite.linq4j.tree.NewExpression
- arguments() - Method in interface org.apache.calcite.adapter.enumerable.AggAddContext
-
Returns Linq4j form of arguments.
- arguments() - Method in class org.apache.calcite.adapter.enumerable.impl.AggAddContextImpl
- arguments() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggAddContextImpl
- arguments(Expression) - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- arguments(Expression) - Method in interface org.apache.calcite.adapter.enumerable.WinAggResultContext
-
Returns Linq4j form of arguments.
- array - Variable in class org.apache.calcite.linq4j.tree.IndexExpression
- array(Object...) - Static method in class org.apache.calcite.runtime.SqlFunctions
- array(RelNode) - Static method in class org.apache.calcite.rex.RexSubQuery
-
Creates an ARRAY sub-query.
- Array - Annotation Type in org.apache.calcite.adapter.java
-
Annotation that indicates that a field is an array type.
- ARRAY - Enum constant in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Records must be represented as arrays.
- ARRAY - Enum constant in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
- ARRAY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- ARRAY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- ARRAY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY(exp, ...)" function (Spark); compare with the standard array value constructor, "ARRAY [exp, ...]".
- ARRAY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_AGG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ARRAY_AGG
aggregate function. - ARRAY_AGG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_AGG(value [ ORDER BY ...])" aggregate function, in BigQuery and PostgreSQL, gathers values into arrays.
- ARRAY_APPEND - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_APPEND
function (Spark semantics). - ARRAY_APPEND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_APPEND - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_APPEND(array, element)" function.
- ARRAY_ARRAY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_BOOLEAN_LITERAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where the first operand must be array and the second operand must be a boolean non-NULL literal.
- ARRAY_COMPACT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_COMPACT
function (Spark semantics). - ARRAY_COMPACT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_COMPACT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_COMPACT(array)" function.
- ARRAY_COMPARER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_CONCAT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_CONCAT
function (BigQuery semantics). - ARRAY_CONCAT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_CONCAT(array [, array]*)" function.
- ARRAY_CONCAT_AGG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ARRAY_CONCAT_AGG
aggregate function. - ARRAY_CONCAT_AGG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_CONCAT_AGG(value [ ORDER BY ...])" aggregate function, in BigQuery and PostgreSQL, concatenates array values into arrays.
- ARRAY_CONTAINS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_CONTAINS
function (Spark semantics). - ARRAY_CONTAINS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_CONTAINS(array, element)" function.
- ARRAY_COPY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_DISTINCT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_DISTINCT
function (Spark semantics). - ARRAY_DISTINCT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_DISTINCT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_DISTINCT(array)" function.
- ARRAY_ELEMENT - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_ELEMENT_NONNULL - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_EXCEPT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_EXCEPT
function (Spark semantics). - ARRAY_EXCEPT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_EXCEPT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_EXCEPT(array1, array2)" function.
- ARRAY_FUNCTION - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_INSERT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_INSERT
function (Spark semantics). - ARRAY_INSERT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_INSERT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_INSERT(array, pos, val)" function (Spark).
- ARRAY_INSERT - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_INTERSECT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_INTERSECT
function (Spark semantics). - ARRAY_INTERSECT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_INTERSECT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_INTERSECT(array1, array2)" function.
- ARRAY_ITEM - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_JOIN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_JOIN
function (Spark semantics). - ARRAY_JOIN - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_JOIN(array, delimiter [, nullText ])" function.
- ARRAY_LENGTH - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_LENGTH
function (Spark semantics). - ARRAY_LENGTH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_LENGTH(array)" function.
- ARRAY_MAX - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_MAX
function (Spark semantics). - ARRAY_MAX - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_MAX - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_MAX(array)" function.
- ARRAY_MIN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_MIN
function (Spark semantics). - ARRAY_MIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_MIN - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_MAX(array)" function.
- ARRAY_NICE - Enum constant in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Consumer would prefer that records are represented as arrays, but can accommodate records represented as objects.
- ARRAY_NONNULL - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Type checker that accepts an ARRAY as the first argument, but not an expression with type NULL (i.e.
- ARRAY_OF_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_OR_MAP - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_POSITION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_POSITION
function (Spark semantics). - ARRAY_POSITION - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_POSITION - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_POSITION(array, element)" function.
- ARRAY_PREPEND - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_PREPEND
function (Spark semantics). - ARRAY_PREPEND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_PREPEND - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_PREPEND(array, element)" function.
- ARRAY_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The ARRAY Query Constructor.
- ARRAY_QUERY_CONSTRUCTOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Array Query Constructor, e.g.
- ARRAY_REMOVE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_REMOVE
function (Spark semantics). - ARRAY_REMOVE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_REMOVE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_REMOVE(array, element)" function.
- ARRAY_REPEAT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_REPEAT
function (Spark semantics). - ARRAY_REPEAT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_REPEAT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_REPEAT(element, count)" function.
- ARRAY_REVERSE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_REVERSE
function (BigQuery semantics). - ARRAY_REVERSE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_REVERSE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_REVERSE(array)" function.
- ARRAY_SIZE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_SIZE
function (Spark semantics). - ARRAY_SIZE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_SIZE(array)" function.
- ARRAY_TO_RDD - Enum constant in enum org.apache.calcite.adapter.spark.SparkMethod
- ARRAY_TO_STRING - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_TO_STRING
function (BigQuery semantics). - ARRAY_TO_STRING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_TO_STRING - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_TO_STRING(array, delimiter [, nullText ])" function.
- ARRAY_UNION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_UNION
function (Spark semantics). - ARRAY_UNION - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_UNION - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_UNION(array1, array2)" function.
- ARRAY_VALUE_CONSTRUCTOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Array Value Constructor, e.g.
- ARRAY_VALUE_CONSTRUCTOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The ARRAY Value Constructor.
- arrayAppend(List, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_APPEND function.
- arrayAppendFun(List, Integer) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- ArrayBindable - Interface in org.apache.calcite.runtime
-
Extension to
Bindable
that returns rows that are arrays of objects. - ArrayComparator - Class in org.apache.calcite.runtime
-
Compares arrays.
- ArrayComparator(boolean...) - Constructor for class org.apache.calcite.runtime.ArrayComparator
- ArrayComparator(Comparator...) - Constructor for class org.apache.calcite.runtime.ArrayComparator
- arrayComparer() - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns an
EqualityComparer
that works on arrays of objects. - arrayConverter(List<RelDataType>, List<Integer>, boolean) - Static method in class org.apache.calcite.adapter.file.CsvEnumerator
- ArrayElementOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Parameter type-checking strategy where types must be Array and Array element type.
- ArrayElementOperandTypeChecker(boolean, boolean) - Constructor for class org.apache.calcite.sql.type.ArrayElementOperandTypeChecker
- ArrayEnumeratorCursor - Class in org.apache.calcite.runtime
- ArrayEnumeratorCursor(Enumerator<Object[]>) - Constructor for class org.apache.calcite.runtime.ArrayEnumeratorCursor
-
Creates an ArrayEnumeratorCursor.
- arrayExcept(List, List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_EXCEPT function.
- arrayIndex(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an expression that represents applying an array index operator to an array of rank one.
- ArrayIndex - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An indexing operation in a one-dimensional array, such as
array[index]
in Java. - arrayIndexOutOfBounds(int) - Method in interface org.apache.calcite.runtime.CalciteResource
- arrayInsert(List, Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_INSERT function.
- ArrayInsertOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Parameter type checking strategy, where the operand size is 3, and the first type is array, the second type is integer, and the third type is the component type of the first array ( strictly matched without leastRestrictive conversion).
- ArrayInsertOperandTypeChecker() - Constructor for class org.apache.calcite.sql.type.ArrayInsertOperandTypeChecker
- arrayIntersect(List, List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_INTERSECT function.
- arrayItem(Object, int) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Gets an item from an array.
- arrayItem(Object, int, Primitive.Sink) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Sends to a sink an from an array.
- arrayItem(List, int, int, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper for "array element reference".
- arrayItem(Primitive.Source, Object, int) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Reads value from a source into an array.
- arrayItemOptional(List, int, int, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
As
SqlFunctions.arrayItem(java.util.List, int, int, boolean)
method, but allows array to be nullable. - arrayLength(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents an expression for obtaining the length of a one-dimensional array.
- ArrayLength - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An operation that obtains the length of a one-dimensional array, such as array.Length.
- ArrayLengthRecordField - Class in org.apache.calcite.linq4j.tree
-
Length field of a RecordType.
- ArrayLengthRecordField(String, Class) - Constructor for class org.apache.calcite.linq4j.tree.ArrayLengthRecordField
- arrayMax(List<? extends T>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_MAX function.
- arrayMin(List<? extends T>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_MIN function.
- arrayOrObjectValueRequiredInStrictModeOfJsonQueryFunc(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- arrayPosition(List, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_POSITION function.
- arrayPrepend(List, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_PREPEND function.
- arrayQuery(Function<RelBuilder, RelNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an ARRAY sub-query.
- arrayRemove(List, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_REMOVE function.
- arrayRepeat(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_REPEAT function.
- arrays(Comparator<V>) - Method in class org.apache.calcite.runtime.SortedMultiMap
- ARRAYS_AS_LIST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAYS_OVERLAP - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAYS_OVERLAP
function (Spark semantics). - ARRAYS_OVERLAP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAYS_OVERLAP - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAYS_OVERLAP(array1, array2)" function (Spark).
- ARRAYS_ZIP - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAYS_ZIP
function (Spark semantics). - ARRAYS_ZIP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAYS_ZIP - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAYS_ZIP(array, ...)" function (Spark).
- arraysOverlap(List, List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAYS_OVERLAP function.
- ArraySqlType - Class in org.apache.calcite.sql.type
-
SQL array type.
- ArraySqlType(RelDataType, boolean) - Constructor for class org.apache.calcite.sql.type.ArraySqlType
-
Creates an ArraySqlType.
- arraysZip(List...) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAYS_ZIP function.
- arrayToList(Array) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a JDBC array to a list.
- arrayToString(Object) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Converts an array to a string.
- arrayToString(List, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ARRAY_TO_STRING(array, delimiter)
function. - arrayToString(List, String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ARRAY_TO_STRING(array, delimiter, nullText)
function. - ArrayType(Type) - Constructor for class org.apache.calcite.linq4j.tree.Types.ArrayType
- ArrayType(Type, boolean, long) - Constructor for class org.apache.calcite.linq4j.tree.Types.ArrayType
- arrayUnion(List, List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_UNION function.
- ArrowFilterRule(ArrowRules.ArrowFilterRule.Config) - Constructor for class org.apache.calcite.adapter.arrow.ArrowRules.ArrowFilterRule
-
Creates an ArrowFilterRule.
- ArrowProjectRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.arrow.ArrowRules.ArrowProjectRule
-
Creates an ArrowProjectRule.
- ArrowRel - Interface in org.apache.calcite.adapter.arrow
-
Relational expression that uses the Arrow calling convention.
- ArrowRel.Implementor - Class in org.apache.calcite.adapter.arrow
-
Callback for the implementation process that converts a tree of
ArrowRel
nodes into a SQL query. - ArrowRules - Class in org.apache.calcite.adapter.arrow
-
Planner rules relating to the Arrow adapter.
- ArrowRules.ArrowFilterRule - Class in org.apache.calcite.adapter.arrow
-
Rule to convert a
Filter
to anArrowFilter
. - ArrowRules.ArrowFilterRule.Config - Interface in org.apache.calcite.adapter.arrow
-
Rule configuration.
- ArrowRules.ArrowProjectRule - Class in org.apache.calcite.adapter.arrow
-
Planner rule that projects from an
ArrowTableScan
just the columns needed to satisfy a projection. - ArrowSchemaFactory - Class in org.apache.calcite.adapter.arrow
-
Factory that creates an
ArrowSchema
. - ArrowSchemaFactory() - Constructor for class org.apache.calcite.adapter.arrow.ArrowSchemaFactory
- ArrowTable - Class in org.apache.calcite.adapter.arrow
-
Arrow Table.
- ARTIFICIAL_SELECTIVITY_FUNC - Static variable in class org.apache.calcite.rel.metadata.RelMdUtil
- as(String) - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
-
Returns a copy of this AggCall with a given alias.
- as(Class<T>) - Method in interface org.apache.calcite.plan.RelRule.Config
-
Casts this configuration to another type, usually a sub-class.
- as(String) - Method in class org.apache.calcite.tools.PigRelBuilder
-
As super-class method, but also retains alias for naming of aggregates.
- as(String) - Method in class org.apache.calcite.tools.RelBuilder
-
Assigns a table alias to the top entry on the stack.
- as(String) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets the alias of this expression, and converts it to a
RexNode
; default is the alias that was set viaRelBuilder.AggCall.as(String)
. - as(SqlNode, String, String...) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Convenience method for creating column and table aliases.
- AS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
AS
operator. - AS - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Alias ("AS").
- AS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
AS
operator associates an expression in the SELECT clause with an alias. - AS_ENUMERABLE - Enum constant in enum org.apache.calcite.adapter.spark.SparkMethod
- AS_ENUMERABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AS_ENUMERABLE2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AS_IS - Enum constant in enum org.apache.calcite.plan.Strong.Policy
-
This kind of expression may be null.
- AS_LIST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AS_QUERYABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- asBufferParameters() - Method in class org.apache.calcite.runtime.BufferStyle
-
Returns buffer parameters.
- ASC - Enum constant in enum org.apache.calcite.piglet.Ast.Direction
- ASC - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeSort
- ASCENDING - Enum constant in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Ascending direction: A value is always followed by a greater or equal value.
- ascii(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL ASCII(string) function.
- ASCII - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ASCII - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- asCopy(Object...) - Static method in class org.apache.calcite.interpreter.Row
-
Creates a Row.
- asEnumerable() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- asEnumerable() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- asEnumerable() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the input typed as
Enumerable<TSource>
. - asEnumerable(Iterable<T>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Adapter that converts an
Iterable
into anEnumerable
. - asEnumerable(Collection<T>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Adapter that converts an
Collection
into anEnumerable
. - asEnumerable(List<T>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Adapter that converts an
List
into anEnumerable
. - asEnumerable(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the input typed as
Enumerable<TSource>
. - asEnumerable(JavaRDD<T>) - Static method in class org.apache.calcite.adapter.spark.SparkRuntime
-
Converts an RDD into an enumerable.
- asEnumerable(T[]) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Adapter that converts an array into an enumerable.
- asEwkt(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Returns the Extended Well-Known text (EWKT) representation of the geometry.
- asFrom() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Returns a node that can be included in the FROM clause or a JOIN.
- asGeoJson(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Returns the GeoJson representation of the geometry.
- asGml(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Returns the GML representation of the geometry.
- asIdentifier(SqlNode) - Static method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Converts a
SqlIntervalQualifier
to aSqlIdentifier
if it is a time frame reference. - asImmutable() - Method in class org.apache.calcite.util.IntList
-
Deprecated.
- asin(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ASIN
operator applied to double values. - asin(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ASIN
operator applied to BigDecimal values. - ASIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ASIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
ASIN(numeric)
function. - asind(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ASIND
operator applied to double values. - asind(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ASIND
operator applied to BigDecimal values. - ASIND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ASIND - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
ACOSD(numeric)
function; returns the inverse sine ofvalue
in degrees. - asIndexMap(Collection<V>, Function<V, K>) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- asIndexMapJ(Collection<V>, Function<V, K>) - Static method in class org.apache.calcite.util.Util
-
Returns a map that is a view onto a collection of values, using the provided function to convert a value to a key.
- asinh(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ASINH
operator applied to double values. - asinh(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ASINH
operator applied to BigDecimal values. - ASINH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ASINH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
ASINH(numeric)
function; returns the inverse hyperbolic sine ofvalue
. - asList() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Creates a view onto this bit set as a list of integers.
- asList(boolean[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(byte[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(char[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(double[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(float[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(int[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(int[]) - Static method in class org.apache.calcite.util.IntList
-
Deprecated.
- asList(long[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(short[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(Object) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Adapts a primitive array into a
List
. - asList(Mappings.TargetMapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Returns a mapping as a list such that
list.get(source)
ismapping.getTarget(source)
andlist.size()
ismapping.getSourceCount()
. - asListNonNull(Mappings.TargetMapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Returns a mapping as a list such that
list.get(source)
ismapping.getTarget(source)
andlist.size()
ismapping.getSourceCount()
. - ASOF - Enum constant in enum org.apache.calcite.linq4j.JoinType
-
An ASOF JOIN operation combines rows from two tables based on comparable timestamp values.
- ASOF - Enum constant in enum org.apache.calcite.rel.core.JoinRelType
-
An ASOF JOIN operation combines rows from two tables based on comparable timestamp values.
- ASOF - Enum constant in enum org.apache.calcite.sql.JoinType
-
An ASOF JOIN operation combines rows from two tables based on comparable timestamp values.
- ASOF_JOIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- asofCannotBeCorrelated() - Method in interface org.apache.calcite.runtime.CalciteResource
- asofConditionMustBeComparison() - Method in interface org.apache.calcite.runtime.CalciteResource
- asofJoin(Enumerable<TInner>, Function1<T, TKey>, Function1<TInner, TKey>, Function2<T, TInner, TResult>, Predicate2<T, TInner>, Comparator<TInner>, boolean) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- asofJoin(Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, TInner, TResult>, Predicate2<TSource, TInner>, Comparator<TInner>, boolean) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Correlates elements of two sequences based on - matching keys - a comparator for timestamps.
- asofJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, TInner, TResult>, Predicate2<TSource, TInner>, Comparator<TInner>, boolean) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
ASOF join implementation.
- asofJoin(JoinRelType, RexNode, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
LogicalAsofJoin
with the specified conditions. - AsofJoin - Class in org.apache.calcite.rel.core
-
Base class for various ASOF JOIN representations.
- AsofJoin(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RelNode, RexNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.rel.core.AsofJoin
- asofJoinFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- asofMatchMustBeComparison() - Method in interface org.apache.calcite.runtime.CalciteResource
- asofRequiresMatchCondition() - Method in interface org.apache.calcite.runtime.CalciteResource
- asOrderedQueryable() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- asOrderedQueryable(Enumerable<T>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- asQueryable() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- asQueryable() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- asQueryable() - Method in interface org.apache.calcite.linq4j.Enumerable
-
Converts this Enumerable to a Queryable.
- asQueryable() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Converts an Enumerable to a
Queryable
. - asQueryable(DefaultEnumerable<T>) - Static method in class org.apache.calcite.linq4j.Extensions
- asQueryable(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Converts an Enumerable to an IQueryable.
- asQueryable(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Converts a generic
Enumerable<T>
to a genericIQueryable<T>
. - asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.arrow.ArrowTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.csv.CsvTranslatableTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.file.CsvTranslatableTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.geode.rel.GeodeTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.innodb.InnodbTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.mongodb.MongoTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.schema.impl.ListTransientTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.schema.impl.ViewTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in interface org.apache.calcite.schema.QueryableTable
-
Converts this table into a
Queryable
. - asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockDynamicTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.util.Smalls.SimpleTable
- asQueryOrValues() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Converts a non-query node into a SELECT node.
- asSelect() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Converts a non-query node into a SELECT node.
- assertArrayEqual(String, Object[], Object[]) - Static method in class org.apache.calcite.test.CalciteAssert
-
Asserts that two objects are equal.
- assertBindType(Matcher<String>) - Method in class org.apache.calcite.test.SqlValidatorFixture
- assertCharset(Matcher<Charset>) - Method in class org.apache.calcite.test.SqlValidatorFixture
- assertCollation(Matcher<String>, Matcher<SqlCollation.Coercibility>) - Method in class org.apache.calcite.test.SqlValidatorFixture
- assertColumnOriginDouble(String, String, String, String, boolean) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks that
RelMetadataQuery.getColumnOrigins(RelNode, int)
for column 0 returns two origins. - assertColumnOriginIsEmpty() - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks that
RelMetadataQuery.getColumnOrigins(RelNode, int)
for column 0 returns no origins. - assertColumnOriginSingle(String, String, boolean) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks that
RelMetadataQuery.getColumnOrigins(RelNode, int)
for column 0 returns one origin. - assertConvertsTo(SqlTestFactory, DiffRepository, String, String, boolean, boolean, boolean) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- assertConvertsTo(SqlTestFactory, DiffRepository, String, String, boolean, boolean, boolean) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Checks that a SQL statement converts to a given plan, optionally trimming columns that are not needed.
- assertCpuCost(Matcher<Double>, String) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks the CPU component of
RelNode.computeSelfCost(RelOptPlanner, RelMetadataQuery)
. - assertEquals(String, String, String) - Method in class org.apache.calcite.test.DiffRepository
- assertEqualsVerbose(String, String) - Static method in class org.apache.calcite.util.TestUtil
- assertExceptionIsThrown(SqlTestFactory, StringAndPos, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- assertExceptionIsThrown(SqlTestFactory, StringAndPos, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Checks that a query is valid, or, if invalid, throws the right message at the right location.
- assertExceptionIsThrown(SqlTestFactory, StringAndPos, String) - Method in class org.apache.calcite.test.SqlOperatorTest.TesterImpl
- assertExceptionIsThrown(SqlTestFactory, StringAndPos, String, boolean) - Method in class org.apache.calcite.test.SqlOperatorTest.TesterImpl
- assertFieldOrigin(Matcher<String>) - Method in class org.apache.calcite.test.SqlValidatorFixture
-
Tests that the list of the origins of each result field of the current query match expected.
- assertInterval(Matcher<Long>) - Method in class org.apache.calcite.test.SqlValidatorFixture
-
Checks if the interval value conversion to milliseconds is valid.
- assertMeasure(int, Matcher<Boolean>) - Method in class org.apache.calcite.test.SqlValidatorFixture
-
Checks that column
column
is or is not a measure. - assertMonotonicity(Matcher<SqlMonotonicity>) - Method in class org.apache.calcite.test.SqlValidatorFixture
-
Tests that the first column of the query has a given monotonicity.
- assertParse(String) - Method in interface org.apache.calcite.test.IntervalTest.Fixture2
-
Checks that the expression parses successfully and produces the given SQL when unparsed.
- assertPercentageOriginalRows(Matcher<Double>) - Method in class org.apache.calcite.test.RelMetadataFixture
- assertRowsUnique(boolean, Matcher<Boolean>, String) - Method in class org.apache.calcite.test.RelMetadataFixture
- assertRowsUnique(Matcher<Boolean>, String) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks
RelMetadataQuery.areRowsUnique(RelNode)
for all values ofignoreNulls
. - assertThatAreColumnsUnique(Function<RelNode, ImmutableBitSet>, UnaryOperator<RelNode>, Matcher<Boolean>) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks
RelMetadataQuery.areColumnsUnique(RelNode, ImmutableBitSet)
, deriving parameters via functions. - assertThatAreColumnsUnique(ImmutableBitSet, Matcher<Boolean>) - Method in class org.apache.calcite.test.RelMetadataFixture
- assertThatAreRowsUnique(Matcher<Boolean>) - Method in class org.apache.calcite.test.RelMetadataFixture
- assertThatDistinctRowCount(Function<RelNode, ImmutableBitSet>, Matcher<Double>) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks
RelMetadataQuery.getDistinctRowCount(RelNode, ImmutableBitSet, RexNode)
with a null predicate, deriving the group key from theRelNode
. - assertThatDistinctRowCount(ImmutableBitSet, Matcher<Double>) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks
RelMetadataQuery.getDistinctRowCount(RelNode, ImmutableBitSet, RexNode)
with a null predicate. - assertThatNodeTypeCount(Matcher<Map<Class<? extends RelNode>, Integer>>) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks the number of each sub-class of
RelNode
, callingRelMetadataQuery.getNodeTypes(RelNode)
. - assertThatNodeTypeCountIs(Class<? extends RelNode>, Integer, Object...) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Shorthand for a call to
RelMetadataFixture.assertThatNodeTypeCount(Matcher)
with a constant map. - assertThatRel(Matcher<RelNode>) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks the
RelNode
produced byRelMetadataFixture.toRel()
. - assertThatRowCount(Matcher<Number>, Matcher<Number>, Matcher<Number>) - Method in class org.apache.calcite.test.RelMetadataFixture
- assertThatScientific(String, Matcher<String>) - Static method in class org.apache.calcite.util.TestUtil
- assertThatSelectivity(Matcher<Double>) - Method in class org.apache.calcite.test.RelMetadataFixture
- assertThatUniqueKeys(Matcher<Iterable<ImmutableBitSet>>) - Method in class org.apache.calcite.test.RelMetadataFixture
- assertThatUniqueKeysAre(ImmutableBitSet...) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks result of getting unique keys for SQL.
- asSet() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Creates a view onto this bit set as a set of integers.
- asSidedDistance(double) - Method in class org.apache.calcite.runtime.BufferStyle
-
Returns a sided distance.
- assign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an assignment operation.
- Assign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An assignment operation, such as (a = b).
- assignableFrom(Primitive) - Method in enum org.apache.calcite.linq4j.tree.Primitive
- AssignableOperandTypeChecker - Class in org.apache.calcite.sql.type
-
AssignableOperandTypeChecker implements
SqlOperandTypeChecker
by verifying that the type of each argument is assignable to a predefined set of parameter types (under the SQL definition of "assignable"). - AssignableOperandTypeChecker(List<RelDataType>, List<String>) - Constructor for class org.apache.calcite.sql.type.AssignableOperandTypeChecker
-
Instantiates this strategy with a specific set of parameter types.
- Assignment(SqlParserPos, Ast.Op, Ast.Identifier) - Constructor for class org.apache.calcite.piglet.Ast.Assignment
- Assignment1(SqlParserPos, Ast.Op, Ast.Identifier, Ast.Identifier) - Constructor for class org.apache.calcite.piglet.Ast.Assignment1
- assignments() - Method in class org.apache.calcite.rex.RexAnalyzer
-
Generates a map of variables and lists of values that could be assigned to them.
- assignNamesFrom(SqlIdentifier) - Method in class org.apache.calcite.sql.SqlIdentifier
-
Copies names and components from another identifier.
- asSql(boolean, boolean) - Method in class org.apache.calcite.util.NlsString
-
As
NlsString.asSql(boolean, boolean, SqlDialect)
but with SQL standard dialect. - asSql(boolean, boolean, SqlDialect) - Method in class org.apache.calcite.util.NlsString
-
Returns the string quoted for SQL, for example
_ISO-8859-1'is it a plane? no it''s superman!'
. - asStatement() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Converts a non-query node into a SELECT node.
- asString() - Method in class org.apache.calcite.rel.externalize.RelJsonWriter
-
Returns a JSON string describing the relational expressions that were just explained.
- asStringBuilder(Appendable, Consumer<StringBuilder>) - Static method in class org.apache.calcite.util.Util
-
Given an
Appendable
, performs an action that requires aStringBuilder
. - Ast - Class in org.apache.calcite.piglet
-
Abstract syntax tree.
- Ast.Assignment - Class in org.apache.calcite.piglet
-
Abstract base class for statements that assign to a named relation.
- Ast.Assignment1 - Class in org.apache.calcite.piglet
-
Abstract base class for an assignment with one source relation.
- Ast.BagType - Class in org.apache.calcite.piglet
-
Parse tree for a bag type.
- Ast.Call - Class in org.apache.calcite.piglet
-
Parse tree node for a call to a function or operator.
- Ast.DescribeStmt - Class in org.apache.calcite.piglet
-
Parse tree node for DESCRIBE statement.
- Ast.Direction - Enum in org.apache.calcite.piglet
-
Sort direction.
- Ast.DistinctStmt - Class in org.apache.calcite.piglet
-
Parse tree node for DISTINCT statement.
- Ast.DumpStmt - Class in org.apache.calcite.piglet
-
Parse tree node for DUMP statement.
- Ast.FieldSchema - Class in org.apache.calcite.piglet
-
Parse tree for field schema.
- Ast.FilterStmt - Class in org.apache.calcite.piglet
-
Parse tree node for FILTER statement.
- Ast.ForeachNestedStmt - Class in org.apache.calcite.piglet
-
Parse tree node for FOREACH statement (nested).
- Ast.ForeachStmt - Class in org.apache.calcite.piglet
-
Parse tree node for FOREACH statement (non-nested).
- Ast.GroupStmt - Class in org.apache.calcite.piglet
-
Parse tree node for GROUP statement.
- Ast.Identifier - Class in org.apache.calcite.piglet
-
Parse tree node for Identifier.
- Ast.LimitStmt - Class in org.apache.calcite.piglet
-
Parse tree node for LIMIT statement.
- Ast.Literal - Class in org.apache.calcite.piglet
-
Parse tree node for Literal.
- Ast.LoadStmt - Class in org.apache.calcite.piglet
-
Parse tree node for LOAD statement.
- Ast.MapType - Class in org.apache.calcite.piglet
-
Parse tree for a map type.
- Ast.Node - Class in org.apache.calcite.piglet
-
Abstract base class for parse tree node.
- Ast.NumericLiteral - Class in org.apache.calcite.piglet
-
Parse tree node for NumericLiteral.
- Ast.Op - Enum in org.apache.calcite.piglet
-
Parse tree node type.
- Ast.OrderStmt - Class in org.apache.calcite.piglet
-
Parse tree node for ORDER statement.
- Ast.Program - Class in org.apache.calcite.piglet
-
Parse tree node for a program.
- Ast.ScalarType - Class in org.apache.calcite.piglet
-
Parse tree for scalar type such as
int
. - Ast.Schema - Class in org.apache.calcite.piglet
-
Parse tree for schema.
- Ast.SpecialIdentifier - Class in org.apache.calcite.piglet
-
Parse tree node for "*", a special kind of identifier.
- Ast.Stmt - Class in org.apache.calcite.piglet
-
Abstract base class for parse tree node representing a statement.
- Ast.TupleType - Class in org.apache.calcite.piglet
-
Parse tree for a tuple type.
- Ast.Type - Class in org.apache.calcite.piglet
-
Parse tree for type.
- Ast.ValuesStmt - Class in org.apache.calcite.piglet
-
Parse tree node for VALUES statement.
- asWkb(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Returns the Extended Well-Known binary (WKB) representation of the geometry.
- asWkt(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Returns the Well-Known text (WKT) representation of the geometry.
- ASYMMETRIC - Enum constant in enum org.apache.calcite.sql.fun.SqlBetweenOperator.Flag
- AT_LEAST_ONE_SAME_VARIADIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where any positive number of operands must all be in the same type family.
- atan(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATAN
operator applied to double values. - atan(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATAN
operator applied to BigDecimal values. - ATAN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ATAN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
ATAN(numeric)
function. - atan2(double, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATAN2
operator applied to double values. - atan2(double, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATAN2
operator applied to double/BigDecimal values. - atan2(BigDecimal, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATAN2
operator applied to BigDecimal/double values. - atan2(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATAN2
operator applied to BigDecimal values. - ATAN2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ATAN2 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
ATAN2(numeric, numeric)
function. - atand(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATAND
operator applied to double values. - atand(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATAN
operator applied to BigDecimal values. - ATAND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ATAND - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
ACOSD(numeric)
function; returns the inverse tangent ofvalue
in degrees. - atanh(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATANH
operator applied to double values. - atanh(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATANH
operator applied to BigDecimal values. - ATANH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ATANH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
ATANH(numeric)
function; returns the inverse hyperbolic tangent ofvalue
. - atLeast(V) - Method in interface org.apache.calcite.util.RangeSets.Consumer
- atLeast(V) - Method in interface org.apache.calcite.util.RangeSets.Handler
- atLeastOneArgumentMustNotBeNull(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- atMost(V) - Method in interface org.apache.calcite.util.RangeSets.Consumer
- atMost(V) - Method in interface org.apache.calcite.util.RangeSets.Handler
- atom(Object) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- atom(Object) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- ATOM - Enum constant in enum org.apache.calcite.util.PrecedenceClimbingParser.Type
- atomicBoolean - Variable in class org.apache.calcite.util.CancelFlag
-
The flag that holds the cancel state.
- attachHints(List<RelHint>) - Method in interface org.apache.calcite.rel.hint.Hintable
-
Attaches list of hints to this relational expression.
- attachRelHint(HintStrategyTable, List<RelHint>, Hintable) - Static method in class org.apache.calcite.sql.SqlUtil
-
Attach the
hints
torel
with specified hint strategies. - attachTo(RelOptPlanner) - Method in class org.apache.calcite.plan.visualizer.RuleMatchVisualizer
-
Attaches the visualizer to the planner.
- ATTEMPT_SUGGESTER - Static variable in class org.apache.calcite.sql.validate.SqlValidatorUtil
- attribute(String, String) - Method in class org.apache.calcite.util.XmlOutput
-
Writes an attribute.
- attribute(SqlParserPos, SqlIdentifier, SqlDataTypeSpec, SqlNode, SqlCollation) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates an attribute definition.
- ATTRIBUTE_DEF - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Attribute definition.
- AttributedDirectedGraph<V,
E extends DefaultEdge> - Class in org.apache.calcite.util.graph -
Directed graph where edges have attributes and allows multiple edges between any two vertices provided that their attributes are different.
- AttributedDirectedGraph(AttributedDirectedGraph.AttributedEdgeFactory<V, E>) - Constructor for class org.apache.calcite.util.graph.AttributedDirectedGraph
-
Creates an attributed graph.
- AttributedDirectedGraph.AttributedEdgeFactory<V,
E> - Interface in org.apache.calcite.util.graph -
Factory for edges that have attributes.
- attributeDefs - Variable in class org.apache.calcite.sql.ddl.SqlCreateType
- attributes - Variable in class org.apache.calcite.model.JsonType
-
Definition of the attributes of this type.
- Author(int, String, BookstoreSchema.Place, List<BookstoreSchema.Book>) - Constructor for class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Author
- authors - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema
- auto - Variable in class org.apache.calcite.materialize.Lattice
- auto - Variable in class org.apache.calcite.model.JsonLattice
-
Whether to materialize tiles on demand as queries are executed.
- auto(boolean) - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Sets the "auto" attribute (default true).
- AUTO_TEMP - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether to store query results in temporary tables.
- autodetectRelTypeFromRegion(Region<?, ?>) - Static method in class org.apache.calcite.adapter.geode.util.GeodeUtils
-
Extract the first entity of each Regions and use it to build a table types.
- autoLattice - Variable in class org.apache.calcite.model.JsonSchema
-
Whether to create lattices in this schema based on queries occurring in other schemas.
- automaton() - Method in class org.apache.calcite.runtime.Pattern.PatternBuilder
-
Returns the resulting automaton.
- Automaton - Class in org.apache.calcite.runtime
-
A nondeterministic finite-state automaton (NFA).
- AutomatonBuilder - Class in org.apache.calcite.runtime
-
Builds a state-transition graph for deterministic finite automaton.
- AutomatonBuilder() - Constructor for class org.apache.calcite.runtime.AutomatonBuilder
- autoPruneOld() - Method in class org.apache.calcite.rel.rules.ProjectRemoveRule
- autoPruneOld() - Method in class org.apache.calcite.rel.rules.PruneEmptyRules.PruneEmptyRule
- autoPruneOld() - Method in class org.apache.calcite.rel.rules.SingleValuesOptimizationRules.PruneSingleValueRule
- autoPruneOld() - Method in interface org.apache.calcite.rel.rules.SubstitutionRule
-
Whether the planner should automatically prune old node when there is at least 1 equivalent rel generated by the rule.
- autoPruneOld() - Method in class org.apache.calcite.rel.rules.UnionEliminatorRule
- autoTemp() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.AUTO_TEMP
. - autoTemp() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- AUX - Enum constant in enum org.apache.calcite.test.CalciteAssert.Config
-
Configuration that loads AUX schema for tests involving view expansions and lateral joins tests.
- AUX - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- auxiliary(String, SqlKind) - Method in class org.apache.calcite.sql.SqlGroupedWindowFunction
-
Creates an auxiliary function from this grouped window function.
- auxiliary(SqlKind) - Method in class org.apache.calcite.sql.SqlGroupedWindowFunction
-
Creates an auxiliary function from this grouped window function.
- AUXILIARY_TABLE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
An auxiliary table.
- AuxiliaryConverter - Interface in org.apache.calcite.sql2rel
-
Converts an expression for a group window function (e.g.
- AuxiliaryConverter.Impl - Class in org.apache.calcite.sql2rel
-
Simple implementation of
AuxiliaryConverter
. - auxiliaryToGroup(SqlKind) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Returns the group function for which a given kind is an auxiliary function, or null if it is not an auxiliary function.
- auxiliaryWithoutMatchingGroupCall(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- AVATICA_VERSION - Static variable in class org.apache.calcite.util.TestUtil
- average(Enumerable<TSource>, BigDecimalFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of Decimal values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, DoubleFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of Double values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, FloatFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of Float values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, IntegerFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of int values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, LongFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of long values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, NullableBigDecimalFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of nullable Decimal values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, NullableDoubleFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of nullable Double values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, NullableFloatFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of nullable Float values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, NullableIntegerFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of nullable int values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, NullableLongFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of nullable long values that are obtained by invoking a transform function on each element of the input sequence.
- average(BigDecimalFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(BigDecimalFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of Decimal values that are obtained by invoking a transform function on each element of the input sequence.
- average(DoubleFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(DoubleFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of Double values that are obtained by invoking a transform function on each element of the input sequence.
- average(FloatFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(FloatFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of Float values that are obtained by invoking a transform function on each element of the input sequence.
- average(IntegerFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(IntegerFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of int values that are obtained by invoking a transform function on each element of the input sequence.
- average(LongFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(LongFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of long values that are obtained by invoking a transform function on each element of the input sequence.
- average(NullableBigDecimalFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(NullableBigDecimalFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of nullable Decimal values that are obtained by invoking a transform function on each element of the input sequence.
- average(NullableDoubleFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(NullableDoubleFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of nullable Double values that are obtained by invoking a transform function on each element of the input sequence.
- average(NullableFloatFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(NullableFloatFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of nullable Float values that are obtained by invoking a transform function on each element of the input sequence.
- average(NullableIntegerFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(NullableIntegerFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of nullable int values that are obtained by invoking a transform function on each element of the input sequence.
- average(NullableLongFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(NullableLongFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of nullable long values that are obtained by invoking a transform function on each element of the input sequence.
- AVERAGE_COLUMN_SIZES - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AVERAGE_ROW_SIZE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- averageBigDecimal(Queryable<T>, FunctionExpression<BigDecimalFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- averageBigDecimal(Queryable<T>, FunctionExpression<BigDecimalFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- averageBigDecimal(Queryable<T>, FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageBigDecimal(FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageBigDecimal(FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- averageColumnSizes() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Size
-
Determines the average size (in bytes) of a value of a column in this relational expression.
- averageColumnSizes(Aggregate, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Calc, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Exchange, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Filter, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Intersect, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Join, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Minus, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Project, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Sort, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(TableModify, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Union, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Values, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Size.Handler
- averageColumnSizes(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
-
Catch-all implementation for
BuiltInMetadata.Size.averageColumnSizes()
, invoked using reflection. - averageDouble(Queryable<T>, FunctionExpression<DoubleFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of Double values that is obtained by invoking a projection function on each element of the input sequence.
- averageDouble(Queryable<T>, FunctionExpression<DoubleFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of Double values that is obtained by invoking a projection function on each element of the input sequence.
- averageDouble(Queryable<T>, FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageDouble(FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageDouble(FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of Double values that is obtained by invoking a projection function on each element of the input sequence.
- averageFieldValueSize(RelDataTypeField) - Method in class org.apache.calcite.rel.metadata.RelMdSize
-
Estimates the average size (in bytes) of a value of a field, knowing nothing more than its type.
- averageFloat(Queryable<T>, FunctionExpression<FloatFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of Float values that is obtained by invoking a projection function on each element of the input sequence.
- averageFloat(Queryable<T>, FunctionExpression<FloatFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of Float values that is obtained by invoking a projection function on each element of the input sequence.
- averageFloat(Queryable<T>, FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageFloat(FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageFloat(FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of Float values that is obtained by invoking a projection function on each element of the input sequence.
- averageInteger(Queryable<T>, FunctionExpression<IntegerFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of int values that is obtained by invoking a projection function on each element of the input sequence.
- averageInteger(Queryable<T>, FunctionExpression<IntegerFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of int values that is obtained by invoking a projection function on each element of the input sequence.
- averageInteger(Queryable<T>, FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageInteger(FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageInteger(FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of int values that is obtained by invoking a projection function on each element of the input sequence.
- averageLong(Queryable<T>, FunctionExpression<LongFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of long values that is obtained by invoking a projection function on each element of the input sequence.
- averageLong(Queryable<T>, FunctionExpression<LongFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of long values that is obtained by invoking a projection function on each element of the input sequence.
- averageLong(Queryable<T>, FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageLong(FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageLong(FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of long values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableBigDecimal(Queryable<T>, FunctionExpression<NullableBigDecimalFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of nullable Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableBigDecimal(Queryable<T>, FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of nullable Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableBigDecimal(Queryable<T>, FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageNullableBigDecimal(FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageNullableBigDecimal(FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of nullable Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableDouble(Queryable<T>, FunctionExpression<NullableDoubleFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of nullable Double values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableDouble(Queryable<T>, FunctionExpression<NullableDoubleFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of nullable Double values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableDouble(Queryable<T>, FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageNullableDouble(FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageNullableDouble(FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of nullable Double values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableFloat(Queryable<T>, FunctionExpression<NullableFloatFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of nullable Float values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableFloat(Queryable<T>, FunctionExpression<NullableFloatFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of nullable Float values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableFloat(Queryable<T>, FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageNullableFloat(FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageNullableFloat(FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of nullable Float values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableInteger(Queryable<T>, FunctionExpression<NullableIntegerFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of nullable int values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableInteger(Queryable<T>, FunctionExpression<NullableIntegerFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of nullable int values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableInteger(Queryable<T>, FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageNullableInteger(FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageNullableInteger(FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of nullable int values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableLong(Queryable<T>, FunctionExpression<NullableLongFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of nullable long values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableLong(Queryable<T>, FunctionExpression<NullableLongFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of nullable long values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableLong(Queryable<T>, FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageNullableLong(FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageNullableLong(FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of nullable long values that is obtained by invoking a projection function on each element of the input sequence.
- averageRexSize(RexNode, List<? extends Double>) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageRowSize() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Size
-
Determines the average size (in bytes) of a row from this relational expression.
- averageRowSize(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Size.Handler
- averageRowSize(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
-
Catch-all implementation for
BuiltInMetadata.Size.averageRowSize()
, invoked using reflection. - averageTypeValueSize(RelDataType) - Method in class org.apache.calcite.rel.metadata.RelMdSize
-
Estimates the average size (in bytes) of a value of a type.
- avg(boolean, String, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
AVG
aggregate function, optionally distinct and with an alias. - avg(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
AVG
aggregate function. - avg(SqlParserPos, boolean, String, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
AVG
aggregate function, optionally distinct and with an alias. - avg(SqlParserPos, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
AVG
aggregate function. - AVG - Enum constant in enum org.apache.calcite.sql.fun.SqlAvgAggFunction.Subtype
-
Deprecated.
- AVG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
AVG
aggregate function. - AVG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
AVG
aggregate function. - AVG_AGG_FUNCTION - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- AVG_AGG_FUNCTIONS - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of SqlAvgAggFunction.
- axisList - Variable in class org.apache.calcite.sql.SqlPivot
- axisList - Variable in class org.apache.calcite.sql.SqlUnpivot
B
- BABEL - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that allows anything supported by any dialect.
- backedBy(List<Object>) - Static method in interface org.apache.calcite.runtime.PairList
-
Creates a PairList backed by a given list.
- BAD_DATETIME_MESSAGE - Static variable in interface org.apache.calcite.sql.test.SqlOperatorFixture
- badFormat(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- badLowerBoundary() - Method in interface org.apache.calcite.runtime.CalciteResource
- BadTableFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.BadTableFunction
- BadType() - Constructor for class org.apache.calcite.test.schemata.catchall.CatchallSchema.BadType
- badTypes - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- badUpperBoundary() - Method in interface org.apache.calcite.runtime.CalciteResource
- BAG - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- BAG_TYPE - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- BagType(SqlParserPos, Ast.Type) - Constructor for class org.apache.calcite.piglet.Ast.BagType
- bangEqualNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- BarfingInvocationHandler - Class in org.apache.calcite.util
-
A class derived from
BarfingInvocationHandler
handles a method call by looking for a method in itself with identical parameters. - BarfingInvocationHandler() - Constructor for class org.apache.calcite.util.BarfingInvocationHandler
- BASE_DIRECTORY - Enum constant in enum org.apache.calcite.model.ModelHandler.ExtraOperand
-
Base directory from which to read files.
- BaseOrderStreamTable - Class in org.apache.calcite.test.schemata.orderstream
-
Base table for the Orders table.
- BaseOrderStreamTable() - Constructor for class org.apache.calcite.test.schemata.orderstream.BaseOrderStreamTable
- BaseQueryable<TSource> - Class in org.apache.calcite.linq4j
-
Skeleton implementation of
Queryable
. - BaseQueryable(QueryProvider, Type, Expression) - Constructor for class org.apache.calcite.linq4j.BaseQueryable
- baseUnit(SqlTypeName) - Static method in class org.apache.calcite.rex.RexBuilder
-
Returns the lowest granularity unit for the given unit.
- BASIC_AGGREGATE_LAMBDA_FACTORY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BASIC_LAZY_ACCUMULATOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BasicAggregateLambdaFactory<TSource,
TAccumulate, TResult, TKey> - Class in org.apache.calcite.adapter.enumerable -
Implementation of
AggregateLambdaFactory
that applies a sequence of accumulator adders to input source. - BasicAggregateLambdaFactory(Function0<TAccumulate>, List<Function2<TAccumulate, TSource, TAccumulate>>) - Constructor for class org.apache.calcite.adapter.enumerable.BasicAggregateLambdaFactory
- BasicLazyAccumulator<TAccumulate,
TSource> - Class in org.apache.calcite.adapter.enumerable -
Performs accumulation against a pre-collected list of input sources, used with
LazyAggregateLambdaFactory
. - BasicLazyAccumulator(Function2<TAccumulate, TSource, TAccumulate>) - Constructor for class org.apache.calcite.adapter.enumerable.BasicLazyAccumulator
- BasicSqlType - Class in org.apache.calcite.sql.type
-
BasicSqlType represents a standard atomic SQL type (excluding interval types).
- BasicSqlType(RelDataTypeSystem, SqlTypeName) - Constructor for class org.apache.calcite.sql.type.BasicSqlType
-
Constructs a type with no parameters.
- BasicSqlType(RelDataTypeSystem, SqlTypeName, boolean) - Constructor for class org.apache.calcite.sql.type.BasicSqlType
- BasicSqlType(RelDataTypeSystem, SqlTypeName, int) - Constructor for class org.apache.calcite.sql.type.BasicSqlType
-
Constructs a type with precision/length but no scale.
- BasicSqlType(RelDataTypeSystem, SqlTypeName, int, int) - Constructor for class org.apache.calcite.sql.type.BasicSqlType
-
Constructs a type with precision/length and scale.
- batchSize() - Method in interface org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoinRule.Config
-
Batch size.
- BcAdCompiledPattern - Class in org.apache.calcite.util.format.postgresql.format.compiled
-
The date/time format compiled component for BC/AD (era, ie.
- BcAdCompiledPattern(Set<PatternModifier>, boolean, boolean) - Constructor for class org.apache.calcite.util.format.postgresql.format.compiled.BcAdCompiledPattern
- BcAdFormatPattern - Class in org.apache.calcite.util.format.postgresql.format
-
The date/time format component for BC/AD (era, ie.
- BcAdFormatPattern(String) - Constructor for class org.apache.calcite.util.format.postgresql.format.BcAdFormatPattern
- before() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- before(Consumer<Puffin.Context<G, F>>) - Method in interface org.apache.calcite.util.Puffin.Builder
-
Adds an action to be called before all sources.
- beforeSource(Consumer<Puffin.Context<G, F>>) - Method in interface org.apache.calcite.util.Puffin.Builder
-
Adds an action to be called before each source.
- beginBeginTag(String) - Method in class org.apache.calcite.util.XmlOutput
- beginNode() - Method in class org.apache.calcite.util.XmlOutput
-
If we are currently inside the start tag, finishes it off.
- beginTag(String, XmlOutput.XMLAttrVector) - Method in class org.apache.calcite.util.XmlOutput
-
Starts writing a new tag to the stream.
- belongsTo(Collection<SqlKind>) - Method in enum org.apache.calcite.sql.SqlKind
-
Returns whether this
SqlKind
belongs to a given category. - Benchmark - Class in org.apache.calcite.util
-
Helps to run benchmarks by running the same task repeatedly and averaging the running times.
- Benchmark(String, Function1<Benchmark.Statistician, Void>, int) - Constructor for class org.apache.calcite.util.Benchmark
- Benchmark.Statistician - Class in org.apache.calcite.util
-
Collects statistics for a test that is run multiple times.
- bestString() - Method in interface org.apache.calcite.sql.validate.SqlNameMatcher
-
Returns the most recent match.
- between(int, int) - Static method in class org.apache.calcite.sql.type.SqlOperandCountRanges
- between(RexNode, RexNode, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
BETWEEN
. - between(T, T) - Static method in class org.apache.calcite.test.Matchers
-
Creates a matcher that matches if the examined value is between bounds:
min ≤ value ≤ max
. - BETWEEN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
BETWEEN
operator. - BETWEEN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- betweenWithoutAnd() - Method in interface org.apache.calcite.runtime.CalciteResource
- BI_PREDICATE_TEST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIG_DECIMAL - Static variable in interface org.apache.calcite.util.JdbcType
- BIG_DECIMAL_ADD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIG_DECIMAL_NEGATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIG_DECIMAL_NULLABLE - Static variable in interface org.apache.calcite.util.JdbcType
- BIG_QUERY - Enum constant in enum org.apache.calcite.config.Lex
-
Lexical policy similar to BigQuery.
- BIG_QUERY - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
A collection of operators that are in Google BigQuery but not in standard SQL.
- BIG_QUERY - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- BIG_QUERY - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that instructs Calcite to use SQL semantics consistent with BigQuery.
- BIG_QUERY - Static variable in class org.apache.calcite.sql.parser.SqlParserTest
- BIG_QUERY - Static variable in class org.apache.calcite.util.format.FormatModels
-
Format model for BigQuery.
- bigDecimal - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- BigDecimalFunction1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function that takes one parameter and returns a
BigDecimal
value. - bigdecimalmax(Tuple) - Static method in class org.apache.calcite.piglet.PigUdfs
- bigdecimalsum(Tuple) - Static method in class org.apache.calcite.piglet.PigUdfs
- BigDecimalSum() - Constructor for class org.apache.calcite.interpreter.AggregateNode.BigDecimalSum
- bigDecimalValue() - Method in class org.apache.calcite.sql.SqlLiteral
-
Returns a numeric literal's value as a
BigDecimal
. - BIGINT - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- BIGINT - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is a BIGINT.
- BIGINT_FORCE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is a nullable BIGINT.
- BIGINT_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is a BIGINT with nulls allowed if any of the operands allow nulls.
- BigQuerySqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for Google BigQuery's "Standard SQL" dialect. - BigQuerySqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.BigQuerySqlDialect
-
Creates a BigQuerySqlDialect.
- bijection(List<Integer>) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Creates a bijection.
- bijection(Map<Integer, Integer>) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Creates a bijection.
- BIJECTION - Enum constant in enum org.apache.calcite.util.mapping.MappingType
- BINARY - Enum constant in enum org.apache.calcite.sql.SqlSyntax
-
Binary operator syntax, as in "x + y".
- BINARY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- BINARY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- BINARY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- BINARY_ARITHMETIC - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of binary arithmetic.
- BINARY_BINARY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- BINARY_COMPARISON - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of binary comparison.
- BINARY_EQUALITY - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of binary equality.
- BINARY_SEARCH5_LOWER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BINARY_SEARCH5_UPPER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BINARY_SEARCH6_LOWER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BINARY_SEARCH6_UPPER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BINARY_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- binaryArithmeticCoercion(SqlCallBinding) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Coerces operand of binary arithmetic expressions to Numeric type.
- binaryArithmeticCoercion(SqlCallBinding) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
-
Coerces operands in binary arithmetic expressions to NUMERIC types.
- binaryArithmeticWithStrings(SqlCallBinding, RelDataType, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
-
For NUMERIC and STRING operands, cast STRING to data type of the other operand.
- binaryComparisonCoercion(SqlCallBinding) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Coerces operands in binary comparison expressions.
- binaryComparisonCoercion(SqlCallBinding) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
-
Coerces operands in binary comparison expressions.
- BinaryExpression - Class in org.apache.calcite.linq4j.tree
-
Represents an expression that has a binary operator.
- binaryLiteralInvalid() - Method in interface org.apache.calcite.runtime.CalciteResource
- binaryLiteralOdd() - Method in interface org.apache.calcite.runtime.CalciteResource
- BinaryOperatorConversion - Class in org.apache.calcite.adapter.druid
-
Binary operator conversion utility class; used to convert expressions like
exp1 Operator exp2
. - BinaryOperatorConversion(SqlOperator, String) - Constructor for class org.apache.calcite.adapter.druid.BinaryOperatorConversion
- BinarySearch - Class in org.apache.calcite.runtime
-
Binary search for the implementation of RANGE BETWEEN XXX PRECEDING/FOLLOWING clause.
- BinarySearch() - Constructor for class org.apache.calcite.runtime.BinarySearch
- BinaryTree(LoptJoinTree) - Constructor for class org.apache.calcite.rel.rules.LoptJoinTree.BinaryTree
- bind(Member, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberAssignment that represents the initialization of a field or property.
- bind(Method, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberAssignment that represents the initialization of a member by using a property accessor method.
- bind(DataContext) - Method in class org.apache.calcite.adapter.druid.DruidQuery
- bind(DataContext) - Method in class org.apache.calcite.adapter.enumerable.EnumerableBindable
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableAggregate
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableFilter
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableIntersect
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableJoin
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableMatch
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableMinus
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableProject
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableSort
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableTableScan
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableUnion
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableValues
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableWindow
- bind(DataContext) - Method in class org.apache.calcite.interpreter.InterpretableConverter
- bind(DataContext) - Method in interface org.apache.calcite.runtime.Bindable
-
Executes this statement and returns an enumerable which will yield rows.
- bind(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.UnboundMetadata
- bindable(RelNode) - Static method in class org.apache.calcite.interpreter.Interpreters
-
Creates a
Bindable
that interprets a given relational expression. - Bindable<T> - Interface in org.apache.calcite.runtime
-
Statement that can be bound to a
DataContext
and then executed. - BINDABLE_AGGREGATE_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_BIND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BINDABLE_CACHE_CONCURRENCY_LEVEL - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
The concurrency level of the cache used for storing Bindable objects, instantiated via dynamically generated Java classes.
- BINDABLE_CACHE_MAX_SIZE - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
The maximum size of the cache used for storing Bindable objects, instantiated via dynamically generated Java classes.
- BINDABLE_FILTER_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_JOIN_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_MATCH_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_PROJECT_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_SET_OP_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_SETOP_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
-
Deprecated.
- BINDABLE_SORT_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_TABLE_SCAN_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_VALUES_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_WINDOW_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BindableAggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableAggregate
-
Deprecated.
- BindableAggregate(RelOptCluster, RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableAggregate
- BindableAggregateRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableAggregateRule
-
Called from the Config.
- BindableConvention - Enum in org.apache.calcite.interpreter
-
Calling convention that returns results as an
Enumerable
of object arrays. - BindableFilter(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableFilter
- BindableFilterRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableFilterRule
-
Called from the Config.
- BindableIntersect(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableIntersect
- BindableJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableJoin
-
Creates a BindableJoin.
- BindableJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, Set<String>) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableJoin
-
Deprecated.
- BindableJoinRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableJoinRule
-
Called from the Config.
- BindableMatchRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableMatchRule
-
Called from the Config.
- BindableMinus(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableMinus
- BindableProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableProject
- BindableProjectRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableProjectRule
-
Called from the Config.
- BindableRel - Interface in org.apache.calcite.interpreter
-
Relational expression that can implement itself in Bindable convention.
- Bindables - Class in org.apache.calcite.interpreter
-
Utilities pertaining to
BindableRel
andBindableConvention
. - Bindables.BindableAggregate - Class in org.apache.calcite.interpreter
-
Implementation of
Aggregate
in bindable calling convention. - Bindables.BindableAggregateRule - Class in org.apache.calcite.interpreter
-
Rule that converts an
Aggregate
to bindable convention. - Bindables.BindableFilter - Class in org.apache.calcite.interpreter
-
Implementation of
Filter
in bindable convention. - Bindables.BindableFilterRule - Class in org.apache.calcite.interpreter
-
Rule that converts a
Filter
to bindable convention. - Bindables.BindableIntersect - Class in org.apache.calcite.interpreter
-
Implementation of
Intersect
in bindable calling convention. - Bindables.BindableJoin - Class in org.apache.calcite.interpreter
-
Implementation of
Join
in bindable calling convention. - Bindables.BindableJoinRule - Class in org.apache.calcite.interpreter
-
Rule to convert a
LogicalJoin
to aBindables.BindableJoin
. - Bindables.BindableMatch - Class in org.apache.calcite.interpreter
-
Implementation of
Match
in bindable convention. - Bindables.BindableMatchRule - Class in org.apache.calcite.interpreter
-
Rule to convert a
LogicalMatch
to aBindables.BindableMatch
. - Bindables.BindableMinus - Class in org.apache.calcite.interpreter
-
Implementation of
Minus
in bindable calling convention. - Bindables.BindableProject - Class in org.apache.calcite.interpreter
-
Implementation of
Project
in bindable calling convention. - Bindables.BindableProjectRule - Class in org.apache.calcite.interpreter
-
Rule to convert a
LogicalProject
to aBindables.BindableProject
. - Bindables.BindableSetOpRule - Class in org.apache.calcite.interpreter
-
Rule to convert an
SetOp
to aBindables.BindableUnion
orBindables.BindableIntersect
orBindables.BindableMinus
. - Bindables.BindableSort - Class in org.apache.calcite.interpreter
-
Implementation of
Sort
bindable calling convention. - Bindables.BindableSortRule - Class in org.apache.calcite.interpreter
-
Rule to convert an
Sort
to aBindables.BindableSort
. - Bindables.BindableTableScan - Class in org.apache.calcite.interpreter
-
Scan of a table that implements
ScannableTable
and therefore can be converted into anEnumerable
. - Bindables.BindableTableScanRule - Class in org.apache.calcite.interpreter
-
Rule that converts a
TableScan
to bindable convention. - Bindables.BindableTableScanRule.Config - Interface in org.apache.calcite.interpreter
-
Rule configuration.
- Bindables.BindableUnion - Class in org.apache.calcite.interpreter
-
Implementation of
Union
in bindable calling convention. - Bindables.BindableValues - Class in org.apache.calcite.interpreter
-
Implementation of
Values
in bindable calling convention. - Bindables.BindableValuesRule - Class in org.apache.calcite.interpreter
-
Rule that converts a
Values
to bindable convention. - Bindables.BindableWindow - Class in org.apache.calcite.interpreter
-
Implementation of
Window
in bindable convention. - Bindables.BindableWindowRule - Class in org.apache.calcite.interpreter
-
Rule to convert a
LogicalWindow
to aBindables.BindableWindow
. - BindableSetOpRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableSetOpRule
-
Called from the Config.
- BindableSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableSort
- BindableSortRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableSortRule
-
Called from the Config.
- BindableTableScanRule(Bindables.BindableTableScanRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableTableScanRule
-
Called from Config.
- BindableTableScanRule(RelBuilderFactory) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableTableScanRule
-
Deprecated.
- BindableUnion(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableUnion
- BindableValuesRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableValuesRule
-
Called from the Config.
- BindableWindowRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableWindowRule
-
Called from the Config.
- BiRel - Class in org.apache.calcite.rel
-
Abstract base class for relational expressions with a two inputs.
- BiRel(RelOptCluster, RelTraitSet, RelNode, RelNode) - Constructor for class org.apache.calcite.rel.BiRel
- birthPlace - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Author
- BIT_AND - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
BIT_AND
aggregate function. - BIT_AND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIT_AND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
BIT_AND
aggregate function. - BIT_COUNT_BIG_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
Alias for
SqlStdOperatorTable.BITCOUNT
. - BIT_COUNT_MYSQL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- BIT_GET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIT_GET - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "BIT_GET(value, position)" function.
- BIT_LENGTH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIT_LENGTH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "BIT_LENGTH(string or binary)" function.
- BIT_NOT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIT_OR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
BIT_OR
aggregate function. - BIT_OR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIT_OR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
BIT_OR
aggregate function. - BIT_SET_INCLUSION_ORDERING - Static variable in class org.apache.calcite.util.PartiallyOrderedSet
-
Ordering that orders bit sets by inclusion.
- BIT_XOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
BIT_XOR
aggregate function. - BIT_XOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIT_XOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
BIT_XOR
aggregate function. - bitAnd(int, Long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BITAND
applied to a Long and int value. - bitAnd(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BIT_AND
applied to integer values. - bitAnd(Long, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BITAND
applied to a Long and int value. - bitAnd(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BIT_AND
applied to binary values. - BITAND - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
BITAND
scalar function. - BITAND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
BITAND
scalar function. - BITAND_AGG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "BITAND_AGG(expression)" function.
- bitCount(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper function for implementing
BITCOUNT
. - bitCount(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper function for implementing
BITCOUNT
. - bitCount(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper function for implementing
BITCOUNT
. - BITCOUNT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BITCOUNT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- bitGet(byte, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL BIT_GET(value, position) function.
- bitGet(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL BIT_GET(value, position) function.
- bitGet(long, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL BIT_GET(value, position) function.
- bitGet(short, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL BIT_GET(value, position) function.
- bitLength(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL BIT_LENGTH(string) function.
- bitLength(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL BIT_LENGTH(binary) function.
- bitNot(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BIT_NOT
applied to integer values. - bitNot(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BIT_NOT
applied to a binary value. - BITNOT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
BITNOT
scalar function. - BITNOT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
BITNOT
scalar function. - bitOr(int, Long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BITOR
applied to a Long and int value. - bitOr(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BIT_OR
applied to integer values. - bitOr(Long, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BITOR
applied to a Long and int value. - bitOr(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BIT_OR
applied to binary values. - BITOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
BITOR
scalar function. - BITOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
BITOR
scalar function. - BITOR_AGG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "BITOR_AGG(expression)" function.
- bits(List<RexNode>, RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil.InputFinder
-
Returns a bit set describing the inputs used by a collection of project expressions and an optional condition.
- bits(RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil.InputFinder
-
Returns a bit set describing the inputs used by an expression.
- bitSet - Variable in class org.apache.calcite.materialize.Lattice.Tile
- bitSet - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.BadType
- bitSet - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- bitSet() - Method in class org.apache.calcite.materialize.Lattice.Tile
- BitSets - Class in org.apache.calcite.util
-
Utility functions for
BitSet
. - BitString - Class in org.apache.calcite.util
-
String of bits.
- BitString(String, int) - Constructor for class org.apache.calcite.util.BitString
- bitXor(int, Long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BITXOR
applied to a Long and int value. - bitXor(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BIT_XOR
applied to integer values. - bitXor(Long, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BITXOR
applied to a Long and int value. - bitXor(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BIT_XOR
applied to binary values. - BITXOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
BITXOR
scalar function. - BITXOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
BITXOR
scalar function. - bl - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- BLACK - Enum constant in enum org.apache.calcite.sql.SqlWriter.SubQueryStyle
-
Damian's style of sub-query nesting.
- Blackboard(SqlValidatorScope, Map<String, RexNode>, boolean) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Creates a Blackboard.
- blackholeMap() - Static method in class org.apache.calcite.util.Util
-
Returns a map which ignores any write operation.
- BLANK - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- bloat() - Method in interface org.apache.calcite.rel.rules.FilterProjectTransposeRule.Config
-
Limit how much complexity can increase during merging.
- bloat() - Method in interface org.apache.calcite.rel.rules.ProjectMergeRule.Config
-
Limit how much complexity can increase during merging.
- bloat() - Method in interface org.apache.calcite.tools.RelBuilder.Config
-
Controls whether to merge two
Project
operators when inlining expressions causes complexity to increase. - block - Variable in class org.apache.calcite.adapter.enumerable.EnumerableRel.Result
- block - Variable in class org.apache.calcite.adapter.spark.SparkRel.Result
- block(Iterable<? extends Statement>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BlockExpression that contains the given statements.
- block(Type, Iterable<? extends Statement>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BlockExpression that contains the given expressions, has no variables and has specific result type.
- block(Type, Statement...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BlockExpression that contains the given statements and has a specific result type, using varargs.
- block(Statement...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BlockExpression that contains the given statements, using varargs.
- Block - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A block of expressions.
- BlockBuilder - Class in org.apache.calcite.linq4j.tree
-
Builder for
BlockStatement
. - BlockBuilder() - Constructor for class org.apache.calcite.linq4j.tree.BlockBuilder
-
Creates a non-optimizing BlockBuilder.
- BlockBuilder(boolean) - Constructor for class org.apache.calcite.linq4j.tree.BlockBuilder
-
Creates a BlockBuilder.
- BlockBuilder(boolean, BlockBuilder) - Constructor for class org.apache.calcite.linq4j.tree.BlockBuilder
-
Creates a BlockBuilder.
- Blocks - Class in org.apache.calcite.linq4j.tree
-
Helper methods concerning
BlockStatement
s. - BlockStatement - Class in org.apache.calcite.linq4j.tree
-
Represents a block that contains a sequence of expressions where variables can be defined.
- body - Variable in class org.apache.calcite.linq4j.tree.CatchBlock
- body - Variable in class org.apache.calcite.linq4j.tree.ConstructorDeclaration
- body - Variable in class org.apache.calcite.linq4j.tree.ForEachStatement
- body - Variable in class org.apache.calcite.linq4j.tree.ForStatement
- body - Variable in class org.apache.calcite.linq4j.tree.FunctionExpression
- body - Variable in class org.apache.calcite.linq4j.tree.MethodDeclaration
- body - Variable in class org.apache.calcite.linq4j.tree.TryStatement
- body - Variable in class org.apache.calcite.linq4j.tree.WhileStatement
- body - Variable in class org.apache.calcite.sql.SqlWith
- Book(String, int, List<BookstoreSchema.Page>) - Constructor for class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Book
- books - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Author
- BOOKSTORE - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- BookstoreSchema - Class in org.apache.calcite.test.schemata.bookstore
-
A Schema representing a bookstore.
- BookstoreSchema() - Constructor for class org.apache.calcite.test.schemata.bookstore.BookstoreSchema
- BookstoreSchema.Author - Class in org.apache.calcite.test.schemata.bookstore
-
Author.
- BookstoreSchema.Book - Class in org.apache.calcite.test.schemata.bookstore
-
Book.
- BookstoreSchema.Coordinate - Class in org.apache.calcite.test.schemata.bookstore
-
Coordinate.
- BookstoreSchema.Page - Class in org.apache.calcite.test.schemata.bookstore
-
Page.
- BookstoreSchema.Place - Class in org.apache.calcite.test.schemata.bookstore
-
Place.
- BOOL_AND - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "BOOL_AND(condition)" aggregate function, PostgreSQL and Redshift's equivalent to
SqlStdOperatorTable.EVERY
. - BOOL_OR - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "BOOL_OR(condition)" aggregate function, PostgreSQL and Redshift's equivalent to
SqlStdOperatorTable.SOME
. - BOOLAND_AGG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "BOOLAND_AGG(condition)" aggregate function, Snowflake's equivalent to
SqlStdOperatorTable.EVERY
. - BOOLEAN - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive
- BOOLEAN - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- BOOLEAN - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- BOOLEAN - Static variable in class org.apache.calcite.sql.type.InferTypes
-
Operand type-inference strategy where an unknown operand type is assumed to be boolean.
- BOOLEAN - Static variable in class org.apache.calcite.sql.type.OperandTypes
- BOOLEAN - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is Boolean.
- BOOLEAN - Static variable in interface org.apache.calcite.util.JdbcType
- BOOLEAN_BOOLEAN - Static variable in class org.apache.calcite.sql.type.OperandTypes
- BOOLEAN_FORCE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is a nullable Boolean.
- BOOLEAN_LITERAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy type must be a boolean non-NULL literal.
- BOOLEAN_NOT_NULL - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is BOOLEAN NOT NULL.
- BOOLEAN_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is Boolean, with nulls allowed if any of the operands allow nulls.
- BOOLEAN_NULLABLE - Static variable in interface org.apache.calcite.util.JdbcType
- BOOLEAN_NULLABLE_IF_ARG0_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is Boolean, with nulls allowed if the type of the operand #0 (0-based) is nullable.
- BOOLEAN_NULLABLE_OPTIMIZED - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy with similar effect to
ReturnTypes.BOOLEAN_NULLABLE
, which is more efficient, but can only be used if all arguments are BOOLEAN. - BOOLEAN_TO_STRING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BOOLEAN_TYPE_CHECKER - Static variable in class org.apache.calcite.sql.test.SqlTests
- BOOLEAN_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- booleanEquality(SqlCallBinding, RelDataType, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
-
Casts "BOOLEAN = NUMERIC" to "NUMERIC = NUMERIC".
- booleanValue() - Method in class org.apache.calcite.sql.SqlLiteral
-
Returns the value as a boolean.
- booleanValue(RexNode) - Static method in class org.apache.calcite.rex.RexLiteral
- BOOLOR_AGG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "BOOLOR_AGG(condition)" aggregate function, Snowflake's equivalent to
SqlStdOperatorTable.SOME
. - boolRelDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- bools - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- BOTH - Enum constant in enum org.apache.calcite.plan.DeriveMode
-
Iterates over each child, uses current child's traits to decide what traits to require from the other children.
- BOTH - Enum constant in enum org.apache.calcite.sql.fun.SqlTrimFunction.Flag
- BOTH_PROJECT - Static variable in interface org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule.Config
- BOTTOM_UP - Enum constant in enum org.apache.calcite.plan.hep.HepMatchOrder
-
Match from leaves up.
- bound - Variable in class org.apache.calcite.linq4j.tree.NewArrayExpression
- box(Class) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Converts a primitive class to a boxed class; returns other classes unchanged.
- box(Type) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Converts a primitive type to a boxed type; returns other types unchanged.
- box(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- box(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Converts e.g.
- box(Expression, Primitive) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Returns an expression to box the value of a primitive expression.
- BOX - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive.Flavor
-
A type that boxes a primitive, e.g.
- boxClass - Variable in enum org.apache.calcite.linq4j.tree.Primitive
- BOXED - Static variable in class org.apache.calcite.rel.core.Project.Flags
-
Deprecated.
- BOXED_FALSE_EXPR - Static variable in class org.apache.calcite.adapter.enumerable.RexImpTable
- BOXED_FALSE_EXPR - Static variable in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- BOXED_TRUE_EXPR - Static variable in class org.apache.calcite.adapter.enumerable.RexImpTable
- BOXED_TRUE_EXPR - Static variable in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- boxName - Variable in enum org.apache.calcite.linq4j.tree.Primitive
- BQ_DOUBLE - Enum constant in enum org.apache.calcite.config.CharLiteralStyle
-
Double-quoted character literal with backslash escapes, as in BigQuery.
- BQ_SINGLE - Enum constant in enum org.apache.calcite.config.CharLiteralStyle
-
Single-quoted character literal with backslash escapes, as in BigQuery.
- BreadthFirstIterator<V,
E extends DefaultEdge> - Class in org.apache.calcite.util.graph -
Iterates over the vertices in a directed graph in breadth-first order.
- BreadthFirstIterator(DirectedGraph<V, E>, V) - Constructor for class org.apache.calcite.util.graph.BreadthFirstIterator
- Break - Enum constant in enum org.apache.calcite.linq4j.tree.GotoExpressionKind
-
A GotoExpression that represents a break statement.
- break_(LabelTarget) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a break statement.
- break_(LabelTarget, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a break statement.
- break_(LabelTarget, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a break statement with the specified type.
- break_(LabelTarget, Expression, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a break statement with the specified type.
- BRIDGE_METHODS - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- BRIDGE_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Decouple an abstraction from its implementation so that the two can very independently.
- BROADCAST_DISTRIBUTED - Enum constant in enum org.apache.calcite.rel.RelDistribution.Type
-
There are multiple instances of the stream, and all records appear in each instance.
- BROADCAST_DISTRIBUTED - Static variable in class org.apache.calcite.rel.RelDistributions
-
The singleton broadcast distribution.
- brokenTestsEnabled() - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns whether to run tests that are considered 'broken'.
- buf - Variable in class org.apache.calcite.materialize.Lattice.SqlWriter
- BufferStyle - Class in org.apache.calcite.runtime
-
A parser for buffer styles as defined by PostGIS.
- BufferStyle(String) - Constructor for class org.apache.calcite.runtime.BufferStyle
- Bug - Class in org.apache.calcite.util
-
Holder for a list of constants describing which bugs which have not been fixed.
- Bug() - Constructor for class org.apache.calcite.util.Bug
- build() - Method in class org.apache.calcite.adapter.druid.VirtualColumn.Builder
- build() - Method in class org.apache.calcite.interpreter.Row.RowBuilder
-
Returns a Row.
- build() - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Builds a lattice.
- build() - Method in class org.apache.calcite.materialize.Lattice.TileBuilder
- build() - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Returns the constructed program, clearing the state of this program builder as a side-effect.
- build() - Method in class org.apache.calcite.plan.RelOptUtil.InputFinder
-
Returns the bit set.
- build() - Method in class org.apache.calcite.profile.ProfilerImpl.Builder
- build() - Method in class org.apache.calcite.rel.hint.HintStrategy.Builder
- build() - Method in class org.apache.calcite.rel.hint.HintStrategyTable.Builder
- build() - Method in class org.apache.calcite.rel.hint.RelHint.Builder
- build() - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Creates a struct type with the current contents of this builder.
- build() - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Creates a
TimeFrameSet
. - build() - Method in class org.apache.calcite.runtime.AutomatonBuilder
-
Builds the automaton.
- build() - Method in class org.apache.calcite.runtime.Matcher.Builder
- build() - Method in class org.apache.calcite.runtime.PairList.Builder
-
Builds the PairList.
- build() - Method in class org.apache.calcite.runtime.Pattern.PatternBuilder
-
Returns the resulting pattern.
- build() - Method in class org.apache.calcite.schema.impl.ReflectiveFunctionBase.ParameterListBuilder
- build() - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Deprecated.Builds a
SqlParser.Config
. - build() - Method in class org.apache.calcite.sql.TableCharacteristic.Builder
- build() - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- build() - Method in class org.apache.calcite.tools.RelBuilder
-
Returns the final relational expression.
- build() - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Builds an ImmutableBitSet from the contents of this Builder.
- build() - Method in class org.apache.calcite.util.ImmutableNullableList.Builder
-
Returns a newly-created
ImmutableNullableList
based on the contents of theBuilder
. - build() - Method in class org.apache.calcite.util.ImmutableNullableSet.Builder
-
Returns a newly-created
ImmutableNullableSet
based on the contents of theBuilder
. - build() - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- build() - Method in interface org.apache.calcite.util.Puffin.Builder
-
Builds the program.
- build(ImmutableList.Builder<SqlValidatorScope.Step>) - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.Path
- build(ImmutableList.Builder<SqlValidatorScope.Step>) - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.Step
- build(RelNode...) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
-
Creates a CorelMap by iterating over a
RelNode
tree. - build(ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Builds an ImmutableBitSet from the contents of this Builder, using an existing ImmutableBitSet if it happens to have the same contents.
- buildAggGroupList(Aggregate, SqlImplementor.Builder, List<SqlNode>, List<SqlNode>) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Builds the group list for an Aggregate node.
- buildAggregate(Aggregate, SqlImplementor.Builder, List<SqlNode>, List<SqlNode>) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Builds an aggregate query.
- buildAndReset() - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Builds an ImmutableBitSet from the contents of this Builder.
- buildBag(Object...) - Static method in class org.apache.calcite.piglet.PigRelSqlUdfs
-
Implementation for PIG_BAG functions.
- buildCompiledPattern(Set<PatternModifier>) - Method in class org.apache.calcite.util.format.postgresql.format.AmPmFormatPattern
- buildCompiledPattern(Set<PatternModifier>) - Method in class org.apache.calcite.util.format.postgresql.format.BcAdFormatPattern
- buildCompiledPattern(Set<PatternModifier>) - Method in class org.apache.calcite.util.format.postgresql.format.DayOfWeekFormatPattern
- buildCompiledPattern(Set<PatternModifier>) - Method in class org.apache.calcite.util.format.postgresql.format.FormatPattern
-
Creates a new instance of the compiled version of this date/time component.
- buildCompiledPattern(Set<PatternModifier>) - Method in class org.apache.calcite.util.format.postgresql.format.MonthFormatPattern
- buildCompiledPattern(Set<PatternModifier>) - Method in class org.apache.calcite.util.format.postgresql.format.NumberFormatPattern
- buildCompiledPattern(Set<PatternModifier>) - Method in class org.apache.calcite.util.format.postgresql.format.RomanNumeralsFormatPattern
- buildCompiledPattern(Set<PatternModifier>) - Method in class org.apache.calcite.util.format.postgresql.format.TimeZoneFormatPattern
- buildCompiledPattern(Set<PatternModifier>) - Method in class org.apache.calcite.util.format.postgresql.format.TimeZoneHoursFormatPattern
- buildCompiledPattern(Set<PatternModifier>) - Method in class org.apache.calcite.util.format.postgresql.format.TimeZoneMinutesFormatPattern
- buildCompiledPattern(Set<PatternModifier>) - Method in class org.apache.calcite.util.format.postgresql.format.TimeZoneOffsetFormatPattern
- buildCompiledPattern(Set<PatternModifier>) - Method in class org.apache.calcite.util.format.postgresql.format.YearWithCommasFormatPattern
- buildDynamic() - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Creates a dynamic struct type with the current contents of this builder.
- builder() - Static method in class org.apache.calcite.adapter.druid.VirtualColumn
- builder() - Static method in class org.apache.calcite.materialize.Lattice.Tile
- builder() - Static method in class org.apache.calcite.plan.hep.HepProgram
- builder() - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Creates a
RelBuilder
to be used by code within the call. - builder() - Static method in class org.apache.calcite.profile.ProfilerImpl
- builder() - Static method in class org.apache.calcite.rel.hint.HintStrategyTable
-
Returns a
HintStrategyTable
builder. - builder() - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a
RelDataTypeFactory.FieldInfoBuilder
. - builder() - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- builder() - Static method in class org.apache.calcite.rel.type.TimeFrameSet
-
Creates a Builder.
- builder() - Static method in interface org.apache.calcite.runtime.PairList
-
Creates a Builder.
- builder() - Static method in interface org.apache.calcite.runtime.Pattern
-
Creates a builder.
- builder() - Static method in class org.apache.calcite.schema.impl.ReflectiveFunctionBase
-
Creates a ParameterListBuilder.
- builder() - Static method in class org.apache.calcite.sql.type.SqlTypeMappingRules
-
Returns a
SqlTypeMappingRules.Builder
to build the type mappings. - builder() - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Creates an empty Builder.
- builder() - Static method in class org.apache.calcite.util.ImmutableNullableList
-
Returns a new builder.
- builder() - Static method in class org.apache.calcite.util.ImmutableNullableSet
-
Returns a new builder.
- builder() - Static method in class org.apache.calcite.util.Puffin
-
Creates a Builder with no state.
- builder(String) - Static method in class org.apache.calcite.rel.hint.RelHint
-
Creates a hint builder with specified hint name.
- builder(Supplier<G>, Function<G, F>) - Static method in class org.apache.calcite.util.Puffin
-
Creates a Builder.
- builder(CalciteSchema, String) - Static method in class org.apache.calcite.materialize.Lattice
- builder(HintPredicate) - Static method in class org.apache.calcite.rel.hint.HintStrategy
-
Returns a
HintStrategy
builder with given hint predicate. - builder(RelNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Creates a builder for the SQL of the given relational expression, using the clauses that you declared when you called
SqlImplementor.visitInput(RelNode, int, Set)
. - builder(RelNode, SqlImplementor.Clause, SqlImplementor.Clause...) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Deprecated.Provide the expected clauses up-front, when you call
SqlImplementor.visitInput(RelNode, int, Set)
, then create a builder usingSqlImplementor.Result.builder(RelNode)
. - builder(Automaton) - Static method in class org.apache.calcite.runtime.Matcher
- builder(TableCharacteristic.Semantics) - Static method in class org.apache.calcite.sql.TableCharacteristic
-
Creates a builder.
- builder(ImmutableBitSet) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Deprecated.
- Builder() - Constructor for class org.apache.calcite.adapter.druid.VirtualColumn.Builder
- Builder() - Constructor for class org.apache.calcite.profile.ProfilerImpl.Builder
- Builder() - Constructor for class org.apache.calcite.rel.hint.HintStrategyTable.Builder
- Builder() - Constructor for class org.apache.calcite.runtime.PairList.Builder
- Builder() - Constructor for class org.apache.calcite.util.ImmutableNullableList.Builder
-
Creates a new builder.
- Builder() - Constructor for class org.apache.calcite.util.ImmutableNullableSet.Builder
-
Creates a new builder.
- Builder() - Constructor for class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- Builder(LatticeSpace, CalciteSchema, String) - Constructor for class org.apache.calcite.materialize.Lattice.Builder
- Builder(RelNode, List<SqlImplementor.Clause>, SqlSelect, SqlImplementor.Context, boolean, Map<String, RelDataType>) - Constructor for class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- Builder(RelDataTypeFactory) - Constructor for class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Creates a Builder with the given type factory.
- BUILDER_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Separate the construction of a complex object from its representation so that the same construction process can create different representations.
- buildImmutable() - Method in class org.apache.calcite.runtime.PairList.Builder
-
Builds an ImmutablePairList.
- buildIndex(Iterable<? extends SqlOperator>) - Static method in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
-
Derives a value to be assigned to
SqlOperatorTables.IndexedSqlOperatorTable.operators
from a given list of operators. - buildQuery(String) - Static method in class org.apache.calcite.sql.test.AbstractSqlTester
- buildQuery2(SqlTestFactory, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
-
Builds a query that extracts all literals as columns in an underlying select.
- buildQueryAgg(String) - Static method in class org.apache.calcite.sql.test.AbstractSqlTester
- buildTuple(Object...) - Static method in class org.apache.calcite.piglet.PigRelSqlUdfs
-
Implementation for PIG_TUPLE functions.
- BUILT_IN_OPERATORS_LIST - Static variable in class org.apache.calcite.sql.SqlDialect
-
Built-in scalar functions and operators common for every dialect.
- builtinFunctionCoercion(SqlCallBinding, List<RelDataType>, List<SqlTypeFamily>) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Type coercion with inferred type from passed in arguments and the
SqlTypeFamily
defined in the checkers, e.g. - builtinFunctionCoercion(SqlCallBinding, List<RelDataType>, List<SqlTypeFamily>) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
- BuiltInMetadata - Class in org.apache.calcite.rel.metadata
-
Contains the interfaces for several common forms of metadata.
- BuiltInMetadata() - Constructor for class org.apache.calcite.rel.metadata.BuiltInMetadata
- BuiltInMetadata.AllPredicates - Interface in org.apache.calcite.rel.metadata
-
Metadata about the predicates that hold in the rows emitted from a relational expression.
- BuiltInMetadata.AllPredicates.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Collation - Interface in org.apache.calcite.rel.metadata
-
Metadata about which columns are sorted.
- BuiltInMetadata.Collation.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.ColumnOrigin - Interface in org.apache.calcite.rel.metadata
-
Metadata about the origins of columns.
- BuiltInMetadata.ColumnOrigin.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.ColumnUniqueness - Interface in org.apache.calcite.rel.metadata
-
Metadata about whether a set of columns uniquely identifies a row.
- BuiltInMetadata.ColumnUniqueness.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.CumulativeCost - Interface in org.apache.calcite.rel.metadata
-
Metadata about the cost of evaluating a relational expression, including all of its inputs.
- BuiltInMetadata.CumulativeCost.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.DistinctRowCount - Interface in org.apache.calcite.rel.metadata
-
Metadata about the number of distinct rows returned by a set of columns in a relational expression.
- BuiltInMetadata.DistinctRowCount.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Distribution - Interface in org.apache.calcite.rel.metadata
-
Metadata about how a relational expression is distributed.
- BuiltInMetadata.Distribution.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.ExplainVisibility - Interface in org.apache.calcite.rel.metadata
-
Metadata about whether a relational expression should appear in a plan.
- BuiltInMetadata.ExplainVisibility.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.ExpressionLineage - Interface in org.apache.calcite.rel.metadata
-
Metadata about the origins of expressions.
- BuiltInMetadata.ExpressionLineage.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.LowerBoundCost - Interface in org.apache.calcite.rel.metadata
-
Metadata to get the lower bound cost of a RelNode.
- BuiltInMetadata.LowerBoundCost.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.MaxRowCount - Interface in org.apache.calcite.rel.metadata
-
Metadata about the maximum number of rows returned by a relational expression.
- BuiltInMetadata.MaxRowCount.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Measure - Interface in org.apache.calcite.rel.metadata
-
Metadata about whether a column is a measure and, if so, what is the expression to evaluate that measure in the current context.
- BuiltInMetadata.Measure.Context - Interface in org.apache.calcite.rel.metadata
-
Context for a use of a measure at a call site.
- BuiltInMetadata.Measure.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Memory - Interface in org.apache.calcite.rel.metadata
-
Metadata about the memory use of an operator.
- BuiltInMetadata.Memory.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.MinRowCount - Interface in org.apache.calcite.rel.metadata
-
Metadata about the minimum number of rows returned by a relational expression.
- BuiltInMetadata.MinRowCount.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.NodeTypes - Interface in org.apache.calcite.rel.metadata
-
Metadata about the node types in a relational expression.
- BuiltInMetadata.NodeTypes.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.NonCumulativeCost - Interface in org.apache.calcite.rel.metadata
-
Metadata about the cost of evaluating a relational expression, not including its inputs.
- BuiltInMetadata.NonCumulativeCost.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Parallelism - Interface in org.apache.calcite.rel.metadata
-
Metadata about the degree of parallelism of a relational expression, and how its operators are assigned to processes with independent resource pools.
- BuiltInMetadata.Parallelism.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.PercentageOriginalRows - Interface in org.apache.calcite.rel.metadata
-
Metadata about the proportion of original rows that remain in a relational expression.
- BuiltInMetadata.PercentageOriginalRows.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.PopulationSize - Interface in org.apache.calcite.rel.metadata
-
Metadata about the number of distinct values in the original source of a column or set of columns.
- BuiltInMetadata.PopulationSize.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Predicates - Interface in org.apache.calcite.rel.metadata
-
Metadata about the predicates that hold in the rows emitted from a relational expression.
- BuiltInMetadata.Predicates.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.RowCount - Interface in org.apache.calcite.rel.metadata
-
Metadata about the number of rows returned by a relational expression.
- BuiltInMetadata.RowCount.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Selectivity - Interface in org.apache.calcite.rel.metadata
-
Metadata about the selectivity of a predicate.
- BuiltInMetadata.Selectivity.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Size - Interface in org.apache.calcite.rel.metadata
-
Metadata about the size of rows and columns.
- BuiltInMetadata.Size.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.TableReferences - Interface in org.apache.calcite.rel.metadata
-
Metadata to obtain references to tables used by a given expression.
- BuiltInMetadata.TableReferences.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.UniqueKeys - Interface in org.apache.calcite.rel.metadata
-
Metadata about which combinations of columns are unique identifiers.
- BuiltInMetadata.UniqueKeys.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMethod - Enum in org.apache.calcite.util
-
Built-in methods.
- by - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- BYTE - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive
- byteDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- BYTES_PER_CHARACTER - Static variable in class org.apache.calcite.rel.metadata.RelMdSize
-
Bytes per character (2).
C
- c(int) - Static method in class org.apache.calcite.test.schemata.tpch.TpchSchema
- cache - Variable in class org.apache.calcite.model.JsonSchema
-
Whether to cache metadata (tables, functions and sub-schemas) generated by this schema.
- CACHED_SQL - Static variable in class org.apache.calcite.materialize.Lattices
-
Statistics provider that uses SQL then stores the results in a cache.
- CacheUtil - Class in org.apache.calcite.rel.metadata.janino
-
Functions used by generated code.
- CachingRelMetadataProvider - Class in org.apache.calcite.rel.metadata
-
Deprecated.
- CachingRelMetadataProvider(RelMetadataProvider, RelOptPlanner) - Constructor for class org.apache.calcite.rel.metadata.CachingRelMetadataProvider
-
Deprecated.
- CachingSqlStatisticProvider - Class in org.apache.calcite.statistic
-
Implementation of
SqlStatisticProvider
that reads and writes a cache. - CachingSqlStatisticProvider(SqlStatisticProvider, Cache<List, Object>) - Constructor for class org.apache.calcite.statistic.CachingSqlStatisticProvider
- calc(RelMetadataProvider) - Static method in class org.apache.calcite.tools.Programs
- calc(RelMetadataQuery, RelNode, RexProgram) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Helper method to determine a
Calc
's collation. - calc(RelMetadataQuery, RelNode, RexProgram) - Static method in class org.apache.calcite.rel.metadata.RelMdDistribution
-
Helper method to determine a
Calc
's distribution. - Calc - Class in org.apache.calcite.rel.core
-
Calc
is an abstract base class for implementations ofLogicalCalc
. - Calc(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RexProgram) - Constructor for class org.apache.calcite.rel.core.Calc
-
Creates a Calc.
- Calc(RelOptCluster, RelTraitSet, RelNode, RexProgram) - Constructor for class org.apache.calcite.rel.core.Calc
-
Deprecated.
- Calc(RelOptCluster, RelTraitSet, RelNode, RexProgram, List<RelCollation>) - Constructor for class org.apache.calcite.rel.core.Calc
-
Deprecated.
- CALC - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
Calc
nodes. - CALC_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that merges a
Calc
onto aCalc
. - CALC_PREDICATE - Static variable in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- CALC_PROGRAM - Static variable in class org.apache.calcite.tools.Programs
-
Program that converts filters and projects to
Calc
s. - CALC_REDUCE_DECIMALS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that reduces operations on the DECIMAL type, such as casts or arithmetic, into operations involving more primitive types such as BIGINT and DOUBLE.
- CALC_REDUCE_EXPRESSIONS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that reduces constants inside a
LogicalCalc
. - CALC_REMOVE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that removes a trivial
LogicalCalc
. - CALC_RULES - Static variable in class org.apache.calcite.plan.RelOptRules
-
Calc rule set; public so that
Programs
can use it. - CALC_RULES - Static variable in class org.apache.calcite.tools.Programs
-
Deprecated.
- CALC_SPLIT - Static variable in class org.apache.calcite.rel.rules.CoreRules
- CALC_TO_WINDOW - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that transforms a
Calc
that contains windowed aggregates to a mixture ofLogicalWindow
andCalc
. - CALCITE - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
Calcite-specific extensions.
- CALCITE - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- CALCITE_1045_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-1045] Decorrelate sub-queries in Project and Join is fixed.
- CALCITE_1048_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-1048] Make metadata more robust is fixed.
- CALCITE_194_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-194] Array items in MongoDB adapter is fixed.
- CALCITE_2400_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_2401_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-2401] Improve RelMdPredicates performance is fixed.
- CALCITE_2869_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-2869] JSON data type support is fixed.
- CALCITE_3243_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-3243] Incomplete validation of operands in JSON functions is fixed.
- CALCITE_4204_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_4205_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_4213_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_4645_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_5422_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-5422] MILLISECOND and MICROSECOND units in INTERVAL literal is fixed.
- CALCITE_6092_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-6092] Invalid test cases in CAST String to Time is fixed.
- CALCITE_6270_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_6293_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-6293] Support OR condition in Arrow adapter is fixed.
- CALCITE_6294_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-6294] Support IN filter in Arrow adapter is fixed.
- CALCITE_6328_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_6367_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_6391_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_673_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-673] Timeout executing joins against MySQL is fixed.
- CALCITE_AS_ADMIN - Enum constant in enum org.apache.calcite.chinook.ConnectionFactory.DatabaseWrapper
- CALCITE_AS_SPECIFIC_USER - Enum constant in enum org.apache.calcite.chinook.ConnectionFactory.DatabaseWrapper
- CalciteAssert - Class in org.apache.calcite.test
-
Fluid DSL for testing Calcite connections and queries.
- CalciteAssert.AssertMetaData - Class in org.apache.calcite.test
-
Fluent interface for building a metadata query to be tested.
- CalciteAssert.AssertQuery - Class in org.apache.calcite.test
-
Fluent interface for building a query to be tested.
- CalciteAssert.AssertThat - Class in org.apache.calcite.test
-
Result of calling
CalciteAssert.that()
. - CalciteAssert.Config - Enum in org.apache.calcite.test
-
Connection configuration.
- CalciteAssert.ConnectionPostProcessor - Interface in org.apache.calcite.test
-
Connection post-processor.
- CalciteAssert.DatabaseInstance - Enum in org.apache.calcite.test
-
Information necessary to create a JDBC connection.
- CalciteAssert.PreparedStatementConsumer - Interface in org.apache.calcite.test
-
We want a consumer that can throw SqlException.
- CalciteAssert.SchemaSpec - Enum in org.apache.calcite.test
-
Specification for common test schemas.
- CalciteCatalogReader - Class in org.apache.calcite.prepare
-
Implementation of
Prepare.CatalogReader
and alsoSqlOperatorTable
based on tables and functions defined schemas. - CalciteCatalogReader(CalciteSchema, List<String>, RelDataTypeFactory, CalciteConnectionConfig) - Constructor for class org.apache.calcite.prepare.CalciteCatalogReader
- CalciteCatalogReader(CalciteSchema, SqlNameMatcher, List<List<String>>, RelDataTypeFactory, CalciteConnectionConfig) - Constructor for class org.apache.calcite.prepare.CalciteCatalogReader
- CalciteChinookMetaFactory() - Constructor for class org.apache.calcite.chinook.ChinookAvaticaServer.CalciteChinookMetaFactory
- CalciteConnection - Interface in org.apache.calcite.jdbc
-
Extension to Calcite's implementation of
JDBC connection
allows schemas to be defined dynamically. - CalciteConnectionConfig - Interface in org.apache.calcite.config
-
Interface for reading connection properties within Calcite code.
- CalciteConnectionConfigImpl - Class in org.apache.calcite.config
-
Implementation of
CalciteConnectionConfig
. - CalciteConnectionConfigImpl(Properties) - Constructor for class org.apache.calcite.config.CalciteConnectionConfigImpl
- CalciteConnectionProperty - Enum in org.apache.calcite.config
-
Properties that may be specified on the JDBC connect string.
- CalciteConnectionProvider - Class in org.apache.calcite.chinook
-
Provider of calcite connections for end-to-end tests.
- CalciteConnectionProvider() - Constructor for class org.apache.calcite.chinook.CalciteConnectionProvider
- CalciteContextException - Exception Class in org.apache.calcite.runtime
-
Exception which contains information about the textual context of the causing exception.
- CalciteContextException(String, Throwable) - Constructor for exception class org.apache.calcite.runtime.CalciteContextException
-
Creates a new CalciteContextException object.
- CalciteContextException(String, Throwable, int, int, int, int) - Constructor for exception class org.apache.calcite.runtime.CalciteContextException
-
Creates a new CalciteContextException object.
- CalciteContextException(String, Throwable, String) - Constructor for exception class org.apache.calcite.runtime.CalciteContextException
-
Creates a new CalciteContextException object.
- CalciteException - Exception Class in org.apache.calcite.runtime
-
Base class for all exceptions originating from Farrago.
- CalciteException(String, Throwable) - Constructor for exception class org.apache.calcite.runtime.CalciteException
-
Creates a new CalciteException object.
- CalciteFactory - Class in org.apache.calcite.jdbc
-
Extension of
AvaticaFactory
for Calcite. - CalciteFactory(int, int) - Constructor for class org.apache.calcite.jdbc.CalciteFactory
-
Creates a JDBC factory with given major/minor version number.
- CalciteFlatMapFunction() - Constructor for class org.apache.calcite.adapter.spark.SparkRuntime.CalciteFlatMapFunction
- CalciteImmutable - Annotation Type in org.apache.calcite
-
Annotation to be used to convert interfaces/abstract classes into Immutable POJO using Immutables package.
- CalciteJdbc41Factory - Class in org.apache.calcite.jdbc
-
Implementation of
AvaticaFactory
for Calcite and JDBC 4.1 (corresponds to JDK 1.7). - CalciteJdbc41Factory() - Constructor for class org.apache.calcite.jdbc.CalciteJdbc41Factory
-
Creates a factory for JDBC version 4.1.
- CalciteJdbc41Factory(int, int) - Constructor for class org.apache.calcite.jdbc.CalciteJdbc41Factory
-
Creates a JDBC factory with given major/minor version number.
- CalciteLogger - Class in org.apache.calcite.util.trace
-
Small extension to
Logger
with some performance improvements. - CalciteLogger(Logger) - Constructor for class org.apache.calcite.util.trace.CalciteLogger
- CalciteMetaColumnFactory - Interface in org.apache.calcite.jdbc
-
Factory for creating instances of
MetaImpl.MetaColumn
. - CalciteMetaColumnFactoryImpl - Class in org.apache.calcite.jdbc
-
Default implementation of CalciteMetaColumnFactoryImpl.
- CalciteMetaColumnFactoryImpl() - Constructor for class org.apache.calcite.jdbc.CalciteMetaColumnFactoryImpl
-
Internal constructor; protected to allow subclassing.
- CalciteMetaImpl - Class in org.apache.calcite.jdbc
-
Helper for implementing the
getXxx
methods such asAvaticaDatabaseMetaData.getTables(java.lang.String, java.lang.String, java.lang.String, java.lang.String[])
. - CalciteMetaImpl(CalciteConnectionImpl) - Constructor for class org.apache.calcite.jdbc.CalciteMetaImpl
-
Deprecated.Use
CalciteMetaImpl.create(CalciteConnection)
instead. - CalciteMetaImpl(CalciteConnectionImpl, CalciteMetaTableFactory, CalciteMetaColumnFactory) - Constructor for class org.apache.calcite.jdbc.CalciteMetaImpl
-
Internal constructor.
- CalciteMetaImpl.CalciteMetaTable - Class in org.apache.calcite.jdbc
-
Metadata describing a Calcite table.
- CalciteMetaTable(Table, String, String, String) - Constructor for class org.apache.calcite.jdbc.CalciteMetaImpl.CalciteMetaTable
-
Creates a CalciteMetaTable.
- CalciteMetaTableFactory - Interface in org.apache.calcite.jdbc
-
Factory for creating instances of
MetaImpl.MetaTable
. - CalciteMetaTableFactoryImpl - Class in org.apache.calcite.jdbc
-
Default implementation of CalciteMetaTableFactory.
- CalciteMetaTableFactoryImpl() - Constructor for class org.apache.calcite.jdbc.CalciteMetaTableFactoryImpl
-
Internal constructor; protected to allow subclassing.
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.BinaryOperatorConversion
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.CeilOperatorConversion
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.DirectOperatorConversion
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.DruidSqlCastConverter
- calciteOperator() - Method in interface org.apache.calcite.adapter.druid.DruidSqlOperatorConverter
-
Returns the calcite SQL operator corresponding to Druid operator.
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.ExtractOperatorConversion
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.FloorOperatorConversion
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.NaryOperatorConverter
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.SubstringOperatorConversion
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.UnaryPrefixOperatorConversion
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.UnarySuffixOperatorConversion
- CalciteParserException - Interface in org.apache.calcite.util
-
Tagging interface to allow a
SqlParseException
to be identified without adding a dependency on it from client-side code. - CalcitePrepare - Interface in org.apache.calcite.jdbc
-
API for a service that prepares statements for execution.
- CalcitePrepare.AnalyzeViewResult - Class in org.apache.calcite.jdbc
-
The result of analyzing a view.
- CalcitePrepare.CalciteSignature<T> - Class in org.apache.calcite.jdbc
-
The result of preparing a query.
- CalcitePrepare.Context - Interface in org.apache.calcite.jdbc
-
Context for preparing a statement.
- CalcitePrepare.ConvertResult - Class in org.apache.calcite.jdbc
-
The result of parsing and validating a SQL query and converting it to relational algebra.
- CalcitePrepare.Dummy - Class in org.apache.calcite.jdbc
-
Namespace that allows us to define non-abstract methods inside an interface.
- CalcitePrepare.ParseResult - Class in org.apache.calcite.jdbc
-
The result of parsing and validating a SQL query.
- CalcitePrepare.Query<T> - Class in org.apache.calcite.jdbc
- CalcitePrepare.SparkHandler - Interface in org.apache.calcite.jdbc
-
Callback to register Spark as the main engine.
- CalcitePrepare.SparkHandler.RuleSetBuilder - Interface in org.apache.calcite.jdbc
-
Allows Spark to declare the rules it needs.
- CalcitePrepareImpl - Class in org.apache.calcite.prepare
-
Shit just got real.
- CalcitePrepareImpl() - Constructor for class org.apache.calcite.prepare.CalcitePrepareImpl
- CalcitePrepareImpl.CalcitePreparingStmt - Class in org.apache.calcite.prepare
-
Holds state for the process of preparing a SQL statement.
- CalcitePreparingStmt(CalcitePrepareImpl, CalcitePrepare.Context, Prepare.CatalogReader, RelDataTypeFactory, CalciteSchema, EnumerableRel.Prefer, RelOptCluster, Convention, SqlRexConvertletTable) - Constructor for class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
-
Constructor.
- CalciteResource - Interface in org.apache.calcite.runtime
-
Compiler-checked resources for the Calcite project.
- CalciteResultSet - Class in org.apache.calcite.jdbc
-
Implementation of
ResultSet
for the Calcite engine. - CalciteRootSchema - Class in org.apache.calcite.jdbc
-
Deprecated.
- CalciteSchema - Class in org.apache.calcite.jdbc
-
Schema.
- CalciteSchema(CalciteSchema, Schema, String, NameMap<CalciteSchema>, NameMap<CalciteSchema.TableEntry>, NameMap<CalciteSchema.LatticeEntry>, NameMap<CalciteSchema.TypeEntry>, NameMultimap<CalciteSchema.FunctionEntry>, NameSet, NameMap<CalciteSchema.FunctionEntry>, List<? extends List<String>>) - Constructor for class org.apache.calcite.jdbc.CalciteSchema
- CalciteSchema.Entry - Class in org.apache.calcite.jdbc
-
Entry in a schema, such as a table or sub-schema.
- CalciteSchema.FunctionEntry - Class in org.apache.calcite.jdbc
-
Membership of a function in a schema.
- CalciteSchema.FunctionEntryImpl - Class in org.apache.calcite.jdbc
-
Implementation of
CalciteSchema.FunctionEntry
where all properties are held in fields. - CalciteSchema.LatticeEntry - Class in org.apache.calcite.jdbc
-
Membership of a lattice in a schema.
- CalciteSchema.LatticeEntryImpl - Class in org.apache.calcite.jdbc
-
Implementation of
CalciteSchema.LatticeEntry
where all properties are held in fields. - CalciteSchema.TableEntry - Class in org.apache.calcite.jdbc
-
Membership of a table in a schema.
- CalciteSchema.TableEntryImpl - Class in org.apache.calcite.jdbc
-
Implementation of
CalciteSchema.TableEntry
where all properties are held in fields. - CalciteSchema.TypeEntry - Class in org.apache.calcite.jdbc
-
Membership of a type in a schema.
- CalciteSchema.TypeEntryImpl - Class in org.apache.calcite.jdbc
-
Implementation of
CalciteSchema.TypeEntry
where all properties are held in fields. - CalciteServer - Interface in org.apache.calcite.server
-
Server.
- CalciteServerStatement - Interface in org.apache.calcite.server
-
Statement within a Calcite server.
- CalciteSignature(String, List<AvaticaParameter>, Map<String, Object>, RelDataType, List<ColumnMetaData>, Meta.CursorFactory, CalciteSchema, List<RelCollation>, long, Bindable<T>, Meta.StatementType) - Constructor for class org.apache.calcite.jdbc.CalcitePrepare.CalciteSignature
- CalciteSignature(String, List<AvaticaParameter>, Map<String, Object>, RelDataType, List<ColumnMetaData>, Meta.CursorFactory, CalciteSchema, List<RelCollation>, long, Bindable<T>) - Constructor for class org.apache.calcite.jdbc.CalcitePrepare.CalciteSignature
-
Deprecated.
- CalciteSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation that produces SQL that can be parsed by Apache Calcite. - CalciteSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.CalciteSqlDialect
-
Creates a CalciteSqlDialect.
- CalciteSqlValidator - Class in org.apache.calcite.prepare
-
Validator.
- CalciteSqlValidator(SqlOperatorTable, CalciteCatalogReader, JavaTypeFactory, SqlValidator.Config) - Constructor for class org.apache.calcite.prepare.CalciteSqlValidator
- CalciteStatement - Class in org.apache.calcite.jdbc
-
Implementation of
Statement
for the Calcite engine. - CalciteSystemProperty<T> - Class in org.apache.calcite.config
-
A Calcite specific system property that is used to configure various aspects of the framework.
- CalciteTimingTracer - Class in org.apache.calcite.util.trace
-
CalciteTimingTracer provides a mechanism for tracing the timing of a call sequence at nanosecond resolution.
- CalciteTimingTracer(Logger, String) - Constructor for class org.apache.calcite.util.trace.CalciteTimingTracer
-
Creates a new timing tracer, publishing an initial event (at elapsed time 0).
- CalciteTrace - Class in org.apache.calcite.util.trace
-
Contains all of the
tracers
used within org.apache.calcite class libraries. - CalciteTrace() - Constructor for class org.apache.calcite.util.trace.CalciteTrace
- CalciteValidatorException - Interface in org.apache.calcite.util
-
Tagging interface to allow a
SqlValidatorException
to be identified without adding a dependency on it from client-side code. - CalcMergeRule - Class in org.apache.calcite.rel.rules
- CalcMergeRule(CalcMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.CalcMergeRule
-
Creates a CalcMergeRule.
- CalcMergeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.CalcMergeRule
-
Deprecated.
- CalcMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- CalcReduceExpressionsRule(Class<? extends Calc>, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.CalcReduceExpressionsRule
-
Deprecated.
- CalcReduceExpressionsRule(Class<? extends Calc>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.CalcReduceExpressionsRule
-
Deprecated.
- CalcReduceExpressionsRule(ReduceExpressionsRule.CalcReduceExpressionsRule.CalcReduceExpressionsRuleConfig) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.CalcReduceExpressionsRule
-
Creates a CalcReduceExpressionsRule.
- CalcRelSplitter - Class in org.apache.calcite.rel.rules
- CalcRelSplitter.RelType - Class in org.apache.calcite.rel.rules
-
Type of relational expression.
- CalcRemoveRule - Class in org.apache.calcite.rel.rules
-
Planner rule that removes a trivial
LogicalCalc
. - CalcRemoveRule(CalcRemoveRule.Config) - Constructor for class org.apache.calcite.rel.rules.CalcRemoveRule
-
Creates a CalcRemoveRule.
- CalcRemoveRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.CalcRemoveRule
-
Deprecated.
- CalcRemoveRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- CalcSplitRule - Class in org.apache.calcite.rel.rules
- CalcSplitRule(CalcSplitRule.Config) - Constructor for class org.apache.calcite.rel.rules.CalcSplitRule
-
Creates a CalcSplitRule.
- CalcSplitRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.CalcSplitRule
-
Deprecated.
- CalcSplitRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- CalcToWindowRule(ProjectToWindowRule.CalcToWindowRule.CalcToWindowRuleConfig) - Constructor for class org.apache.calcite.rel.rules.ProjectToWindowRule.CalcToWindowRule
-
Creates a CalcToWindowRule.
- calendar() - Static method in class org.apache.calcite.util.Util
-
Creates a
Calendar
in the UTC time zone and root locale. - calendar(long) - Static method in class org.apache.calcite.util.Util
-
Creates a
Calendar
in the UTC time zone and root locale with a given time. - calendar(long, TimeZone) - Static method in class org.apache.calcite.util.Util
-
Creates a
Calendar
in the specified time zone. - call - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- call - Variable in class org.apache.calcite.sql.validate.AliasNamespace
- call() - Method in interface org.apache.calcite.adapter.enumerable.AggResultContext
-
Returns the aggregate call.
- call() - Method in class org.apache.calcite.adapter.enumerable.impl.AggResetContextImpl
- call() - Method in class org.apache.calcite.adapter.enumerable.impl.AggResultContextImpl
- call(Method, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a static method that has arguments.
- call(Method, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a static method that has arguments, using varargs.
- call(Type, String, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a static method by calling the appropriate factory method.
- call(Type, String, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a static method by calling the appropriate factory method, using varargs.
- call(Type, Expression, Method, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a method that takes arguments, with an explicit return type.
- call(Type, Expression, Method, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a method that takes arguments, with an explicit return type, with varargs.
- call(Expression, Class, String, List<? extends Expression>) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
-
A more powerful version of
Expressions.call(Type, String, Iterable)
. - call(Expression, Method, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a method that takes arguments.
- call(Expression, Method, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a method that takes arguments, using varargs.
- call(Expression, String, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to an instance method by calling the appropriate factory method.
- call(Expression, String, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to an instance method by calling the appropriate factory method, using varargs.
- call(SqlOperator, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to a scalar operator.
- call(SqlOperator, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to a scalar operator.
- call(PrecedenceClimbingParser.Op, ImmutableList<PrecedenceClimbingParser.Token>) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- call(PrecedenceClimbingParser.Op, PrecedenceClimbingParser.Token, PrecedenceClimbingParser.Token) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- Call - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A method call, such as in the
obj.sampleMethod()
expression. - Call(SqlParserPos, Ast.Op, Iterable<? extends Ast.Node>) - Constructor for class org.apache.calcite.piglet.Ast.Call
- Call(SqlParserPos, Ast.Op, Ast.Node...) - Constructor for class org.apache.calcite.piglet.Ast.Call
- CALL - Enum constant in enum org.apache.calcite.util.PrecedenceClimbingParser.Type
- CallCopyingArgHandler(SqlCall, boolean) - Constructor for class org.apache.calcite.sql.util.SqlShuttle.CallCopyingArgHandler
- CallImplementor - Interface in org.apache.calcite.adapter.enumerable
-
Implements a call via given translator.
- callRewrite() - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Returns whether to enable rewrite of "macro-like" calls such as COALESCE.
- CallSiteBinder - Interface in org.apache.calcite.linq4j.tree
-
Creates a
DynamicExpression
that represents a dynamic operation bound by the providedCallSiteBinder
. - callToOperandTypesMap - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Provides the data for
SqlValidatorImpl.getValidatedOperandTypes(SqlCall)
. - camelName - Variable in enum org.apache.calcite.DataContext.Variable
- camelName - Variable in enum org.apache.calcite.model.ModelHandler.ExtraOperand
- camelName() - Method in enum org.apache.calcite.config.CalciteConnectionProperty
- canApplyFrom(SqlTypeName, SqlTypeName) - Method in interface org.apache.calcite.sql.type.SqlTypeMappingRule
-
Returns whether it is valid to apply the defined rules from type
from
to typeto
. - canAssignFrom(RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Tests whether a value can be assigned to a site.
- canBeRepresentedExactly(BigDecimal, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether the decimal value can be represented without information loss using the specified type.
- canBeUsed(AggregateCall) - Method in class org.apache.calcite.adapter.druid.ComplexMetric
-
Returns true if and only if this
ComplexMetric
can be used in the givenAggregateCall
. - canCastFrom(RelDataType, RelDataType, boolean) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Compares two types and returns whether
fromType
can be cast totoType
, using either coercion or assignment. - canCastFrom(RelDataType, RelDataType, SqlTypeMappingRule) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Compares two types and returns whether
fromType
can be cast totoType
. - CANCEL_FLAG - Enum constant in enum org.apache.calcite.DataContext.Variable
-
A mutable flag that indicates whether user has requested that the current statement be canceled.
- cancelFlag - Variable in class org.apache.calcite.plan.AbstractRelOptPlanner
- CancelFlag - Class in org.apache.calcite.util
-
CancelFlag is used to post and check cancellation requests.
- CancelFlag(AtomicBoolean) - Constructor for class org.apache.calcite.util.CancelFlag
- cancelNullsOnLeft() - Method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns a join type similar to this but that does not generate nulls on the left.
- cancelNullsOnRight() - Method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns a join type similar to this but that does not generate nulls on the right.
- canConvert(RelOptPlanner, Convention, Convention) - Method in class org.apache.calcite.plan.ConventionTraitDef
- canConvert(RelOptPlanner, RelCollation, RelCollation) - Method in class org.apache.calcite.rel.RelCollationTraitDef
- canConvert(RelOptPlanner, RelDistribution, RelDistribution) - Method in class org.apache.calcite.rel.RelDistributionTraitDef
- canConvert(RelOptPlanner, T, T) - Method in class org.apache.calcite.plan.RelTraitDef
-
Tests whether the given RelTrait can be converted to another RelTrait.
- canConvertConvention(Convention) - Method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- canConvertConvention(Convention) - Method in enum org.apache.calcite.interpreter.BindableConvention
- canConvertConvention(Convention) - Method in enum org.apache.calcite.interpreter.InterpretableConvention
- canConvertConvention(Convention) - Method in interface org.apache.calcite.plan.Convention
-
Returns whether we should convert from this convention to
toConvention
. - canConvertConvention(Convention) - Method in class org.apache.calcite.plan.Convention.Impl
- canConvertSubQuery() - Method in interface org.apache.calcite.sql2rel.SubQueryConverter
-
Returns whether the sub-query can be converted.
- canExpand(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
This defaults to the utility method,
RexUtil.requiresDecimalExpansion(RexNode, boolean)
which checks general guidelines on whether a rewrite should be considered at all. - canFlattenStatic(AggregateCall) - Static method in class org.apache.calcite.rel.rules.AggregateRemoveRule
-
As
AggregateRemoveRule.canFlatten(org.apache.calcite.rel.core.AggregateCall)
, but only allows static aggregate functions. - canHandle(RelOptTable) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
-
Returns whether EnumerableTableScan can generate code to handle a particular variant of the Table SPI.
- canHandle(RelOptTable) - Static method in class org.apache.calcite.interpreter.Bindables.BindableTableScan
- canHandle(Table) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
-
Deprecated.remove before Calcite 2.0
- canImplement(LogicalCalc, String) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter
-
Returns whether a relational expression can be implemented solely in a given
CalcRelSplitter.RelType
. - canImplement(RexCall) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.RelType
- canImplement(RexDynamicParam) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.RelType
- canImplement(RexFieldAccess) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.RelType
- canImplement(RexLiteral) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.RelType
- canImplement(RexNode, boolean) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.RelType
-
Returns whether this
RelType
can implement a given expression. - canImplement(RexProgram) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.RelType
-
Returns whether this tester's
RelType
can implement a given program. - canInsertInto() - Method in enum org.apache.calcite.schema.ColumnStrategy
-
Returns whether you can insert into the column.
- canNotApplyOp2Type(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- cannotCallTableFunctionHere(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- cannotCastValue(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- cannotConvert(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- cannotConvertToRelation(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- cannotConvertToStream(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- cannotImplement() - Method in class org.apache.calcite.rel.convert.ConverterImpl
-
Deprecated.
- cannotOverrideWindowAttribute() - Method in interface org.apache.calcite.runtime.CalciteResource
- CannotPlanException(String) - Constructor for exception class org.apache.calcite.plan.RelOptPlanner.CannotPlanException
- cannotStreamResultsForNonStreamingInputs(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- cannotStreamValues() - Method in interface org.apache.calcite.runtime.CalciteResource
- cannotUseDisallowPartialWithRange() - Method in interface org.apache.calcite.runtime.CalciteResource
- cannotUseWithinWithoutOrderBy() - Method in interface org.apache.calcite.runtime.CalciteResource
- canonize(RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
-
Registers a type, or returns the existing type if it is already registered.
- canonize(RelDataType) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- canonize(StructKind, List<String>, List<RelDataType>) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- canonize(StructKind, List<String>, List<RelDataType>, boolean) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
-
Looks up a type using a temporary key, and if not present, creates a permanent key and type.
- canonize(T) - Method in class org.apache.calcite.plan.RelTraitDef
-
Takes an arbitrary RelTrait and returns the canonical representation of that RelTrait.
- canonize(T) - Method in class org.apache.calcite.plan.RelTraitSet
-
Converts a trait to canonical form.
- canPushIntoFromAbove() - Method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns whether this join type accepts pushing predicates from above into its predicate.
- canPushLeftFromAbove() - Method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns whether this join type accepts pushing predicates from above into its left input.
- canPushLeftFromWithin() - Method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns whether this join type accepts pushing predicates from within into its left input.
- canPushRightFromAbove() - Method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns whether this join type accepts pushing predicates from above into its right input.
- canPushRightFromWithin() - Method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns whether this join type accepts pushing predicates from within into its right input.
- canReduce() - Method in class org.apache.calcite.linq4j.tree.Expression
-
Indicates that the node can be reduced to a simpler node.
- canReduce(AggregateCall) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Returns whether this rule can reduce a given aggregate function call.
- canReduceAggCallByGrouping(Aggregate, AggregateCall) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Returns whether this rule can reduce some agg-call, which its arg exists in the aggregate's group.
- canReinterpretOverflow(RexCall) - Static method in class org.apache.calcite.rex.RexUtil
- canRollUpTo(TimeFrame) - Method in interface org.apache.calcite.rel.type.TimeFrame
-
Whether this frame can roll up to
toFrame
. - capInfinity(Double) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Caps a double value at Double.MAX_VALUE if it's currently infinity
- CapitalizationEnum - Enum in org.apache.calcite.util.format.postgresql
-
Casing styles that can be applied to a string.
- CAPITALIZED - Enum constant in enum org.apache.calcite.util.format.postgresql.CapitalizationEnum
- cardinality() - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Returns the number of set bits.
- cardinality() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns the number of bits set to
true
in thisImmutableBitSet
. - cardinality(List<Lattice.Column>) - Method in class org.apache.calcite.materialize.DelegatingLatticeStatisticProvider
- cardinality(List<Lattice.Column>) - Method in interface org.apache.calcite.materialize.LatticeStatisticProvider
-
Returns an estimate of the number of distinct values in a column or list of columns.
- cardinality(ImmutableBitSet) - Method in class org.apache.calcite.profile.Profiler.Profile
- CARDINALITY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The CARDINALITY operator, used to retrieve the number of elements in a MULTISET, ARRAY or MAP.
- CARDINALITY_VIOLATION - Enum constant in enum org.apache.calcite.sql.SqlStateCodes
-
Deprecated.
- cardOfProjExpr(RelMetadataQuery, Project, RexNode) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Computes the cardinality of a particular expression from the projection list.
- CartesianProductEnumerator<T,
E> - Class in org.apache.calcite.linq4j -
Enumerator over the cartesian product of enumerators.
- CartesianProductEnumerator(List<Enumerator<T>>) - Constructor for class org.apache.calcite.linq4j.CartesianProductEnumerator
- cascade(SqlReturnTypeInference, SqlTypeTransform...) - Static method in class org.apache.calcite.sql.type.ReturnTypes
-
Creates a return-type inference that applies a rule then a sequence of transforms.
- CASE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CASE
expression. - CASE - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
CASE expression.
- CASE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- CASE_SENSITIVE - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether identifiers are matched case-sensitively.
- caseClausesOnNewLines() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether the WHEN, THEN and ELSE clauses of a CASE expression appear at the start of a new line.
- caseSensitive - Variable in enum org.apache.calcite.config.Lex
- caseSensitive() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.CASE_SENSITIVE
. - caseSensitive() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- caseSensitive() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- caseSensitive() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- CaseShuttle() - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.CaseShuttle
- caseWhenCoercion(SqlCallBinding) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Coerces CASE WHEN statement branches to one common type.
- caseWhenCoercion(SqlCallBinding) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
-
CASE and COALESCE type coercion, collect all the branches types including then operands and else operands to find a common type, then cast the operands to the common type when needed.
- CASSANDRA_QUERYABLE_QUERY - Enum constant in enum org.apache.calcite.adapter.cassandra.CassandraMethod
- CassandraFilter - Class in org.apache.calcite.adapter.cassandra
-
Implementation of a
Filter
relational expression in Cassandra. - CassandraFilter(RelOptCluster, RelTraitSet, RelNode, RexNode, List<String>, List<String>, List<RelFieldCollation>) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraFilter
- CassandraFilterRule(CassandraRules.CassandraFilterRule.CassandraFilterRuleConfig) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraFilterRule
-
Creates a CassandraFilterRule.
- CassandraLimit - Class in org.apache.calcite.adapter.cassandra
-
Implementation of limits in Cassandra.
- CassandraLimit(RelOptCluster, RelTraitSet, RelNode, RexNode, RexNode) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraLimit
- CassandraLimitRule(CassandraRules.CassandraLimitRule.CassandraLimitRuleConfig) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraLimitRule
-
Creates a CassandraLimitRule.
- CassandraMethod - Enum in org.apache.calcite.adapter.cassandra
-
Builtin methods in the Cassandra adapter.
- CassandraProject - Class in org.apache.calcite.adapter.cassandra
-
Implementation of
Project
relational expression in Cassandra. - CassandraProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraProject
- CassandraProjectRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraProjectRule
- CassandraQueryable(QueryProvider, SchemaPlus, CassandraTable, String) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- CassandraRel - Interface in org.apache.calcite.adapter.cassandra
-
Relational expression that uses Cassandra calling convention.
- CassandraRel.Implementor - Class in org.apache.calcite.adapter.cassandra
-
Callback for the implementation process that converts a tree of
CassandraRel
nodes into a CQL query. - CassandraRules - Class in org.apache.calcite.adapter.cassandra
-
Rules and relational operators for
CassandraRel.CONVENTION
calling convention. - CassandraRules.CassandraFilterRule - Class in org.apache.calcite.adapter.cassandra
-
Rule to convert a
LogicalFilter
to aCassandraFilter
. - CassandraRules.CassandraFilterRule.CassandraFilterRuleConfig - Interface in org.apache.calcite.adapter.cassandra
-
Rule configuration.
- CassandraRules.CassandraFilterRule.Config - Interface in org.apache.calcite.adapter.cassandra
-
Deprecated.
- CassandraRules.CassandraLimitRule - Class in org.apache.calcite.adapter.cassandra
-
Rule to convert a
EnumerableLimit
to aCassandraLimit
. - CassandraRules.CassandraLimitRule.CassandraLimitRuleConfig - Interface in org.apache.calcite.adapter.cassandra
-
Rule configuration.
- CassandraRules.CassandraLimitRule.Config - Interface in org.apache.calcite.adapter.cassandra
-
Deprecated.
- CassandraRules.CassandraProjectRule - Class in org.apache.calcite.adapter.cassandra
-
Rule to convert a
LogicalProject
to aCassandraProject
. - CassandraRules.CassandraSortRule - Class in org.apache.calcite.adapter.cassandra
-
Rule to convert a
Sort
to aCassandraSort
. - CassandraRules.CassandraSortRule.CassandraSortRuleConfig - Interface in org.apache.calcite.adapter.cassandra
-
Rule configuration.
- CassandraRules.CassandraSortRule.Config - Interface in org.apache.calcite.adapter.cassandra
-
Deprecated.
- CassandraSchema - Class in org.apache.calcite.adapter.cassandra
-
Schema mapped onto a Cassandra column family.
- CassandraSchema(CqlSession, SchemaPlus, String) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraSchema
-
Creates a Cassandra schema.
- CassandraSchema(CqlSession, SchemaPlus, String, String) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraSchema
-
Creates a Cassandra schema.
- CassandraSchemaFactory - Class in org.apache.calcite.adapter.cassandra
-
Factory that creates a
CassandraSchema
. - CassandraSchemaFactory() - Constructor for class org.apache.calcite.adapter.cassandra.CassandraSchemaFactory
- CassandraSort - Class in org.apache.calcite.adapter.cassandra
-
Implementation of
Sort
relational expression in Cassandra. - CassandraSort(RelOptCluster, RelTraitSet, RelNode, RelCollation) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraSort
- CassandraSortRule(CassandraRules.CassandraSortRule.CassandraSortRuleConfig) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraSortRule
-
Creates a CassandraSortRule.
- CassandraTable - Class in org.apache.calcite.adapter.cassandra
-
Table based on a Cassandra column family.
- CassandraTable(CassandraSchema, String) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraTable
-
Deprecated.
- CassandraTable(CassandraSchema, String, boolean) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraTable
-
Deprecated.
- CassandraTable(CassandraSchema, String, String) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraTable
- CassandraTable(CassandraSchema, String, String, boolean) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraTable
- CassandraTable.CassandraQueryable<T> - Class in org.apache.calcite.adapter.cassandra
-
Implementation of
Queryable
based on aCassandraTable
. - CassandraTableScan - Class in org.apache.calcite.adapter.cassandra
-
Relational expression representing a scan of a Cassandra collection.
- CassandraTableScan(RelOptCluster, RelTraitSet, RelOptTable, CassandraTable, RelDataType) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraTableScan
-
Creates a CassandraTableScan.
- CassandraToEnumerableConverter - Class in org.apache.calcite.adapter.cassandra
-
Relational expression representing a scan of a table in a Cassandra data source.
- CassandraToEnumerableConverter(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraToEnumerableConverter
- CassandraToEnumerableConverterRule - Class in org.apache.calcite.adapter.cassandra
-
Rule to convert a relational expression from
CassandraRel.CONVENTION
toEnumerableConvention
. - CassandraToEnumerableConverterRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraToEnumerableConverterRule
-
Creates a CassandraToEnumerableConverterRule.
- cast(Class<T2>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- cast(Class<T2>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- cast(Class<T2>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Converts the elements of this Enumerable to the specified type.
- cast(Class<T2>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- cast(Iterable<? super E>, Class<E>) - Static method in class org.apache.calcite.util.Util
-
Converts an
Iterable
whose members are automatically down-cast to a given type. - cast(Iterable<TSource>, Class<TResult>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Converts the elements of a given Iterable to the specified type.
- cast(Iterator<? extends Object>, Class<E>) - Static method in class org.apache.calcite.util.Util
-
Converts a iterator whose members are automatically down-cast to a given type.
- cast(List<? super E>, Class<E>) - Static method in class org.apache.calcite.util.Util
-
Converts a list whose members are automatically down-cast to a given type.
- cast(Enumerable<TSource>, Class<T2>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Analogous to LINQ's Enumerable.Cast extension method.
- cast(Queryable<T>, Class<T2>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Analogous to LINQ's Enumerable.Cast extension method.
- cast(Queryable<T>, Class<T2>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
- cast(Queryable<T>, Class<T2>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- cast(RelDataType, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- cast(RexNode, SqlTypeName) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an expression that casts an expression to a given type.
- cast(RexNode, SqlTypeName, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an expression that casts an expression to a type with a given name and precision or length.
- cast(RexNode, SqlTypeName, int, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an expression that casts an expression to a type with a given name, precision and scale.
- cast(SqlParserPos, RexNode, SqlTypeName) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an expression that casts an expression to a given type.
- cast(SqlParserPos, RexNode, SqlTypeName, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an expression that casts an expression to a type with a given name and precision or length.
- cast(SqlParserPos, RexNode, SqlTypeName, int, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an expression that casts an expression to a type with a given name, precision and scale.
- CAST - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The "CAST" operator, and also the PostgreSQL-style infix cast operator "::".
- CAST - Enum constant in enum org.apache.calcite.sql.test.SqlOperatorFixture.CastType
- CAST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
CAST
operator. - castIfNecessary(Type, Expression) - Static method in class org.apache.calcite.linq4j.tree.Types
-
Wraps an expression in a cast if it is not already of the desired type, or cannot be implicitly converted to it.
- CastingList<E> - Class in org.apache.calcite.util
-
Converts a list whose members are automatically down-cast to a given type.
- CastingList(List<? super E>, Class<E>) - Constructor for class org.apache.calcite.util.CastingList
- castNonNull(T) - Static method in class org.apache.calcite.linq4j.Nullness
-
Allows you to treat a nullable type as non-nullable with no assertions.
- castNonNull(DiffRepository) - Static method in class org.apache.calcite.test.DiffRepository
-
Returns the diff repository, checking that it is not null.
- castNonNullArray(T[]) - Static method in class org.apache.calcite.linq4j.Nullness
-
Allows you to treat an array of nullable values as an array of non-nullable values.
- castNonNullList(List<? extends T>) - Static method in class org.apache.calcite.linq4j.Nullness
-
Allows you to treat a list of nullable values as an list of non-nullable values.
- castQueryable() - Method in class org.apache.calcite.linq4j.QueryableDefaults.ReplayableQueryable
-
Convenience method, for
QueryableRecorder
methods that return a Queryable of a different element type than the source. - castToInitialized(T) - Static method in class org.apache.calcite.linq4j.Nullness
-
Allows you to treat an uninitialized or under-initialization object as initialized with no assertions.
- castToValidatedType(SqlParserPos, SqlNode, RexNode, SqlValidator, RexBuilder, boolean) - Static method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Casts a RexNode value to the validated type of a SqlCall.
- castToValidatedType(SqlNode, RexNode, SqlValidator, RexBuilder) - Static method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Deprecated.
- castToValidatedType(SqlRexContext, SqlCall, RexNode) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Deprecated.
- catalog - Variable in class org.apache.calcite.test.ConnectionSpec
- CATALOG - Enum constant in enum org.apache.calcite.sql.validate.SqlMonikerType
- CATALOG_COLUMNS - Static variable in class org.apache.calcite.jdbc.CalciteMetaImpl
-
The columns returned by
DatabaseMetaData.getCatalogs()
. - catalogReader - Variable in class org.apache.calcite.prepare.Prepare
- catalogReader - Variable in class org.apache.calcite.rel.core.TableModify
-
The connection to the optimizing session.
- catalogReader - Variable in class org.apache.calcite.rel.mutable.MutableTableModify
- catalogReader - Variable in class org.apache.calcite.sql.validate.DelegatingSqlValidatorCatalogReader
- catalogReader - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- catalogReader - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- catch_(ParameterExpression, Statement) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a CatchBlock representing a catch statement with a reference to the caught Exception object for use in the handler body.
- CatchallSchema - Class in org.apache.calcite.test.schemata.catchall
-
Object whose fields are relations.
- CatchallSchema() - Constructor for class org.apache.calcite.test.schemata.catchall.CatchallSchema
- CatchallSchema.AllPrivate - Class in org.apache.calcite.test.schemata.catchall
-
All field are private, therefore the resulting record has no fields.
- CatchallSchema.BadType - Class in org.apache.calcite.test.schemata.catchall
-
Table that has a field that cannot be recognized as a SQL type.
- CatchallSchema.EveryType - Class in org.apache.calcite.test.schemata.catchall
-
Record that has a field of every interesting type.
- CatchallSchema.IntAndString - Class in org.apache.calcite.test.schemata.catchall
-
Table that has integer and string fields.
- CatchallSchema.IntHolder - Class in org.apache.calcite.test.schemata.catchall
-
Custom java class that holds just a single field.
- CatchBlock - Class in org.apache.calcite.linq4j.tree
-
Represents a catch statement in a try block.
- CatchBlock(ParameterExpression, Statement) - Constructor for class org.apache.calcite.linq4j.tree.CatchBlock
- catchBlocks - Variable in class org.apache.calcite.linq4j.tree.TryStatement
- category(SqlOperator) - Static method in class org.apache.calcite.sql.util.ListSqlOperatorTable
- causeOrSelf(Throwable) - Static method in class org.apache.calcite.util.Util
-
Returns cause of the given throwable if it is non-null or the throwable itself.
- cbrt(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CBRT
operator applied to double values. - cbrt(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CBRT
operator applied to BigDecimal values. - CBRT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CBRT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CBRT(numeric)
function. - CBSTRING_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where the first operand is a character or binary string (CHAR, VARCHAR, BINARY or VARBINARY), and the second operand is INTEGER.
- CC - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- cdata(String, boolean) - Method in class org.apache.calcite.util.XmlOutput
-
Writes a CDATA section (as
XmlOutput.cdata(String)
). - cdata(String) - Method in class org.apache.calcite.util.XmlOutput
-
Writes a CDATA section.
- ceil(byte, byte) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CEIL
operator applied to byte values. - ceil(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
- ceil(float) - Static method in class org.apache.calcite.runtime.SqlFunctions
- ceil(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CEIL
operator applied to int values. - ceil(int, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
- ceil(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CEIL
operator applied to long values. - ceil(short, short) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CEIL
operator applied to short values. - ceil(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
- ceil(BigDecimal, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- ceil(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
- CEIL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CEIL
function. - CEIL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CEIL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CEIL
function. - CEIL_BIG_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CEIL(value)" function.
- ceilDate(int, TimeFrame) - Method in class org.apache.calcite.rel.type.TimeFrameSet
-
Computes "FLOOR(date TO frame)", where
date
is the number of days since UNIX Epoch. - CeilOperatorConversion - Class in org.apache.calcite.adapter.druid
-
DruidSqlOperatorConverter implementation that handles Ceil operations conversions.
- CeilOperatorConversion() - Constructor for class org.apache.calcite.adapter.druid.CeilOperatorConversion
- ceilTimestamp(long, TimeFrame) - Method in class org.apache.calcite.rel.type.TimeFrameSet
-
Computes "CEIL(timestamp TO frame)", where
ts
is the number of milliseconds since UNIX Epoch. - CENTURIES - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- ch - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- chain(Iterable<SqlOperatorTable>) - Static method in class org.apache.calcite.sql.util.SqlOperatorTables
-
Creates a composite operator table.
- chain(Context...) - Static method in class org.apache.calcite.plan.Contexts
-
Returns a context that wraps a list of contexts.
- chain(SqlOperatorTable...) - Static method in class org.apache.calcite.sql.util.SqlOperatorTables
-
Creates a composite operator table from an array of tables.
- chain(SqlReturnTypeInference...) - Static method in class org.apache.calcite.sql.type.ReturnTypes
-
Creates a return-type inference that applies a rule then a sequence of rules, returning the first non-null result.
- CHAIN_OF_RESPONSIBILITY_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Avoid coupling the sender of a request to its receiver by giving more than one object a chance to handle the request.
- ChainedRelMetadataProvider - Class in org.apache.calcite.rel.metadata
-
Implementation of the
RelMetadataProvider
interface via theGlossary.CHAIN_OF_RESPONSIBILITY_PATTERN
. - ChainedRelMetadataProvider(ImmutableList<RelMetadataProvider>) - Constructor for class org.apache.calcite.rel.metadata.ChainedRelMetadataProvider
-
Creates a chain.
- ChainedSqlOperatorTable - Class in org.apache.calcite.sql.util
-
ChainedSqlOperatorTable implements the
SqlOperatorTable
interface by chaining together any number of underlying operator table instances. - ChainedSqlOperatorTable(ImmutableList<SqlOperatorTable>) - Constructor for class org.apache.calcite.sql.util.ChainedSqlOperatorTable
-
Internal constructor; call
SqlOperatorTables.chain(java.lang.Iterable<org.apache.calcite.sql.SqlOperatorTable>)
. - ChainedSqlOperatorTable(List<SqlOperatorTable>) - Constructor for class org.apache.calcite.sql.util.ChainedSqlOperatorTable
-
Deprecated.
- changeTraits(RelNode, RelTraitSet) - Method in class org.apache.calcite.plan.hep.HepPlanner
- changeTraits(RelNode, RelTraitSet) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Changes a relational expression to an equivalent one with a different set of traits.
- changeTraits(RelNode, RelTraitSet) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- changeTraits(RelNode, RelTraitSet) - Method in class org.apache.calcite.test.MockRelOptPlanner
- CHAR - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive
- CHAR - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- CHAR - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CHAR(n)" function; returns the character whose ASCII code is
n
% 256, or null ifn
< 0. - CHAR - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is a Char.
- CHAR_DECIMAL_CAST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CHAR_DECIMAL_CAST_ROUNDING_MODE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CHAR_FORCE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is a nullable CHAR(1).
- CHAR_FROM_ASCII - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CHAR_FROM_UTF8 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CHAR_LENGTH - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CHAR_LENGTH
function. - CHAR_LENGTH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CHAR_LENGTH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- CHAR_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- CHARACTER - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- CHARACTER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- CHARACTER_CHARACTER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- CHARACTER_CHARACTER_DATETIME - Static variable in class org.apache.calcite.sql.type.OperandTypes
- CHARACTER_DATE - Static variable in class org.apache.calcite.sql.type.OperandTypes
- CHARACTER_LENGTH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Alias for
SqlStdOperatorTable.CHAR_LENGTH
. - CHARACTER_TIME - Static variable in class org.apache.calcite.sql.type.OperandTypes
- CHARARRAY - Enum constant in enum org.apache.calcite.adapter.pig.PigDataType
- charDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- charFromAscii(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL CHAR(integer) function, as in MySQL and Spark.
- charFromUtf8(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL CHR(integer) function, as in Oracle and Postgres.
- charLength(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL CHARACTER_LENGTH(string) function.
- charLiteral(String) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- charLiteralAliasNotValid() - Method in interface org.apache.calcite.runtime.CalciteResource
- CharLiteralStyle - Enum in org.apache.calcite.config
-
Styles of character literal.
- charLiteralStyles - Variable in enum org.apache.calcite.config.Lex
- charLiteralStyles() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
-
Returns which character literal styles are supported.
- charsetEncoding(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- charToDecimalCast(String, int, int) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Called from BuiltInMethod.CHAR_DECIMAL_CAST
- charToDecimalCast(String, int, int, RoundingMode) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Called from BuiltInMethod.CHAR_DECIMAL_CAST_ROUNDING_MODE
- check() - Method in class org.apache.calcite.test.RelOptFixture
-
Checks the plan for a SQL statement before/after executing a given rule, with an optional pre-program specified by
RelOptFixture.withPre(HepProgram)
to prepare the tree. - check(boolean, String, Object...) - Method in interface org.apache.calcite.util.Litmus
-
Checks a condition.
- check(String, String, Object) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- check(String, SqlTester.TypeChecker, Object) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Tests that a SQL query returns a single column with the given type.
- check(String, SqlTester.TypeChecker, SqlTester.ParameterChecker, SqlTester.ResultChecker) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Tests that a SQL query returns a result of expected type and value.
- check(SqlParserPos, SqlIdentifier, SqlNode) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a CHECK constraint.
- check(SqlTestFactory, String, SqlTester.TypeChecker, SqlTester.ParameterChecker, SqlTester.ResultChecker) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- check(SqlTestFactory, String, SqlTester.TypeChecker, SqlTester.ParameterChecker, SqlTester.ResultChecker) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a SQL query returns a result of expected type and value.
- check(SqlTestFactory, String, SqlTester.TypeChecker, SqlTester.ParameterChecker, SqlTester.ResultChecker) - Method in class org.apache.calcite.test.SqlOperatorTest.TesterImpl
- check(SqlTestFactory, String, SqlTester.TypeChecker, SqlTester.ResultChecker) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a SQL query returns a single column with the given type.
- check(SqlTestFactory, StringAndPos, SqlDialect, UnaryOperator<String>, String, Consumer<SqlParser>) - Method in interface org.apache.calcite.sql.parser.SqlParserTest.Tester
- check(SqlTestFactory, StringAndPos, SqlDialect, UnaryOperator<String>, String, Consumer<SqlParser>) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- check(SqlTestFactory, StringAndPos, SqlDialect, UnaryOperator<String>, String, Consumer<SqlParser>) - Method in class org.apache.calcite.sql.parser.SqlParserTest.UnparsingTesterImpl
- CHECK - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CHECK
constraint. - checkActualAndReferenceFiles() - Method in class org.apache.calcite.test.DiffRepository
- checkAgg(String, String[], String, SqlTester.ResultChecker) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Checks that an aggregate expression returns the expected result.
- checkAgg(String, String[], SqlTester.ResultChecker) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Checks that an aggregate expression returns the expected result.
- checkAgg(SqlTestFactory, String, String[], SqlTester.ResultChecker) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkAgg(SqlTestFactory, String, String[], SqlTester.ResultChecker) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Checks that an aggregate expression returns the expected result.
- checkAggFails(String, String[], String, boolean) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Tests that an aggregate expression fails at run time.
- checkAggFails(SqlTestFactory, String, String[], String, boolean) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkAggFails(SqlTestFactory, String, String[], String, boolean) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that an aggregate expression fails at run time.
- checkAggFails(SqlTestFactory, String, String[], String, boolean) - Method in class org.apache.calcite.test.SqlOperatorTest.TesterImpl
- checkAggregateExpr(SqlNode, boolean) - Method in interface org.apache.calcite.sql.validate.AggregatingScope
-
Checks whether an expression is constant within the GROUP BY clause.
- checkAggregateExpr(SqlNode, boolean) - Method in class org.apache.calcite.sql.validate.AggregatingSelectScope
- checkAggType(String, String) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Very similar to
SqlOperatorFixture.checkType(java.lang.String, java.lang.String)
, but generates inside a SELECT with a non-empty GROUP BY. - checkAggWithMultipleArgs(String, String[][], SqlTester.ResultChecker) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Checks that an aggregate expression with multiple args returns the expected result.
- checkBoolean(String, Boolean) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Tests that a scalar SQL expression returns the expected boolean result.
- checkCancel() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Checks to see whether cancellation has been requested, and if so, throws an exception.
- checkCancel() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- checkCastFails(String, String, String, boolean, SqlOperatorFixture.CastType) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- checkCastToApproxOkay(String, String, Object, SqlOperatorFixture.CastType) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- checkCastToScalarOkay(String, String, String, SqlOperatorFixture.CastType) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- checkCastToScalarOkay(String, String, SqlOperatorFixture.CastType) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- checkCastToString(String, String, String, SqlOperatorFixture.CastType) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- checkCastToStringOkay(String, String, String, SqlOperatorFixture.CastType) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- checkCharsetAndCollateConsistentIfCharType(RelDataType) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
- checkClientTrusted(X509Certificate[], String) - Method in class org.apache.calcite.util.UnsafeX509ExtendedTrustManager
- checkClientTrusted(X509Certificate[], String, Socket) - Method in class org.apache.calcite.util.UnsafeX509ExtendedTrustManager
- checkClientTrusted(X509Certificate[], String, SSLEngine) - Method in class org.apache.calcite.util.UnsafeX509ExtendedTrustManager
- checkColumnType(String, String) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Checks that a query returns one column of an expected type.
- checkColumnType(SqlTestFactory, String, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkColumnType(SqlTestFactory, String, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Checks that a query returns one column of an expected type.
- checkDateFormat(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Checks if the date/time format is valid, throws if not.
- checker - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- checkEx(Throwable, String, StringAndPos, SqlTests.Stage) - Static method in class org.apache.calcite.sql.test.SqlTests
-
Checks whether an exception matches the expected pattern.
- checkEx(String, StringAndPos, Throwable) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- checkExp(SqlTestFactory, StringAndPos, UnaryOperator<String>, String, Consumer<SqlParser>) - Method in interface org.apache.calcite.sql.parser.SqlParserTest.Tester
- checkExp(SqlTestFactory, StringAndPos, UnaryOperator<String>, String, Consumer<SqlParser>) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- checkExp(SqlTestFactory, StringAndPos, UnaryOperator<String>, String, Consumer<SqlParser>) - Method in class org.apache.calcite.sql.parser.SqlParserTest.UnparsingTesterImpl
- checkExpFails(SqlTestFactory, StringAndPos, String) - Method in interface org.apache.calcite.sql.parser.SqlParserTest.Tester
-
Tests that an expression throws an exception that matches the given pattern.
- checkExpFails(SqlTestFactory, StringAndPos, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- checkExpFails(SqlTestFactory, StringAndPos, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.UnparsingTesterImpl
- checkFails(String, String, boolean) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
As
SqlOperatorFixture.checkFails(StringAndPos, String, boolean)
, but with a string that contains carets. - checkFails(StringAndPos, String, boolean) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Tests that a scalar SQL expression fails at run time.
- checkFails(SqlTestFactory, String, String, boolean) - Method in interface org.apache.calcite.sql.test.SqlTester
-
As
SqlTester.checkFails(SqlTestFactory, StringAndPos, String, boolean)
, but with a string that contains carets. - checkFails(SqlTestFactory, StringAndPos, boolean, String) - Method in interface org.apache.calcite.sql.parser.SqlParserTest.Tester
- checkFails(SqlTestFactory, StringAndPos, boolean, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- checkFails(SqlTestFactory, StringAndPos, boolean, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.UnparsingTesterImpl
- checkFails(SqlTestFactory, StringAndPos, String, boolean) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkFails(SqlTestFactory, StringAndPos, String, boolean) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a scalar SQL expression fails at run time.
- checkFails(SqlTestFactory, StringAndPos, String, boolean) - Method in class org.apache.calcite.test.SqlOperatorTest.TesterImpl
- checkIndicator(boolean) - Static method in class org.apache.calcite.rel.core.Aggregate
-
Used internally; will removed when
Aggregate.indicator
is removed, before 2.0. - checkInputForCollationAndLimit(RelMetadataQuery, RelNode, RelCollation, RexNode, RexNode) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Returns whether a relational expression is already sorted and has fewer rows than the sum of offset and limit.
- checkList(SqlTestFactory, StringAndPos, SqlDialect, UnaryOperator<String>, List<String>) - Method in interface org.apache.calcite.sql.parser.SqlParserTest.Tester
- checkList(SqlTestFactory, StringAndPos, SqlDialect, UnaryOperator<String>, List<String>) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- checkList(SqlTestFactory, StringAndPos, SqlDialect, UnaryOperator<String>, List<String>) - Method in class org.apache.calcite.sql.parser.SqlParserTest.UnparsingTesterImpl
- checkMap(LogicalRelationalOperator) - Method in class org.apache.calcite.piglet.PigRelBuilder
-
Checks if a Pig logical operator has been translated before.
- checkMaskedResultContains(String) - Static method in class org.apache.calcite.test.CalciteAssert
- checkNode(SqlTestFactory, StringAndPos, Matcher<SqlNode>) - Method in interface org.apache.calcite.sql.parser.SqlParserTest.Tester
- checkNode(SqlTestFactory, StringAndPos, Matcher<SqlNode>) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- checkNull(String) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Tests that a SQL expression returns the SQL NULL value.
- checkOperandCount(SqlValidator, SqlOperandTypeChecker, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlJsonArrayFunction
- checkOperandCount(SqlValidator, SqlOperandTypeChecker, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlJsonDepthFunction
- checkOperandCount(SqlValidator, SqlOperandTypeChecker, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlJsonModifyFunction
- checkOperandCount(SqlValidator, SqlOperandTypeChecker, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlJsonObjectFunction
- checkOperandCount(SqlValidator, SqlOperandTypeChecker, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlJsonPrettyFunction
- checkOperandCount(SqlValidator, SqlOperandTypeChecker, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlJsonTypeFunction
- checkOperandCount(SqlValidator, SqlOperandTypeChecker, SqlCall) - Method in class org.apache.calcite.sql.SqlOperator
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlCaseOperator
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlCastFunction
-
Makes sure that the number and types of arguments are allowable.
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlConvertFunction
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlDatePartFunction
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlDotOperator
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlItemOperator
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlJsonModifyFunction
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlJsonObjectFunction
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlJsonRemoveFunction
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlLikeOperator
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlLiteralChainOperator
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlMapValueConstructor
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlMultisetMemberOfOperator
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlMultisetQueryConstructor
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlMultisetValueConstructor
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlOverlapsOperator
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlPositionFunction
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlPosixRegexOperator
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlSubstringFunction
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlTranslateFunction
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlTrimFunction
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.SqlDescriptorOperator
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.SqlOperator
-
Checks that the operand values in a
SqlCall
to this operator are valid. - checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.ArrayElementOperandTypeChecker
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.ArrayInsertOperandTypeChecker
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.AssignableOperandTypeChecker
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.ComparableOperandTypeChecker
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.ExplicitOperandTypeChecker
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.FamilyOperandTypeChecker
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.MultisetOperandTypeChecker
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.NotNullOperandTypeChecker
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.SameOperandTypeChecker
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.SetopOperandTypeChecker
- checkOperandTypes(SqlCallBinding, boolean) - Method in interface org.apache.calcite.sql.type.SqlOperandTypeChecker
-
Checks the types of all operands to an operator call.
- checkOperandTypes(SqlCallBinding, boolean) - Method in interface org.apache.calcite.sql.type.SqlSingleOperandTypeChecker
- checkOperandTypes(SqlOperatorBinding, SqlCallBinding) - Method in class org.apache.calcite.sql.type.ComparableOperandTypeChecker
-
Similar functionality to
ComparableOperandTypeChecker.checkOperandTypes(SqlCallBinding, boolean)
, but not part of the interface, and cannot throw an error. - checkOperandTypes(SqlOperatorBinding, SqlCallBinding) - Method in class org.apache.calcite.sql.type.SameOperandTypeChecker
-
Similar functionality to
SameOperandTypeChecker.checkOperandTypes(SqlCallBinding, boolean)
, but not part of the interface, and cannot throw an error. - checkOperandTypesImpl(SqlOperatorBinding, boolean, SqlCallBinding) - Method in class org.apache.calcite.sql.type.SameOperandTypeChecker
- checkOperandTypesImpl(SqlOperatorBinding, boolean, SqlCallBinding) - Method in class org.apache.calcite.sql.type.SameOperandTypeExceptLastOperandChecker
- checkOperandTypesWithoutTypeCoercion(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.FamilyOperandTypeChecker
- checkOperandTypesWithoutTypeCoercion(SqlCallBinding, boolean) - Method in interface org.apache.calcite.sql.type.ImplicitCastOperandTypeChecker
-
Checks the types of an operator's all operands, but without type coercion.
- checkOptions(RelHint, Litmus) - Method in interface org.apache.calcite.rel.hint.HintOptionChecker
-
Checks if the given hint is valid.
- checkParameters(RelDataType) - Method in interface org.apache.calcite.sql.test.SqlTester.ParameterChecker
- checkParseEx(Throwable, String, StringAndPos) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkPrecScale(SqlTypeName, boolean, boolean) - Static method in class org.apache.calcite.sql.type.BasicSqlType
-
Throws if
typeName
does not allow the given combination of precision and scale. - checkProjAndChildInputs(Project, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- checkQuery(String) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Tests that a SQL query succeeds at prepare time.
- checkQueryFails(StringAndPos, String) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Tests that a SQL query fails at prepare time.
- checkQueryFails(SqlTestFactory, StringAndPos, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkQueryFails(SqlTestFactory, StringAndPos, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a SQL query fails at prepare time.
- checkResult(String, ResultSet) - Method in interface org.apache.calcite.sql.test.SqlTester.ResultChecker
- checkResultContains(String...) - Static method in class org.apache.calcite.test.CalciteAssert
- checkResultContains(String, int) - Static method in class org.apache.calcite.test.CalciteAssert
- checkResultCount(Matcher<Integer>) - Static method in class org.apache.calcite.test.CalciteAssert
- checkResultType(String) - Static method in class org.apache.calcite.test.CalciteAssert
- checkRun(String) - Method in class org.apache.calcite.test.QuidemTest
- checkScalar(String, Object, String) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Tests that a scalar SQL expression returns the expected result and the expected type.
- checkScalar(String, SqlTester.TypeChecker, SqlTester.ResultChecker) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- checkScalarApprox(String, String, Object) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Tests that a scalar SQL expression returns expected approximate numeric result.
- checkScalarExact(String, int) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Tests that a scalar SQL expression returns the expected exact numeric result as an integer.
- checkScalarExact(String, String, String) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Tests that a scalar SQL expression returns the expected exact numeric result.
- checkScalarExact(String, String, SqlTester.ResultChecker) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- checkServerTrusted(X509Certificate[], String) - Method in class org.apache.calcite.util.UnsafeX509ExtendedTrustManager
- checkServerTrusted(X509Certificate[], String, Socket) - Method in class org.apache.calcite.util.UnsafeX509ExtendedTrustManager
- checkServerTrusted(X509Certificate[], String, SSLEngine) - Method in class org.apache.calcite.util.UnsafeX509ExtendedTrustManager
- checkSingleOperandType(SqlCallBinding, SqlNode, int, boolean) - Method in class org.apache.calcite.sql.type.CompositeSingleOperandTypeChecker
- checkSingleOperandType(SqlCallBinding, SqlNode, int, boolean) - Method in class org.apache.calcite.sql.type.FamilyOperandTypeChecker
- checkSingleOperandType(SqlCallBinding, SqlNode, int, boolean) - Method in class org.apache.calcite.sql.type.IntervalOperandTypeChecker
- checkSingleOperandType(SqlCallBinding, SqlNode, int, boolean) - Method in class org.apache.calcite.sql.type.LiteralOperandTypeChecker
- checkSingleOperandType(SqlCallBinding, SqlNode, int, boolean) - Method in class org.apache.calcite.sql.type.SameOperandTypeChecker
- checkSingleOperandType(SqlCallBinding, SqlNode, int, boolean) - Method in interface org.apache.calcite.sql.type.SqlSingleOperandTypeChecker
-
Checks the type of a single operand against a particular ordinal position within a formal operator signature.
- checkSingleOperandType(SqlCallBinding, SqlNode, int, SqlTypeFamily, boolean) - Method in class org.apache.calcite.sql.type.FamilyOperandTypeChecker
- checkString(String, String, String) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Tests that a scalar SQL expression returns the expected string result.
- checkType(String, String) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Tests that a SQL expression has a given type.
- checkType(Supplier<String>, RelDataType) - Method in interface org.apache.calcite.sql.test.SqlTester.TypeChecker
- checkType(Supplier<String>, RelDataType) - Method in class org.apache.calcite.sql.test.SqlTests.StringTypeChecker
- checkTypeAssignment(SqlValidatorScope, SqlValidatorTable, RelDataType, RelDataType, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Checks the type assignment of an INSERT or UPDATE query.
- checkUnchanged() - Method in class org.apache.calcite.test.RelOptFixture
-
Checks that the plan is the same before and after executing a given planner.
- checkUnicodeEscapeChar(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Checks a UESCAPE string for validity, and returns the escape character if no exception is thrown.
- checkUpdateCount(int) - Static method in class org.apache.calcite.test.CalciteAssert
- checkValid(MaterializationKey) - Method in class org.apache.calcite.materialize.MaterializationService
-
Checks whether a materialization is valid, and if so, returns the table where the data are stored.
- checkWinAgg(String, String[], String, String, SqlTester.ResultChecker) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Checks that a windowed aggregate expression returns the expected result.
- checkWinAgg(SqlTestFactory, String, String[], String, String, SqlTester.ResultChecker) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkWinAgg(SqlTestFactory, String, String[], String, String, SqlTester.ResultChecker) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Checks that a windowed aggregate expression returns the expected result.
- Chi - Class in org.apache.calcite.rel.stream
-
Relational operator that converts a stream to a relation.
- Chi(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.rel.stream.Chi
- childPolicy - Variable in class org.apache.calcite.plan.RelOptRuleOperand
-
Whether child operands can be matched in any order.
- children - Variable in class org.apache.calcite.sql.validate.ListScope
-
List of child
SqlValidatorNamespace
objects and their names. - children() - Method in enum org.apache.calcite.sql.fun.SqlLibrary
- childrenAccept(MutableRelVisitor) - Method in class org.apache.calcite.rel.mutable.MutableJoin
- childrenAccept(MutableRelVisitor) - Method in class org.apache.calcite.rel.mutable.MutableScan
- childrenAccept(MutableRelVisitor) - Method in class org.apache.calcite.rel.mutable.MutableUnion
- childrenAccept(MutableRelVisitor) - Method in class org.apache.calcite.rel.mutable.MutableRel
- childrenAccept(MutableRelVisitor) - Method in class org.apache.calcite.rel.mutable.MutableSort
- childrenAccept(RelVisitor) - Method in class org.apache.calcite.rel.AbstractRelNode
- childrenAccept(RelVisitor) - Method in class org.apache.calcite.rel.BiRel
- childrenAccept(RelVisitor) - Method in interface org.apache.calcite.rel.RelNode
-
Interacts with the
RelVisitor
in avisitor pattern
to traverse the tree of relational expressions. - childrenAccept(RelVisitor) - Method in class org.apache.calcite.rel.SingleRel
- ChinookAvaticaServer - Class in org.apache.calcite.chinook
-
Wrapping Calcite engine with Avatica tansport for testing JDBC capabilities between Avatica JDBC transport and Calcite.
- ChinookAvaticaServer() - Constructor for class org.apache.calcite.chinook.ChinookAvaticaServer
- ChinookAvaticaServer.CalciteChinookMetaFactory - Class in org.apache.calcite.chinook
-
Factory for Chinook Calcite database wrapped in meta for Avatica.
- ChinookAvaticaServer.RawChinookMetaFactory - Class in org.apache.calcite.chinook
-
Factory for Chinook Calcite database wrapped in meta for Avatica.
- chooseBestSemiJoin(LoptMultiJoin) - Method in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
-
Finds the optimal semijoin for filtering the least costly fact table from among the remaining possible semijoins to choose from.
- chooseDelegate() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- chooseDelegate() - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Negotiates an appropriate planner to deal with distributed queries.
- chooseDelegate() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- CHOP - Enum constant in enum org.apache.calcite.sql.SqlWriterConfig.LineFolding
-
Chop down if long.
- ChosenCustomerEmail - Class in org.apache.calcite.chinook
-
Example UDF for WHERE clause to check pushing to JDBC.
- ChosenCustomerEmail() - Constructor for class org.apache.calcite.chinook.ChosenCustomerEmail
- CHR - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CHR(n)" function; returns the character whose UTF-8 code is
n
. - ChronoUnitEnum - Enum in org.apache.calcite.util.format.postgresql
-
A component of a datetime.
- ChunkList<E> - Class in org.apache.calcite.util
-
Implementation of list similar to
LinkedList
, but stores elements in chunks of 32 elements. - ChunkList() - Constructor for class org.apache.calcite.util.ChunkList
-
Creates an empty ChunkList.
- ChunkList(Collection<E>) - Constructor for class org.apache.calcite.util.ChunkList
-
Creates a ChunkList whose contents are a given Collection.
- city - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Place
- classClass - Variable in class org.apache.calcite.linq4j.tree.ClassDeclaration
- classCount() - Method in class org.apache.calcite.util.EquivalenceSet
-
Returns the number of equivalence classes in this equivalence set.
- classDecl(int, String, Type, List<Type>, List<MemberDeclaration>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Declares a class.
- ClassDeclaration - Class in org.apache.calcite.linq4j.tree
-
Declaration of a class.
- ClassDeclaration(int, String, Type, List<Type>, List<MemberDeclaration>) - Constructor for class org.apache.calcite.linq4j.tree.ClassDeclaration
- ClassDeclarationFinder - Class in org.apache.calcite.linq4j.tree
-
Entry point for optimizers that factor out deterministic expressions to final static fields.
- ClassDeclarationFinder(ClassDeclarationFinder) - Constructor for class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Creates a child optimizer.
- CLASSIFIER - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CLASSIFIER
operator inMATCH_RECOGNIZE
. - CLASSIFIER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
CLASSIFIER
function to be used withinMATCH_RECOGNIZE
. - classifyFilters(RelNode, List<RexNode>, boolean, boolean, boolean, List<RexNode>, List<RexNode>, List<RexNode>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Classifies filters according to where they should be processed.
- classifyFilters(RelNode, List<RexNode>, JoinRelType, boolean, boolean, boolean, List<RexNode>, List<RexNode>, List<RexNode>) - Static method in class org.apache.calcite.plan.RelOptUtil
- className - Variable in class org.apache.calcite.model.JsonFunction
-
Name of the class that implements this function.
- classToTypeName(Class<? extends RelNode>) - Method in class org.apache.calcite.rel.externalize.RelJson
-
Inverse of
RelJson.typeNameToClass(java.lang.String)
. - clauseEndsLine() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether a clause (FROM, WHERE, GROUP BY, HAVING, WINDOW, ORDER BY) is followed by a new line.
- clauseStartsLine() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether a clause (FROM, WHERE, GROUP BY, HAVING, WINDOW, ORDER BY) starts a new line.
- clazz - Variable in enum org.apache.calcite.DataContext.Variable
- clazz - Variable in class org.apache.calcite.plan.SubstitutionVisitor.Operand
- clear() - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Clears this BlockBuilder.
- clear() - Method in class org.apache.calcite.materialize.MaterializationService
-
De-registers all materialized tables in the system.
- clear() - Method in class org.apache.calcite.piglet.PigRelBuilder
- clear() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- clear() - Method in class org.apache.calcite.plan.hep.HepPlanner
- clear() - Method in interface org.apache.calcite.plan.RelDigest
-
Reset state, possibly cache of hash code.
- clear() - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Removes all internal state, including all registered rules, materialized views, and lattices.
- clear() - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
clear this rule queue.
- clear() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- clear() - Method in class org.apache.calcite.util.ImmutableIntList
- clear() - Method in class org.apache.calcite.sql.parser.Span
-
Clears the contents of this Span, and returns this Span.
- clear() - Method in class org.apache.calcite.sql.SqlNodeList
- clear() - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Clears the contents of the buffer.
- clear() - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.ResolvedImpl
-
Resets all state.
- clear() - Method in class org.apache.calcite.test.MockRelOptPlanner
- clear() - Method in class org.apache.calcite.tools.RelBuilder
-
Clears the stack.
- clear() - Method in class org.apache.calcite.util.ChunkList
- clear() - Method in class org.apache.calcite.util.CompositeMap
- clear() - Method in class org.apache.calcite.util.EquivalenceSet
-
Removes all elements in this equivalence set.
- clear() - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- clear() - Method in class org.apache.calcite.util.mapping.AbstractSourceMapping
- clear() - Method in class org.apache.calcite.util.mapping.AbstractTargetMapping
- clear() - Method in interface org.apache.calcite.util.mapping.Mapping
-
Removes all elements in the mapping.
- clear() - Method in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
- clear() - Method in class org.apache.calcite.util.mapping.Mappings.OverridingSourceMapping
- clear() - Method in class org.apache.calcite.util.mapping.Mappings.OverridingTargetMapping
- clear() - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- clear() - Method in class org.apache.calcite.util.PartiallyOrderedSet
- clear() - Method in class org.apache.calcite.util.Permutation
- clear(int) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
- clear(int) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns a bit set the same as this but with a given bit cleared.
- clear(StringWriter) - Static method in class org.apache.calcite.util.Unsafe
-
Clears the contents of a
StringWriter
. - clearCache(RelNode) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Removes cached metadata values for specified RelNode.
- clearCache(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQueryBase
-
Removes cached metadata values for specified RelNode.
- clearCancel() - Method in class org.apache.calcite.util.CancelFlag
-
Clears any pending cancellation request.
- clearCondition() - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Clears the condition.
- clearCorrelVariable(String) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- clearDebugInfo() - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a DebugInfoExpression for clearing a sequence point.
- clearIf(int, boolean) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns a bit set the same as this but with a given bit cleared if condition is true.
- clearProjects() - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Removes all project items.
- clearRelTraitDefs() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- clearRelTraitDefs() - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Clear all the registered RelTraitDef.
- clearRelTraitDefs() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- clearStaticCache() - Static method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- CLICKHOUSE - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- ClickHouseSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the ClickHouse database. - ClickHouseSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.ClickHouseSqlDialect
-
Creates a ClickHouseSqlDialect.
- clone() - Method in class org.apache.calcite.rel.mutable.Holder
- clone() - Method in class org.apache.calcite.rel.mutable.MutableAggregate
- clone() - Method in class org.apache.calcite.rel.mutable.MutableCalc
- clone() - Method in class org.apache.calcite.rel.mutable.MutableCollect
- clone() - Method in class org.apache.calcite.rel.mutable.MutableCorrelate
- clone() - Method in class org.apache.calcite.rel.mutable.MutableExchange
- clone() - Method in class org.apache.calcite.rel.mutable.MutableFilter
- clone() - Method in class org.apache.calcite.rel.mutable.MutableIntersect
- clone() - Method in class org.apache.calcite.rel.mutable.MutableJoin
- clone() - Method in class org.apache.calcite.rel.mutable.MutableMatch
- clone() - Method in class org.apache.calcite.rel.mutable.MutableMinus
- clone() - Method in class org.apache.calcite.rel.mutable.MutableProject
- clone() - Method in class org.apache.calcite.rel.mutable.MutableRel
- clone() - Method in class org.apache.calcite.rel.mutable.MutableSample
- clone() - Method in class org.apache.calcite.rel.mutable.MutableScan
- clone() - Method in class org.apache.calcite.rel.mutable.MutableSort
- clone() - Method in class org.apache.calcite.rel.mutable.MutableTableFunctionScan
- clone() - Method in class org.apache.calcite.rel.mutable.MutableTableModify
- clone() - Method in class org.apache.calcite.rel.mutable.MutableUncollect
- clone() - Method in class org.apache.calcite.rel.mutable.MutableUnion
- clone() - Method in class org.apache.calcite.rel.mutable.MutableValues
- clone() - Method in class org.apache.calcite.rel.mutable.MutableWindow
- clone() - Method in class org.apache.calcite.sql.SqlNode
-
Deprecated.Please use
SqlNode.clone(SqlNode)
; this method brings along too much baggage from early versions of Java - clone() - Method in class org.apache.calcite.util.NlsString
- clone() - Method in class org.apache.calcite.util.Permutation
- clone(E) - Static method in class org.apache.calcite.sql.SqlNode
-
Creates a copy of a SqlNode.
- clone(RelNode) - Method in class org.apache.calcite.rex.RexSubQuery
- clone(RelDataType, List<RexNode>) - Method in class org.apache.calcite.rel.core.Window.RexWinAggCall
- clone(RelDataType, List<RexNode>) - Method in class org.apache.calcite.rex.RexCall
-
Creates a new call to the same operator with different operands.
- clone(RelDataType, List<RexNode>) - Method in class org.apache.calcite.rex.RexOver
- clone(RelDataType, List<RexNode>) - Method in class org.apache.calcite.rex.RexSubQuery
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlBasicCall
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlBinaryStringLiteral
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlCall
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlCharStringLiteral
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlDateLiteral
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlDynamicParam
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlIdentifier
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalLiteral
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlLiteral
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlNode
-
Clones a SqlNode with a different position.
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlNodeList
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlNumericLiteral
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlTimeLiteral
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlTimestampLiteral
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlTimestampTzLiteral
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlTimeTzLiteral
- clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlUnknownLiteral
- CLONE_FOODMART - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- cloneArray(SqlNode[]) - Static method in class org.apache.calcite.sql.SqlNode
-
Deprecated.
- cloneChildren() - Method in class org.apache.calcite.rel.mutable.MutableUnion
- CloneSchema - Class in org.apache.calcite.adapter.clone
-
Schema that contains in-memory copies of tables from a JDBC schema.
- CloneSchema(SchemaPlus) - Constructor for class org.apache.calcite.adapter.clone.CloneSchema
-
Creates a CloneSchema.
- CloneSchema.Factory - Class in org.apache.calcite.adapter.clone
-
Schema factory that creates a
CloneSchema
. - close() - Method in class org.apache.calcite.adapter.file.CsvEnumerator
- close() - Method in class org.apache.calcite.adapter.file.FileReader
- close() - Method in class org.apache.calcite.adapter.file.JsonEnumerator
- close() - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleEnumerator
- close() - Method in class org.apache.calcite.adapter.kafka.KafkaMessageEnumerator
- close() - Method in class org.apache.calcite.adapter.os.OsQuery
- close() - Method in class org.apache.calcite.adapter.redis.RedisJedisManager
- close() - Method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.SplunkResultEnumerator
- close() - Method in class org.apache.calcite.interpreter.UncollectNode
- close() - Method in class org.apache.calcite.interpreter.Interpreter
- close() - Method in class org.apache.calcite.interpreter.JoinNode
- close() - Method in interface org.apache.calcite.interpreter.Node
- close() - Method in class org.apache.calcite.interpreter.SetOpNode
- close() - Method in interface org.apache.calcite.interpreter.Source
- close() - Method in class org.apache.calcite.linq4j.CartesianProductEnumerator
- close() - Method in class org.apache.calcite.linq4j.DelegatingEnumerator
- close() - Method in interface org.apache.calcite.linq4j.Enumerator
-
Closes this enumerable and releases resources.
- close() - Method in class org.apache.calcite.linq4j.MemoryEnumerator
- close() - Method in class org.apache.calcite.linq4j.TransformedEnumerator
- close() - Method in class org.apache.calcite.prepare.PlannerImpl
- close() - Method in class org.apache.calcite.runtime.EnumeratorCursor
- close() - Method in interface org.apache.calcite.runtime.Hook.Closeable
- close() - Method in class org.apache.calcite.runtime.ObjectEnumeratorCursor
- close() - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- close() - Method in interface org.apache.calcite.tools.Planner
-
Releases all internal resources utilized while this
Planner
exists. - close() - Method in class org.apache.calcite.util.Closer
- close() - Method in interface org.apache.calcite.util.TryThreadLocal.Memo
-
Sets the value back; never throws.
- close_() - Method in class org.apache.calcite.jdbc.CalciteStatement
- CLOSE_SQL_IDENTIFIER - Static variable in class org.apache.calcite.util.StackWriter
-
Directive for ending an SQL identifier.
- CLOSE_SQL_STRING_LITERAL - Static variable in class org.apache.calcite.util.StackWriter
-
Directive for ending an SQL string literal.
- closeClientCache() - Static method in class org.apache.calcite.adapter.geode.util.GeodeUtils
- closed(V, V) - Method in interface org.apache.calcite.util.RangeSets.Consumer
- closed(V, V) - Method in interface org.apache.calcite.util.RangeSets.Handler
- closedOpen(V, V) - Method in interface org.apache.calcite.util.RangeSets.Consumer
- closedOpen(V, V) - Method in interface org.apache.calcite.util.RangeSets.Handler
- Closer - Class in org.apache.calcite.util
-
Helper that holds onto
AutoCloseable
resources and releases them when its#close
method is called. - Closer() - Constructor for class org.apache.calcite.util.Closer
- closeStatement(Meta.StatementHandle) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- closure(SortedMap<Integer, BitSet>) - Static method in class org.apache.calcite.util.BitSets
-
Computes the closure of a map from integers to bits.
- closure(SortedMap<Integer, ImmutableBitSet>) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Computes the closure of a map from integers to bits.
- cluster - Variable in class org.apache.calcite.rel.mutable.MutableRel
- cluster - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- cluster - Variable in class org.apache.calcite.tools.RelBuilder
- CLUSTERED - Enum constant in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Clustered direction: Values occur in no particular order, and the same value may occur in contiguous groups, but never occurs after that.
- cm - Variable in class org.apache.calcite.sql2rel.RelDecorrelator
- coalesce(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a coalescing operation.
- coalesce(Expression, Expression, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a coalescing operation, given a conversion function.
- Coalesce - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A node that represents a null coalescing operation, such as (a ?? b) in C# or If(a, b) in Visual Basic.
- COALESCE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
COALESCE
operator. - COALESCE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The COALESCE builtin function.
- code() - Method in enum org.apache.calcite.runtime.SpatialTypeUtils.SpatialType
- CODE_POINTS_TO_BYTES - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CODE_POINTS_TO_BYTES - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CODE_POINTS_TO_BYTES(integers)" function (BigQuery); Converts an array of extended ASCII code points to bytes.
- CODE_POINTS_TO_STRING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CODE_POINTS_TO_STRING - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CODE_POINTS_TO_STRING(integers)" function (BigQuery); Converts an array of Unicode code points to string.
- codePointsToBytes(List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL CODE_POINTS_TO_BYTES(list) function.
- codePointsToString(List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL CODE_POINTS_TO_STRING(list) function.
- CodesFunction - Class in org.apache.calcite.chinook
-
Example Table Function for lateral join checks.
- COERCE_INPUTS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that pre-casts inputs to a particular type.
- coerceColumnType(SqlValidatorScope, SqlNodeList, int, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
-
Cast column at index
index
to target type. - CoerceInputsRule - Class in org.apache.calcite.rel.rules
-
CoerceInputsRule pre-casts inputs to a particular type.
- CoerceInputsRule(Class<? extends RelNode>, boolean) - Constructor for class org.apache.calcite.rel.rules.CoerceInputsRule
-
Deprecated.
- CoerceInputsRule(Class<? extends RelNode>, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.CoerceInputsRule
-
Deprecated.
- CoerceInputsRule(CoerceInputsRule.Config) - Constructor for class org.apache.calcite.rel.rules.CoerceInputsRule
-
Creates a CoerceInputsRule.
- CoerceInputsRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- coerceOperandsType(SqlValidatorScope, SqlCall, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
-
Coerce all the operands to
commonType
. - coerceOperandType(SqlValidatorScope, SqlCall, int, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
-
Cast operand at index
index
to target type. - coerceStringToArray(SqlCall, SqlNode, int, RelDataType, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
-
Coerce STRING type to ARRAY type.
- COERCIBLE - Enum constant in enum org.apache.calcite.sql.SqlCollation.Coercibility
- COERCIBLE - Static variable in class org.apache.calcite.sql.SqlCollation
- cogroup(Iterable<? extends RelBuilder.GroupKey>) - Method in class org.apache.calcite.piglet.PigRelBuilder
-
Cogroups relations on top of the stack.
- col1 - Variable in class org.apache.calcite.test.schemata.hr.NullableTest
- col2 - Variable in class org.apache.calcite.test.schemata.hr.NullableTest
- col3 - Variable in class org.apache.calcite.test.schemata.hr.NullableTest
- collapseExpandedIsNotDistinctFromExpr(RexCall, RexBuilder) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Collapses an expanded version of
IS NOT DISTINCT FROM
expression. - collation - Variable in class org.apache.calcite.rel.core.AggregateCall
- collation - Variable in class org.apache.calcite.rel.core.Sort
- collation - Variable in class org.apache.calcite.rel.core.SortExchange
- collation - Variable in class org.apache.calcite.rel.mutable.MutableSort
- collation - Variable in class org.apache.calcite.rel.RelRoot
- collation() - Method in class org.apache.calcite.rel.core.Window.Group
- collationList - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- collationName - Variable in class org.apache.calcite.sql.SqlCollation
- collations - Variable in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- collations() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Collation
-
Determines which columns are sorted.
- collations(EnumerableCorrelate, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(EnumerableHashJoin, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(EnumerableLimit, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(EnumerableMergeJoin, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(EnumerableMergeUnion, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(EnumerableNestedLoopJoin, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(JdbcToEnumerableConverter, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(HepRelVertex, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(RelSubset, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(Calc, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(Filter, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(Match, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(Project, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(SortExchange, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(Sort, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(TableModify, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(Values, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(Window, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- collations(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.Collation.collations()
statistic. - collations(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Collation.Handler
- collations(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Catch-all implementation for
BuiltInMetadata.Collation.collations()
, invoked using reflection, for any relational expression not handled by a more specific method. - COLLATIONS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- collationsCompatible(RelCollation, RelCollation) - Method in class org.apache.calcite.adapter.innodb.InnodbRules.InnodbSortTableScanRule
-
Check if it is possible to exploit sorting for a given collation.
- collationsContainKeysOrderless(List<RelCollation>, List<Integer>) - Static method in class org.apache.calcite.rel.RelCollations
-
Returns whether one of a list of collations contains the given list of keys regardless the order.
- collect() - Method in class org.apache.calcite.piglet.PigRelBuilder
-
Collects all rows of the top rel into a single multiset value.
- collect(Project) - Static method in class org.apache.calcite.rex.RexUtil.SubQueryCollector
- collect(RexNode, RexNode, RelOptUtil.Logic, List<RelOptUtil.Logic>) - Static method in class org.apache.calcite.rex.LogicVisitor
- Collect - Class in org.apache.calcite.rel.core
-
A relational expression that collapses multiple rows into one.
- Collect(RelOptCluster, RelTraitSet, RelNode, String) - Constructor for class org.apache.calcite.rel.core.Collect
-
Deprecated.
- Collect(RelOptCluster, RelTraitSet, RelNode, RelDataType) - Constructor for class org.apache.calcite.rel.core.Collect
-
Creates a Collect.
- Collect(RelInput) - Constructor for class org.apache.calcite.rel.core.Collect
-
Creates a Collect by parsing serialized output.
- COLLECT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
COLLECT
aggregate function. - COLLECT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The COLLECT operator.
- COLLECTED - Enum constant in enum org.apache.calcite.tools.PigRelBuilder.GroupOption
- collectExplainTerms(String, RelWriter) - Method in class org.apache.calcite.rex.RexProgram
- collectExplainTerms(String, RelWriter, SqlExplainLevel) - Method in class org.apache.calcite.rex.RexProgram
-
Collects the expressions in this program into a list of terms and values.
- collectInsertTargets(SqlInsert, RexNode, List<String>, List<RexNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Given an INSERT statement, collects the list of names to be populated and the expressions to put in them.
- COLLECTION - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Checks that returns whether a value is a multiset or an array.
- COLLECTION_ADD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COLLECTION_ADDALL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COLLECTION_ALL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COLLECTION_ELEMENT_TYPE_NULLABLE - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy where a derived type is transformed into the same type but nullable if any of element of a calls operands is nullable.
- COLLECTION_EXISTS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COLLECTION_NULLABLE_ALL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COLLECTION_NULLABLE_EXISTS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COLLECTION_OR_MAP - Static variable in class org.apache.calcite.sql.type.OperandTypes
- COLLECTION_RETAIN_ALL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COLLECTION_SIZE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COLLECTION_TABLE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Table operator which converts user-defined transform into a relation, for example,
select * from TABLE(udx(x, y, z))
. - COLLECTION_TABLE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The "table function derived table" operator, which a table-valued function into a relation, e.g.
- COLLECTIONS_EMPTY_LIST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COLLECTIONS_REVERSE_ORDER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COLLECTIONS_SINGLETON_LIST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CollectNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for COLLECT and TABLE constructs.
- CollectNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
Collect
. - CollectNode(Compiler, Collect) - Constructor for class org.apache.calcite.interpreter.CollectNode
- collectOperandTypes() - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Collects the types of the bound operands into a list.
- CollectOperation - Class in org.apache.calcite.runtime
-
Used at run time by the ST_Collect function.
- CollectOperation() - Constructor for class org.apache.calcite.runtime.CollectOperation
- collectParserError(String, List<SqlAdvisor.ValidateErrorInfo>) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
-
Attempts to parse a SQL statement and adds to the errorList if any syntax error is found.
- collectVariablesSet(Set<CorrelationId>) - Method in class org.apache.calcite.plan.volcano.RelSubset
- collectVariablesSet(Set<CorrelationId>) - Method in class org.apache.calcite.rel.AbstractRelNode
- collectVariablesSet(Set<CorrelationId>) - Method in interface org.apache.calcite.rel.RelNode
-
Collects variables set by this expression.
- collectVariablesUsed(Set<CorrelationId>) - Method in class org.apache.calcite.plan.volcano.RelSubset
- collectVariablesUsed(Set<CorrelationId>) - Method in class org.apache.calcite.rel.AbstractRelNode
- collectVariablesUsed(Set<CorrelationId>) - Method in class org.apache.calcite.rel.logical.LogicalCalc
- collectVariablesUsed(Set<CorrelationId>) - Method in interface org.apache.calcite.rel.RelNode
-
Collects variables known to be used by this expression or its descendants.
- COLON_EXPR - Static variable in class org.apache.calcite.adapter.enumerable.RexImpTable
- column - Variable in class org.apache.calcite.materialize.Lattice.BaseColumn
-
Name of the column.
- column(int, int) - Method in class org.apache.calcite.materialize.Lattice.Builder
- column(SqlParserPos, SqlIdentifier, SqlDataTypeSpec, SqlNode, ColumnStrategy) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a column declaration.
- Column(int, String) - Constructor for class org.apache.calcite.profile.Profiler.Column
-
Creates a Column.
- COLUMN - Enum constant in enum org.apache.calcite.sql.validate.SqlMonikerType
- COLUMN_COLUMNS - Static variable in class org.apache.calcite.jdbc.CalciteMetaImpl
-
Column names returned by
DatabaseMetaData.getColumns(java.lang.String, java.lang.String, java.lang.String, java.lang.String)
. - COLUMN_DECL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Column declaration.
- COLUMN_LIST - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The non-standard constructor used to pass a COLUMN_LIST parameter to a user-defined transform.
- COLUMN_LIST - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- COLUMN_LIST - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- COLUMN_LIST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The COLUMN_LIST constructor.
- COLUMN_LIST - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that always returns "COLUMN_LIST".
- COLUMN_ORIGIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COLUMN_UNIQUENESS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- columnAmbiguous(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- columnCountMismatch() - Method in interface org.apache.calcite.runtime.CalciteResource
- columnCountMismatchInSetop(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- columnHasDefaultValue(RelDataType, int, InitializerContext) - Method in class org.apache.calcite.prepare.Prepare.AbstractPreparingTable
- columnHasDefaultValue(RelDataType, int, InitializerContext) - Method in interface org.apache.calcite.sql.validate.SqlValidatorTable
-
Deprecated.
- columnInUsingNotUnique(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- columnList - Variable in class org.apache.calcite.sql.ddl.SqlCreateMaterializedView
- columnList - Variable in class org.apache.calcite.sql.ddl.SqlCreateTable
- columnList - Variable in class org.apache.calcite.sql.ddl.SqlCreateView
- columnList - Variable in class org.apache.calcite.sql.SqlWithItem
- columnList - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- columnListParamToParentCursorMap - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.FunctionParamInfo
-
Maps a column list parameter to the parent cursor parameter it references.
- columnMapping - Variable in class org.apache.calcite.jdbc.CalcitePrepare.AnalyzeViewResult
- columnMappings - Variable in class org.apache.calcite.rel.core.TableFunctionScan
- columnMappings - Variable in class org.apache.calcite.rel.mutable.MutableTableFunctionScan
- columnNotFound(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- columnNotFoundDidYouMean(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- columnNotFoundInTable(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- columnNotFoundInTableDidYouMean(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- columnNotNullable(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- columnOffset(Table) - Method in class org.apache.calcite.schema.impl.StarTable
-
Returns the column offset of the first column of
table
in this star table's output row type. - columnReferenceExpansion() - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Returns whether column reference expansion is enabled.
- columns - Variable in class org.apache.calcite.materialize.Lattice
- columns - Variable in class org.apache.calcite.model.JsonTable
-
Definition of the columns of this table.
- columns(MetaImpl.MetaTable) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- columnStrategies(RelOptTable) - Static method in class org.apache.calcite.prepare.RelOptTableImpl
- ColumnStrategy - Enum in org.apache.calcite.schema
-
Describes how a column gets populated.
- columnType(String) - Method in interface org.apache.calcite.test.IntervalTest.Fixture2
-
Checks that the expression is valid in the parser and validator and has the given column type.
- columnType(String) - Method in class org.apache.calcite.test.SqlValidatorFixture
-
Checks that a query returns a single column, and that the column has the expected type.
- columnTypeMismatchInSetop(int, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- ColumnTypeToSqlTypeConversionRules - Class in org.apache.calcite.adapter.innodb
-
Mappings from
innodb-java-reader
column types to corresponding SQL types. - ColumnTypeToSqlTypeConversionRules() - Constructor for class org.apache.calcite.adapter.innodb.ColumnTypeToSqlTypeConversionRules
- columnUses - Variable in class org.apache.calcite.materialize.Lattice
- combine(ImmutableList.Builder<E>, ImmutableList.Builder<E>) - Static method in class org.apache.calcite.util.Util
-
Combines a second immutable list builder into a first.
- combine(ArrayList<E>, ArrayList<E>) - Static method in class org.apache.calcite.util.Util
-
Combines a second array list into a first.
- combine(RelDataTypeFactoryImpl, IntervalSqlType) - Method in class org.apache.calcite.sql.type.IntervalSqlType
-
Combines two IntervalTypes and returns the result.
- combine(ImmutableBitSet.Builder) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Merges another builder.
- combinedRowType(List<RelNode>) - Method in interface org.apache.calcite.interpreter.Compiler
- combinedRowType(List<RelNode>) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- combineFractionalSecondPrecisionPreservingDefault(RelDataTypeSystem, SqlIntervalQualifier, SqlIntervalQualifier) - Static method in class org.apache.calcite.sql.SqlIntervalQualifier
- combineStartPrecisionPreservingDefault(RelDataTypeSystem, SqlIntervalQualifier, SqlIntervalQualifier) - Static method in class org.apache.calcite.sql.SqlIntervalQualifier
- COMMA - Enum constant in enum org.apache.calcite.sql.JoinType
-
Comma join: the good old-fashioned SQL
FROM
clause, where table expressions are specified with commas between them, and join conditions are specified in theWHERE
clause. - COMMA - Static variable in interface org.apache.calcite.sql.SqlWriter
-
Comma operator.
- COMMA_DELIMITER - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeSchemaFactory
- COMMA_DELIMITER - Static variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchemaFactory
- COMMA_EXPR - Static variable in class org.apache.calcite.adapter.enumerable.RexImpTable
- commaList(List<T>) - Static method in class org.apache.calcite.util.Util
-
Converts a list of a string, with commas between elements.
- COMMAND_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Encapsulate a request as an object, thereby letting you parameterize clients with different requests, queue or log requests, and support undoable operations.
- commission - Variable in class org.apache.calcite.test.schemata.hr.Employee
- commit(Meta.ConnectionHandle) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- COMMIT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
COMMIT
session control statement. - CommonRelSubExprRule - Class in org.apache.calcite.plan
-
A
CommonRelSubExprRule
is an abstract base class for rules that are fired only on relational expressions that appear more than once in a query tree. - CommonRelSubExprRule(CommonRelSubExprRule.Config) - Constructor for class org.apache.calcite.plan.CommonRelSubExprRule
-
Creates a CommonRelSubExprRule.
- CommonRelSubExprRule.Config - Interface in org.apache.calcite.plan
-
Rule configuration.
- commonTypeForBinaryComparison(RelDataType, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
-
Determines common type for a comparison operator.
- commonTypeForBinaryComparison(RelDataType, RelDataType) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Determines common type for a comparison operator.
- commonTypeForComparison(List<RelDataType>) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
-
Finds the common type for binary comparison when the size of operands
dataTypes
is more than 2. - COMMUTE - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to exploit join commutative property.
- compact(List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_COMPACT function.
- COMPARABLE_EMPTY_LIST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COMPARABLE_EMPTY_LIST - Static variable in class org.apache.calcite.runtime.FlatLists
- COMPARABLE_ORDERED - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where operand type must allow ordered comparisons.
- COMPARABLE_ORDERED_COMPARABLE_ORDERED - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where operand types must allow ordered comparisons.
- COMPARABLE_UNORDERED_COMPARABLE_UNORDERED - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where operand types must allow unordered comparisons.
- ComparableOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Type checking strategy which verifies that types have the required attributes to be used as arguments to comparison operators.
- ComparableOperandTypeChecker(int, RelDataTypeComparability) - Constructor for class org.apache.calcite.sql.type.ComparableOperandTypeChecker
-
Deprecated.
- ComparableOperandTypeChecker(int, RelDataTypeComparability, SqlOperandTypeChecker.Consistency) - Constructor for class org.apache.calcite.sql.type.ComparableOperandTypeChecker
- comparator(RelFieldCollation) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
- COMPARATOR - Static variable in class org.apache.calcite.rel.RelNodes
-
Comparator that provides an arbitrary but stable ordering to
RelNode
s. - COMPARATOR - Static variable in interface org.apache.calcite.sql.validate.SqlMoniker
- COMPARATOR - Static variable in class org.apache.calcite.util.ImmutableBitSet
-
Compares bit sets topologically, so that enclosing bit sets come first, using natural ordering to break ties.
- COMPARATOR - Static variable in class org.apache.calcite.util.NameSet
- COMPARATOR_COMPARE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- compare(boolean, boolean) - Static method in class org.apache.calcite.runtime.Utilities
- compare(byte, byte) - Static method in class org.apache.calcite.runtime.Utilities
- compare(char, char) - Static method in class org.apache.calcite.runtime.Utilities
- compare(double, double) - Static method in class org.apache.calcite.runtime.Utilities
- compare(float, float) - Static method in class org.apache.calcite.runtime.Utilities
- compare(int, int) - Static method in class org.apache.calcite.runtime.Utilities
- compare(long, long) - Static method in class org.apache.calcite.runtime.Utilities
- compare(short, short) - Static method in class org.apache.calcite.runtime.Utilities
- compare(Range<C>, Range<C>) - Static method in class org.apache.calcite.util.RangeSets
-
Compares two ranges.
- compare(RangeSet<C>, RangeSet<C>) - Static method in class org.apache.calcite.util.RangeSets
-
Compares two range sets.
- compare(Comparable, Comparable, int) - Static method in class org.apache.calcite.rel.RelFieldCollation
-
Utility method that compares values taking into account null direction.
- compare(Comparable, Comparable, Comparator) - Static method in class org.apache.calcite.runtime.Utilities
- compare(Comparable, Comparable) - Static method in class org.apache.calcite.runtime.Utilities
- compare(Object[], Object[]) - Method in class org.apache.calcite.runtime.ArrayComparator
- compare(String) - Method in class org.apache.calcite.sql.parser.SqlParserFixture
- compare(List, List) - Static method in class org.apache.calcite.runtime.Utilities
- compare(SpaceFillingCurve2D.IndexRange, SpaceFillingCurve2D.IndexRange) - Method in class org.apache.calcite.runtime.SpaceFillingCurve2D.IndexRangeOrdering
- COMPARE - Enum constant in enum org.apache.calcite.sql.type.SqlOperandTypeChecker.Consistency
-
Make arguments of consistent type using comparison semantics.
- COMPARE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COMPARE_NULLS_FIRST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COMPARE_NULLS_FIRST2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COMPARE_NULLS_LAST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COMPARE_NULLS_LAST2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COMPARE_TO - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COMPARE2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- compareLists(List<?>, List<?>) - Static method in class org.apache.calcite.linq4j.function.Functions
- compareNullsFirst(Comparable, Comparable) - Static method in class org.apache.calcite.runtime.Utilities
- compareNullsFirst(Comparable, Comparable, Comparator) - Static method in class org.apache.calcite.runtime.Utilities
- compareNullsLast(Comparable, Comparable) - Static method in class org.apache.calcite.runtime.Utilities
- compareNullsLast(Comparable, Comparable, Comparator) - Static method in class org.apache.calcite.runtime.Utilities
- compareNullsLast(List, List) - Static method in class org.apache.calcite.runtime.Utilities
- compareNullsLastForMergeJoin(Comparable, Comparable) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- compareNullsLastForMergeJoin(Comparable, Comparable) - Static method in class org.apache.calcite.runtime.Utilities
- compareNullsLastForMergeJoin(Comparable, Comparable, Comparator) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- compareNullsLastForMergeJoin(Comparable, Comparable, Comparator) - Static method in class org.apache.calcite.runtime.Utilities
- compareObjectArrays(Object[], Object[]) - Static method in class org.apache.calcite.linq4j.function.Functions
- comparePrecision(int, int) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a precision is greater or equal than another, treating
RelDataType.PRECISION_NOT_SPECIFIED
as infinity. - comparer() - Method in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
- comparer() - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Returns a expression that yields a comparer, or null if this type is comparable.
- comparer() - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- compareRels(RelNode[], RelNode[]) - Static method in class org.apache.calcite.rel.RelNodes
-
Compares arrays of
RelNode
. - compareRows(Expression, Expression) - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- compareRows(Expression, Expression) - Method in interface org.apache.calcite.adapter.enumerable.WinAggFrameResultContext
-
Compares two rows given by absolute positions according to the order collation of the current window.
- compareTo(List) - Method in class org.apache.calcite.runtime.FlatLists.Flat1List
- compareTo(List) - Method in class org.apache.calcite.runtime.FlatLists.Flat2List
- compareTo(List) - Method in class org.apache.calcite.runtime.FlatLists.Flat3List
- compareTo(List) - Method in class org.apache.calcite.runtime.FlatLists.Flat4List
- compareTo(List) - Method in class org.apache.calcite.runtime.FlatLists.Flat5List
- compareTo(List) - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- compareTo(Lattice.Column) - Method in class org.apache.calcite.materialize.Lattice.Column
- compareTo(Lattice.Measure) - Method in class org.apache.calcite.materialize.Lattice.Measure
- compareTo(RelMultipleTrait) - Method in class org.apache.calcite.rel.RelCollationImpl
- compareTo(Profiler.Column) - Method in class org.apache.calcite.profile.Profiler.Column
- compareTo(CorrelationId) - Method in class org.apache.calcite.rel.core.CorrelationId
- compareTo(Match.RexMRAggCall) - Method in class org.apache.calcite.rel.core.Match.RexMRAggCall
- compareTo(RexTableInputRef.RelTableRef) - Method in class org.apache.calcite.rex.RexTableInputRef.RelTableRef
- compareTo(Unit) - Method in class org.apache.calcite.runtime.Unit
- compareTo(DateString) - Method in class org.apache.calcite.util.DateString
- compareTo(ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Compares this ImmutableBitSet with another, using a lexicographic ordering.
- compareTo(NlsString) - Method in class org.apache.calcite.util.NlsString
- compareTo(Pair<T1, T2>) - Method in class org.apache.calcite.util.Pair
- compareTo(Sarg<C>) - Method in class org.apache.calcite.util.Sarg
- compareTo(TimestampString) - Method in class org.apache.calcite.util.TimestampString
- compareTo(TimestampWithTimeZoneString) - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
- compareTo(TimeString) - Method in class org.apache.calcite.util.TimeString
- compareTo(TimeWithTimeZoneString) - Method in class org.apache.calcite.util.TimeWithTimeZoneString
- compareTo(Version) - Method in class org.apache.calcite.util.Version
- compareTypePrecedence(RelDataType, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypePrecedenceList
-
Compares the precedence of two types.
- compareTypePrecedence(RelDataType, RelDataType) - Method in class org.apache.calcite.sql.type.SqlTypeExplicitPrecedenceList
- COMPARISON - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of comparison operators.
- comparisonKind - Variable in class org.apache.calcite.sql.fun.SqlQuantifyOperator
- Compatible - Interface in org.apache.calcite.linq4j.util
-
Compatibility layer.
- Compatible - Interface in org.apache.calcite.util
-
Compatibility layer.
- Compatible.Factory - Class in org.apache.calcite.linq4j.util
-
Creates an implementation of
Compatible
suitable for the current environment. - Compatible.Factory - Class in org.apache.calcite.util
-
Creates the implementation of Compatible suitable for the current environment.
- compatibleType(RelDataType, RelDataType) - Static method in class org.apache.calcite.piglet.PigRelBuilder
-
Checks if two relational data types are compatible.
- compatibleTypes(List<RexNode>, RelDataType, Litmus) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether the type of an array of expressions is compatible with a struct type.
- compensatePartial(Set<RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses, Set<RexTableInputRef.RelTableRef>, Multimap<RexTableInputRef, RexTableInputRef>) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
It checks whether the target can be rewritten using the source even though the source uses additional tables.
- compensateViewPartial(RelBuilder, RexBuilder, RelMetadataQuery, RelNode, Project, RelNode, Set<RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses, Project, RelNode, Set<RexTableInputRef.RelTableRef>) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule
- compensateViewPartial(RelBuilder, RexBuilder, RelMetadataQuery, RelNode, Project, RelNode, Set<RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses, Project, RelNode, Set<RexTableInputRef.RelTableRef>) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewJoinRule
- compensateViewPartial(RelBuilder, RexBuilder, RelMetadataQuery, RelNode, Project, RelNode, Set<RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses, Project, RelNode, Set<RexTableInputRef.RelTableRef>) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
It checks whether the query can be rewritten using the view even though the query uses additional tables.
- compile() - Method in class org.apache.calcite.linq4j.tree.FunctionExpression
- compile() - Method in class org.apache.calcite.util.javac.JaninoCompiler
- compile() - Method in interface org.apache.calcite.util.javac.JavaCompiler
- compile(List<RexNode>, RelDataType) - Method in interface org.apache.calcite.interpreter.Compiler
-
Compiles an expression to an executable form.
- compile(List<RexNode>, RelDataType) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- compile(List<RexNode>, RelDataType) - Method in class org.apache.calcite.interpreter.JaninoRexCompiler
- compile(ClassDeclaration, String) - Method in class org.apache.calcite.adapter.spark.SparkHandlerImpl
- compile(ClassDeclaration, String) - Method in interface org.apache.calcite.jdbc.CalcitePrepare.SparkHandler
- CompiledDateTimeFormat - Class in org.apache.calcite.util.format.postgresql
-
Contains a parsed date/time format.
- CompiledDateTimeFormat(ImmutableList<CompiledItem>) - Constructor for class org.apache.calcite.util.format.postgresql.CompiledDateTimeFormat
- CompiledItem - Interface in org.apache.calcite.util.format.postgresql.format.compiled
-
A single component of a parsed date/time format.
- CompiledPattern - Class in org.apache.calcite.util.format.postgresql.format.compiled
-
A single date/time format compiled component such as "YYYY" or "MI".
- CompiledPattern(ChronoUnitEnum, Set<PatternModifier>) - Constructor for class org.apache.calcite.util.format.postgresql.format.compiled.CompiledPattern
- compilePattern(String) - Static method in class org.apache.calcite.util.format.postgresql.PostgresqlDateTimeFormatter
- compilePattern(String, ParsePosition) - Method in class org.apache.calcite.util.format.postgresql.format.FormatPattern
-
Creates the compiled version of the parsed date/time component along with any flags that it had.
- compiler - Variable in class org.apache.calcite.interpreter.InterpretableRel.InterpreterImplementor
- Compiler - Interface in org.apache.calcite.interpreter
-
Context while converting a tree of
RelNode
to a program that can be run by anInterpreter
. - COMPLETE - Enum constant in enum org.apache.calcite.rel.rules.materialize.MaterializedViewRule.MatchModality
- COMPLEX - Enum constant in enum org.apache.calcite.adapter.druid.DruidType
- complexity() - Method in class org.apache.calcite.util.Sarg
-
Returns a measure of the complexity of this expression.
- ComplexMetric - Class in org.apache.calcite.adapter.druid
-
Stores information about available complex metrics in the Druid Adapter.
- ComplexMetric(String, DruidType) - Constructor for class org.apache.calcite.adapter.druid.ComplexMetric
- component() - Element in annotation type org.apache.calcite.adapter.java.Array
-
Component type.
- component(int) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Returns the physical type of a given field's component type.
- component(int) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- componentIsNullable() - Element in annotation type org.apache.calcite.adapter.java.Array
-
Whether components may be null.
- componentIsNullable() - Method in class org.apache.calcite.linq4j.tree.Types.ArrayType
-
Returns whether elements in the array may be null.
- componentName - Variable in enum org.apache.calcite.sql.test.SqlTests.Stage
- componentPositions - Variable in class org.apache.calcite.sql.SqlIdentifier
-
A list of the positions of the components of compound identifiers.
- compose(Matcher<T>, Function<F, T>) - Static method in class org.apache.calcite.test.Matchers
-
Creates a matcher by applying a function to a value before calling another matcher.
- composeConjunction(RexBuilder, Iterable<? extends RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
As
RexUtil.composeConjunction(RexBuilder, Iterable, boolean)
but never returns null. - composeConjunction(RexBuilder, Iterable<? extends RexNode>, boolean) - Static method in class org.apache.calcite.rex.RexUtil
-
Converts a collection of expressions into an AND.
- composeDisjunction(RexBuilder, Iterable<? extends RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Converts a collection of expressions into an OR.
- composeDisjunction(RexBuilder, Iterable<? extends RexNode>, boolean) - Static method in class org.apache.calcite.rex.RexUtil
-
Converts a collection of expressions into an OR, optionally returning null if the list is empty.
- COMPOSITE_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Compose objects into tree structures to represent part-whole hierarchies.
- compositeElement(String, FormatElement...) - Static method in class org.apache.calcite.util.format.FormatModels
-
Creates a composite format element from the provided list of elements and description.
- CompositeFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.CompositeFunction
- CompositeHintPredicate - Class in org.apache.calcite.rel.hint
-
A
HintPredicate
to combine multiple hint predicates into one. - CompositeHintPredicate.Composition - Enum in org.apache.calcite.rel.hint
-
How hint predicates are composed.
- CompositeList<T> - Class in org.apache.calcite.util
-
Read-only list that is the concatenation of sub-lists.
- CompositeMap<K,
V> - Class in org.apache.calcite.util -
Unmodifiable view onto multiple backing maps.
- CompositeMap(ImmutableList<Map<K, V>>) - Constructor for class org.apache.calcite.util.CompositeMap
- CompositeOperandTypeChecker - Class in org.apache.calcite.sql.type
-
This class allows multiple existing
SqlOperandTypeChecker
rules to be combined into one rule. - CompositeOperandTypeChecker(CompositeOperandTypeChecker.Composition, ImmutableList<? extends SqlOperandTypeChecker>, String, BiFunction<SqlOperator, String, String>, SqlOperandCountRange) - Constructor for class org.apache.calcite.sql.type.CompositeOperandTypeChecker
-
Creates a CompositeOperandTypeChecker.
- CompositeOperandTypeChecker.Composition - Enum in org.apache.calcite.sql.type
-
How operands are composed.
- CompositeSingleOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Allows multiple
SqlSingleOperandTypeChecker
rules to be combined into one rule. - composition - Variable in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- compoundOrderByProhibitsRange() - Method in interface org.apache.calcite.runtime.CalciteResource
- compress(String) - Static method in class org.apache.calcite.runtime.CompressionFunctions
-
MySql Compression is based on zlib.
- COMPRESS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COMPRESS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- CompressionFunctions - Class in org.apache.calcite.runtime
-
A collection of functions used in compression and decompression.
- comprises(RelTrait...) - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns whether this trait set comprises precisely the list of given traits.
- computeCompensationPredicates(RexBuilder, RexSimplify, MaterializedViewRule.EquivalenceClasses, Pair<RexNode, RexNode>, MaterializedViewRule.EquivalenceClasses, Pair<RexNode, RexNode>, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
We check whether the predicates in the source are contained in the predicates in the target.
- computeDigest() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
-
Computes the digest field.
- computeDigest(boolean) - Method in class org.apache.calcite.rex.RexCall
- computeDigest(boolean) - Method in class org.apache.calcite.rex.RexOver
- computeDigest(boolean) - Method in class org.apache.calcite.rex.RexSubQuery
- computeDigest(RexDigestIncludeType) - Method in class org.apache.calcite.rex.RexLiteral
-
Returns a string which concisely describes the definition of this rex literal.
- computeDruidJsonAgg(List<AggregateCall>, List<String>, Project, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Translates aggregate calls to Druid
DruidQuery.JsonAggregation
s when possible. - computeIndex(Expression, WinAggImplementor.SeekType) - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- computeIndex(Expression, WinAggImplementor.SeekType) - Method in interface org.apache.calcite.adapter.enumerable.WinAggFrameResultContext
-
Converts absolute index position of the given relative position.
- computeProjectAsScan(Project, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Translates a list of projects to Druid Column names and Virtual Columns if any.
- computeProjectGroupSet(Project, ImmutableBitSet, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Computes the project group set.
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.cassandra.CassandraFilter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.cassandra.CassandraLimit
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.cassandra.CassandraProject
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.cassandra.CassandraSort
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.cassandra.CassandraToEnumerableConverter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.csv.CsvTableScan
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.druid.DruidQuery
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchAggregate
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchProject
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSort
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTableScan
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchToEnumerableConverter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.enumerable.EnumerableAsofJoin
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoin
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.enumerable.EnumerableHashJoin
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.enumerable.EnumerableInterpreter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMergeJoin
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.enumerable.EnumerableNestedLoopJoin
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindow
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.file.CsvTableScan
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.geode.rel.GeodeAggregate
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.geode.rel.GeodeProject
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.geode.rel.GeodeSort
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.geode.rel.GeodeToEnumerableConverter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.innodb.InnodbFilter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.innodb.InnodbProject
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.innodb.InnodbSort
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.innodb.InnodbToEnumerableConverter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcCalc
-
Deprecated.
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcJoin
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcProject
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcSort
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcTableModify
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcUnion
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.mongodb.MongoFilter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.mongodb.MongoProject
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.mongodb.MongoSort
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.mongodb.MongoTableScan
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.mongodb.MongoToEnumerableConverter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.spark.EnumerableToSparkConverter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.spark.JdbcToSparkConverter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.spark.SparkRules.SparkCalc
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.spark.SparkToEnumerableConverter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.interpreter.Bindables.BindableTableScan
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.interpreter.Bindables.BindableWindow
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.hep.HepRelVertex
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.AbstractConverter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.RelSubset
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.AbstractRelNode
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.convert.ConverterImpl
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Aggregate
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Calc
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Correlate
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Exchange
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Filter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Join
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Project
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Sort
-
Returns the cost of this plan (not including children).
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.core.TableModify
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.core.TableScan
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Values
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Window
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.logical.LogicalTableFunctionScan
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in interface org.apache.calcite.rel.RelNode
-
Returns the cost of this plan (not including children).
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.schema.impl.StarTable.StarTableScan
- computeSemiJoinSelectivity(RelMetadataQuery, RelNode, RelNode, List<Integer>, List<Integer>) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Computes the selectivity of a semijoin filter if it is applied on a fact table.
- computeSemiJoinSelectivity(RelMetadataQuery, RelNode, RelNode, Join) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Computes the selectivity of a semijoin filter if it is applied on a fact table.
- computeTiles() - Method in class org.apache.calcite.materialize.Lattice
- concat(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
string || string
operator. - concat(List<Enumerable<E>>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Concatenates two or more
Enumerable
s to form a composite enumerable that contains the union of their elements. - concat(List<BitString>) - Static method in class org.apache.calcite.util.BitString
-
Concatenates some BitStrings.
- concat(List<NlsString>) - Static method in class org.apache.calcite.util.NlsString
-
Concatenates some
NlsString
objects. - concat(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
binary || binary
operator. - concat(Enumerable<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- concat(Enumerable<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- concat(Enumerable<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Concatenates two sequences.
- concat(Enumerable<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Concatenates two sequences.
- concat(Enumerable<TSource>, Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Concatenates two sequences.
- concat(Queryable<T>, Enumerable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Concatenates two sequences.
- concat(Queryable<T>, Enumerable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Concatenates two sequences.
- concat(Queryable<T>, Enumerable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- CONCAT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CONCAT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
String and array-to-array concatenation operator, '
||
'. - CONCAT_FUNCTION - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CONCAT(arg, ...)" function that concatenates strings.
- CONCAT_FUNCTION_WITH_NULL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CONCAT(arg, ...)" function that concatenates strings, which never returns null.
- CONCAT_WITH_NULL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
CONCAT
function (Postgresql and MSSQL) that ignores NULL. - CONCAT_WS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CONCAT_WS(separator, arg1, ...)" function (MySQL); concatenates strings with separator, and treats null arguments as empty strings.
- CONCAT_WS_MSSQL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
CONCAT_WS
function (MSSQL). - CONCAT_WS_MSSQL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CONCAT_WS(separator, arg1, arg2, ...)" function in (MSSQL).
- CONCAT_WS_POSTGRESQL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
CONCAT_WS
function (Postgresql). - CONCAT_WS_POSTGRESQL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CONCAT_WS(separator, arg1, ...)" function (Postgres).
- CONCAT_WS_SPARK - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
CONCAT_WS
function (Spark). - CONCAT_WS_SPARK - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CONCAT_WS(separator[, str | array(str)]+)" function in (SPARK).
- concat1(List<SqlLiteral>) - Method in class org.apache.calcite.sql.SqlBinaryStringLiteral
- concat1(List<SqlLiteral>) - Method in class org.apache.calcite.sql.SqlCharStringLiteral
- CONCAT2 - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The two-argument
CONCAT
function (Oracle). - CONCAT2 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CONCAT(arg0, arg1)" function that concatenates strings.
- concatenateLiterals(List<SqlLiteral>) - Static method in class org.apache.calcite.sql.SqlUtil
-
Concatenates string literals.
- concatenateOperands(SqlCall) - Static method in class org.apache.calcite.sql.fun.SqlLiteralChainOperator
-
Concatenates the operands of a call to this operator.
- concatMulti(String...) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CONCAT(arg0, arg1, arg2, ...)
function. - concatMultiObjectWithSeparator(String, Object...) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CONCAT_WS(sep[, any]+)
function, return null for null sep. - concatMultiTypeWithSeparator(String, Object...) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CONCAT_WS(sep[, str | array(str)]+)
function, return null for null sep. - concatMultiWithNull(String...) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CONCAT(arg0, ...)
function which can accept null but never return null. - concatMultiWithSeparator(String...) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CONCAT_WS(sep, arg1, arg2, ...)
function; treats null arguments as empty strings. - concatWithNull(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Concatenates two strings.
- condition - Variable in class org.apache.calcite.linq4j.tree.ForStatement
- condition - Variable in class org.apache.calcite.linq4j.tree.WhileStatement
- condition - Variable in class org.apache.calcite.rel.core.Filter
- condition - Variable in class org.apache.calcite.rel.core.Join
- condition - Variable in class org.apache.calcite.rel.mutable.MutableFilter
- condition - Variable in class org.apache.calcite.rel.mutable.MutableJoin
- condition(Expression, Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ConditionalExpression that represents a conditional statement.
- condition(Expression, Expression, Expression, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ConditionalExpression that represents a conditional statement.
- conditional(Predicate<RelNode>, Program) - Static method in class org.apache.calcite.tools.Programs
-
Creates a program that executes if a predicate is true.
- Conditional - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A conditional operation, such as
a > b ? a : b
in Java. - ConditionalExpression - Class in org.apache.calcite.linq4j.tree
-
Represents an expression that has a conditional operator.
- ConditionalExpression(List<Node>, Type) - Constructor for class org.apache.calcite.linq4j.tree.ConditionalExpression
- ConditionalStatement - Class in org.apache.calcite.linq4j.tree
-
Represents an expression that has a conditional operator.
- ConditionalStatement(List<Node>) - Constructor for class org.apache.calcite.linq4j.tree.ConditionalStatement
- condMustBeBoolean(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- config - Variable in class org.apache.calcite.plan.RelRule
- config - Variable in class org.apache.calcite.prepare.CalciteCatalogReader
- config - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- config() - Method in interface org.apache.calcite.jdbc.CalciteConnection
- config() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.Context
- config() - Static method in class org.apache.calcite.sql.parser.SqlParser
-
Returns a default
SqlParser.Config
. - config() - Static method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Creates a
SqlWriterConfig
with Calcite's SQL dialect. - config() - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the config of the validator.
- config() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- config() - Static method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Returns a default
SqlToRelConverter.Config
. - config() - Static method in class org.apache.calcite.tools.Hoist
-
Creates a Config.
- config(ConverterRule, RelBuilderFactory) - Static method in class org.apache.calcite.rel.convert.TraitMatchingRule
-
Creates a configuration for a TraitMatchingRule.
- CONFIG - Static variable in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Default configuration.
- configBuilder() - Static method in class org.apache.calcite.sql.parser.SqlParser
-
Deprecated.
- configBuilder(SqlParser.Config) - Static method in class org.apache.calcite.sql.parser.SqlParser
-
Deprecated.Use
config
, and modify it using its mutator methods - configureParser(SqlParser.Config) - Method in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
- configureParser(SqlParser.Config) - Method in class org.apache.calcite.sql.SqlDialect
-
Copies settings from this dialect into a parser configuration.
- configureParser(SqlParser.ConfigBuilder) - Method in class org.apache.calcite.sql.SqlDialect
-
Deprecated.
- conformance() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.CONFORMANCE
. - conformance() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- conformance() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- conformance() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- conformance() - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns the conformance.
- conformance() - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Returns the dialect of SQL (SQL:2003, etc.) this validator recognizes.
- conformance() - Method in class org.apache.calcite.test.SqlValidatorFixture
- CONFORMANCE - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
SQL conformance level.
- conjunctions(RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a condition decomposed by AND.
- connect() - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Use sparingly.
- connect(String) - Method in class org.apache.calcite.test.QuidemTest.QuidemConnectionFactory
- connect(String, boolean) - Method in class org.apache.calcite.chinook.ConnectionFactory
- connect(String, boolean) - Method in class org.apache.calcite.test.QuidemTest.QuidemConnectionFactory
- connect(String, Properties) - Method in class org.apache.calcite.adapter.splunk.SplunkDriver
- connect(CalciteSchema, JavaTypeFactory) - Static method in class org.apache.calcite.jdbc.CalciteMetaImpl
-
A trojan-horse method, subject to change without notice.
- CONNECT_STRING_PREFIX - Static variable in class org.apache.calcite.jdbc.Driver
- connection() - Method in class org.apache.calcite.chinook.CalciteConnectionProvider
- connection() - Method in enum org.apache.calcite.chinook.ConnectionFactory.DatabaseWrapper
- ConnectionFactories - Class in org.apache.calcite.test
-
Utilities for
ConnectionFactory
andCalciteAssert.ConnectionPostProcessor
. - connectionFactory - Variable in class org.apache.calcite.sql.test.SqlTestFactory
- ConnectionFactory - Class in org.apache.calcite.chinook
-
Wrapping connection factory for Quidem.
- ConnectionFactory - Interface in org.apache.calcite.test
-
Creates JDBC connections for tests.
- ConnectionFactory() - Constructor for class org.apache.calcite.chinook.ConnectionFactory
- ConnectionFactory.DatabaseWrapper - Enum in org.apache.calcite.chinook
-
Wrapping with Fairy environmental decoration.
- ConnectionSpec - Class in org.apache.calcite.test
-
Information necessary to create a JDBC connection.
- ConnectionSpec(String, String, String, String, String) - Constructor for class org.apache.calcite.test.ConnectionSpec
- connectThrows(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Asserts that there is an exception with the given message while creating a connection.
- connectThrows(Consumer<Throwable>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Asserts that there is an exception that matches the given predicate while creating a connection.
- cons(E, List<? extends E>) - Static method in class org.apache.calcite.util.Static
-
Builds a list.
- ConsList<E> - Class in org.apache.calcite.runtime
-
List that consists of a head element and an immutable non-empty list.
- constant(Object) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ConstantExpression that has the Value property set to the specified value.
- constant(Object, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ConstantExpression that has the Value and Type properties set to the specified values.
- constant(Object, Type, RoundingMode) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ConstantExpression that has the Value 、Type 、RoundingMode properties set to the specified values.
- constant(RexBuilder, ImmutableBitSet, ImmutableList<ImmutableBitSet>, AggregateCall) - Method in interface org.apache.calcite.sql.SqlStaticAggFunction
-
Generates an expression for the aggregate function; or null if the value is not constant.
- constant(R) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns a 1-parameter function that always returns the same value.
- Constant - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A constant value.
- CONSTANT - Enum constant in enum org.apache.calcite.sql.validate.SqlMonotonicity
- ConstantExpression - Class in org.apache.calcite.linq4j.tree
-
Represents an expression that has a constant value.
- ConstantExpression(Type, Object) - Constructor for class org.apache.calcite.linq4j.tree.ConstantExpression
- constantMap - Variable in class org.apache.calcite.plan.RelOptPredicateList
-
A map of each (e, constant) pair that occurs within
RelOptPredicateList.pulledUpPredicates
. - constantNull() - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns a 1-parameter function that always returns null.
- constantNull() - Method in class org.apache.calcite.rex.RexBuilder
-
Deprecated.Use
RexBuilder.makeNullLiteral(RelDataType)
, which produces a NULL of the correct type - constants - Variable in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
The map contains known to be effectively-final expression.
- constants - Variable in class org.apache.calcite.rel.core.Window
- constants - Variable in class org.apache.calcite.rel.mutable.MutableWindow
- ConstantUntypedNull - Class in org.apache.calcite.linq4j.tree
-
Represents a constant null of unknown type Java allows type inference for such nulls, thus "null" cannot always be replaced to (Object)null and vise versa.
- constraint - Variable in class org.apache.calcite.jdbc.CalcitePrepare.AnalyzeViewResult
- constructArgNameList(SqlCall) - Method in class org.apache.calcite.sql.SqlOperator
- constructArgTypeList(SqlValidator, SqlValidatorScope, SqlCall, List<SqlNode>, boolean) - Method in class org.apache.calcite.sql.SqlOperator
- constructOperandList(SqlValidator, SqlCall, List<String>) - Method in class org.apache.calcite.sql.SqlOperator
- constructor - Variable in enum org.apache.calcite.util.BuiltInMethod
- constructorDecl(int, Type, Iterable<? extends ParameterExpression>, BlockStatement) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Declares a constructor.
- ConstructorDeclaration - Class in org.apache.calcite.linq4j.tree
-
Declaration of a constructor.
- ConstructorDeclaration(int, Type, List<ParameterExpression>, BlockStatement) - Constructor for class org.apache.calcite.linq4j.tree.ConstructorDeclaration
- CONSUMER_ACCEPT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- consumerRelClass() - Method in interface org.apache.calcite.rel.rules.CoerceInputsRule.Config
-
Class of
RelNode
to coerce to. - consumesPreparedStatement(CalciteAssert.PreparedStatementConsumer) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- containComplexExprs(List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a list of expressions contains complex expressions, that is, a call whose arguments are not
RexVariable
(or a subtype such asRexInputRef
) orRexLiteral
. - contained() - Method in class org.apache.calcite.runtime.SpaceFillingCurve2D.CoveredRange
- contained() - Method in interface org.apache.calcite.runtime.SpaceFillingCurve2D.IndexRange
- contained() - Method in class org.apache.calcite.runtime.SpaceFillingCurve2D.OverlappingRange
- containIdentity(List<? extends RexNode>, RelDataType, Litmus) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether the leading edge of a given array of expressions is wholly
RexInputRef
objects with types corresponding to the underlying datatype. - containNoCommonExprs(List<RexNode>, Litmus) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether an array of expressions has any common sub-expressions.
- containNoForwardRefs(List<RexNode>, RelDataType, Litmus) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether an array of expressions contains no forward references.
- contains(int) - Method in class org.apache.calcite.util.IntegerIntervalSet
- contains(Object) - Method in class org.apache.calcite.util.ImmutableIntList
- contains(Object) - Method in class org.apache.calcite.sql.SqlNodeList
- contains(Object) - Method in class org.apache.calcite.util.ImmutableNullableSet
- contains(Object) - Method in class org.apache.calcite.util.IntegerIntervalSet
- contains(Object) - Method in class org.apache.calcite.util.PartiallyOrderedSet
- contains(CharSequence) - Method in interface org.apache.calcite.util.Puffin.Line
-
Returns whether the current line starts with
seek
. - contains(String[], int, String) - Static method in class org.apache.calcite.util.Util
-
Returns whether an array of strings contains a given string among the first
length
entries. - contains(String, boolean) - Method in class org.apache.calcite.util.NameSet
-
Returns whether this set contains the given name, with a given case-sensitivity.
- contains(BitSet, BitSet) - Static method in class org.apache.calcite.util.BitSets
-
Returns true if all bits set in the second parameter are also set in the first.
- contains(BitSet, ImmutableBitSet) - Static method in class org.apache.calcite.util.BitSets
-
Returns true if all bits set in the second parameter are also set in the first.
- contains(List<RelCollation>, ImmutableIntList) - Static method in class org.apache.calcite.rel.RelCollations
-
Returns whether one of a list of collations indicates that the collection is sorted on the given list of keys.
- contains(Enumerable<TSource>, TSource) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Determines whether a sequence contains a specified element by using the default equality comparer.
- contains(Enumerable<TSource>, TSource, EqualityComparer<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Determines whether a sequence contains a specified element by using a specified
EqualityComparer<TSource>
. - contains(Queryable<T>, T) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Determines whether a sequence contains a specified element by using the default equality comparer.
- contains(Queryable<T>, T) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Determines whether a sequence contains a specified element by using the default equality comparer.
- contains(Queryable<T>, T) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- contains(Queryable<T>, T, EqualityComparer) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Determines whether a sequence contains a specified element by using a specified
EqualityComparer<T>
. - contains(Queryable<T>, T, EqualityComparer<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Determines whether a sequence contains a specified element by using a specified
EqualityComparer<T>
. - contains(Queryable<T>, T, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- contains(LatticeRootNode) - Method in class org.apache.calcite.materialize.LatticeRootNode
-
Whether this node's graph is a super-set of (or equal to) another node's graph.
- contains(RelTrait) - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns whether this trait set contains a given trait.
- contains(MutableRel, MutableRel) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- contains(RelCollation, Iterable<Integer>) - Static method in class org.apache.calcite.rel.RelCollations
-
Returns whether a collation indicates that the collection is sorted on a given list of keys.
- contains(RelNode) - Method in class org.apache.calcite.plan.volcano.RelSubset
-
Returns whether this subset contains the specified relational expression.
- contains(RelNode, Predicate<AggregateCall>, RexUtil.RexFinder) - Static method in class org.apache.calcite.rel.RelNodes
- contains(RelNode, RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns whether relational expression
target
occurs within a relational expressionancestor
. - contains(RelDataType) - Method in enum org.apache.calcite.sql.type.SqlTypeFamily
- contains(RexNode) - Method in class org.apache.calcite.rex.RexUtil.RexFinder
-
Returns whether the given expression contains what this RexFinder seeks.
- contains(ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns true if all bits set in the second parameter are also set in the first.
- contains(T) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- contains(T, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- contains(TSource) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Determines whether a sequence contains a specified element by using the default equality comparer.
- contains(TSource, EqualityComparer<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Determines whether a sequence contains a specified element by using a specified
EqualityComparer<TSource>
. - CONTAINS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CONTAINS
operator for periods. - CONTAINS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- CONTAINS_SUBSTR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CONTAINS_SUBSTR
function (BigQuery semantics). - CONTAINS_SUBSTR - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
"CONTAINS_SUBSTR(expression, string[, json_scope => json_scope_value ])" function; returns whether string exists as substring in expression, with optional json_scope argument.
- containsAgg(SqlNode) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns whether an AST tree contains a call to an aggregate function.
- containsAggs() - Method in class org.apache.calcite.rex.RexProgram
-
Returns whether this program contains windowed aggregate functions.
- containsAll(Collection<?>) - Method in class org.apache.calcite.util.ImmutableIntList
- containsAll(Collection<?>) - Method in class org.apache.calcite.sql.SqlNodeList
- containsCall(SqlNode, Predicate<SqlCall>) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns whether an AST tree contains a call that matches a given predicate.
- containsCorrelation(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether an expression contains a
RexCorrelVariable
. - containsDefault(SqlNode) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns whether a given node contains a
SqlKind.DEFAULT
expression. - containsDistinctCall() - Method in class org.apache.calcite.rel.core.Aggregate
-
Returns whether any of the aggregates are DISTINCT.
- containsFieldAccess(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a given tree contains any
RexFieldAccess
nodes. - containsIfApplicable(RelTrait) - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns whether this trait set contains the given trait, or whether the trait is not present because its
RelTraitDef
is not enabled. - containsIn(SqlNode) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns whether a given node contains a
SqlInOperator
. - containsInputRef(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a given tree contains any {link RexInputRef} nodes.
- containsKey(Object) - Method in class org.apache.calcite.util.CompositeMap
- containsKey(String, boolean) - Method in class org.apache.calcite.util.NameMap
-
Returns whether this map contains a given key, with a given case-sensitivity.
- containsKey(String, boolean) - Method in class org.apache.calcite.util.NameMultimap
-
Returns whether this map contains a given key, with a given case-sensitivity.
- containsMixing(RexNode) - Static method in class org.apache.calcite.rex.RexMultisetUtil
-
Returns true if a node contains a mixing between multiset and non-multiset calls.
- containsMixing(RexProgram) - Static method in class org.apache.calcite.rex.RexMultisetUtil
-
Returns true if any expression in a program contains a mixing between multiset and non-multiset calls.
- containsMonotonic(SqlValidatorScope) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Returns whether there are any input columns that are sorted.
- containsMultiset(List<RexNode>, boolean) - Static method in class org.apache.calcite.rex.RexMultisetUtil
-
Returns whether a list of expressions contains a multiset.
- containsMultiset(RexNode, boolean) - Static method in class org.apache.calcite.rex.RexMultisetUtil
-
Returns true if node contains a multiset operator, otherwise false.
- containsMultiset(RexProgram) - Static method in class org.apache.calcite.rex.RexMultisetUtil
-
Returns whether a program contains a multiset.
- containsNonAscii(String) - Static method in class org.apache.calcite.sql.SqlDialect
-
Returns whether the string contains any characters outside the comfortable 7-bit ASCII range (32 through 127, plus linefeed (10) and carriage return (13)).
- containsNullable(List<RelDataType>) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether one or more of an array of types is nullable.
- containsNullable(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Determines whether a type or any of its fields (if a structured type) are nullable.
- containsOrderless(List<Integer>, RelCollation) - Static method in class org.apache.calcite.rel.RelCollations
-
Returns whether a collation is contained by a given list of keys regardless ordering.
- containsOrderless(RelCollation, List<Integer>) - Static method in class org.apache.calcite.rel.RelCollations
-
Returns whether a collation contains a given list of keys regardless the order.
- containsOver() - Method in class org.apache.calcite.rel.core.Calc
-
Returns whether this Calc contains any windowed-aggregate functions.
- containsOver() - Method in class org.apache.calcite.rel.core.Filter
-
Returns whether this Filter contains any windowed-aggregate functions.
- containsOver() - Method in class org.apache.calcite.rel.core.Project
-
Returns whether this Project contains any windowed-aggregate functions.
- containsOver(List<? extends RexNode>, RexNode) - Static method in class org.apache.calcite.rex.RexOver
-
Returns whether an expression list contains an OVER clause.
- containsOver(RexNode) - Static method in class org.apache.calcite.rex.RexOver
-
Returns whether an expression contains an OVER clause.
- containsOver(RexProgram) - Static method in class org.apache.calcite.rex.RexOver
-
Returns whether a program contains an OVER clause.
- containsStringLinux(String) - Static method in class org.apache.calcite.test.Matchers
-
Creates a matcher that matches when the examined string is equal to the specified
operand
when all Windows-style line endings ("\r\n") have been converted to Unix-style line endings ("\n"). - containsSubQuery(Filter) - Static method in class org.apache.calcite.rex.RexUtil.SubQueryFinder
-
Returns whether a
Filter
contains a sub-query. - containsSubQuery(Join) - Static method in class org.apache.calcite.rex.RexUtil.SubQueryFinder
-
Returns whether a
Join
contains a sub-query. - containsSubQuery(Project) - Static method in class org.apache.calcite.rex.RexUtil.SubQueryFinder
-
Returns whether a
Project
contains a sub-query. - containsSubstr(boolean, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CONTAINS_SUBSTR(boolean, substr)
operator. - containsSubstr(int, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CONTAINS_SUBSTR(int, substr)
operator. - containsSubstr(long, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CONTAINS_SUBSTR(long, substr)
operator. - containsSubstr(Object[], String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CONTAINS_SUBSTR(rows, substr)
operator. - containsSubstr(Object, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CONTAINS_SUBSTR(expr, substr)
operator. - containsSubstr(String, String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CONTAINS_SUBSTR(jsonString, substr, json_scope=>jsonScope)
operator. - containsSubstr(List, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CONTAINS_SUBSTR(arr, substr)
operator. - containsTableInputRef(List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether any of the given expression trees contains a {link RexTableInputRef} node.
- containsTableInputRef(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a given tree contains any {link RexTableInputRef} nodes.
- containsType(RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypePrecedenceList
-
Determines whether a type appears in this precedence list.
- containsType(RelDataType) - Method in class org.apache.calcite.sql.type.SqlTypeExplicitPrecedenceList
- containsValue(Object) - Method in class org.apache.calcite.util.CompositeMap
- containsWithoutNodeIds(String) - Static method in class org.apache.calcite.test.Matchers
-
Creates a
Matcher
that matches execution plan and trims, id=123
node ids. - content(String) - Method in class org.apache.calcite.util.XmlOutput
-
Writes content.
- contentType - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Page
- context - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- context - Variable in class org.apache.calcite.plan.AbstractRelOptPlanner
-
External context.
- context - Variable in class org.apache.calcite.prepare.Prepare
- context - Variable in class org.apache.calcite.rel.metadata.RelMdMeasure.DelegatingContext
- context - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- context - Variable in class org.apache.calcite.rex.RexChecker
- context - Variable in class org.apache.calcite.sql2rel.RelDecorrelator
- context(Context) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- Context - Class in org.apache.calcite.interpreter
-
Context for executing a scalar expression in an interpreter.
- Context - Interface in org.apache.calcite.plan
-
Provides library users a way to store data within the planner session and access it within rules.
- Context(SqlDialect, int) - Constructor for class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- Context(SqlDialect, int, boolean) - Constructor for class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- CONTEXT_ROOT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CONTEXT_VALUES - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- Contexts - Class in org.apache.calcite.plan
-
Utilities for
Context
. - Contexts() - Constructor for class org.apache.calcite.rel.metadata.RelMdMeasure.Contexts
- ContextSqlValidator - Class in org.apache.calcite.jdbc
-
A SqlValidator with schema and type factory of the given
CalcitePrepare.Context
. - ContextSqlValidator(CalcitePrepare.Context, boolean) - Constructor for class org.apache.calcite.jdbc.ContextSqlValidator
-
Create a
ContextSqlValidator
. - Continue - Enum constant in enum org.apache.calcite.linq4j.tree.GotoExpressionKind
-
A GotoExpression that represents a continue statement.
- continue_(LabelTarget) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a continue statement.
- continue_(LabelTarget, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a continue statement with the specified type.
- continueIdentify - Variable in class org.apache.calcite.sql.ddl.SqlTruncateTable
- ControlFlowException - Exception Class in org.apache.calcite.util
-
Exception intended to be used for control flow, as opposed to the usual use of exceptions which is to signal an error condition.
- ControlFlowException() - Constructor for exception class org.apache.calcite.util.ControlFlowException
- Convention - Interface in org.apache.calcite.plan
-
Calling convention trait.
- CONVENTION - Static variable in interface org.apache.calcite.adapter.arrow.ArrowRel
-
Calling convention for relational operations that occur in Arrow.
- CONVENTION - Static variable in interface org.apache.calcite.adapter.cassandra.CassandraRel
-
Calling convention for relational operations that occur in Cassandra.
- CONVENTION - Static variable in interface org.apache.calcite.adapter.elasticsearch.ElasticsearchRel
-
Calling convention for relational operations that occur in Elasticsearch.
- CONVENTION - Static variable in interface org.apache.calcite.adapter.geode.rel.GeodeRel
-
Calling convention for relational operations that occur in Geode.
- CONVENTION - Static variable in interface org.apache.calcite.adapter.innodb.InnodbRel
-
Calling convention for relational operations that occur in InnoDB.
- CONVENTION - Static variable in interface org.apache.calcite.adapter.mongodb.MongoRel
-
Calling convention for relational operations that occur in MongoDB.
- CONVENTION - Static variable in interface org.apache.calcite.adapter.pig.PigRel
-
Calling convention for relational operations that occur in Pig.
- CONVENTION - Static variable in interface org.apache.calcite.adapter.spark.SparkRel
-
Calling convention for relational operations that occur in Spark.
- Convention.Impl - Class in org.apache.calcite.plan
-
Default implementation.
- ConventionTraitDef - Class in org.apache.calcite.plan
-
Definition of the convention trait.
- ConversionUtil - Class in org.apache.calcite.util
-
Utility functions for converting from one type to another.
- convert(Object) - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleEnumerator
- convert(EnumerableLimit) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraLimitRule
- convert(CalciteConnection, CalciteSchema, List<String>, String) - Static method in class org.apache.calcite.schema.Schemas
-
Parses and validates a SQL query and converts to relational algebra.
- convert(CalcitePrepare.Context, String) - Method in interface org.apache.calcite.jdbc.CalcitePrepare
- convert(CalcitePrepare.Context, String) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- convert(Expression, Type) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
-
Convert
operand
to target typetoType
. - convert(Expression, Type, Type) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
-
Convert
operand
to target typetoType
. - convert(RelOptPlanner, RelNode, RelTrait) - Static method in class org.apache.calcite.plan.RelOptRule
- convert(RelOptPlanner, RelNode, Convention, boolean) - Method in class org.apache.calcite.plan.ConventionTraitDef
- convert(RelOptPlanner, RelNode, RelTraitSet) - Static method in class org.apache.calcite.plan.RelOptRule
- convert(RelOptPlanner, RelNode, RelCollation, boolean) - Method in class org.apache.calcite.rel.RelCollationTraitDef
- convert(RelOptPlanner, RelNode, RelDistribution, boolean) - Method in class org.apache.calcite.rel.RelDistributionTraitDef
- convert(RelOptPlanner, RelNode, T, boolean) - Method in class org.apache.calcite.plan.RelTraitDef
-
Converts the given RelNode to the given RelTrait.
- convert(RelTrait) - Method in interface org.apache.calcite.plan.RelRule.OperandDetailBuilder
-
Indicates that this operand converts a relational expression to another trait.
- convert(Join, boolean) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcJoinRule
-
Converts a
Join
into aJdbcJoin
. - convert(Sort, boolean) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcSortRule
-
Converts a
Sort
into aJdbcSort
. - convert(Sort, CassandraFilter) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraSortRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.arrow.ArrowRules.ArrowProjectRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraProjectRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.cassandra.CassandraToEnumerableConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchToEnumerableConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableBindable.EnumerableToBindableConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCorrelateRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableInterpreterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMatchRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRepeatUnionRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableFunctionScanRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableModifyRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableScanRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableSpoolRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableValuesRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.geode.rel.GeodeToEnumerableConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.innodb.InnodbRules.InnodbProjectRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.innodb.InnodbToEnumerableConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcAggregateRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcFilterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcIntersectRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcJoinRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcMinusRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcProjectRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcSortRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcTableModificationRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcUnionRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcValuesRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.mongodb.MongoToEnumerableConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.pig.PigToEnumerableConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.spark.JdbcToSparkConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.spark.SparkRules.SparkValuesRule
- convert(RelNode) - Method in class org.apache.calcite.interpreter.Bindables.BindableAggregateRule
- convert(RelNode) - Method in class org.apache.calcite.interpreter.Bindables.BindableFilterRule
- convert(RelNode) - Method in class org.apache.calcite.interpreter.Bindables.BindableJoinRule
- convert(RelNode) - Method in class org.apache.calcite.interpreter.Bindables.BindableMatchRule
- convert(RelNode) - Method in class org.apache.calcite.interpreter.Bindables.BindableProjectRule
- convert(RelNode) - Method in class org.apache.calcite.interpreter.Bindables.BindableSetOpRule
- convert(RelNode) - Method in class org.apache.calcite.interpreter.Bindables.BindableSortRule
- convert(RelNode) - Method in class org.apache.calcite.interpreter.Bindables.BindableValuesRule
- convert(RelNode) - Method in class org.apache.calcite.interpreter.Bindables.BindableWindowRule
- convert(RelNode) - Method in class org.apache.calcite.interpreter.NoneToBindableConverterRule
- convert(RelNode) - Method in class org.apache.calcite.rel.convert.ConverterRule
-
Converts a relational expression to the target trait(s) of this rule.
- convert(RelNode, RelTrait) - Static method in class org.apache.calcite.plan.RelOptRule
-
Converts one trait of a relational expression, if it does not already have that trait.
- convert(RelNode, RelTraitSet) - Static method in class org.apache.calcite.plan.RelOptRule
-
Converts a relation expression to a given set of traits, if it does not already have those traits.
- convert(RelDataType, boolean) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a projection that converts the current relational expression's output to a desired row type.
- convert(RexBuilder, RexNode, RexNode) - Method in interface org.apache.calcite.sql2rel.AuxiliaryConverter
-
Converts an expression.
- convert(RexBuilder, RexNode, RexNode) - Method in class org.apache.calcite.sql2rel.AuxiliaryConverter.Impl
- convert(SqlNode) - Method in class org.apache.calcite.prepare.PlannerImpl
- convert(SqlNode) - Method in interface org.apache.calcite.tools.Planner
-
Deprecated.
- Convert - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A cast or conversion operation, such as
(SampleType) obj
in Java. - CONVERT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CONVERT
function. - CONVERT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CONVERT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CONVERT(charValue, srcCharsetName, destCharsetName)
function convertscharValue
withdestCharsetName
, whose original encoding is specified bysrcCharsetName
. - convert_(Expression, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents a type conversion operation.
- convert_(Expression, Type, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents a conversion operation for which the implementing method is specified.
- CONVERT_TIMEZONE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CONVERT_TIMEZONE(tz1, tz2, datetime)" function; converts the timezone of
datetime
fromtz1
totz2
. - convertAgg(SqlToRelConverter.Blackboard, SqlSelect, List<SqlNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts the SELECT, GROUP BY and HAVING clauses of an aggregate query.
- convertAggregateFunction(SqlRexContext, SqlAggFunction, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertArray(SqlRexContext, SqlArrayValueConstructor, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertAsCalc - Variable in class org.apache.calcite.test.RelMetadataFixture
- convertAuxiliaryToGroupCall(SqlCall) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Converts a call to a grouped auxiliary function to a call to the grouped window function.
- convertBetween(SqlRexContext, SqlBetweenOperator, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Converts a BETWEEN expression.
- convertCall(RexCall) - Method in interface org.apache.calcite.rex.RexToSqlNodeConverter
- convertCall(RexCall) - Method in class org.apache.calcite.rex.RexToSqlNodeConverterImpl
- convertCall(RexToSqlNodeConverter, RexCall) - Method in interface org.apache.calcite.rex.RexSqlConvertlet
- convertCall(RexToSqlNodeConverter, RexCall) - Method in class org.apache.calcite.rex.RexSqlStandardConvertletTable
-
Converts a call to an operator into a
SqlCall
to the same operator. - convertCall(SqlRexContext, SqlCall) - Method in interface org.apache.calcite.sql2rel.SqlNodeToRexConverter
- convertCall(SqlRexContext, SqlCall) - Method in class org.apache.calcite.sql2rel.SqlNodeToRexConverterImpl
- convertCall(SqlRexContext, SqlCall) - Method in interface org.apache.calcite.sql2rel.SqlRexConvertlet
- convertCall(SqlRexContext, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Converts a call to an operator into a
RexCall
to the same operator. - convertCase(SqlRexContext, SqlCase) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Converts a CASE expression.
- convertCast(SqlRexContext, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertCharset(SqlRexContext, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertChecked(Expression, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents a conversion operation that throws an exception if the target type is overflowed.
- ConvertChecked - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A cast or conversion operation, such as
(SampleType) obj
in Java. - convertChecked_(Expression, Type, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents a conversion operation that throws an exception if the target type is overflowed and for which the implementing method is specified.
- convertCollectionTable(SqlToRelConverter.Blackboard, SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertColumnList(SqlInsert, RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Creates a source for an INSERT statement.
- convertConditionToSqlNode(RexNode, SqlImplementor.Context, SqlImplementor.Context) - Static method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- convertContains(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Checks that when the query (which was set using
CalciteAssert.AssertThat.query(String)
) is converted to a relational algebra expression matching the given string. - convertCorrelateToJoin() - Method in interface org.apache.calcite.tools.RelBuilder.Config
-
Whether to convert Correlate to Join if correlation variable is unused.
- convertDatetimeMinus(SqlRexContext, SqlDatetimeSubtractionOperator, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertDynamicParam(SqlDynamicParam) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- CONVERTED - Enum constant in enum org.apache.calcite.runtime.Hook
-
Called with the output of sql-to-rel-converter.
- converter - Variable in class org.apache.calcite.test.RelMetadataFixture.MetadataConfig
- Converter - Interface in org.apache.calcite.rel.convert
-
A relational expression implements the interface
Converter
to indicate that it converts a physical attribute, ortrait
, of a relational expression from one value to another. - ConverterImpl - Class in org.apache.calcite.rel.convert
-
Abstract implementation of
Converter
. - ConverterImpl(RelOptCluster, RelTraitDef, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.rel.convert.ConverterImpl
-
Creates a ConverterImpl.
- converterRule() - Method in interface org.apache.calcite.rel.convert.TraitMatchingRule.Config
-
Returns the rule to be restricted; rule must take a single operand expecting a single input.
- ConverterRule - Class in org.apache.calcite.rel.convert
-
Abstract base class for a rule which converts from one calling convention to another without changing semantics.
- ConverterRule(Class<? extends RelNode>, RelTrait, RelTrait, String) - Constructor for class org.apache.calcite.rel.convert.ConverterRule
-
Deprecated.
- ConverterRule(Class<R>, Predicate<? super R>, RelTrait, RelTrait, String) - Constructor for class org.apache.calcite.rel.convert.ConverterRule
-
Deprecated.
- ConverterRule(Class<R>, Predicate<? super R>, RelTrait, RelTrait, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.convert.ConverterRule
-
Deprecated.
- ConverterRule(Class<R>, Predicate<? super R>, RelTrait, RelTrait, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.convert.ConverterRule
-
Deprecated.
- ConverterRule(ConverterRule.Config) - Constructor for class org.apache.calcite.rel.convert.ConverterRule
-
Creates a
ConverterRule
. - ConverterRule.Config - Interface in org.apache.calcite.rel.convert
-
Rule configuration.
- converterRules - Variable in class org.apache.calcite.rel.hint.HintStrategy
- converterRules(ConverterRule...) - Method in class org.apache.calcite.rel.hint.HintStrategy.Builder
-
Registers an array of desired converter rules during the
RelOptPlanner
planning. - convertExpression(SqlNode) - Method in interface org.apache.calcite.sql2rel.InitializerContext
-
Converts a
SqlNode
toRexNode
. - convertExpression(SqlNode) - Method in interface org.apache.calcite.sql2rel.SqlRexContext
- convertExpression(SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- convertExpression(SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertExpression(SqlNode, Map<String, RexNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertExtendedExpression(SqlNode, SqlToRelConverter.Blackboard) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts a non-standard expression.
- convertExtract(SqlRexContext, SqlExtractFunction, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Converts a call to the
EXTRACT
function. - convertFloorCeil(SqlRexContext, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertFrom(SqlToRelConverter.Blackboard, SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertFrom(SqlToRelConverter.Blackboard, SqlNode, List<String>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts a FROM clause into a relational expression.
- convertFunction(SqlRexContext, SqlFunction, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertGroupToAuxiliaryCalls(SqlCall) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Deprecated.
- convertGroupToAuxiliaryCalls(SqlCall, BiConsumer<SqlNode, AuxiliaryConverter>) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Converts a call to a grouped window function to a call to its auxiliary window function(s).
- convertingProjectAsCalc() - Method in class org.apache.calcite.test.RelMetadataFixture
- convertInputRef(RexInputRef) - Method in interface org.apache.calcite.rex.RexToSqlNodeConverter
-
Converts a
RexInputRef
to aSqlIdentifier
. - convertInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexToSqlNodeConverterImpl
- convertInsert(SqlInsert) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertInterval(SqlIntervalQualifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- convertInterval(SqlRexContext, SqlIntervalQualifier) - Method in interface org.apache.calcite.sql2rel.SqlNodeToRexConverter
-
Converts a
SQL Interval Qualifier
to aREX literal
. - convertInterval(SqlRexContext, SqlIntervalQualifier) - Method in class org.apache.calcite.sql2rel.SqlNodeToRexConverterImpl
- convertJdbc(SqlRexContext, SqlJdbcFunctionCall, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertJsonQueryFunction(SqlRexContext, SqlJsonQueryFunction, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertJsonReturningFunction(SqlRexContext, SqlFunction, SqlCall, Predicate<List<SqlNode>>, Function<SqlCall, List<SqlNode>>) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertJsonValueFunction(SqlRexContext, SqlJsonValueFunction, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertletTable - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- convertletTable(SqlRexConvertletTable) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- convertList(List<RelNode>, RelTrait) - Static method in class org.apache.calcite.plan.RelOptRule
-
Converts a list of relational expressions.
- convertLiteral(RexLiteral) - Method in interface org.apache.calcite.rex.RexToSqlNodeConverter
-
Converts a
RexLiteral
to aSqlLiteral
. - convertLiteral(RexLiteral) - Method in class org.apache.calcite.rex.RexToSqlNodeConverterImpl
- convertLiteral(SqlLiteral) - Method in interface org.apache.calcite.sql2rel.SqlRexContext
-
Converts a literal.
- convertLiteral(SqlLiteral) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- convertLiteral(SqlRexContext, SqlLiteral) - Method in interface org.apache.calcite.sql2rel.SqlNodeToRexConverter
-
Converts a
SQL literal
to aREX literal
. - convertLiteral(SqlRexContext, SqlLiteral) - Method in class org.apache.calcite.sql2rel.SqlNodeToRexConverterImpl
- convertLiteralChain(SqlRexContext, SqlLiteralChainOperator, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Converts a LiteralChain expression: that is, concatenates the operands immediately, to produce a single literal string.
- convertMap(SqlRexContext, SqlMapValueConstructor, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertMatches(Consumer<RelNode>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- convertMatchRecognize(SqlToRelConverter.Blackboard, SqlMatchRecognize) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertMultiset(SqlRexContext, SqlMultisetValueConstructor, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertMultisetQuery(SqlRexContext, SqlMultisetQueryConstructor, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertNode(RexNode) - Method in interface org.apache.calcite.rex.RexToSqlNodeConverter
- convertNode(RexNode) - Method in class org.apache.calcite.rex.RexToSqlNodeConverterImpl
- convertOperand(Class<R>, Predicate<? super R>, RelTrait) - Static method in class org.apache.calcite.plan.RelOptRule
-
Deprecated.
- convertOperand(Class<R>, Predicate<? super R>, RelTrait) - Static method in class org.apache.calcite.plan.RelOptRule
-
Deprecated.
- convertOrder(SqlSelect, SqlToRelConverter.Blackboard, RelCollation, List<SqlNode>, SqlNode, SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts a query's ORDER BY clause, if any.
- convertOrderItem(SqlSelect, SqlNode, List<SqlNode>, RelFieldCollation.Direction, RelFieldCollation.NullDirection) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertOverlaps(SqlRexContext, SqlOverlapsOperator, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Converts a call to OVERLAPS.
- convertPivot(SqlToRelConverter.Blackboard, SqlPivot) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertProject(RexNode) - Method in class org.apache.calcite.rel.rules.PushProjector
-
Decomposes a projection to the input references referenced by a projection and a filter, either of which is optional.
- convertQuery(SqlNode, boolean, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts an unvalidated query's parse tree into a relational expression.
- convertQueryRecursive(SqlNode, boolean, RelDataType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Recursively converts a query to a relational expression.
- convertRefsAndExprs(RexNode, List<RelDataTypeField>, int[]) - Method in class org.apache.calcite.rel.rules.PushProjector
-
Clones an expression tree and walks through it, adjusting each RexInputRef index by some amount, and converting expressions that need to be preserved to field references.
- ConvertResult(CalcitePrepareImpl, SqlValidator, String, SqlNode, RelDataType, RelRoot) - Constructor for class org.apache.calcite.jdbc.CalcitePrepare.ConvertResult
- convertRow(SqlRexContext, SqlRowOperator, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Converts a ROW.
- convertSelect(SqlSelect, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts a SELECT statement's parse tree into a relational expression.
- convertSelectImpl(SqlToRelConverter.Blackboard, SqlToRelConverter.Blackboard, SqlSelect) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Implementation of
SqlToRelConverter.convertSelect(SqlSelect, boolean)
; derived class may override. - convertSequenceValue(SqlRexContext, SqlSequenceValueOperator, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertSetOp(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts a set operation (UNION, INTERSECT, MINUS) into relational expressions.
- convertSortExpression(SqlNode, RelFieldCollation.Direction, RelFieldCollation.NullDirection) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Deprecated.
- convertSqlToRel(SqlTestFactory, String, boolean, boolean) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Converts a SQL string to a
RelNode
tree. - convertSqlToRel2(SqlTestFactory, String, boolean, boolean) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- convertSqlToRel2(SqlTestFactory, String, boolean, boolean) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Converts a SQL string to a (SqlValidator, RelNode) pair.
- convertsTo(String) - Method in class org.apache.calcite.test.SqlToRelFixture
- convertSubQuery(SqlCall, SqlToRelConverter, boolean, boolean) - Method in interface org.apache.calcite.sql2rel.SubQueryConverter
-
Converts the sub-query to an equivalent expression.
- convertSubstring(SqlRexContext, SqlSubstringFunction, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Converts a SUBSTRING expression.
- convertTo(Expression, JavaRowFormat) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Converts an enumerable of this physical type to an enumerable that uses the
targetFormat
for representing its rows. - convertTo(Expression, JavaRowFormat) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- convertTo(Expression, PhysType) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Deprecated.Use
PhysType.convertTo(Expression, JavaRowFormat)
. The use of PhysType as a second parameter is misleading since only the row format of the expression is affected by the conversion. Moreover it requires to have at hand a PhysType object which is not really necessary for achieving the desired result. - convertTo(Expression, PhysType) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- convertToLinux - Variable in class org.apache.calcite.sql.parser.SqlParserFixture
- convertToRowValues(List<RelDataTypeField>, Object) - Static method in class org.apache.calcite.adapter.geode.util.GeodeUtils
-
Converts a Geode object into a Row tuple.
- convertToSingleValueSubq(SqlNode, RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts the RelNode tree for a select statement to a select that produces a single value.
- convertToString(ZonedDateTime, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.AmPmCompiledPattern
- convertToString(ZonedDateTime, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.BcAdCompiledPattern
- convertToString(ZonedDateTime, Locale) - Method in interface org.apache.calcite.util.format.postgresql.format.compiled.CompiledItem
-
Creates one portion of the formatted date/time.
- convertToString(ZonedDateTime, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.DayOfWeekCompiledPattern
- convertToString(ZonedDateTime, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.LiteralCompiledItem
- convertToString(ZonedDateTime, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.MonthCompiledPattern
- convertToString(ZonedDateTime, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.NumberCompiledPattern
- convertToString(ZonedDateTime, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.RomanNumeralsCompiledPattern
- convertToString(ZonedDateTime, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneCompiledPattern
- convertToString(ZonedDateTime, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneHoursCompiledPattern
- convertToString(ZonedDateTime, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneMinutesCompiledPattern
- convertToString(ZonedDateTime, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneOffsetCompiledPattern
- convertToString(ZonedDateTime, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.YearWithCommasCompiledPattern
- convertToStruct(RelDataType) - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- convertTypeToSpec(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Converts an instance of RelDataType to an instance of SqlDataTypeSpec.
- convertTypeToSpec(RelDataType, String, int, int) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Converts an instance of RelDataType to an instance of SqlDataTypeSpec.
- convertUnpivot(SqlToRelConverter.Blackboard, SqlUnpivot) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertValues(SqlCall, RelDataType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts a SELECT statement's parse tree into a relational expression.
- convertWindowFunction(SqlRexContext, SqlWindowTableFunction, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertWith(SqlWith, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts a WITH sub-query into a relational expression.
- convertWithCharset(String, String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CONVERT(s, src_charset, dest_charset)
function. - Coordinate(BigDecimal, BigDecimal) - Constructor for class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Coordinate
- CoordinateTransformer - Class in org.apache.calcite.runtime
-
Transforms the coordinates of a geometry.
- CoordinateTransformer(Function<Coordinate, Coordinate>) - Constructor for class org.apache.calcite.runtime.CoordinateTransformer
-
Creates a transformer that applies the
transform
to all coordinates. - coords - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Place
- copy() - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Call
- copy() - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Op
- copy() - Method in class org.apache.calcite.util.PrecedenceClimbingParser.SpecialOp
- copy() - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Token
- copy(int) - Method in class org.apache.calcite.rel.RelFieldCollation
-
Deprecated.
- copy(int, Predicate<PrecedenceClimbingParser.Token>) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- copy(Range<C>, Function<C, C2>) - Static method in class org.apache.calcite.util.RangeSets
-
Copies a range.
- copy(RangeSet<C>, Function<C, C2>) - Static method in class org.apache.calcite.util.RangeSets
-
Copies a range set.
- copy(E[], int) - Method in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRule
- copy(String) - Method in class org.apache.calcite.util.NlsString
-
Creates a copy of this
NlsString
with different content but same charset and collation. - copy(List<Integer>) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- copy(List<Integer>) - Method in class org.apache.calcite.rel.hint.RelHint
-
Returns a copy of this hint with specified inherit path.
- copy(List<Integer>, int) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- copy(List<Integer>, int, RelCollation) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- copy(List<Integer>, int, ImmutableBitSet, RelCollation) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- copy(List<RexLiteral>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindow
- copy(List<RexLiteral>) - Method in class org.apache.calcite.interpreter.Bindables.BindableWindow
- copy(List<RexLiteral>) - Method in class org.apache.calcite.rel.core.Window
-
Creates a copy of this
Window
. - copy(List<RexLiteral>) - Method in class org.apache.calcite.rel.logical.LogicalWindow
- copy(ParameterExpression, ParameterExpression, int, int) - Method in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
-
Returns an expression that copies the fields of a row of this type to the array.
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.cassandra.CassandraLimit
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTableScan
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.cassandra.CassandraToEnumerableConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.csv.CsvTableScan
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.druid.DruidQuery
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTableScan
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchToEnumerableConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableAsofJoin
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableBindable
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableInterpretable
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableInterpreter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableLimit
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMatch
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRepeatUnion
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableModify
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableValues
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindow
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.file.CsvTableScan
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeTableScan
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeToEnumerableConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.innodb.InnodbTableScan
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.innodb.InnodbToEnumerableConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcCalc
-
Deprecated.
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcTableModify
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcValues
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.jdbc.JdbcTableScan
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.mongodb.MongoTableScan
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.mongodb.MongoToEnumerableConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.pig.PigToEnumerableConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.spark.EnumerableToSparkConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.spark.JdbcToSparkConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.spark.SparkRules.SparkCalc
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.spark.SparkRules.SparkValues
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.adapter.spark.SparkToEnumerableConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.interpreter.Bindables.BindableMatch
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.interpreter.Bindables.BindableValues
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.interpreter.Bindables.BindableWindow
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.interpreter.InterpretableConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.hep.HepRelVertex
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.AbstractConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.RelSubset
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.AbstractRelNode
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.convert.NoneConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.Aggregate
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.Calc
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.Collect
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.Correlate
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.Exchange
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.Filter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.Join
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.Project
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.Sample
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.SetOp
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.Snapshot
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.Sort
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.Spool
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.TableFunctionScan
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.core.Uncollect
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.logical.LogicalAsofJoin
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.logical.LogicalMatch
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.logical.LogicalRepeatUnion
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.logical.LogicalTableModify
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.logical.LogicalTableScan
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.logical.LogicalValues
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.logical.LogicalWindow
- copy(RelTraitSet, List<RelNode>) - Method in interface org.apache.calcite.rel.RelNode
-
Creates a copy of this relational expression, perhaps changing traits and inputs.
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.rules.MultiJoin
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.rel.stream.LogicalDelta
- copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.calcite.adapter.enumerable.EnumerableIntersect
- copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMergeUnion
- copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMinus
- copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.calcite.adapter.enumerable.EnumerableUnion
- copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcIntersect
- copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcMinus
- copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcUnion
- copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.calcite.interpreter.Bindables.BindableIntersect
- copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.calcite.interpreter.Bindables.BindableMinus
- copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.calcite.interpreter.Bindables.BindableUnion
- copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.calcite.rel.core.SetOp
- copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.calcite.rel.logical.LogicalIntersect
- copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.calcite.rel.logical.LogicalMinus
- copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.calcite.rel.logical.LogicalUnion
- copy(RelTraitSet, List<RelNode>, RexNode, Type, RelDataType, Set<RelColumnMapping>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableFunctionScan
- copy(RelTraitSet, List<RelNode>, RexNode, Type, RelDataType, Set<RelColumnMapping>) - Method in class org.apache.calcite.rel.core.TableFunctionScan
-
Copies this relational expression, substituting traits and inputs.
- copy(RelTraitSet, List<RelNode>, RexNode, Type, RelDataType, Set<RelColumnMapping>) - Method in class org.apache.calcite.rel.logical.LogicalTableFunctionScan
- copy(RelTraitSet, RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCollect
- copy(RelTraitSet, RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableUncollect
- copy(RelTraitSet, RelNode) - Method in class org.apache.calcite.rel.core.Collect
- copy(RelTraitSet, RelNode) - Method in class org.apache.calcite.rel.core.Uncollect
- copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.rel.core.Aggregate
-
Deprecated.
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.calcite.adapter.cassandra.CassandraProject
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchProject
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.calcite.adapter.enumerable.EnumerableProject
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.calcite.adapter.geode.rel.GeodeProject
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.calcite.adapter.innodb.InnodbProject
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcProject
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.calcite.adapter.mongodb.MongoProject
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.calcite.adapter.pig.PigProject
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.calcite.interpreter.Bindables.BindableProject
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.calcite.rel.core.Project
-
Copies a project.
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.calcite.rel.logical.LogicalProject
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType, int) - Method in class org.apache.calcite.rel.core.Project
-
Deprecated.
- copy(RelTraitSet, RelNode, Spool.Type, Spool.Type) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableSpool
- copy(RelTraitSet, RelNode, Spool.Type, Spool.Type) - Method in class org.apache.calcite.rel.core.Spool
- copy(RelTraitSet, RelNode, Spool.Type, Spool.Type) - Method in class org.apache.calcite.rel.logical.LogicalTableSpool
- copy(RelTraitSet, RelNode, RelCollation) - Method in class org.apache.calcite.rel.core.Sort
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.adapter.cassandra.CassandraSort
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSort
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableLimitSort
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableSort
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcSort
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.interpreter.Bindables.BindableSort
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.rel.core.Sort
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.rel.logical.LogicalSort
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.adapter.geode.rel.GeodeSort
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.adapter.innodb.InnodbSort
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.adapter.mongodb.MongoSort
- copy(RelTraitSet, RelNode, RelDistribution) - Method in class org.apache.calcite.rel.core.Exchange
- copy(RelTraitSet, RelNode, RelDistribution) - Method in class org.apache.calcite.rel.core.SortExchange
- copy(RelTraitSet, RelNode, RelDistribution) - Method in class org.apache.calcite.rel.logical.LogicalExchange
- copy(RelTraitSet, RelNode, RelDistribution, RelCollation) - Method in class org.apache.calcite.rel.core.SortExchange
- copy(RelTraitSet, RelNode, RelDistribution, RelCollation) - Method in class org.apache.calcite.rel.logical.LogicalSortExchange
- copy(RelTraitSet, RelNode, RelNode, CorrelationId, ImmutableBitSet, JoinRelType) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCorrelate
- copy(RelTraitSet, RelNode, RelNode, CorrelationId, ImmutableBitSet, JoinRelType) - Method in class org.apache.calcite.rel.core.Correlate
- copy(RelTraitSet, RelNode, RelNode, CorrelationId, ImmutableBitSet, JoinRelType) - Method in class org.apache.calcite.rel.logical.LogicalCorrelate
- copy(RelTraitSet, RelNode, RelNode, CorrelationId, ImmutableBitSet, JoinRelType) - Method in class org.apache.calcite.test.SqlToRelTestBase.CustomCorrelate
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.calcite.adapter.cassandra.CassandraFilter
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableFilter
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.calcite.adapter.innodb.InnodbFilter
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcFilter
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.calcite.adapter.mongodb.MongoFilter
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.calcite.adapter.pig.PigFilter
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.calcite.interpreter.Bindables.BindableFilter
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.calcite.rel.core.Filter
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.calcite.rel.core.Snapshot
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.calcite.rel.logical.LogicalFilter
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.calcite.rel.logical.LogicalSnapshot
- copy(RelTraitSet, RelNode, RexProgram) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCalc
- copy(RelTraitSet, RelNode, RexProgram) - Method in class org.apache.calcite.rel.core.Calc
-
Creates a copy of this
Calc
. - copy(RelTraitSet, RelNode, RexProgram) - Method in class org.apache.calcite.rel.logical.LogicalCalc
- copy(RelTraitSet, RelNode, RexProgram, List<RelCollation>) - Method in class org.apache.calcite.rel.core.Calc
-
Deprecated.
- copy(RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregate
- copy(RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableSortedAggregate
- copy(RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcAggregate
- copy(RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.adapter.mongodb.MongoAggregate
- copy(RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.interpreter.Bindables.BindableAggregate
- copy(RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.rel.core.Aggregate
-
Creates a copy of this aggregate.
- copy(RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.rel.logical.LogicalAggregate
- copy(RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchAggregate
- copy(RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeAggregate
- copy(RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.adapter.pig.PigAggregate
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.calcite.adapter.enumerable.EnumerableAsofJoin
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoin
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.calcite.adapter.enumerable.EnumerableHashJoin
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMergeJoin
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.calcite.adapter.enumerable.EnumerableNestedLoopJoin
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcJoin
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.calcite.adapter.pig.PigJoin
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.calcite.interpreter.Bindables.BindableJoin
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.calcite.rel.core.Join
-
Creates a copy of this join, overriding condition, system fields and inputs.
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.calcite.rel.logical.LogicalAsofJoin
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.calcite.rel.logical.LogicalJoin
- copy(RelTraitSet, RexNode, RexNode, RelNode, RelNode) - Method in class org.apache.calcite.rel.logical.LogicalAsofJoin
- copy(MaterializedViewRule.EquivalenceClasses) - Static method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule.EquivalenceClasses
- copy(RelDataType) - Method in class org.apache.calcite.prepare.RelOptTableImpl
-
Creates a copy of this RelOptTable.
- copy(RexNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a copy of an expression, which may have been created using a different RexBuilder and/or
RelDataTypeFactory
, using this RexBuilder. - copy(SqlValidatorScope, SqlNodeList) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.Copies a list of nodes.
- copy(T...) - Static method in class org.apache.calcite.runtime.FlatLists
-
Deprecated.
- copyOf(int...) - Static method in class org.apache.calcite.util.ImmutableIntList
-
Same as
ImmutableIntList.of(int...)
, but less ambiguous for code generators and compilers. - copyOf(E[]) - Static method in class org.apache.calcite.util.ImmutableNullableList
-
Returns an immutable list containing the given elements, in order.
- copyOf(E[]) - Static method in class org.apache.calcite.util.ImmutableNullableSet
-
Returns an immutable set containing the given elements.
- copyOf(Iterable<? extends E>) - Static method in class org.apache.calcite.util.ImmutableNullableList
-
Returns an immutable list containing the given elements, in order.
- copyOf(Iterable<? extends E>) - Static method in class org.apache.calcite.util.ImmutableNullableSet
-
Returns an immutable set containing the given elements.
- copyOf(Iterable<? extends Number>) - Static method in class org.apache.calcite.util.ImmutableIntList
-
Creates an ImmutableIntList from an iterable of
Number
. - copyOf(Iterable<? extends Map.Entry<T, U>>) - Static method in interface org.apache.calcite.runtime.ImmutablePairList
-
Creates an ImmutablePairList whose contents are a copy of a given collection.
- copyOf(Number...) - Static method in class org.apache.calcite.util.ImmutableIntList
-
Creates an ImmutableIntList from an array of
Number
. - copyOf(Collection<? extends E>) - Static method in class org.apache.calcite.util.ImmutableNullableList
-
Returns an immutable list containing the given elements, in order.
- copyOf(Iterator<? extends Number>) - Static method in class org.apache.calcite.util.ImmutableIntList
-
Creates an ImmutableIntList from an iterator of
Number
. - copyOf(Map<? extends K, ? extends V>) - Static method in class org.apache.calcite.util.ImmutableNullableMap
-
Returns an immutable map containing the given elements.
- copyOf(SortedMap<? extends K, ? extends V>) - Static method in class org.apache.calcite.util.ImmutableNullableMap
-
Returns an immutable navigable map containing the given entries.
- copyOf(T...) - Static method in class org.apache.calcite.runtime.FlatLists
-
Creates a memory-, CPU- and cache-efficient comparable immutable list, always copying the contents.
- copyOf(T, U, Object...) - Static method in interface org.apache.calcite.runtime.ImmutablePairList
-
Creates an ImmutablePairList with one or more entries.
- copyOf(T, U, Object...) - Static method in interface org.apache.calcite.runtime.PairList
-
Creates a PairList with one or more entries.
- copyOf(T, U, Object...) - Static method in class org.apache.calcite.runtime.PairList.Helper
-
Deprecated.
- copyRelHints(RelNode, RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
- copyRelHints(RelNode, RelNode, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
- copyType(RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Duplicates a type, making a deep copy.
- copyType(RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- copyValues() - Method in class org.apache.calcite.interpreter.Row
-
Returns a copy of the values.
- CORE - Static variable in class org.apache.calcite.rel.type.TimeFrames
-
The core time frame set.
- CorelMapBuilder() - Constructor for class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
- CoreRules - Class in org.apache.calcite.rel.rules
-
Rules that perform logical transformations on relational expressions.
- correctRoundedFloat(String) - Static method in class org.apache.calcite.util.TestUtil
-
Removes floating-point rounding errors from the end of a string.
- correl(List<RelDataTypeField>, CorrelationId) - Method in class org.apache.calcite.piglet.PigRelBuilder
-
Makes the correlated expression from rel input fields and correlation id.
- CORREL_PREFIX - Static variable in class org.apache.calcite.plan.RelOptQuery
-
Prefix to the name of correlating variables.
- CORREL_PREFIX - Static variable in class org.apache.calcite.rel.core.CorrelationId
-
Prefix to the name of correlating variables.
- CORREL_VARIABLE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Reference to correlation variable.
- correlate(JoinRelType, CorrelationId, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Correlate
with aCorrelationId
and a list of fields that are used by correlation. - correlate(JoinRelType, CorrelationId, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Correlate
with aCorrelationId
and an array of fields that are used by correlation. - Correlate - Class in org.apache.calcite.rel.core
-
A relational operator that performs nested-loop joins.
- Correlate(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RelNode, CorrelationId, ImmutableBitSet, JoinRelType) - Constructor for class org.apache.calcite.rel.core.Correlate
-
Creates a Correlate.
- Correlate(RelOptCluster, RelTraitSet, RelNode, RelNode, CorrelationId, ImmutableBitSet, JoinRelType) - Constructor for class org.apache.calcite.rel.core.Correlate
-
Deprecated.
- Correlate(RelInput) - Constructor for class org.apache.calcite.rel.core.Correlate
-
Creates a Correlate by parsing serialized output.
- CORRELATE - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
Correlate
nodes. - CORRELATE_BATCH_JOIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CORRELATE_JOIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CORRELATE_LEFT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts a
Correlate
to empty if its left child is empty. - CORRELATE_RIGHT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts a
Correlate
to empty if its right child is empty. - correlateBatchJoin(JoinType, Enumerable<TSource>, Function1<List<TSource>, Enumerable<TInner>>, Function2<TSource, TInner, TResult>, Predicate2<TSource, TInner>, int) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Fetches blocks of size
batchSize
fromouter
, storing each block into a list (outerValues
). - correlateFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- correlateJoin(JoinType, Enumerable<TSource>, Function1<TSource, Enumerable<TInner>>, Function2<TSource, ? super TInner, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
For each row of the
outer
enumerable returns the correlated rows from theinner
enumerable. - correlateJoin(JoinType, Function1<T, Enumerable<TInner>>, Function2<T, TInner, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- correlateJoin(JoinType, Function1<TSource, Enumerable<TInner>>, Function2<TSource, TInner, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
For each row of the current enumerable returns the correlated rows from the
inner
enumerable (nested loops join). - CorrelateProjectExtractor - Class in org.apache.calcite.sql2rel
- CorrelateProjectExtractor(RelBuilderFactory) - Constructor for class org.apache.calcite.sql2rel.CorrelateProjectExtractor
- correlationColumns(CorrelationId, RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Finds which columns of a correlation variable are used within a relational expression.
- correlationId - Variable in class org.apache.calcite.rel.core.Correlate
- correlationId - Variable in class org.apache.calcite.rel.mutable.MutableCorrelate
- CorrelationId - Class in org.apache.calcite.rel.core
-
Describes the necessary parameters for an implementation in order to identify and set dynamic variables.
- CorrelationId(int) - Constructor for class org.apache.calcite.rel.core.CorrelationId
-
Creates a correlation identifier.
- CorrelationId(String) - Constructor for class org.apache.calcite.rel.core.CorrelationId
-
Creates a correlation identifier from a name.
- correlationIds() - Method in interface org.apache.calcite.rel.RelNode.Context
- correlationIds() - Method in class org.apache.calcite.rel.RelValidityChecker
- CorrelationReferenceFinder - Class in org.apache.calcite.sql2rel
-
Shuttle that finds references to a given
CorrelationId
within a tree ofRelNode
s. - CorrelationReferenceFinder() - Constructor for class org.apache.calcite.sql2rel.CorrelationReferenceFinder
-
Creates CorrelationReferenceFinder.
- correlTableMap - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor
- cos(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
COS
operator applied to double values. - cos(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
COS
operator applied to BigDecimal values. - COS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
COS(numeric)
function. - cosd(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
COSD
operator applied to double values. - cosd(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
COSD
operator applied to BigDecimal values. - COSD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COSD - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
COSD(numeric)
function; returns the cosine ofvalue
. - cosh(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
COSH
operator applied to double values. - cosh(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
COSH
operator applied to BigDecimal values. - COSH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COSH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- COST_MULTIPLIER - Static variable in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
-
Cost of an enumerable node versus implementing an equivalent node in a "typical" calling convention.
- COST_MULTIPLIER - Static variable in class org.apache.calcite.adapter.jdbc.JdbcConvention
-
Cost of a JDBC node versus implementing an equivalent node in a "typical" calling convention.
- COST_MULTIPLIER - Static variable in enum org.apache.calcite.interpreter.BindableConvention
-
Cost of a bindable node versus implementing an equivalent node in a "typical" calling convention.
- costFactory - Variable in class org.apache.calcite.plan.AbstractRelOptPlanner
- costFactory(RelOptCostFactory) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- cot(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
COT
operator applied to double values. - cot(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
COT
operator applied to BigDecimal values. - COT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
COT(numeric)
function. - coth(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
COTH
operator applied to double values. - coth(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
COTH
operator applied to BigDecimal values. - COTH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- COTH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "COTH(value)" function; returns the hyperbolic cotangent of
value
. - count() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- count() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the number of elements in a sequence.
- count() - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope.Resolved
- count() - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.ResolvedImpl
- count(boolean, String, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
COUNT
aggregate function, optionally distinct and with an alias. - count(boolean, String, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
COUNT
aggregate function, optionally distinct and with an alias. - count(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
COUNT
aggregate function. - count(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the number of elements in a sequence.
- count(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns a number that represents how many elements in the specified sequence satisfy a condition.
- count(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- count(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns a number that represents how many elements in the specified sequence satisfy a condition.
- count(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the number of elements in a sequence.
- count(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the number of elements in a sequence.
- count(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- count(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the number of elements in the specified sequence that satisfies a condition.
- count(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the number of elements in the specified sequence that satisfies a condition.
- count(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- count(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- count(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns the number of elements in the specified sequence that satisfies a condition.
- count(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
COUNT
aggregate function. - COUNT - Enum constant in enum org.apache.calcite.adapter.pig.PigAggFunction
- COUNT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
COUNT
aggregate function. - COUNT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
COUNT
aggregate function. - COUNT_STAR - Enum constant in enum org.apache.calcite.adapter.pig.PigAggFunction
- COUNTIF - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
COUNTIF
aggregate function. - COUNTIF - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "COUNTIF(condition) [OVER (...)]" function, in BigQuery, returns the count of TRUE values for expression.
- CountingFactory - Class in org.apache.calcite.test.catalog
- CountingSearchResultListener(boolean) - Constructor for class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.CountingSearchResultListener
- countJoins(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns the number of
Join
nodes in a tree. - countPoints(RangeSet<C>) - Static method in class org.apache.calcite.util.RangeSets
-
Returns the number of ranges in a range set that are points.
- CountriesTableFunction - Class in org.apache.calcite.test.schemata.countries
-
A table function that returns all countries in the world.
- country - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Place
- CountSplitter() - Constructor for class org.apache.calcite.sql.SqlSplittableAggFunction.CountSplitter
- countSql(ImmutableBitSet) - Method in class org.apache.calcite.materialize.Lattice
-
Returns a SQL query that counts the number of distinct values of the attributes given in
groupSet
. - countStar(String) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
COUNT(*)
aggregate function. - COVAR_AVG_AGG_FUNCTIONS - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of SqlCovarAggFunction.
- COVAR_POP - Enum constant in enum org.apache.calcite.sql.fun.SqlCovarAggFunction.Subtype
-
Deprecated.
- COVAR_POP - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
COVAR_POP
aggregate function. - COVAR_POP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
COVAR_POP
aggregate function. - COVAR_REGR_FUNCTION - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- COVAR_SAMP - Enum constant in enum org.apache.calcite.sql.fun.SqlCovarAggFunction.Subtype
-
Deprecated.
- COVAR_SAMP - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
COVAR_SAMP
aggregate function. - COVAR_SAMP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
COVAR_SAMP
aggregate function. - CPU_INFO - Enum constant in enum org.apache.calcite.adapter.os.OsQueryType
- CPU_TIME - Enum constant in enum org.apache.calcite.adapter.os.OsQueryType
- CpuInfoTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "cpu_info".
- CpuTimeTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "cpu_info".
- CqlToSqlTypeConversionRules - Class in org.apache.calcite.adapter.cassandra
-
CqlToSqlTypeConversionRules defines mappings from CQL types to corresponding SQL types.
- CqlToSqlTypeConversionRules() - Constructor for class org.apache.calcite.adapter.cassandra.CqlToSqlTypeConversionRules
- create() - Method in class org.apache.calcite.linq4j.MemoryFactory
- create() - Static method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Creates visitor that uses default optimizer.
- create() - Static method in class org.apache.calcite.rel.externalize.RelJson
-
Creates a RelJson.
- create() - Static method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- create(Reader, SqlParser.Config) - Static method in class org.apache.calcite.sql.parser.SqlParser
-
Creates a
SqlParser
to parse the given string using the parser implementation created from givenSqlParserImplFactory
with given quoting syntax and casing policies for identifiers. - create(Class) - Method in interface org.apache.calcite.linq4j.tree.TableExpressionFactory
-
Creates
Expression
to be used in generated code for accessing table data. - create(Class<?>) - Static method in class org.apache.calcite.schema.impl.AggregateFunctionImpl
-
Creates an aggregate function, or returns null.
- create(Class<?>) - Static method in class org.apache.calcite.schema.impl.TableFunctionImpl
-
Creates a
TableFunctionImpl
from a class, looking for an "eval" method. - create(Class<?>) - Static method in class org.apache.calcite.schema.impl.TableMacroImpl
-
Creates a
TableMacro
from a class, looking for an "eval" method. - create(Class<?>, String) - Static method in class org.apache.calcite.schema.impl.ScalarFunctionImpl
-
Creates
ScalarFunction
from given class. - create(Class<?>, String) - Static method in class org.apache.calcite.schema.impl.TableFunctionImpl
-
Creates a
TableFunctionImpl
from a class, looking for a method with a given name. - create(Class<? extends ClassDeclarationFinder>) - Static method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Creates visitor that uses given class as optimizer.
- create(Method) - Static method in class org.apache.calcite.schema.impl.ScalarFunctionImpl
-
Creates
ScalarFunction
from given method. - create(Method) - Static method in class org.apache.calcite.schema.impl.TableFunctionImpl
-
Creates a
TableFunctionImpl
from a method. - create(Method) - Static method in class org.apache.calcite.schema.impl.TableMacroImpl
-
Creates a
TableMacro
from a method. - create(String) - Static method in class org.apache.calcite.sql.parser.SqlParser
-
Creates a
SqlParser
to parse the given string using Calcite's parser implementation. - create(String) - Static method in class org.apache.calcite.sql.SqlAccessType
- create(String) - Static method in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Creates a frame type.
- create(String[]) - Static method in class org.apache.calcite.sql.SqlAccessType
- create(String, QueryType, List<Object>, ComparisonOperator, ComparisonOperator, List<Object>, List<Object>) - Static method in class org.apache.calcite.adapter.innodb.IndexCondition
-
Creates a new instance for code generation to build query parameters for underlying storage engine
Innodb-java-reader
. - create(String, SqlParser.Config) - Static method in class org.apache.calcite.sql.parser.SqlParser
-
Creates a
SqlParser
to parse the given string using the parser implementation created from givenSqlParserImplFactory
with given quoting syntax and casing policies for identifiers. - create(String, SqlKind, SqlReturnTypeInference, SqlOperandTypeChecker) - Static method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
-
Creates a SqlBasicAggFunction.
- create(String, SqlKind, SqlReturnTypeInference, SqlOperandTypeChecker) - Static method in class org.apache.calcite.sql.SqlBasicFunction
-
Creates a
SqlBasicFunction
. - create(String, SqlReturnTypeInference, SqlOperandTypeChecker) - Static method in class org.apache.calcite.sql.SqlBasicFunction
-
Creates a
SqlBasicFunction
with kindSqlKind.OTHER_FUNCTION
and categorySqlFunctionCategory.NUMERIC
. - create(String, SqlReturnTypeInference, SqlOperandTypeChecker, SqlFunctionCategory) - Static method in class org.apache.calcite.sql.SqlBasicFunction
-
Creates a
SqlBasicFunction
with kindSqlKind.OTHER_FUNCTION
. - create(DatabaseMetaData) - Static method in class org.apache.calcite.sql.SqlDialect
-
Deprecated.Replaced by
SqlDialectFactory
- create(DatabaseMetaData) - Method in interface org.apache.calcite.sql.SqlDialectFactory
-
Creates a
SqlDialect
from a DatabaseMetaData. - create(DatabaseMetaData) - Method in class org.apache.calcite.sql.SqlDialectFactoryImpl
- create(List<String>) - Method in class org.apache.calcite.chinook.ChinookAvaticaServer.CalciteChinookMetaFactory
- create(List<String>) - Method in class org.apache.calcite.chinook.ChinookAvaticaServer.RawChinookMetaFactory
- create(List<RelNode>, boolean) - Static method in class org.apache.calcite.rel.logical.LogicalIntersect
-
Creates a LogicalIntersect.
- create(List<RelNode>, boolean) - Static method in class org.apache.calcite.rel.logical.LogicalMinus
-
Creates a LogicalMinus.
- create(List<RelNode>, boolean) - Static method in class org.apache.calcite.rel.logical.LogicalUnion
-
Creates a LogicalUnion.
- create(Map<String, Object>) - Method in class org.apache.calcite.rel.externalize.RelJson
- create(Map<String, FormatElement>) - Static method in class org.apache.calcite.util.format.FormatModels
-
Creates a
FormatModel
that uses the provided map to identifyFormatElement
s while parsing a format string. - create(JdbcConvention) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcAggregateRule
-
Creates a JdbcAggregateRule.
- create(JdbcConvention) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcFilterRule
-
Creates a JdbcFilterRule.
- create(JdbcConvention) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcIntersectRule
-
Creates a JdbcIntersectRule.
- create(JdbcConvention) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcJoinRule
-
Creates a JdbcJoinRule.
- create(JdbcConvention) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcMinusRule
-
Creates a JdbcMinusRule.
- create(JdbcConvention) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcProjectRule
-
Creates a JdbcProjectRule.
- create(JdbcConvention) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcSortRule
-
Creates a JdbcSortRule.
- create(JdbcConvention) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcTableModificationRule
-
Creates a JdbcToEnumerableConverterRule.
- create(JdbcConvention) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcUnionRule
-
Creates a JdbcUnionRule.
- create(JdbcConvention) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcValuesRule
-
Creates a JdbcValuesRule.
- create(JdbcConvention) - Static method in class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverterRule
-
Creates a JdbcToEnumerableConverterRule.
- create(JdbcConvention) - Static method in class org.apache.calcite.adapter.spark.JdbcToSparkConverterRule
-
Creates a JdbcToSparkConverterRule.
- create(ColumnMetaData.AvaticaType, Iterable<Object>) - Method in class org.apache.calcite.jdbc.CalciteResultSet
- create(CalciteConnection) - Static method in class org.apache.calcite.jdbc.CalciteMetaImpl
-
Creates a CalciteMetaImpl.
- create(CalciteConnection, CalciteMetaTableFactory, CalciteMetaColumnFactory) - Static method in class org.apache.calcite.jdbc.CalciteMetaImpl
-
Creates a CalciteMetaImpl.
- create(CalciteSchema, String, boolean) - Static method in class org.apache.calcite.materialize.Lattice
-
Creates a Lattice.
- create(CalciteSchema, String, List<String>, List<String>, String, boolean) - Static method in class org.apache.calcite.schema.impl.MaterializedViewTable
-
Table macro that returns a materialized view.
- create(Function1<ClassDeclarationFinder, ClassDeclarationFinder>) - Static method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Creates visitor that uses given factory to create optimizers.
- create(Statement, BlockStatement) - Static method in class org.apache.calcite.linq4j.tree.Blocks
-
Prepends a statement to a block.
- create(RelOptSchema, RelDataType, List<String>, Expression) - Static method in class org.apache.calcite.prepare.RelOptTableImpl
- create(RelOptSchema, RelDataType, List<String>, Table, Expression) - Static method in class org.apache.calcite.prepare.RelOptTableImpl
-
Deprecated.
- create(RelOptSchema, RelDataType, List<String>, Table, TableExpressionFactory) - Static method in class org.apache.calcite.prepare.RelOptTableImpl
-
Creates
RelOptTableImpl
instance with specified arguments and row count obtained from table statistic. - create(RelOptSchema, RelDataType, CalciteSchema.TableEntry, Double) - Static method in class org.apache.calcite.prepare.RelOptTableImpl
- create(RelOptSchema, RelDataType, Table, ImmutableList<String>) - Static method in class org.apache.calcite.prepare.RelOptTableImpl
- create(RelOptSchema, RelDataType, Table, Path) - Static method in class org.apache.calcite.prepare.RelOptTableImpl
- create(Context) - Method in interface org.apache.calcite.sql.test.SqlTestFactory.PlannerFactory
- create(RelOptCluster, List<RelNode>, RexNode, Type, RelDataType, Set<RelColumnMapping>) - Static method in class org.apache.calcite.rel.logical.LogicalTableFunctionScan
-
Creates a LogicalTableFunctionScan.
- create(RelOptCluster, RelOptSchema) - Method in interface org.apache.calcite.tools.RelBuilderFactory
-
Creates a RelBuilder.
- create(RelOptCluster, RelOptTable) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
-
Creates an EnumerableTableScan.
- create(RelOptCluster, RelOptTable) - Static method in class org.apache.calcite.interpreter.Bindables.BindableTableScan
-
Creates a BindableTableScan.
- create(RelOptCluster, RelOptTable, List<RelHint>) - Static method in class org.apache.calcite.rel.logical.LogicalTableScan
-
Creates a LogicalTableScan.
- create(RelOptCluster, RelOptTable, List<RexNode>, List<Integer>) - Static method in class org.apache.calcite.interpreter.Bindables.BindableTableScan
-
Creates a BindableTableScan.
- create(RelOptCluster, RelTraitSet, RelOptTable, DruidTable, List<RelNode>) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Creates a DruidQuery.
- create(RelOptCluster, RelTraitSet, RelOptTable, DruidTable, List<RelNode>, Map<SqlOperator, DruidSqlOperatorConverter>) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Creates a DruidQuery.
- create(RelOptCluster, RelTraitSet, RelNode, RelDataType, RexNode, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, ImmutableBitSet, RelCollation, RexNode) - Static method in class org.apache.calcite.rel.logical.LogicalMatch
-
Creates a LogicalMatch.
- create(RelOptCluster, RelTraitSet, RelNode, RexNode, IndexCondition, TableDef, String) - Static method in class org.apache.calcite.adapter.innodb.InnodbFilter
-
Creates an InnodbFilter.
- create(RelOptCluster, RelTraitSet, RelBuilder, RelNode, RexProgram) - Static method in class org.apache.calcite.rel.logical.LogicalWindow
-
Creates a LogicalWindow by parsing a
RexProgram
. - create(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableValues
-
Creates an EnumerableValues.
- create(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>) - Static method in class org.apache.calcite.rel.logical.LogicalValues
-
Creates a LogicalValues.
- create(RelOptPlanner, RexBuilder) - Static method in class org.apache.calcite.plan.RelOptCluster
-
Creates a cluster.
- create(RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean) - Static method in class org.apache.calcite.rel.logical.LogicalTableModify
-
Creates a LogicalTableModify.
- create(RelTraitSet, RelNode, boolean) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableUncollect
-
Creates an EnumerableUncollect.
- create(RelTraitSet, RelNode, boolean, List<String>) - Static method in class org.apache.calcite.rel.core.Uncollect
-
Creates an Uncollect.
- create(RelTraitSet, RelNode, List<RexLiteral>, RelDataType, List<Window.Group>) - Static method in class org.apache.calcite.rel.logical.LogicalWindow
-
Creates a LogicalWindow.
- create(MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRuleCall
-
Creates a
SubstitutionVisitor.UnifyRuleCall
based on the parent ofquery
. - create(RelCollation, List<RelNode>, boolean) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableMergeUnion
- create(RelInput) - Static method in class org.apache.calcite.rex.RexProgram
-
Create a program from serialized output.
- create(RelNode) - Static method in class org.apache.calcite.rel.stream.LogicalDelta
-
Creates a LogicalDelta.
- create(RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Static method in class org.apache.calcite.rel.logical.LogicalAggregate
-
Deprecated.
- create(RelNode, double) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableInterpreter
-
Creates an EnumerableInterpreter.
- create(RelNode, List<? extends RexNode>, RelDataType) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableProject
-
Creates an EnumerableProject, specifying row type rather than field names.
- create(RelNode, List<RelHint>, List<? extends RexNode>, List<? extends String>) - Static method in class org.apache.calcite.rel.logical.LogicalProject
-
Deprecated.
- create(RelNode, List<RelHint>, List<? extends RexNode>, List<? extends String>, Set<CorrelationId>) - Static method in class org.apache.calcite.rel.logical.LogicalProject
-
Creates a LogicalProject.
- create(RelNode, List<RelHint>, List<? extends RexNode>, RelDataType) - Static method in class org.apache.calcite.rel.logical.LogicalProject
-
Deprecated.
- create(RelNode, List<RelHint>, List<? extends RexNode>, RelDataType, Set<CorrelationId>) - Static method in class org.apache.calcite.rel.logical.LogicalProject
-
Creates a LogicalProject, specifying row type rather than field names.
- create(RelNode, List<RelHint>, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Static method in class org.apache.calcite.rel.logical.LogicalAggregate
-
Creates a LogicalAggregate.
- create(RelNode, Spool.Type, Spool.Type, RelOptTable) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableTableSpool
-
Creates an EnumerableTableSpool.
- create(RelNode, Spool.Type, Spool.Type, RelOptTable) - Static method in class org.apache.calcite.rel.logical.LogicalTableSpool
-
Creates a LogicalTableSpool.
- create(RelNode, RelCollation, RexNode, RexNode) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableLimitSort
-
Creates an EnumerableLimitSort.
- create(RelNode, RelCollation, RexNode, RexNode) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableSort
-
Creates an EnumerableSort.
- create(RelNode, RelCollation, RexNode, RexNode) - Static method in class org.apache.calcite.rel.logical.LogicalSort
-
Creates a LogicalSort.
- create(RelNode, RelDistribution) - Static method in class org.apache.calcite.rel.logical.LogicalExchange
-
Creates a LogicalExchange.
- create(RelNode, RelDistribution, RelCollation) - Static method in class org.apache.calcite.rel.logical.LogicalSortExchange
-
Creates a LogicalSortExchange.
- create(RelNode, RelNode, boolean, int, RelOptTable) - Static method in class org.apache.calcite.rel.logical.LogicalRepeatUnion
-
Creates a LogicalRepeatUnion.
- create(RelNode, RelNode, boolean, RelOptTable) - Static method in class org.apache.calcite.rel.logical.LogicalRepeatUnion
-
Creates a LogicalRepeatUnion.
- create(RelNode, RelNode, List<RelHint>, CorrelationId, ImmutableBitSet, JoinRelType) - Static method in class org.apache.calcite.rel.logical.LogicalCorrelate
-
Creates a LogicalCorrelate.
- create(RelNode, RelNode, List<RelHint>, RexNode, Set<CorrelationId>, JoinRelType) - Static method in class org.apache.calcite.rel.logical.LogicalJoin
-
Creates a LogicalJoin.
- create(RelNode, RelNode, List<RelHint>, RexNode, Set<CorrelationId>, JoinRelType, boolean, ImmutableList<RelDataTypeField>) - Static method in class org.apache.calcite.rel.logical.LogicalJoin
-
Creates a LogicalJoin, flagged with whether it has been translated to a semi-join.
- create(RelNode, RelNode, List<RelHint>, RexNode, RexNode, JoinRelType, ImmutableList<RelDataTypeField>) - Static method in class org.apache.calcite.rel.logical.LogicalAsofJoin
-
Creates a LogicalAsofJoin.
- create(RelNode, RelNode, CorrelationId, ImmutableBitSet, JoinRelType) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableCorrelate
-
Creates an EnumerableCorrelate.
- create(RelNode, RelNode, CorrelationId, ImmutableBitSet, JoinRelType) - Static method in class org.apache.calcite.rel.logical.LogicalCorrelate
-
Deprecated.
- create(RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableHashJoin
-
Creates an EnumerableHashJoin.
- create(RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableNestedLoopJoin
-
Creates an EnumerableNestedLoopJoin.
- create(RelNode, RelNode, RexNode, RexNode, Set<CorrelationId>, JoinRelType) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableAsofJoin
-
Creates an EnumerableAsofJoin.
- create(RelNode, RelNode, RexNode, ImmutableBitSet, Set<CorrelationId>, JoinRelType) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoin
- create(RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList, JoinRelType) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableMergeJoin
- create(RelNode, RelDataType) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableCollect
-
Creates an EnumerableCollect.
- create(RelNode, RelDataType) - Static method in class org.apache.calcite.rel.core.Collect
-
Creates a Collect.
- create(RelNode, RelDataType, RexNode, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, ImmutableBitSet, RelCollation, RexNode) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableMatch
-
Creates an EnumerableMatch.
- create(RelNode, RelDataType, RexNode, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, ImmutableBitSet, RelCollation, RexNode) - Static method in class org.apache.calcite.rel.logical.LogicalMatch
-
Creates a LogicalMatch.
- create(RelNode, RexNode, RexNode) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableLimit
-
Creates an EnumerableLimit.
- create(RelNode, RexNode) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableFilter
-
Creates an EnumerableFilter.
- create(RelNode, RexNode) - Static method in class org.apache.calcite.interpreter.Bindables.BindableFilter
-
Creates a BindableFilter.
- create(RelNode, RexNode) - Static method in class org.apache.calcite.rel.logical.LogicalFilter
-
Creates a LogicalFilter.
- create(RelNode, RexNode) - Static method in class org.apache.calcite.rel.logical.LogicalSnapshot
-
Creates a LogicalSnapshot.
- create(RelNode, RexNode, ImmutableSet<CorrelationId>) - Static method in class org.apache.calcite.rel.logical.LogicalFilter
-
Creates a LogicalFilter.
- create(RelNode, RexProgram) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableCalc
-
Creates an EnumerableCalc.
- create(RelNode, RexProgram) - Static method in class org.apache.calcite.rel.logical.LogicalCalc
- create(RelNode, SqlKind, String) - Static method in class org.apache.calcite.rel.core.Collect
-
Creates a Collect.
- create(RelNode, SqlTypeName, String) - Static method in class org.apache.calcite.rel.core.Collect
-
Deprecated.
- create(RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Static method in class org.apache.calcite.rel.logical.LogicalAggregate
-
Deprecated.
- create(RelDataTypeFactory, boolean) - Method in interface org.apache.calcite.sql.test.SqlTestFactory.CatalogReaderFactory
- create(RelDataTypeFactory, boolean) - Static method in class org.apache.calcite.test.catalog.MockCatalogReaderDynamic
-
Creates and initializes a MockCatalogReaderDynamic.
- create(RelDataTypeFactory, boolean) - Static method in class org.apache.calcite.test.catalog.MockCatalogReaderExtended
-
Creates and initializes a MockCatalogReaderExtended.
- create(RelDataTypeFactory, boolean) - Static method in class org.apache.calcite.test.catalog.MockCatalogReaderSimple
-
Creates and initializes a MockCatalogReaderSimple.
- create(RelDataTypeFactory, boolean) - Static method in class org.apache.calcite.test.catalog.MustFilterMockCatalogReader
- create(RelDataTypeFactory, RexCall, List<RelCollation>) - Static method in class org.apache.calcite.rex.RexCallBinding
-
Creates a binding of the appropriate type.
- create(RelDataTypeFactory, RexCall, RexProgram, List<RelCollation>) - Static method in class org.apache.calcite.rex.RexCallBinding
-
Creates a binding of the appropriate type, optionally with a program.
- create(RelDataTypeFactory, SqlValidator) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercionFactory
-
Creates a TypeCoercion.
- create(RelDataType, List<? extends RexNode>, RexNode, List<? extends String>, RexBuilder) - Static method in class org.apache.calcite.rex.RexProgram
-
Creates a program which calculates projections and filters rows based upon a condition.
- create(RelDataType, List<? extends RexNode>, RexNode, RelDataType, RexBuilder) - Static method in class org.apache.calcite.rex.RexProgram
-
Creates a program which calculates projections and filters rows based upon a condition.
- create(RexBuilder, RelDataType, List<RexNode>, List<? extends RexNode>, RexNode, RelDataType, boolean) - Static method in class org.apache.calcite.rex.RexProgramBuilder
-
Deprecated.
- create(RexBuilder, RelDataType, List<RexNode>, List<? extends RexNode>, RexNode, RelDataType, boolean, boolean) - Static method in class org.apache.calcite.rex.RexProgramBuilder
-
Deprecated.
- create(RexBuilder, RelDataType, List<RexNode>, List<? extends RexNode>, RexNode, RelDataType, boolean, RexSimplify) - Static method in class org.apache.calcite.rex.RexProgramBuilder
-
Creates a program builder with the same contents as a program.
- create(RexBuilder, RelDataType, List<RexNode>, List<RexLocalRef>, RexLocalRef, RelDataType, RexShuttle, boolean) - Static method in class org.apache.calcite.rex.RexProgramBuilder
-
Creates a program builder with the same contents as a program, applying a shuttle first.
- create(SchemaPlus, String, DataSource, String) - Static method in class org.apache.calcite.adapter.jdbc.JdbcCatalogSchema
- create(SchemaPlus, String, DataSource, SqlDialectFactory, String) - Static method in class org.apache.calcite.adapter.jdbc.JdbcCatalogSchema
- create(ViewTable, MockCatalogReader, String, String, String, boolean, double, MockCatalogReader.ColumnResolver) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockRelViewTable
- create(SchemaPlus, String, List<String>, String, String) - Static method in class org.apache.calcite.model.ModelHandler
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.arrow.ArrowSchemaFactory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.cassandra.CassandraSchemaFactory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.clone.CloneSchema.Factory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.csv.CsvSchemaFactory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.druid.DruidSchemaFactory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchemaFactory
-
Create an ElasticSearch
Schema
. - create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.file.FileSchemaFactory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeSchemaFactory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchemaFactory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.innodb.InnodbSchemaFactory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.java.ReflectiveSchema.Factory
- create(SchemaPlus, String, Map<String, Object>) - Static method in class org.apache.calcite.adapter.jdbc.JdbcSchema
-
Creates a JdbcSchema, taking credentials from a map.
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema.Factory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.mongodb.MongoSchemaFactory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.pig.PigSchemaFactory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.redis.RedisSchemaFactory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.tpcds.TpcdsSchemaFactory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.tpch.TpchSchemaFactory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.schema.impl.AbstractSchema.Factory
- create(SchemaPlus, String, Map<String, Object>) - Method in interface org.apache.calcite.schema.SchemaFactory
-
Creates a Schema.
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.adapter.csv.CsvStreamTableFactory
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.adapter.csv.CsvTableFactory
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.adapter.file.CsvTableFactory
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.adapter.kafka.KafkaTableFactory
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.adapter.pig.PigTableFactory
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.chinook.PreferredAlbumsTableFactory
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.chinook.PreferredGenresTableFactory
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in interface org.apache.calcite.schema.TableFactory
-
Creates a Table.
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.test.schemata.orderstream.InfiniteOrdersStreamTableFactory
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.test.schemata.orderstream.OrdersStreamTableFactory
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.test.schemata.orderstream.ProductsTableFactory
- create(SchemaPlus, String, Map, RelDataType) - Method in class org.apache.calcite.adapter.druid.DruidTableFactory
- create(SchemaPlus, String, Map, RelDataType) - Method in class org.apache.calcite.adapter.redis.RedisTableFactory
- create(SchemaPlus, String, DataSource, String, String) - Static method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- create(SchemaPlus, String, DataSource, SqlDialectFactory, String, String) - Static method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- create(SqlIdentifier, SqlIdentifier, SqlNodeList, SqlNodeList, SqlLiteral, SqlNode, SqlNode, SqlLiteral, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlWindow
- create(SqlIdentifier, SqlIdentifier, SqlNodeList, SqlNodeList, SqlLiteral, SqlNode, SqlNode, SqlLiteral, SqlLiteral, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlWindow
- create(SqlParserPos, SqlAggFunction, boolean, boolean, boolean, List<RexNode>, List<Integer>, int, ImmutableBitSet, RelCollation, int, RelNode, RelDataType, String) - Static method in class org.apache.calcite.rel.core.AggregateCall
- create(SqlParserPos, SqlAggFunction, boolean, boolean, boolean, List<RexNode>, List<Integer>, int, ImmutableBitSet, RelCollation, RelDataType, String) - Static method in class org.apache.calcite.rel.core.AggregateCall
- create(SqlAggFunction, boolean, boolean, boolean, List<Integer>, int, RelCollation, RelDataType, String) - Static method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- create(SqlAggFunction, boolean, boolean, boolean, List<Integer>, int, ImmutableBitSet, RelCollation, int, RelNode, RelDataType, String) - Static method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- create(SqlAggFunction, boolean, boolean, boolean, List<RexNode>, List<Integer>, int, ImmutableBitSet, RelCollation, int, RelNode, RelDataType, String) - Static method in class org.apache.calcite.rel.core.AggregateCall
-
Creates an AggregateCall, inferring its type if
type
is null. - create(SqlAggFunction, boolean, boolean, boolean, List<RexNode>, List<Integer>, int, ImmutableBitSet, RelCollation, RelDataType, String) - Static method in class org.apache.calcite.rel.core.AggregateCall
-
Creates an AggregateCall.
- create(SqlAggFunction, boolean, boolean, List<Integer>, int, int, RelNode, RelDataType, String) - Static method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- create(SqlAggFunction, boolean, boolean, List<Integer>, int, RelCollation, int, RelNode, RelDataType, String) - Static method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- create(SqlAggFunction, boolean, boolean, List<Integer>, int, RelCollation, RelDataType, String) - Static method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- create(SqlAggFunction, boolean, boolean, List<Integer>, int, RelDataType, String) - Static method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- create(SqlAggFunction, boolean, List<Integer>, int, int, RelNode, RelDataType, String) - Static method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- create(SqlAggFunction, boolean, List<Integer>, int, RelNode, RelDataType, String) - Static method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- create(SqlAggFunction, boolean, List<Integer>, int, RelDataType, String) - Static method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- create(SqlKind, SqlReturnTypeInference, SqlOperandTypeChecker) - Static method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
-
Creates a SqlBasicAggFunction whose name is the same as its kind.
- create(SqlKind, SqlReturnTypeInference, SqlOperandTypeChecker) - Static method in class org.apache.calcite.sql.SqlBasicFunction
-
Creates a
SqlBasicFunction
whose name is the same as its kind and whose categorySqlFunctionCategory.SYSTEM
. - create(SqlNode) - Static method in enum org.apache.calcite.rex.RexWindowExclusion
-
Creates a window exclusion from a
SqlNode
. - create(SqlNode, RexNode) - Static method in class org.apache.calcite.rex.RexWindowBounds
-
Creates a window bound from a
SqlNode
. - create(SqlNode, RexNode) - Static method in class org.apache.calcite.rex.RexWindowBound
-
Deprecated.
- create(SqlOperatorTable, SqlValidatorCatalogReader, RelDataTypeFactory, SqlValidator.Config) - Method in interface org.apache.calcite.sql.test.SqlTestFactory.ValidatorFactory
- create(SqlValidatorScope, int, SqlValidatorNamespace, SqlIdentifier) - Static method in class org.apache.calcite.sql.validate.SqlQualified
- create(SqlConformance, RelDataTypeSystem) - Method in interface org.apache.calcite.sql.test.SqlTestFactory.TypeFactoryFactory
- create(MockCatalogReader.MockModifiableViewRelOptTable.MockModifiableViewTable, MockCatalogReader, String, String, String, boolean, double, MockCatalogReader.ColumnResolver) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable
- create(MockCatalogReader, List<String>, boolean, double) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- create(MockCatalogReader, MockCatalogReader.MockSchema, String, boolean, double) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- create(MockCatalogReader, MockCatalogReader.MockSchema, String, boolean, double, double) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- create(MockCatalogReader, MockCatalogReader.MockSchema, String, boolean, double, MockCatalogReader.ColumnResolver) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- create(MockCatalogReader, MockCatalogReader.MockSchema, String, boolean, double, MockCatalogReader.ColumnResolver, double) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- create(MockCatalogReader, MockCatalogReader.MockSchema, String, boolean, double, MockCatalogReader.ColumnResolver, InitializerExpressionFactory, boolean) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- create(MockCatalogReader, MockCatalogReader.MockSchema, String, boolean, double, MockCatalogReader.ColumnResolver, InitializerExpressionFactory, boolean, Double) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- create(MockCatalogReader, MockCatalogReader.MockSchema, String, boolean, double, MockCatalogReader.ColumnResolver, InitializerExpressionFactory, boolean, Map<String, String>) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MustFilterMockTable
-
Creates a MustFilterMockTable.
- create(FrameworkConfig) - Static method in class org.apache.calcite.piglet.PigConverter
-
Creates a PigConverter using default property settings.
- create(FrameworkConfig) - Static method in class org.apache.calcite.piglet.PigRelBuilder
-
Creates a PigRelBuilder.
- create(FrameworkConfig) - Static method in class org.apache.calcite.tools.PigRelBuilder
-
Creates a PigRelBuilder.
- create(FrameworkConfig) - Static method in class org.apache.calcite.tools.RelBuilder
-
Creates a RelBuilder.
- create(FrameworkConfig, Properties) - Static method in class org.apache.calcite.piglet.PigConverter
-
Creates a PigConverter using the given property settings.
- create(Hoist.Config) - Static method in class org.apache.calcite.tools.Hoist
-
Creates a Hoist.
- create(RelBuilderFactory) - Static method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewOnlyAggregateRule.Config
- create(RelBuilderFactory) - Static method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewProjectAggregateRule.Config
- create(AttributedDirectedGraph.AttributedEdgeFactory<V, E>) - Static method in class org.apache.calcite.util.graph.AttributedDirectedGraph
- create(DirectedGraph.EdgeFactory<V, E>) - Static method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- create(MappingType, int, int) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Creates a mapping with required properties.
- CREATE_ENRICHER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CREATE_FOREIGN_SCHEMA - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CREATE FOREIGN SCHEMA
DDL statement. - CREATE_FUNCTION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CREATE FUNCTION
DDL statement. - CREATE_INDEX - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CREATE INDEX
DDL statement. - CREATE_MATERIALIZATION - Enum constant in enum org.apache.calcite.runtime.Hook
-
Called when materialization is created.
- CREATE_MATERIALIZATIONS - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether Calcite should create materializations.
- CREATE_MATERIALIZED_VIEW - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CREATE MATERIALIZED VIEW
DDL statement. - CREATE_RDD - Enum constant in enum org.apache.calcite.adapter.spark.SparkMethod
- CREATE_SCHEMA - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CREATE SCHEMA
DDL statement. - CREATE_SEQUENCE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CREATE SEQUENCE
DDL statement. - CREATE_TABLE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CREATE TABLE
DDL statement. - CREATE_TABLE_LIKE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CREATE TABLE LIKE
DDL statement. - CREATE_TYPE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CREATE TYPE
DDL statement. - CREATE_VIEW - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CREATE VIEW
DDL statement. - createAccumulatorAdders(ParameterExpression, List<AggImpState>, PhysType, ParameterExpression, PhysType, BlockBuilder, EnumerableRelImplementor, JavaTypeFactory) - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase
- createAdvisor() - Method in class org.apache.calcite.sql.test.SqlTestFactory
- createAggregate(RelNode, List<RelHint>, ImmutableBitSet, ImmutableList<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.adapter.pig.PigRelFactories.PigAggregateFactory
- createAggregate(RelNode, List<RelHint>, ImmutableBitSet, ImmutableList<ImmutableBitSet>, List<AggregateCall>) - Method in interface org.apache.calcite.rel.core.RelFactories.AggregateFactory
-
Creates an aggregate.
- createAggregate(SqlToRelConverter.Blackboard, ImmutableBitSet, ImmutableList<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Creates an Aggregate.
- createAggStateTypes(List<Expression>, BlockBuilder, List<AggImpState>, JavaTypeFactory) - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase
- createAll(Class<?>) - Static method in class org.apache.calcite.schema.impl.ScalarFunctionImpl
-
Deprecated.
- createAllPossibleExpressions(RexBuilder, RexNode, Map<RexInputRef, Set<RexNode>>) - Static method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
-
Given an expression, it will create all equivalent expressions resulting from replacing all possible combinations of references in the mapping by the corresponding expressions.
- createApproxNumeric(String, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
- createArrayType(RelDataTypeFactory, RelDataType, boolean) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- createArrayType(RelDataType, long) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates an array type.
- createArrayType(RelDataType, long) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- createAsFullOperands(RelDataType, SqlNode, String) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Creates operands for a full AS operator.
- createAsofJoin(RelNode, RelNode, List<RelHint>, RexNode, RexNode, JoinRelType) - Method in interface org.apache.calcite.rel.core.RelFactories.AsofJoinFactory
-
Creates an ASOF join.
- createAsofJoin(SqlParserPos, SqlToRelConverter.Blackboard, RelNode, RelNode, RexNode, RexNode, JoinRelType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- createBinaryString(byte[], SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Creates a literal like X'ABAB' from an array of bytes.
- createBinaryString(String, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Creates a literal like X'ABAB'.
- createBinding(Aggregate) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Creates a binding of this call in the context of an
LogicalAggregate
, which can then be used to infer the return type. - createBlackboard(SqlValidatorScope, Map<String, RexNode>, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Factory method for creating translation workspace.
- createBoolean(boolean, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Creates a boolean literal.
- createBound(SqlLiteral) - Static method in class org.apache.calcite.sql.SqlWindow
- createCache() - Static method in class org.apache.calcite.sql.dialect.JethroDataSqlDialect
- createCall(SqlLiteral, SqlParserPos, Iterable<? extends SqlNode>) - Method in class org.apache.calcite.sql.SqlOperator
-
Creates a call to this operator with a list of operands.
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.fun.SqlCaseOperator
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.fun.SqlJsonArrayAggAggFunction
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.fun.SqlJsonArrayFunction
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.fun.SqlJsonObjectFunction
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.fun.SqlJsonQueryFunction
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.fun.SqlTrimFunction
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.SqlAsofJoin.SqlAsofJoinOperator
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.SqlJoin.SqlJoinOperator
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.SqlMatchRecognize.SqlMatchRecognizeOperator
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.SqlNullTreatmentOperator
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.SqlOperator
-
Creates a call to this operator with an array of operands.
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.SqlSelectOperator
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.SqlSetSemanticsTableOperator
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.SqlSnapshot.SqlSnapshotOperator
- createCall(SqlLiteral, SqlParserPos, SqlNodeList) - Static method in class org.apache.calcite.sql.SqlOperator
-
Deprecated.
- createCall(SqlParserPos, List<? extends SqlNode>) - Method in class org.apache.calcite.sql.SqlOperator
-
Creates a call to this operator with a list of operands.
- createCall(SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall.SimpleMakeCall
- createCall(SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.SqlOperator
-
Creates a call to this operator with an array of operands.
- createCall(SqlParserPos, SqlNodeList) - Method in class org.apache.calcite.sql.SqlOperator
-
Deprecated.
- createCall(SqlNodeList) - Method in class org.apache.calcite.sql.SqlOperator
-
Creates a call to this operator with a list of operands contained in a
SqlNodeList
. - createCall(SqlNodeList, SqlNodeList, SqlNode, SqlNode, SqlNodeList, SqlNode, SqlNodeList, SqlNode, SqlNodeList, SqlNode, SqlNode, SqlNodeList, SqlParserPos) - Method in class org.apache.calcite.sql.SqlSelectOperator
-
Deprecated.
- createCall(SqlOperator, SqlParserPos, List<SqlNode>) - Static method in class org.apache.calcite.sql.SqlUtil
-
Creates a call to an operator.
- createCastRel(MutableRel, RelDataType, boolean) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- createCastRel(RelNode, RelDataType, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Creates a projection which casts a rel's output to a desired row type.
- createCastRel(RelNode, RelDataType, boolean, RelFactories.ProjectFactory) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Creates a projection which casts a rel's output to a desired row type.
- createCharString(String, String, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Creates a string literal, with optional character-set.
- createCharString(String, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Creates a string literal in the system character set.
- createChecker(Object) - Static method in class org.apache.calcite.sql.test.ResultCheckers
-
Creates a ResultChecker from an expected result.
- createChecker(Matcher<T>, JdbcType<T>) - Static method in class org.apache.calcite.sql.test.ResultCheckers
-
Creates a ResultChecker that accesses a column of a given type and then uses a Hamcrest matcher to check the value.
- createClientCache(String, int, String, boolean) - Static method in class org.apache.calcite.adapter.geode.util.GeodeUtils
-
Creates a Geode client instance connected to locator and configured to support PDX instances.
- createCloneTable(JavaTypeFactory, RelProtoDataType, List<ColumnMetaData.Rep>, Enumerable<T>) - Static method in class org.apache.calcite.adapter.clone.CloneSchema
-
Deprecated.
- createCloneTable(JavaTypeFactory, RelProtoDataType, List<RelCollation>, List<ColumnMetaData.Rep>, Enumerable<T>) - Static method in class org.apache.calcite.adapter.clone.CloneSchema
- createCluster(RelOptPlanner, RexBuilder) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Factory method for cluster.
- createCluster(RelDataTypeFactory, RexBuilder) - Method in class org.apache.calcite.plan.RelOptQuery
-
Deprecated.
- createColumn(Table, String, String, String, String, int, String, Integer, Integer, int, int, Integer, int, String) - Method in interface org.apache.calcite.jdbc.CalciteMetaColumnFactory
-
Instantiates a MetaColumn.
- createColumn(Table, String, String, String, String, int, String, Integer, Integer, int, int, Integer, int, String) - Method in class org.apache.calcite.jdbc.CalciteMetaColumnFactoryImpl
- createCommandHandler() - Method in class org.apache.calcite.test.QuidemTest
-
Creates a command handler.
- createConnection() - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- createConnection() - Method in interface org.apache.calcite.test.ConnectionFactory
- createConnectionFactory() - Method in class org.apache.calcite.test.QuidemTest
-
Creates a connection factory.
- createContext() - Method in interface org.apache.calcite.interpreter.Compiler
- createContext() - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- createContext(DatabaseMetaData) - Static method in class org.apache.calcite.sql.SqlDialects
-
Extracts information from
DatabaseMetaData
intoSqlDialect.Context
. - createConvertletTable() - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Factory method for default convertlet table.
- createCorrel() - Method in class org.apache.calcite.plan.RelOptCluster
-
Constructs a new id for a correlating variable.
- createCorrel() - Method in class org.apache.calcite.plan.RelOptQuery
-
Deprecated.
- createCorrelate(RelNode, RelNode, List<RelHint>, CorrelationId, ImmutableBitSet, JoinRelType) - Method in interface org.apache.calcite.rel.core.RelFactories.CorrelateFactory
-
Creates a correlate.
- createCurrentRow(SqlParserPos) - Static method in class org.apache.calcite.sql.SqlWindow
- createCurrentRowWindow(String) - Method in class org.apache.calcite.sql.SqlWindow
-
Creates a window
(RANGE columnName CURRENT ROW)
. - createDataContext(Connection, SchemaPlus) - Static method in class org.apache.calcite.schema.Schemas
- createDataContext(CalciteConnection) - Static method in class org.apache.calcite.jdbc.CalciteMetaImpl
-
A trojan-horse method, subject to change without notice.
- createDataType(SqlParserPos) - Method in enum org.apache.calcite.sql.SqlJdbcDataTypeName
-
Creates a parse tree node for a type identifier of this name.
- createDate(Calendar, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Deprecated.
- createDate(DateString, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
- createDecimalProduct(RelDataType, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
- createDecimalProduct(RelDataType, RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
-
Deprecated.
- createDecimalQuotient(RelDataType, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
- createDecimalQuotient(RelDataType, RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
-
Deprecated.
- createDefault(String) - Static method in class org.apache.calcite.adapter.druid.TimeExtractionFunction
-
Creates the default time format extraction function.
- createDialect(DataSource) - Static method in class org.apache.calcite.adapter.jdbc.JdbcSchema
-
Deprecated.
- createDialect(SqlDialectFactory, DataSource) - Static method in class org.apache.calcite.adapter.jdbc.JdbcSchema
-
Returns a suitable SQL dialect for the given data source.
- createDispatcher(Class<R>, Class<E>) - Static method in class org.apache.calcite.util.ReflectUtil
-
Creates a dispatcher for calls to
ReflectUtil.lookupVisitMethod(java.lang.Class<?>, java.lang.Class<?>, java.lang.String)
. - createDistinctRel(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createDmlRowType(SqlKind, RelDataTypeFactory) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Creates the row type descriptor for the result of a DML operation, which is a single column named ROWCOUNT of type BIGINT for INSERT; a single column named PLAN for EXPLAIN.
- createDriverVersion() - Method in class org.apache.calcite.adapter.splunk.SplunkDriver
- createDriverVersion() - Method in class org.apache.calcite.jdbc.Driver
- createEdge(RexNode) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- createEdge(V, V) - Method in interface org.apache.calcite.util.graph.DirectedGraph.EdgeFactory
- createEdge(V, V, Object...) - Method in interface org.apache.calcite.util.graph.AttributedDirectedGraph.AttributedEdgeFactory
- createEmpty() - Static method in class org.apache.calcite.plan.RelTraitSet
-
Creates an empty trait set.
- createEmpty(RelOptCluster, RelDataType) - Static method in class org.apache.calcite.rel.logical.LogicalValues
-
Creates a LogicalValues that outputs no rows of a given row type.
- createEmptyRelOrEquivalent(RelOptRuleCall, Calc) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.CalcReduceExpressionsRule
-
For static schema systems, a filter that is always false or null can be replaced by a values operator that produces no rows, as the schema information can just be taken from the input Rel.
- createEmptyRelOrEquivalent(RelOptRuleCall, Filter) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.FilterReduceExpressionsRule
-
For static schema systems, a filter that is always false or null can be replaced by a values operator that produces no rows, as the schema information can just be taken from the input Rel.
- createEmptyStructType(RelDataTypeFactory) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Records a struct type with no fields.
- createEnricher(Integer[], DataContext) - Static method in class org.apache.calcite.runtime.ResultSetEnumerable
-
Called from generated code that proposes to create a
ResultSetEnumerable
over a prepared statement. - createEquiJoinCondition(RelNode, List<Integer>, RelNode, List<Integer>, RexBuilder) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Builds an equi-join condition from a set of left and right keys.
- createExactNumeric(String, SqlParserPos) - Static method in class org.apache.calcite.piglet.Ast.Literal
- createExactNumeric(String, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
- createExchange(RelNode, RelDistribution) - Method in interface org.apache.calcite.rel.core.RelFactories.ExchangeFactory
-
Creates an Exchange.
- createExcludeCurrentRow(SqlParserPos) - Static method in class org.apache.calcite.sql.SqlWindow
- createExcludeGroup(SqlParserPos) - Static method in class org.apache.calcite.sql.SqlWindow
- createExcludeNoOthers(SqlParserPos) - Static method in class org.apache.calcite.sql.SqlWindow
- createExcludeTies(SqlParserPos) - Static method in class org.apache.calcite.sql.SqlWindow
- createExistsPlan(RelOptCluster, RelNode, List<RexNode>, RexLiteral, String) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createExistsPlan(RelNode, RelOptUtil.SubQueryType, RelOptUtil.Logic, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createExistsPlan(RelNode, RelOptUtil.SubQueryType, RelOptUtil.Logic, boolean, RelBuilder) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Creates a plan suitable for use in
EXISTS
orIN
statements. - createExtractFromGranularity(Granularity, String) - Static method in class org.apache.calcite.adapter.druid.TimeExtractionFunction
-
Creates the time format extraction function for the given granularity.
- createField(Expression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Creates final static field to hold the given expression.
- createFieldTrimmer(SqlValidator, RelBuilder) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
-
Creates a RelFieldTrimmer.
- createFilter(RelNode, Iterable<? extends RexNode>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Creates a filter, using the default filter factory, or returns the original relational expression if the condition is trivial.
- createFilter(RelNode, Iterable<? extends RexNode>, RelFactories.FilterFactory) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Creates a filter using the default factory, or returns the original relational expression if the condition is trivial.
- createFilter(RelNode, RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createFilter(RelNode, RexNode) - Method in interface org.apache.calcite.rel.core.RelFactories.FilterFactory
-
Deprecated.
- createFilter(RelNode, RexNode, Set<CorrelationId>) - Method in class org.apache.calcite.adapter.pig.PigRelFactories.PigFilterFactory
- createFilter(RelNode, RexNode, Set<CorrelationId>) - Method in interface org.apache.calcite.rel.core.RelFactories.FilterFactory
-
Creates a filter.
- createFilter(RelNode, RexNode, RelFactories.FilterFactory) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createFinishingOptimizeShuttle() - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Creates a final optimization shuttle.
- createFloorFromGranularity(Granularity, String) - Static method in class org.apache.calcite.adapter.druid.TimeExtractionFunction
-
Creates time format floor time extraction function using a given granularity.
- createFollowing(SqlNode, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlWindow
- createForeignSchema(SqlParserPos, boolean, boolean, SqlIdentifier, SqlNode, SqlNode, SqlNodeList) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a CREATE FOREIGN SCHEMA.
- createFromBitString(String) - Static method in class org.apache.calcite.util.BitString
-
Creates a BitString representation out of a Bit String.
- createFromBytes(byte[]) - Static method in class org.apache.calcite.util.BitString
-
Creates a BitString from an array of bytes.
- createFromHexString(String) - Static method in class org.apache.calcite.util.BitString
-
Creates a BitString representation out of a Hex String.
- createFunction(SqlParserPos, boolean, boolean, SqlIdentifier, SqlNode, SqlNodeList) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a CREATE FUNCTION.
- createFunctionSqlType(RelDataType, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a function type.
- createFunctionSqlType(RelDataType, RelDataType) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- createGetter(int) - Method in class org.apache.calcite.runtime.ArrayEnumeratorCursor
- createGetter(int) - Method in class org.apache.calcite.runtime.ObjectEnumeratorCursor
- createGetter(int) - Method in class org.apache.calcite.runtime.RecordEnumeratorCursor
- createGranularity(TimeUnitRange, String) - Static method in class org.apache.calcite.adapter.druid.Granularities
-
Creates a Granularity based on a time unit.
- createHandler() - Method in class org.apache.calcite.jdbc.Driver
- createIdentity(int) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Creates the identity mapping.
- createIdentity(RelDataType) - Static method in class org.apache.calcite.rex.RexProgram
-
Creates the identity program.
- createIdentity(RelDataType, RelDataType) - Static method in class org.apache.calcite.rex.RexProgram
-
Creates a program that projects its input fields but with possibly different names for the output fields.
- createImplementor(NotNullImplementor, NullPolicy, boolean) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- createInterval(int, String, SqlIntervalQualifier, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Creates an interval literal.
- createInterval(RexNode) - Static method in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
-
Generates a list of
Interval
s equivalent to a given expression. - createIterable(Meta.StatementHandle, QueryState, Meta.Signature, List<TypedValue>, Meta.Frame) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- createJavaType(Class) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a type that corresponds to a Java class.
- createJavaType(Class) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- createJoin(RelNode, RelNode, List<RelHint>, RexNode, Set<CorrelationId>, JoinRelType, boolean) - Method in class org.apache.calcite.adapter.pig.PigRelFactories.PigJoinFactory
- createJoin(RelNode, RelNode, List<RelHint>, RexNode, Set<CorrelationId>, JoinRelType, boolean) - Method in interface org.apache.calcite.rel.core.RelFactories.JoinFactory
-
Creates a join.
- createJoin(SqlToRelConverter.Blackboard, RelNode, RelNode, RexNode, JoinRelType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- createJoinType(RelDataType...) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a cartesian product type.
- createJoinType(RelDataType...) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- createJoinType(RelDataTypeFactory, RelDataType, RelDataType, List<String>, List<RelDataTypeField>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Returns the type the row which results when two relations are joined.
- createJoinType(RelDataTypeFactory, RelDataType, RelDataType, List<String>, List<RelDataTypeField>) - Static method in class org.apache.calcite.rel.core.Join
-
Deprecated.
- createListFrame(SqlWriter.FrameType, String, String, String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Creates a list frame.
- createLiteral(Object, SqlParserPos) - Method in enum org.apache.calcite.sql.type.SqlTypeName
- createMapping(ImmutableBitSet, int) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
- createMapType(RelDataTypeFactory, RelDataType, RelDataType, boolean) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- createMapType(RelDataType, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a map type.
- createMapType(RelDataType, RelDataType) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- createMapTypeFromRecord(RelDataTypeFactory, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Creates a MAP type from a record type.
- createMatch(RelNode, RexNode, RelDataType, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, ImmutableBitSet, RelCollation, RexNode) - Method in interface org.apache.calcite.rel.core.RelFactories.MatchFactory
-
Creates a
Match
. - createMatchRecognizeNameSpace(SqlMatchRecognize, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- createMaterializations() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.CREATE_MATERIALIZATIONS
. - createMaterializations() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- createMaterializedView(SqlParserPos, boolean, boolean, SqlIdentifier, SqlNodeList, SqlNode) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a CREATE MATERIALIZED VIEW.
- createMeasureType(RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a measure type.
- createMeasureType(RelDataType) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- createMeta(AvaticaConnection) - Method in class org.apache.calcite.jdbc.Driver
- createMethodDispatcher(Class<T>, ReflectiveVisitor, String, Class<E>, Class...) - Static method in class org.apache.calcite.util.ReflectUtil
-
Creates a dispatcher for calls to a single multi-method on a particular object.
- createMultisetType(RelDataTypeFactory, RelDataType, boolean) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- createMultisetType(RelDataType, long) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a multiset type.
- createMultisetType(RelDataType, long) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- createName(int) - Static method in class org.apache.calcite.rex.RexInputRef
-
Creates a name for an input reference, of the form "$index".
- createNamed(String) - Static method in class org.apache.calcite.sql.SqlSampleSpec
-
Creates a sample which substitutes one relation for another.
- createNegative(SqlNumericLiteral, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
- createNewProject(RelNode, int[]) - Method in class org.apache.calcite.rel.rules.PushProjector
-
Creates a new projection based on the original projection, adjusting all input refs using an adjustment array passed in.
- createNlsStringType(RelDataTypeFactory, NlsString) - Static method in class org.apache.calcite.sql.SqlUtil
-
Creates the type of an
NlsString
. - createNull(SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Creates a NULL literal.
- createNullFilter(RelNode, Integer[]) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createOneRow(RelOptCluster) - Static method in class org.apache.calcite.rel.logical.LogicalValues
-
Creates a LogicalValues that outputs one row and one column.
- createOptimizeShuttle() - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Creates a shuttle that will be used during block optimization.
- createOrderedEnumerable(Function1<T, TKey>, Comparator<TKey>, boolean) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- createOrderedEnumerable(Function1<T, TKey>, Comparator<TKey>, boolean) - Method in interface org.apache.calcite.linq4j.ExtendedOrderedEnumerable
-
Performs a subsequent ordering of the elements in an
OrderedEnumerable
according to a key, using a specified comparator. - createOrderedEnumerable(OrderedEnumerable<TSource>, Function1<TSource, TKey>, Comparator<TKey>, boolean) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Performs a subsequent ordering of the elements in a sequence according to a key.
- createParser(String) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Factory method for default SQL parser.
- createParser(String) - Method in class org.apache.calcite.sql.test.SqlTestFactory
-
Creates a parser.
- createParser(String, SqlParser.Config) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Factory method for SQL parser with a given configuration.
- createParser(String, SqlParser.ConfigBuilder) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Deprecated.
- createParserConfig() - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Deprecated.
- createPartitionState(int, int) - Method in class org.apache.calcite.runtime.Matcher
- createPdxType(PdxInstance) - Method in class org.apache.calcite.adapter.geode.util.JavaTypeFactoryExtImpl
- createPdxType2(PdxInstance) - Method in class org.apache.calcite.adapter.geode.util.JavaTypeFactoryExtImpl
- createPivotNameSpace(SqlPivot, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- createPlanner(CalcitePrepare.Context) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Creates a query planner and initializes it with a default set of rules.
- createPlanner(CalcitePrepare.Context, Context, RelOptCostFactory) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Creates a query planner and initializes it with a default set of rules.
- createPlannerFactories() - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Creates a collection of planner factories.
- createPreceding(SqlNode, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlWindow
- createPrepare() - Method in class org.apache.calcite.jdbc.Driver
-
Creates a
CalcitePrepare
to be used to prepare a statement for execution. - createPrepareContext() - Method in interface org.apache.calcite.jdbc.CalciteConnection
-
Creates a context for preparing a statement for execution.
- createPrepareContext() - Method in interface org.apache.calcite.server.CalciteServerStatement
-
Creates a context for preparing a statement for execution.
- createPreparedExplanation(RelDataType, RelDataType, RelRoot, SqlExplainFormat, SqlExplainLevel) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- createPreparedExplanation(RelDataType, RelDataType, RelRoot, SqlExplainFormat, SqlExplainLevel) - Method in class org.apache.calcite.prepare.Prepare
- createPrepareFactory() - Method in class org.apache.calcite.jdbc.Driver
-
Deprecated.
- createProject(RelFactories.ProjectFactory, RelNode, List<Integer>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Creates a relational expression that projects the given fields of the input.
- createProject(MutableRel, List<Integer>) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- createProject(RelNode, List<? extends RexNode>, List<? extends String>, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createProject(RelNode, List<? extends RexNode>, List<? extends String>, boolean, RelBuilder) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createProject(RelNode, List<? extends RexNode>, List<String>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createProject(RelNode, List<Integer>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Creates a relational expression that projects the given fields of the input.
- createProject(RelNode, List<RelHint>, List<? extends RexNode>, List<? extends String>) - Method in interface org.apache.calcite.rel.core.RelFactories.ProjectFactory
-
Deprecated.
- createProject(RelNode, List<RelHint>, List<? extends RexNode>, List<? extends String>, Set<CorrelationId>) - Method in interface org.apache.calcite.rel.core.RelFactories.ProjectFactory
-
Creates a project.
- createProject(RelNode, List<Pair<RexNode, ? extends String>>, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createProject(RelNode, Mappings.TargetMapping) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Creates a
LogicalProject
that projects particular fields of its input, according to a mapping. - createProject(RelNode, Mappings.TargetMapping, RelFactories.ProjectFactory) - Static method in class org.apache.calcite.plan.RelOptUtil
- createProjectExprs(Project, RelNode, int, RexBuilder, List<RelDataTypeField>, List<Pair<RexNode, String>>) - Method in class org.apache.calcite.rel.rules.JoinProjectTransposeRule
-
Creates projection expressions corresponding to one of the inputs into the join.
- createProjectExprs(MutableRel, List<Integer>) - Static method in class org.apache.calcite.rel.mutable.MutableRels
-
Construct expression list of Project by the given fields of the input.
- createProjectJoinRel(List<Integer>, RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createProjectRefsAndExprs(RelNode, boolean, boolean) - Method in class org.apache.calcite.rel.rules.PushProjector
-
Creates a projection based on the inputs specified in a bitmap and the expressions that need to be preserved.
- createProjects(MutableRel, List<RexNode>) - Static method in class org.apache.calcite.rel.mutable.MutableRels
-
Construct expression list of Project by the given fields of the input.
- createQuery(Expression, Class<T>) - Method in interface org.apache.calcite.linq4j.QueryProvider
-
Constructs a
Queryable
object that can evaluate the query represented by a specified expression tree. - createQuery(Expression, Class<T>) - Method in class org.apache.calcite.linq4j.QueryProviderImpl
- createQuery(Expression, Type) - Method in interface org.apache.calcite.linq4j.QueryProvider
-
Constructs a
Queryable
object that can evaluate the query represented by a specified expression tree. - createQuery(Expression, Type) - Method in class org.apache.calcite.linq4j.QueryProviderImpl
- createRdd(JavaSparkContext, Enumerable<T>) - Static method in class org.apache.calcite.adapter.spark.SparkRuntime
-
Converts an enumerable into an RDD.
- createRdd(JavaSparkContext, T[]) - Static method in class org.apache.calcite.adapter.spark.SparkRuntime
-
Converts an array into an RDD.
- createRecordTypeFromMap(RelDataTypeFactory, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Creates a ROW type from a map type.
- createRegexPatternLiteral(SqlNode, SqlLiteral) - Static method in class org.apache.calcite.util.RelToSqlConverterUtil
-
Creates regex pattern based on the TRIM flag.
- createRegion(GemFireCache, String) - Static method in class org.apache.calcite.adapter.geode.util.GeodeUtils
-
Obtains a proxy pointing to an existing Region on the server.
- createRelOptTable(RelOptSchema, RelDataType, List<String>) - Static method in class org.apache.calcite.piglet.PigTable
-
Creates a
RelOptTable
for a schema only table. - createRename(RelNode, List<? extends String>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createRenameRel(RelDataType, RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createRepeatUnion(RelNode, RelNode, boolean, int, RelOptTable) - Method in interface org.apache.calcite.rel.core.RelFactories.RepeatUnionFactory
-
Creates a
RepeatUnion
. - createResultSet(Map<String, Object>, List<ColumnMetaData>, Meta.CursorFactory, Meta.Frame) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- createRootSchema(boolean) - Static method in class org.apache.calcite.jdbc.CalciteSchema
-
Creates a root schema.
- createRootSchema(boolean) - Static method in class org.apache.calcite.tools.Frameworks
-
Creates a root schema.
- createRootSchema(boolean, boolean) - Static method in class org.apache.calcite.jdbc.CalciteSchema
-
Creates a root schema.
- createRootSchema(boolean, boolean, String) - Static method in class org.apache.calcite.jdbc.CalciteSchema
-
Creates a root schema.
- createRootSchema(boolean, boolean, String, Schema) - Static method in class org.apache.calcite.jdbc.CalciteSchema
- createSample(RelNode, RelOptSamplingParameters) - Method in interface org.apache.calcite.rel.core.RelFactories.SampleFactory
-
Creates a
Sample
. - createSample(SqlSampleSpec, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Creates a literal which represents a sample specification.
- createScan(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.adapter.pig.PigRelFactories.PigTableScanFactory
- createScan(RelOptTable.ToRelContext, RelOptTable) - Method in interface org.apache.calcite.rel.core.RelFactories.TableScanFactory
-
Creates a
TableScan
. - createSchema(SqlParserPos, boolean, boolean, SqlIdentifier) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a CREATE SCHEMA.
- createSelectNamespace(SqlSelect, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Creates a namespace for a
SELECT
node. - createSemiJoin(RelNode, RelNode, RexNode) - Method in interface org.apache.calcite.rel.core.RelFactories.SemiJoinFactory
-
Deprecated.Creates a semi-join.
- createSet() - Method in interface org.apache.calcite.sql.validate.SqlNameMatcher
-
Creates a set that has the same case-sensitivity as this matcher.
- createSetOp(SqlKind, List<RelNode>, boolean) - Method in interface org.apache.calcite.rel.core.RelFactories.SetOpFactory
-
Creates a set operation.
- createSetopNamespace(SqlCall, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Creates a namespace for a set operation (
UNION
,INTERSECT
, orEXCEPT
). - createShiftMapping(int, int...) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Creates a mapping that consists of a set of contiguous ranges.
- createSingleTableCatalogReader(boolean, String, RelDataTypeFactory, RelDataType) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Creates a catalog reader that contains a single
Table
with temporary table name and specifiedrowType
. - createSingleton(int) - Static method in class org.apache.calcite.rel.RelCollationImpl
-
Deprecated.
- createSingleton(int) - Static method in class org.apache.calcite.rel.RelCollations
-
Creates a list containing one collation containing one field.
- createSingleValueAggRel(RelOptCluster, RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Creates a LogicalAggregate that removes all duplicates from the result of an underlying relational expression.
- createSnapshot(RelNode, RexNode) - Method in interface org.apache.calcite.rel.core.RelFactories.SnapshotFactory
-
Creates a
Snapshot
. - createSnapshot(RelNode, RexNode) - Method in class org.apache.calcite.rel.core.RelFactories.SnapshotFactoryImpl
- createSnapshot(SchemaVersion) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Creates a snapshot of this CalciteSchema as of the specified time.
- createSocket() - Method in class org.apache.calcite.runtime.SocketFactoryImpl
- createSocket(String, int) - Method in class org.apache.calcite.runtime.SocketFactoryImpl
- createSocket(String, int, InetAddress, int) - Method in class org.apache.calcite.runtime.SocketFactoryImpl
- createSocket(InetAddress, int) - Method in class org.apache.calcite.runtime.SocketFactoryImpl
- createSocket(InetAddress, int, InetAddress, int) - Method in class org.apache.calcite.runtime.SocketFactoryImpl
- createSort(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in interface org.apache.calcite.rel.core.RelFactories.SortFactory
-
Deprecated.
- createSort(RelNode, RelCollation, RexNode, RexNode) - Method in interface org.apache.calcite.rel.core.RelFactories.SortFactory
-
Creates a sort.
- createSortExchange(RelNode, RelDistribution, RelCollation) - Method in interface org.apache.calcite.rel.core.RelFactories.SortExchangeFactory
-
Creates a
SortExchange
. - createSourceSelectForDelete(SqlDelete) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Creates the SELECT statement that putatively feeds rows into a DELETE statement to be deleted.
- createSourceSelectForUpdate(SqlUpdate) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Creates the SELECT statement that putatively feeds rows into an UPDATE statement to be updated.
- createSqlIntervalType(SqlIntervalQualifier) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a SQL interval type.
- createSqlIntervalType(SqlIntervalQualifier) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- createSqlToRelConverter() - Method in class org.apache.calcite.sql.test.SqlTestFactory
- createSqlType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.SqlAbstractDateTimeLiteral
- createSqlType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.SqlDateLiteral
- createSqlType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.SqlLiteral
- createSqlType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.SqlNumericLiteral
- createSqlType(SqlTypeName) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a SQL type with no precision or scale.
- createSqlType(SqlTypeName) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- createSqlType(SqlTypeName, int) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a SQL type with length (precision) but no scale.
- createSqlType(SqlTypeName, int) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- createSqlType(SqlTypeName, int, int) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a SQL type with precision and scale.
- createSqlType(SqlTypeName, int, int) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- createSqlValidator(Prepare.CatalogReader, UnaryOperator<SqlValidator.Config>) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- createSqlWriter(SqlDialect, StringBuilder, IntFunction<SqlNode>) - Method in class org.apache.calcite.materialize.Lattice
-
Creates a context to which SQL can be generated.
- createStarTable() - Method in class org.apache.calcite.materialize.Lattice
- createStatement(Meta.ConnectionHandle) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- createStructType(Class) - Method in class org.apache.calcite.adapter.geode.util.JavaTypeFactoryExtImpl
- createStructType(Class) - Method in interface org.apache.calcite.adapter.java.JavaTypeFactory
-
Creates a record type based upon the public fields of a Java class.
- createStructType(Class) - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl
- createStructType(List<? extends Map.Entry<String, RelDataType>>) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a type that represents a structured collection of fieldList, obtaining the field information from a list of (name, type) pairs.
- createStructType(List<? extends Map.Entry<String, RelDataType>>) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- createStructType(List<RelDataType>, List<String>) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a type that represents a structured collection of fields.
- createStructType(List<RelDataType>, List<String>) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- createStructType(RelDataTypeFactory.FieldInfo) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Deprecated.
- createStructType(RelDataTypeFactory.FieldInfo) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- createStructType(RelDataTypeFactory, List<? extends RexNode>, List<? extends String>, SqlValidatorUtil.Suggester) - Static method in class org.apache.calcite.rex.RexUtil
-
Creates a record type with specified field names.
- createStructType(RelDataTypeFactory, List<? extends RexNode>, List<String>) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- createStructType(RelDataTypeFactory, List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Creates a record type with anonymous field names.
- createStructType(StructKind, List<RelDataType>, List<String>) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a type that represents a structured collection of fields, given lists of the names and types of the fields.
- createStructType(StructKind, List<RelDataType>, List<String>) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- createSwappedJoinExprs(RelNode, Join, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Creates projection expressions reflecting the swapping of a join's input.
- createSwitched(SqlParserPos, SqlNode, SqlNodeList, SqlNodeList, SqlNode) - Static method in class org.apache.calcite.sql.fun.SqlCase
-
Creates a call to the switched form of the CASE operator.
- createSymbol(Enum<?>, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Creates a literal which represents a parser symbol, for example the
TRAILING
keyword in the callTrim(TRAILING 'x' FROM 'Hello world!')
. - createSyntheticType(List<Type>) - Method in interface org.apache.calcite.adapter.java.JavaTypeFactory
-
Creates a synthetic Java class whose fields have the given Java types.
- createSyntheticType(List<Type>) - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl
- createTable(CalciteSchema, String, List<String>) - Method in class org.apache.calcite.materialize.MaterializationService.DefaultTableFactory
- createTable(CalciteSchema, String, List<String>) - Method in interface org.apache.calcite.materialize.MaterializationService.TableFactory
- createTable(Table, String, String, String) - Method in interface org.apache.calcite.jdbc.CalciteMetaTableFactory
-
Instantiates a MetaTable.
- createTable(Table, String, String, String) - Method in class org.apache.calcite.jdbc.CalciteMetaTableFactoryImpl
- createTable(SqlParserPos, boolean, boolean, SqlIdentifier, SqlNodeList, SqlNode) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a CREATE TABLE.
- createTableFunctionScan(RelOptCluster, List<RelNode>, RexCall, Type, Set<RelColumnMapping>) - Method in interface org.apache.calcite.rel.core.RelFactories.TableFunctionScanFactory
-
Creates a
TableFunctionScan
. - createTableLike(SqlParserPos, boolean, boolean, SqlIdentifier, SqlIdentifier, SqlNodeList, SqlNodeList) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a CREATE TABLE LIKE.
- createTableRequiresColumnList() - Method in interface org.apache.calcite.runtime.CalciteResource
- createTableRequiresColumnTypes(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- createTableSample(boolean, float) - Static method in class org.apache.calcite.sql.SqlSampleSpec
-
Deprecated.
- createTableSample(boolean, float, int) - Static method in class org.apache.calcite.sql.SqlSampleSpec
-
Deprecated.
- createTableSample(boolean, BigDecimal) - Static method in class org.apache.calcite.sql.SqlSampleSpec
-
Creates a table sample without repeatability.
- createTableSample(boolean, BigDecimal, int) - Static method in class org.apache.calcite.sql.SqlSampleSpec
-
Creates a table sample with repeatability.
- createTableSpool(RelNode, Spool.Type, Spool.Type, RelOptTable) - Method in interface org.apache.calcite.rel.core.RelFactories.SpoolFactory
-
Creates a
TableSpool
. - createTargetRowType(SqlValidatorTable, SqlNodeList, boolean, SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Derives a row-type for INSERT and UPDATE operations.
- createTime(Calendar, int, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Deprecated.
- createTime(TimeString, int, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
- createTime(TimeWithTimeZoneString, int, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
- createTimestamp(Calendar, int, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Deprecated.
- createTimestamp(SqlTypeName, TimestampString, int, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Creates a TIMESTAMP or TIMESTAMP WITH LOCAL TIME ZONE literal.
- createTimestamp(TimestampString, int, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Deprecated.
- createTimestamp(TimestampWithTimeZoneString, int, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Creates a TIMESTAMP WITH TIME ZONE literal.
- createType(Type) - Method in interface org.apache.calcite.adapter.java.JavaTypeFactory
-
Creates a type, deducing whether a record, scalar or primitive type is needed.
- createType(Type) - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl
- createType(SqlParserPos, boolean, SqlIdentifier, SqlNodeList, SqlDataTypeSpec) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a CREATE TYPE.
- createTypeCoercion(RelDataTypeFactory, SqlValidator) - Static method in class org.apache.calcite.sql.validate.implicit.TypeCoercions
-
Creates a default type coercion instance.
- createTypeFromProjection(RelDataType, List<String>) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- createTypeFromProjection(RelDataType, List<String>) - Method in interface org.apache.calcite.sql.validate.SqlValidatorCatalogReader
- createTypeFromProjection(RelDataType, List<String>, RelDataTypeFactory, boolean) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
- createTypeWithCharsetAndCollation(RelDataType, Charset, SqlCollation) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a type that is the same as another type but with possibly different charset or collation.
- createTypeWithCharsetAndCollation(RelDataType, Charset, SqlCollation) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- createTypeWithNullability(RelDataType, boolean) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a type that is the same as another type but with possibly different nullability.
- createTypeWithNullability(RelDataType, boolean) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- createTypeWithNullability(RelDataType, boolean) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- createUnboundedFollowing(SqlParserPos) - Static method in class org.apache.calcite.sql.SqlWindow
- createUnboundedPreceding(SqlParserPos) - Static method in class org.apache.calcite.sql.SqlWindow
- createUnboundedPrecedingWindow(String) - Method in class org.apache.calcite.sql.SqlWindow
-
Creates a window
(RANGE columnName UNBOUNDED PRECEDING)
. - createUnion(RelBuilder, RexBuilder, RelNode, RelNode, RelNode) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule
- createUnion(RelBuilder, RexBuilder, RelNode, RelNode, RelNode) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewJoinRule
- createUnion(RelBuilder, RexBuilder, RelNode, RelNode, RelNode) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
If the view will be used in a union rewriting, this method is responsible for generating the union and any other operator needed on top of it, e.g., a Project operator.
- createUnknown(String, String, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Creates a literal whose type is unknown until validation time.
- createUnknown(SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
- createUnknownType() - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a SQL type that represents the "unknown" type.
- createUnknownType() - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- createUnpivotNameSpace(SqlUnpivot, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- createUnsafe(Method) - Static method in class org.apache.calcite.schema.impl.ScalarFunctionImpl
-
Creates unsafe version of
ScalarFunction
from any method. - createValidator() - Method in class org.apache.calcite.sql.test.SqlTestFactory
-
Creates a validator.
- createValues(RelOptCluster, RelDataType, List<ImmutableList<RexLiteral>>) - Method in interface org.apache.calcite.rel.core.RelFactories.ValuesFactory
-
Creates a Values.
- createView(SqlParserPos, boolean, SqlIdentifier, SqlNodeList, SqlNode) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a CREATE VIEW.
- CROSS - Enum constant in enum org.apache.calcite.sql.JoinType
-
Cross join (also known as Cartesian product).
- crossJoinDisallowsCondition() - Method in interface org.apache.calcite.runtime.CalciteResource
- csc(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CSC
operator applied to double values. - csc(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CSC
operator applied to BigDecimal values. - CSC - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CSC - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- csch(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CSCH
operator applied to double values. - csch(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CSCH
operator applied to BigDecimal values. - CSCH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CSCH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "COTH(value)" function; returns the hyperbolic cosecant of
value
. - CSV - Enum constant in enum org.apache.calcite.adapter.redis.RedisDataFormat
-
Treat redis key and value as a csv format And parse the string to get the corresponding field content,The default separator is colon.
- CsvEnumerator<E> - Class in org.apache.calcite.adapter.file
-
Enumerator that reads from a CSV file.
- CsvEnumerator(Source, AtomicBoolean, boolean, String[], CsvEnumerator.RowConverter<E>) - Constructor for class org.apache.calcite.adapter.file.CsvEnumerator
- CsvEnumerator(Source, AtomicBoolean, List<RelDataType>, List<Integer>) - Constructor for class org.apache.calcite.adapter.file.CsvEnumerator
- CsvFilterableTable - Class in org.apache.calcite.adapter.csv
-
Table based on a CSV file that can implement simple filtering.
- CsvFilterableTable(Source, RelProtoDataType) - Constructor for class org.apache.calcite.adapter.csv.CsvFilterableTable
-
Creates a CsvFilterableTable.
- CsvProjectTableScanRule - Class in org.apache.calcite.adapter.csv
-
Planner rule that projects from a
CsvTableScan
scan just the columns needed to satisfy a projection. - CsvProjectTableScanRule - Class in org.apache.calcite.adapter.file
-
Planner rule that projects from a
CsvTableScan
scan just the columns needed to satisfy a projection. - CsvProjectTableScanRule(CsvProjectTableScanRule.Config) - Constructor for class org.apache.calcite.adapter.csv.CsvProjectTableScanRule
-
Creates a CsvProjectTableScanRule.
- CsvProjectTableScanRule(CsvProjectTableScanRule.Config) - Constructor for class org.apache.calcite.adapter.file.CsvProjectTableScanRule
-
Creates a CsvProjectTableScanRule.
- CsvProjectTableScanRule.Config - Interface in org.apache.calcite.adapter.csv
-
Rule configuration.
- CsvProjectTableScanRule.Config - Interface in org.apache.calcite.adapter.file
-
Rule configuration.
- CsvRules - Class in org.apache.calcite.adapter.csv
-
Planner rules relating to the CSV adapter.
- CsvScannableTable - Class in org.apache.calcite.adapter.csv
-
Table based on a CSV file.
- CsvSchema - Class in org.apache.calcite.adapter.csv
-
Schema mapped onto a directory of CSV files.
- CsvSchema(File, CsvTable.Flavor) - Constructor for class org.apache.calcite.adapter.csv.CsvSchema
-
Creates a CSV schema.
- CsvSchemaFactory - Class in org.apache.calcite.adapter.csv
-
Factory that creates a
CsvSchema
. - CsvStreamScannableTable - Class in org.apache.calcite.adapter.csv
-
Table based on a CSV file.
- CsvStreamTableFactory - Class in org.apache.calcite.adapter.csv
-
Factory that creates a
CsvTranslatableTable
. - CsvStreamTableFactory() - Constructor for class org.apache.calcite.adapter.csv.CsvStreamTableFactory
- CsvTable - Class in org.apache.calcite.adapter.csv
-
Base class for table that reads CSV files.
- CsvTable - Class in org.apache.calcite.adapter.file
-
Base class for table that reads CSV files.
- CsvTable.Flavor - Enum in org.apache.calcite.adapter.csv
-
Various degrees of table "intelligence".
- CsvTable.Flavor - Enum in org.apache.calcite.adapter.file
-
Various degrees of table "intelligence".
- CsvTableFactory - Class in org.apache.calcite.adapter.csv
-
Factory that creates a
CsvTranslatableTable
. - CsvTableFactory - Class in org.apache.calcite.adapter.file
-
Factory that creates a
CsvTranslatableTable
. - CsvTableFactory() - Constructor for class org.apache.calcite.adapter.csv.CsvTableFactory
- CsvTableFactory() - Constructor for class org.apache.calcite.adapter.file.CsvTableFactory
- CsvTableScan - Class in org.apache.calcite.adapter.csv
-
Relational expression representing a scan of a CSV file.
- CsvTableScan - Class in org.apache.calcite.adapter.file
-
Relational expression representing a scan of a CSV file.
- CsvTableScan(RelOptCluster, RelOptTable, CsvTranslatableTable, int[]) - Constructor for class org.apache.calcite.adapter.csv.CsvTableScan
- CsvTableScan(RelOptCluster, RelOptTable, CsvTranslatableTable, int[]) - Constructor for class org.apache.calcite.adapter.file.CsvTableScan
- CsvTranslatableTable - Class in org.apache.calcite.adapter.csv
-
Table based on a CSV file.
- CsvTranslatableTable - Class in org.apache.calcite.adapter.file
-
Table based on a CSV file.
- cube(List<ImmutableBitSet>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Computes the cube of bit sets.
- CUBE - Enum constant in enum org.apache.calcite.rel.core.Aggregate.Group
- CUBE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The internal
CUBE
operator that occurs within aGROUP BY
clause. - CUBE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
CUBE
operator, occurs withinGROUP BY
clause or nested within aGROUPING SETS
. - CUME_DIST - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ROW_NUMBER
window function. - CUME_DIST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
CUME_DIST
window function. - CUMULATIVE_COST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CUMULATIVE_MEMORY_WITHIN_PHASE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CUMULATIVE_MEMORY_WITHIN_PHASE_SPLIT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- cumulativeMemoryWithinPhase() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Memory
-
Returns the cumulative amount of memory, in bytes, required by the physical operator implementing this relational expression, and all other operators within the same phase, across all splits.
- cumulativeMemoryWithinPhase(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.Memory.cumulativeMemoryWithinPhase()
statistic. - cumulativeMemoryWithinPhase(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Memory.Handler
- cumulativeMemoryWithinPhase(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMemory
-
Catch-all implementation for
BuiltInMetadata.Memory.cumulativeMemoryWithinPhase()
, invoked using reflection. - cumulativeMemoryWithinPhaseSplit() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Memory
-
Returns the expected cumulative amount of memory, in bytes, required by the physical operator implementing this relational expression, and all operators within the same phase, within each split.
- cumulativeMemoryWithinPhaseSplit(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.Memory.cumulativeMemoryWithinPhaseSplit()
statistic. - cumulativeMemoryWithinPhaseSplit(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Memory.Handler
- cumulativeMemoryWithinPhaseSplit(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMemory
-
Catch-all implementation for
BuiltInMetadata.Memory.cumulativeMemoryWithinPhaseSplit()
, invoked using reflection. - current() - Method in class org.apache.calcite.adapter.file.CsvEnumerator
- current() - Method in class org.apache.calcite.adapter.file.JsonEnumerator
- current() - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleEnumerator
- current() - Method in class org.apache.calcite.adapter.kafka.KafkaMessageEnumerator
-
It returns an Array of Object, with each element represents a field of row.
- current() - Method in class org.apache.calcite.adapter.os.OsQuery
- current() - Method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.SplunkResultEnumerator
- current() - Method in class org.apache.calcite.linq4j.DelegatingEnumerator
- current() - Method in interface org.apache.calcite.linq4j.Enumerator
-
Gets the current element in the collection.
- current() - Method in class org.apache.calcite.linq4j.MemoryEnumerator
- current() - Method in class org.apache.calcite.linq4j.TransformedEnumerator
- current() - Method in class org.apache.calcite.runtime.EnumeratorCursor
- current() - Method in class org.apache.calcite.runtime.ObjectEnumeratorCursor
- CURRENT_CATALOG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CURRENT_CATALOG
function. - CURRENT_DATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CURRENT_DATE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CURRENT_DATE
function. - CURRENT_DATETIME - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CURRENT_DATETIME - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CURRENT_DATETIME([timezone])" function.
- CURRENT_DATETIME2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CURRENT_PATH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CURRENT_PATH
function. - CURRENT_ROLE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CURRENT_ROLE
function. - CURRENT_ROW - Static variable in class org.apache.calcite.rex.RexWindowBounds
-
CURRENT ROW.
- CURRENT_SCHEMA - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CURRENT_SCHEMA
function. - CURRENT_TIME - Enum constant in enum org.apache.calcite.runtime.Hook
-
Called to get the current time.
- CURRENT_TIME - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CURRENT_TIME - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CURRENT_TIME [(precision)]
function. - CURRENT_TIMESTAMP - Enum constant in enum org.apache.calcite.DataContext.Variable
-
The time at which the current statement started executing.
- CURRENT_TIMESTAMP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CURRENT_TIMESTAMP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CURRENT_TIMESTAMP [(precision)]
function. - CURRENT_TZ - Static variable in class org.apache.calcite.test.SqlOperatorTest
- CURRENT_USER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CURRENT_USER
function. - CURRENT_VALUE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The "CURRENT VALUE OF sequence" operator.
- CURRENT_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The sequence current value function:
CURRENT VALUE FOR sequence
. - currentBlock() - Method in interface org.apache.calcite.adapter.enumerable.NestedBlockBuilder
-
Returns the current code block.
- currentBlock() - Method in class org.apache.calcite.adapter.enumerable.NestedBlockBuilderImpl
-
Returns the current code block.
- currentDate(DataContext) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CURRENT_DATE
function. - currentDatetime(DataContext) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CURRENT_DATETIME
function. - currentDatetime(DataContext, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CURRENT_DATETIME
function with a specified timezone. - currentPosition() - Method in interface org.apache.calcite.adapter.enumerable.WinAggAddContext
-
Returns current position inside for-loop of window aggregate.
- currentRel - Variable in class org.apache.calcite.sql2rel.RelDecorrelator
- currentRow() - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
CURRENT ROW
window bound, for use in methods such asRelBuilder.OverCall.rowsFrom(RexWindowBound)
andRelBuilder.OverCall.rangeBetween(RexWindowBound, RexWindowBound)
. - currentRowFollowingError() - Method in interface org.apache.calcite.runtime.CalciteResource
- currentRowPrecedingError() - Method in interface org.apache.calcite.runtime.CalciteResource
- currentTime(DataContext) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CURRENT_TIME
function. - currentTimestamp(DataContext) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CURRENT_TIMESTAMP
function. - currentTimeString(TimeZone) - Static method in class org.apache.calcite.test.SqlOperatorTest
-
Returns a time string, in GMT, that will be valid for at least 2 minutes.
- cursor - Variable in class org.apache.calcite.sql.parser.StringAndPos
- cursor(int, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a RexCall to the
CURSOR
function by ordinal. - CURSOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
CURSOR
constructor, for example,SELECT * FROM TABLE(udx(CURSOR(SELECT ...), x, y, z))
. - CURSOR - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- CURSOR - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- CURSOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The CURSOR constructor.
- CURSOR - Static variable in class org.apache.calcite.sql.type.OperandTypes
- CURSOR - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that always returns "CURSOR".
- cursorPosToSelectMap - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.FunctionParamInfo
-
Maps a cursor (based on its position relative to other cursor parameters within a function call) to the SELECT associated with the cursor.
- CursorReturnTypeInference - Class in org.apache.calcite.sql.type
-
Returns the rowtype of a cursor of the operand at a particular 0-based ordinal position.
- CursorReturnTypeInference(int) - Constructor for class org.apache.calcite.sql.type.CursorReturnTypeInference
- cust_id - Variable in class org.apache.calcite.test.schemata.foodmart.FoodmartSchema.SalesFact
- custId - Variable in class org.apache.calcite.test.schemata.tpch.TpchSchema.Customer
- custId - Variable in class org.apache.calcite.test.schemata.tpch.TpchSchema.LineItem
- CUSTOM - Enum constant in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Records must be represented as objects.
- CUSTOM - Enum constant in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
- CUSTOM - Enum constant in enum org.apache.calcite.model.JsonSchema.Type
- CUSTOM - Enum constant in enum org.apache.calcite.plan.Strong.Policy
-
This kind of expression has its own particular rules about whether it is null.
- CUSTOM_DATE_ADD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CUSTOM_DATE_CEIL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CUSTOM_DATE_DIFF - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CUSTOM_DATE_FLOOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CUSTOM_NICE - Enum constant in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Consumer would prefer that records are represented as objects, but can accommodate records represented as arrays.
- CUSTOM_TIMESTAMP_ADD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CUSTOM_TIMESTAMP_CEIL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CUSTOM_TIMESTAMP_DIFF - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CUSTOM_TIMESTAMP_FLOOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- CustomColumnResolvingTable - Interface in org.apache.calcite.schema
-
Extension to
Table
that specifies a custom way to resolve column names. - CustomCorrelate(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RelNode, CorrelationId, ImmutableBitSet, JoinRelType) - Constructor for class org.apache.calcite.test.SqlToRelTestBase.CustomCorrelate
- customDateAdd(DataContext, String, int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
DATEADD
function applied to a custom time frame. - customDateCeil(DataContext, String, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CEIL
function applied to aDATE
value and a custom time frame. - customDateDiff(DataContext, String, int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
DATEDIFF
function applied to a custom time frame. - customDateFloor(DataContext, String, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
FLOOR
function applied to aDATE
value and a custom time frame. - customer - Variable in class org.apache.calcite.test.schemata.tpch.TpchSchema
- Customer(int) - Constructor for class org.apache.calcite.test.schemata.tpch.TpchSchema.Customer
- customMatches(String, Consumer<SqlNode>) - Static method in class org.apache.calcite.sql.parser.SqlParserTest
-
Returns a
Matcher
that calls a consumer and then succeeds. - customTimestampAdd(DataContext, String, long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TIMESTAMPADD
function applied to a custom time frame. - customTimestampCeil(DataContext, String, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CEIL
function applied to aTIMESTAMP
value and a custom time frame. - customTimestampDiff(DataContext, String, long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TIMESTAMPDIFF
function applied to a custom time frame. - customTimestampFloor(DataContext, String, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
FLOOR
function applied to aTIMESTAMP
value and a custom time frame. - CustomTypeSystems - Class in org.apache.calcite.test
-
Custom implementations of
RelDataTypeSystem
for testing. - CycleDetector<V,
E extends DefaultEdge> - Class in org.apache.calcite.util.graph -
Detects cycles in directed graphs.
- CycleDetector(DirectedGraph<V, E>) - Constructor for class org.apache.calcite.util.graph.CycleDetector
- cyclicDefinition(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- CyclicDefinitionException - Exception Class in org.apache.calcite.sql.validate
-
Thrown when an object, such as a view, is found to have a cylic definition.
- CyclicDefinitionException(int, List<String>) - Constructor for exception class org.apache.calcite.sql.validate.CyclicDefinitionException
-
Creates CyclicDefinitionException.
- CyclicMetadataException - Exception Class in org.apache.calcite.rel.metadata
-
Exception that indicates that a cycle has been detected while computing metadata.
- CyclicMetadataException() - Constructor for exception class org.apache.calcite.rel.metadata.CyclicMetadataException
-
Creates a CyclicMetadataException.
D
- d - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- D - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- data(String) - Static method in class org.apache.calcite.test.QuidemTest
- DATA_CONTEXT_GET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DATA_CONTEXT_GET_QUERY_PROVIDER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DATA_CONTEXT_GET_ROOT_SCHEMA - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- databaseMajorVersion() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- DatabaseMetaDataInvocationHandler(String, String) - Constructor for class org.apache.calcite.sql.SqlUtil.DatabaseMetaDataInvocationHandler
- databaseMinorVersion() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- databaseProduct() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- databaseProductName() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- databaseVersion() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- dataContext - Variable in class org.apache.calcite.interpreter.InterpretableRel.InterpreterImplementor
- DataContext - Interface in org.apache.calcite
-
Runtime context allowing access to the tables in a database.
- DataContext.Variable - Enum in org.apache.calcite
-
Variable that may be asked for in a call to
DataContext.get(java.lang.String)
. - DataContexts - Class in org.apache.calcite
-
Utilities for
DataContext
. - dataList - Variable in class org.apache.calcite.adapter.file.JsonTable
- dataSource(String, String, String, String) - Static method in class org.apache.calcite.adapter.jdbc.JdbcSchema
-
Creates a JDBC data source with the given specification.
- dataType - Variable in class org.apache.calcite.sql.ddl.SqlAttributeDefinition
- dataType - Variable in class org.apache.calcite.sql.ddl.SqlColumnDeclaration
- dataType - Variable in class org.apache.calcite.sql.ddl.SqlCreateType
- dataTypeSystem() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- date(int, int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
DATE(year, month, day)
function. - date(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
DATE(TIMESTAMP)
andDATE(TIMESTAMP WITH LOCAL TIME ZONE)
functions. - date(long, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
DATE(TIMESTAMP WITH LOCAL TIME, timeZone)
function. - DATE - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- DATE - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- DATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DATE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DATE" function.
- DATE - Static variable in class org.apache.calcite.sql.type.OperandTypes
- DATE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is DATE.
- DATE_ADD - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DATE_ADD
function (BigQuery Semantics). - DATE_ADD - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
THE "DATE_ADD(date, interval)" function (BigQuery) adds the interval to the date.
- DATE_ADD_SPARK - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DATE_ADD(start_date, num_days)" function (Spark) Returns the date that is num_days after start_date.
- DATE_ANY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- DATE_CHARACTER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- DATE_DIFF - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
THE "DATE_DIFF(date, date2, timeUnit)" function (BigQuery) returns the number of timeUnit in (date - date2).
- DATE_FROM_UNIX_DATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DATE_FROM_UNIX_DATE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DATE_FROM_UNIX_DATE(integer)" function; returns a DATE value a given number of seconds after 1970-01-01.
- DATE_INTERVAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
- DATE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is nullable DATE.
- DATE_OR_TIMESTAMP - Static variable in class org.apache.calcite.sql.type.OperandTypes
- DATE_PART - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DATE_PART(timeUnit, datetime)" function (Databricks, Postgres, Redshift, Snowflake).
- DATE_PATTERN - Static variable in class org.apache.calcite.test.SqlOperatorTest
-
Regular expression for a SQL DATE value.
- DATE_SUB - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DATE_SUB
function (BigQuery). - DATE_SUB - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DATE_SUB(date, interval)" function (BigQuery); subtracts interval from the date, independent of any time zone.
- DATE_TIME - Static variable in class org.apache.calcite.sql.type.OperandTypes
- DATE_TO_INT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DATE_TO_INT_OFFSET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DATE_TO_INT_OPTIONAL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DATE_TO_INT_OPTIONAL_OFFSET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DATE_TRUNC - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DATE_TRUNC
function (BigQuery). - DATE_TRUNC - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DATE_TRUNC(date, timeUnit)" function (BigQuery); truncates a DATE value to the beginning of a timeUnit.
- DATEADD - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DATEADD(timeUnit, numeric, datetime)" function (Microsoft SQL Server, Redshift, Snowflake).
- DateCalendarEnum - Enum in org.apache.calcite.util.format.postgresql
-
Calendar types that can be used in PostgreSQL datetime formats.
- dateDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- DATEDIFF - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DATEDIFF(timeUnit, datetime, datetime2)" function (Microsoft SQL Server, Redshift, Snowflake).
- dateEpoch() - Method in interface org.apache.calcite.rel.type.TimeFrame
-
Returns a date where this time frame is at the start of a cycle.
- DateFormatFunction() - Constructor for class org.apache.calcite.runtime.SqlFunctions.DateFormatFunction
- DateFormatFunctionPg(DataContext) - Constructor for class org.apache.calcite.runtime.SqlFunctions.DateFormatFunctionPg
- dateFromUnixDate(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- dateFun(Date) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- dateInterval() - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a checker for DATE intervals (YEAR, WEEK, ISOWEEK, WEEK_WEDNESDAY, etc.)
- dateLiteral(DateString) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- dateLiteralOutOfRange(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- DateParseFunction() - Constructor for class org.apache.calcite.runtime.SqlFunctions.DateParseFunction
- DATEPART - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DATEPART(timeUnit, datetime)" function (Microsoft SQL Server).
- DateRangeRules - Class in org.apache.calcite.rel.rules
-
Collection of planner rules that convert
EXTRACT(timeUnit FROM dateTime) = constant
,FLOOR(dateTime to timeUnit
= constant} andCEIL(dateTime to timeUnit
= constant} todateTime BETWEEN lower AND upper
. - DateRangeRules.FilterDateRangeRule - Class in org.apache.calcite.rel.rules
-
Rule that converts EXTRACT, FLOOR and CEIL in a
Filter
into a date range. - DateRangeRules.FilterDateRangeRule.FilterDateRangeRuleConfig - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- dateRequiresInterval() - Method in interface org.apache.calcite.runtime.CalciteResource
- DateString - Class in org.apache.calcite.util
-
Date literal.
- DateString(int, int, int) - Constructor for class org.apache.calcite.util.DateString
-
Creates a DateString for year, month, day values.
- DateString(String) - Constructor for class org.apache.calcite.util.DateString
-
Creates a DateString.
- datetime(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
DATETIME(DATE)
function; returns a Calcite TIMESTAMP. - datetime(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
DATETIME(DATE, TIME)
function; returns a Calcite TIMESTAMP. - datetime(int, int, int, int, int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
DATETIME(<year>, <month>, <day>, <hour>, <minute>, <second>)
function. - datetime(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
DATETIME(TIMESTAMP WITH LOCAL TIME ZONE)
function; returns a Calcite TIMESTAMP. - datetime(long, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
DATETIME(TIMESTAMP, timeZone)
function; returns a Calcite TIMESTAMP. - DATETIME - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- DATETIME - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DATETIME - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DATETIME" function returns a Calcite
TIMESTAMP
(which BigQuery calls aDATETIME
). - DATETIME - Static variable in class org.apache.calcite.sql.type.OperandTypes
- DATETIME_ADD - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DATETIME_ADD(timestamp, interval)" function (BigQuery).
- DATETIME_DIFF - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DATETIME_DIFF(timestamp, timestamp2, timeUnit)" function (BigQuery).
- DATETIME_INTERVAL - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- DATETIME_INTERVAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
- DATETIME_INTERVAL_INTERVAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
- DATETIME_INTERVAL_INTERVAL_TIME - Static variable in class org.apache.calcite.sql.type.OperandTypes
- DATETIME_INTERVAL_TIME - Static variable in class org.apache.calcite.sql.type.OperandTypes
- DATETIME_PLUS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Infix datetime plus operator, '
DATETIME + INTERVAL
'. - DATETIME_SUB - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DATETIME_SUB(timestamp, interval)" function (BigQuery).
- DATETIME_TRUNC - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DATETIME_TRUNC(timestamp, timeUnit)" function (BigQuery); truncates a TIMESTAMP value to the beginning of a timeUnit.
- DATETIME_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- dateTimeFormatString(SqlTypeName) - Static method in class org.apache.calcite.adapter.druid.DruidSqlCastConverter
- dateTimeStringEquality(SqlCallBinding, RelDataType, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
-
Datetime and STRING equality: cast STRING type to datetime type, SqlToRelConverter already makes the conversion but we still keep this interface overridable so user can have their custom implementation.
- DateTimeStringUtils - Class in org.apache.calcite.util
-
Utility methods to manipulate String representation of DateTime values.
- day - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- Day - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- DAY - Enum constant in enum org.apache.calcite.adapter.druid.Granularity.Type
- DAY - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- DAY_INTERVAL_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- DAY_VARIANTS - Static variable in class org.apache.calcite.test.SqlOperatorTest
- DAYNAME - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DAYNAME(datetime)" function; returns the name of the day of the week, in the current locale, of a TIMESTAMP or DATE argument.
- DAYNAME_WITH_DATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DAYNAME_WITH_TIMESTAMP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- dayNameWithDate(int, Locale) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
DAYNAME
function, applied to a DATE argument. - dayNameWithTimestamp(long, Locale) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
DAYNAME
function, applied to a TIMESTAMP argument. - DAYOFMONTH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
DAYOFMONTH
operator. - DAYOFWEEK - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
DAYOFWEEK
operator. - DayOfWeekCompiledPattern - Class in org.apache.calcite.util.format.postgresql.format.compiled
-
The date/time format compiled component for a text representation of a day of the week.
- DayOfWeekCompiledPattern(Set<PatternModifier>, CapitalizationEnum, TextStyle) - Constructor for class org.apache.calcite.util.format.postgresql.format.compiled.DayOfWeekCompiledPattern
- DayOfWeekFormatPattern - Class in org.apache.calcite.util.format.postgresql.format
-
The date/time format component for a text representation of a day of the week.
- DayOfWeekFormatPattern(String) - Constructor for class org.apache.calcite.util.format.postgresql.format.DayOfWeekFormatPattern
- DAYOFYEAR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
DAYOFYEAR
operator. - DAYS_IN_MONTH - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- DAYS_IN_WEEK - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- DAYS_IN_YEAR - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- DAYS_IN_YEAR_ISO_8601 - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- DAYS_JULIAN - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- DB - Static variable in class org.apache.calcite.test.CalciteAssert
-
Which database to use for tests that require a JDBC data source.
- DB2 - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- Db2SqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the IBM DB2 database. - Db2SqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.Db2SqlDialect
-
Creates a Db2SqlDialect.
- DD - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- DDD - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- DDL - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category consisting of all DDL operators.
- DDL_OPERATOR - Static variable in class org.apache.calcite.sql.SqlDdl
-
Use this operator only if you don't have a better one.
- DdlExecutor - Interface in org.apache.calcite.server
-
Executes DDL commands.
- DdlExecutorImpl - Class in org.apache.calcite.server
-
Abstract implementation of
DdlExecutor
. - DdlExecutorImpl() - Constructor for class org.apache.calcite.server.DdlExecutorImpl
-
Creates a DdlExecutorImpl.
- debug(String, Object, Object) - Method in class org.apache.calcite.util.trace.CalciteLogger
-
Logs a DEBUG message with two Object parameters.
- debug(String, Object, Object, Object) - Method in class org.apache.calcite.util.trace.CalciteLogger
-
Conditionally logs a DEBUG message with three Object parameters.
- debug(String, Object, Object, Object, Object) - Method in class org.apache.calcite.util.trace.CalciteLogger
-
Conditionally logs a DEBUG message with four Object parameters.
- debug(String, Object...) - Method in class org.apache.calcite.util.trace.CalciteLogger
- DEBUG - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to run Calcite in debug mode.
- debugCode(PrintStream, String) - Static method in class org.apache.calcite.util.Util
-
Prints the given code with line numbering.
- debugInfo() - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a DebugInfoExpression with the specified span.
- DebugInfo - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
Debugging information.
- dec - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- DECIMAL - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- DECIMAL - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- DECIMAL_DECIMAL_CAST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DECIMAL_DECIMAL_CAST_ROUNDING_MODE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DECIMAL_MOD - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- DECIMAL_MOD_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the decimal modulus of two exact numeric operands where at least one of the operands is a decimal.
- DECIMAL_OR_DOUBLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that returns DECIMAL if any of the arguments are DECIMAL.
- DECIMAL_OR_DOUBLE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- DECIMAL_PRODUCT - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the decimal product of two exact numeric operands where at least one of the operands is a decimal.
- DECIMAL_PRODUCT_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.DECIMAL_PRODUCT
but returns with nullability if any of the operands is nullable by usingSqlTypeTransforms.TO_NULLABLE
. - DECIMAL_QUOTIENT - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the decimal quotient of two exact numeric operands where at least one of the operands is a decimal.
- DECIMAL_QUOTIENT_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.DECIMAL_QUOTIENT
but returns with nullability if any of the operands is nullable by usingSqlTypeTransforms.TO_NULLABLE
. - DECIMAL_SCALE0 - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy for a call where the first argument is a decimal.
- DECIMAL_SUM - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the decimal sum of two exact numeric operands where at least one of the operands is a decimal.
- DECIMAL_SUM_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.DECIMAL_SUM
but returns with nullability if any of the operands is nullable by usingSqlTypeTransforms.TO_NULLABLE
. - decimalDecimalCast(BigDecimal, int, int) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Called from BuiltInMethod.DECIMAL_DECIMAL_CAST
- decimalDecimalCast(BigDecimal, int, int, RoundingMode) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Called from BuiltInMethod.DECIMAL_DECIMAL_CAST_ROUNDING_MODE
- decimalFormat(String) - Static method in class org.apache.calcite.util.NumberUtil
-
Creates a format.
- decimalOf(RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Create a decimal type equivalent to the numeric
type
, this is related to specific system implementation, you can override this logic if it is required. - decimalOf(RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- Declaration - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
Declaration of a variable.
- declarations - Variable in class org.apache.calcite.linq4j.tree.ForStatement
- DeclarationStatement - Class in org.apache.calcite.linq4j.tree
-
Expression that declares and optionally initializes a variable.
- DeclarationStatement(int, ParameterExpression, Expression) - Constructor for class org.apache.calcite.linq4j.tree.DeclarationStatement
- declare(int, String, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an expression that declares and initializes a variable.
- declare(int, ParameterExpression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a statement that declares a variable.
- declareCursor(SqlSelect, SqlValidatorScope) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Declares a SELECT expression as a cursor.
- declareCursor(SqlSelect, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- declareParentAccumulator(List<Expression>, BlockBuilder, PhysType) - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase
- declaringClass - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- DECODE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DECODE
function (Oracle). - DECODE - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
Deprecated.
- DECODE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "DECODE(v, v1, result1, [v2, result2, ...], resultN)" function.
- decodeIntervalOrDecimal(RexNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Retrieves an INTERVAL or DECIMAL node's integer representation.
- decodeIntervalOrDecimal(SqlParserPos, RexNode) - Method in class org.apache.calcite.rex.RexBuilder
- decodeList(CharSequence, char) - Static method in class org.apache.calcite.adapter.splunk.util.StringUtils
- decodeValue(SqlParserPos, RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Retrieves a decimal node's integer representation.
- decomposeConjunction(RexNode, List<RexNode>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Decomposes a predicate into a list of expressions that are AND'ed together.
- decomposeConjunction(RexNode, List<RexNode>, List<RexNode>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Decomposes a predicate into a list of expressions that are AND'ed together, and a list of expressions that are preceded by NOT.
- decomposeDisjunction(RexNode, List<RexNode>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Decomposes a predicate into a list of expressions that are OR'ed together.
- DECORATOR_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Attach additional responsibilities to an object dynamically.
- decorrelate(RelNode) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelate(SqlNode, RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
If sub-query is correlated and decorrelation is enabled, performs decorrelation.
- decorrelate(SqlToRelConverter, SqlNode, RelNode) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- decorrelate(SqlToRelConverter, SqlNode, RelNode) - Method in class org.apache.calcite.prepare.Prepare
- decorrelateExpr(RelNode, Map<RelNode, RelDecorrelator.Frame>, RelDecorrelator.CorelMap, RexNode) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateQuery(RelNode) - Static method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Deprecated.
- decorrelateQuery(RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- decorrelateQuery(RelNode, RelBuilder) - Static method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Decorrelates a query.
- decorrelateRel(Aggregate, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateRel(Correlate, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateRel(Filter, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateRel(Join, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateRel(Project, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateRel(Sort, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateRel(Values, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateRel(LogicalAggregate, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateRel(LogicalCorrelate, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateRel(LogicalFilter, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateRel(LogicalJoin, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateRel(LogicalProject, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateRel(LogicalSnapshot, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateRel(LogicalTableFunctionScan, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- decorrelateRel(RelNode, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Fallback if none of the other
decorrelateRel
methods match. - decorrelator() - Method in interface org.apache.calcite.sql2rel.RelDecorrelator.Config
-
Returns the RelDecorrelator that will be context for the created rule instance.
- DECREASING - Enum constant in enum org.apache.calcite.sql.validate.SqlMonotonicity
- decRelDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- decrement(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents the decrementing of the expression by 1.
- decrement(Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents the decrementing of the expression by 1.
- Decrement - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A unary decrement operation, such as (a - 1) in C# and Visual Basic.
- deduceCollations(List<RelCollation>, int, List<RexLocalRef>, List<RelCollation>) - Static method in class org.apache.calcite.rex.RexProgram
-
Given a list of expressions and a description of which are ordered, populates a list of collations, sorted in natural order.
- deduceElementType(Table) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
- deduceFormat(RelOptTable) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
- deduceRowType(JavaTypeFactory, Source, List<RelDataType>, Boolean) - Static method in class org.apache.calcite.adapter.file.CsvEnumerator
-
Deduces the names and types of a table's columns by reading the first line of a CSV file.
- deduceType(RelDataTypeFactory, TimeUnit, RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.fun.SqlTimestampAddFunction
-
Deprecated.
- dedup - Variable in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
The map that de-duplicates expressions, so the same expressions may reuse the same final static fields.
- dedupAggregateCalls() - Method in interface org.apache.calcite.tools.RelBuilder.Config
-
Whether
RelBuilder.aggregate(org.apache.calcite.tools.RelBuilder.GroupKey, org.apache.calcite.tools.RelBuilder.AggCall...)
should eliminate duplicate aggregate calls; default true. - DedupFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.DedupFunction
- deduplicateColumns(List<RelDataTypeField>, List<RelDataTypeField>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns the set of columns with unique names, with prior columns taking precedence over columns that appear later in the list.
- DeduplicateCorrelateVariables - Class in org.apache.calcite.sql2rel
-
Rewrites relations to ensure the same correlation is referenced by the same correlation variable.
- deep - Variable in class org.apache.calcite.rex.RexBiVisitorImpl
- deep - Variable in class org.apache.calcite.rex.RexVisitorImpl
- deep() - Method in class org.apache.calcite.rel.mutable.MutableRel
- deepEquals(Object) - Method in class org.apache.calcite.plan.hep.HepRelVertex
- deepEquals(Object) - Method in class org.apache.calcite.plan.volcano.RelSubset
- deepEquals(Object) - Method in class org.apache.calcite.rel.AbstractRelNode
-
Equality check for RelNode digest.
- deepEquals(Object) - Method in class org.apache.calcite.rel.logical.LogicalAsofJoin
- deepEquals(Object) - Method in class org.apache.calcite.rel.logical.LogicalFilter
- deepEquals(Object) - Method in class org.apache.calcite.rel.logical.LogicalJoin
- deepEquals(Object) - Method in class org.apache.calcite.rel.logical.LogicalProject
- deepEquals(Object) - Method in interface org.apache.calcite.rel.RelNode
-
Deep equality check for RelNode digest.
- deepEquals0(Object) - Method in class org.apache.calcite.rel.core.Filter
- deepEquals0(Object) - Method in class org.apache.calcite.rel.core.Join
- deepEquals0(Object) - Method in class org.apache.calcite.rel.core.Project
- deepHashCode() - Method in class org.apache.calcite.plan.hep.HepRelVertex
- deepHashCode() - Method in class org.apache.calcite.plan.volcano.RelSubset
- deepHashCode() - Method in class org.apache.calcite.rel.AbstractRelNode
-
Compute hash code for RelNode digest.
- deepHashCode() - Method in class org.apache.calcite.rel.logical.LogicalAsofJoin
- deepHashCode() - Method in class org.apache.calcite.rel.logical.LogicalFilter
- deepHashCode() - Method in class org.apache.calcite.rel.logical.LogicalJoin
- deepHashCode() - Method in class org.apache.calcite.rel.logical.LogicalProject
- deepHashCode() - Method in interface org.apache.calcite.rel.RelNode
-
Compute deep hash code for RelNode digest.
- deepHashCode0() - Method in class org.apache.calcite.rel.core.Filter
- deepHashCode0() - Method in class org.apache.calcite.rel.core.Join
- deepHashCode0() - Method in class org.apache.calcite.rel.core.Project
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.AllPredicates
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Collation
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ColumnOrigin
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ColumnUniqueness
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.CumulativeCost
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.DistinctRowCount
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Distribution
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ExplainVisibility
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ExpressionLineage
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.LowerBoundCost
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.MaxRowCount
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Measure
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Memory
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.MinRowCount
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.NodeTypes
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.NonCumulativeCost
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Parallelism
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.PercentageOriginalRows
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.PopulationSize
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Predicates
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.RowCount
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Selectivity
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Size
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.TableReferences
- DEF - Static variable in interface org.apache.calcite.rel.metadata.BuiltInMetadata.UniqueKeys
- Default - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A default value.
- DEFAULT - Enum constant in enum org.apache.calcite.schema.ColumnStrategy
-
Column has a default value.
- DEFAULT - Enum constant in enum org.apache.calcite.sql.SqlJsonValueEmptyOrErrorBehavior
- DEFAULT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DEFAULT
operator. - DEFAULT - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Calcite's default SQL behavior.
- DEFAULT - Static variable in interface org.apache.calcite.adapter.arrow.ArrowRules.ArrowFilterRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.adapter.cassandra.CassandraRules.CassandraFilterRule.CassandraFilterRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.adapter.cassandra.CassandraRules.CassandraLimitRule.CassandraLimitRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.adapter.cassandra.CassandraRules.CassandraSortRule.CassandraSortRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.adapter.csv.CsvProjectTableScanRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.adapter.druid.DruidRules.DruidAggregateProjectRule.DruidAggregateProjectRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.adapter.druid.DruidRules.DruidAggregateRule.DruidAggregateRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.adapter.druid.DruidRules.DruidFilterRule.DruidFilterRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.adapter.druid.DruidRules.DruidHavingFilterRule.DruidHavingFilterRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.adapter.druid.DruidRules.DruidPostAggregationProjectRule.DruidPostAggregationProjectRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.adapter.druid.DruidRules.DruidProjectRule.DruidProjectRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.adapter.druid.DruidRules.DruidSortRule.DruidSortRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoinRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.adapter.enumerable.EnumerableFilterToCalcRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.adapter.enumerable.EnumerableLimitRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.adapter.enumerable.EnumerableLimitSortRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.adapter.enumerable.EnumerableProjectToCalcRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.adapter.file.CsvProjectTableScanRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.adapter.innodb.InnodbRules.InnodbFilterRule.InnodbFilterRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.adapter.innodb.InnodbRules.InnodbSortFilterRule.InnodbSortFilterRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.adapter.innodb.InnodbRules.InnodbSortTableScanRule.InnodbSortTableScanRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.config.CalciteConnectionConfig
-
Default configuration.
- DEFAULT - Static variable in interface org.apache.calcite.interpreter.Bindables.BindableTableScanRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.plan.volcano.AbstractConverter.ExpandConversionRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.externalize.RelDotWriter.WriteOption
-
Default configuration.
- DEFAULT - Static variable in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateCaseToFilterRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateExpandWithinDistinctRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateExtractProjectRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateFilterTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateJoinJoinRemoveRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateJoinRemoveRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateJoinTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateMergeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateProjectConstantToDummyJoinRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateProjectMergeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateProjectPullUpConstantsRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateProjectStarTableRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateReduceFunctionsRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateRemoveRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateStarTableRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateUnionAggregateRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateUnionTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.AggregateValuesRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.CalcMergeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.CalcRemoveRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.CalcSplitRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.CoerceInputsRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.DateRangeRules.FilterDateRangeRule.FilterDateRangeRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ExchangeRemoveConstantKeysRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterAggregateTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterCalcMergeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterCorrelateRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterFlattenCorrelatedConditionRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterJoinRule.FilterIntoJoinRule.FilterIntoJoinRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterJoinRule.JoinConditionPushRule.JoinConditionPushRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterMergeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterMultiJoinMergeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterProjectTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterRemoveIsNotDistinctFromRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterSampleTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterSetOpTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterTableFunctionTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterTableScanRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterToCalcRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.FilterWindowTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.IntersectToDistinctRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.JoinAddRedundantSemiJoinRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.JoinAssociateRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.JoinCommuteRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.JoinDeriveIsNotNullFilterRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.JoinExtractFilterRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.JoinProjectTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.JoinPushExpressionsRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.JoinPushTransitivePredicatesRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.JoinToCorrelateRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.JoinToMultiJoinRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.LoptOptimizeJoinRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.MatchRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.materialize.MaterializedViewOnlyAggregateRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.materialize.MaterializedViewOnlyFilterRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.materialize.MaterializedViewOnlyJoinRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.materialize.MaterializedViewProjectAggregateRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.materialize.MaterializedViewProjectFilterRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.materialize.MaterializedViewProjectJoinRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.MaterializedViewFilterScanRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.MeasureRules.AggregateMeasure2RuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.MeasureRules.AggregateMeasureRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.MeasureRules.FilterSortMeasureRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.MeasureRules.ProjectMeasureRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.MeasureRules.ProjectSortMeasureRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.MinusToDistinctRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectAggregateMergeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectCalcMergeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectFilterTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectJoinJoinRemoveRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectJoinRemoveRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectJoinTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectMergeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectMultiJoinMergeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectOverSumToSum0Rule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectRemoveRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectSetOpTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectTableScanRule.Config
-
Config that matches Project on TableScan.
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectToCalcRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectToWindowRule.CalcToWindowRule.CalcToWindowRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectToWindowRule.ProjectToLogicalProjectAndWindowRule.ProjectToLogicalProjectAndWindowRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ProjectWindowTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.PruneEmptyRules.CorrelateLeftEmptyRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.PruneEmptyRules.CorrelateRightEmptyRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.PruneEmptyRules.IntersectEmptyPruneRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.PruneEmptyRules.JoinLeftEmptyRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.PruneEmptyRules.JoinRightEmptyRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.PruneEmptyRules.MinusEmptyPruneRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.PruneEmptyRules.SortFetchZeroRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.PruneEmptyRules.UnionEmptyPruneRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.PruneEmptyRules.ZeroMaxRowsRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ReduceDecimalsRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.CalcReduceExpressionsRule.CalcReduceExpressionsRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.FilterReduceExpressionsRule.FilterReduceExpressionsRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.JoinReduceExpressionsRule.JoinReduceExpressionsRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.ProjectReduceExpressionsRule.ProjectReduceExpressionsRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.WindowReduceExpressionsRule.WindowReduceExpressionsRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SampleToFilterRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SemiJoinFilterTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SemiJoinJoinTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SemiJoinProjectTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SemiJoinRemoveRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SemiJoinRule.JoinOnUniqueToSemiJoinRule.JoinOnUniqueToSemiJoinRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SemiJoinRule.JoinToSemiJoinRule.JoinToSemiJoinRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SemiJoinRule.ProjectToSemiJoinRule.ProjectToSemiJoinRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SortJoinCopyRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SortJoinTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SortProjectTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SortRemoveConstantKeysRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SortRemoveRedundantRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SortRemoveRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SortUnionTransposeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.SpatialRules.FilterHilbertRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.TableScanRule.Config
-
Deprecated.
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.UnionEliminatorRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.UnionMergeRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.UnionPullUpConstantsRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.UnionToDistinctRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.rules.UnionToValuesRule.Config
- DEFAULT - Static variable in interface org.apache.calcite.rel.stream.StreamRules.DeltaAggregateTransposeRule.DeltaAggregateTransposeRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.stream.StreamRules.DeltaFilterTransposeRule.DeltaFilterTransposeRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.stream.StreamRules.DeltaJoinTransposeRule.DeltaJoinTransposeRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.stream.StreamRules.DeltaProjectTransposeRule.DeltaProjectTransposeRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.stream.StreamRules.DeltaSortTransposeRule.DeltaSortTransposeRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.stream.StreamRules.DeltaTableScanRule.DeltaTableScanRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.stream.StreamRules.DeltaTableScanToEmptyRule.DeltaTableScanToEmptyRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.stream.StreamRules.DeltaUnionTransposeRule.DeltaUnionTransposeRuleConfig
- DEFAULT - Static variable in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Default type system.
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.AccessSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.AnsiSqlDialect
-
A dialect useful for generating generic SQL.
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.CalciteSqlDialect
-
A dialect useful for generating SQL which can be parsed by the Apache Calcite parser, in particular quoting literals and identifiers.
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.ClickHouseSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.Db2SqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.DerbySqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.ExasolSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.FirebirdSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.FireboltSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.H2SqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.HiveSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.HsqldbSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.InfobrightSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.InformixSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.IngresSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.InterbaseSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.LucidDbSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.NeoviewSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.NetezzaSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.OracleSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.ParaccelSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.PhoenixSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.RedshiftSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.SnowflakeSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.SparkSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.StarRocksSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.SybaseSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.TeradataSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.VerticaSqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
DEFAULT
operator indicates that an argument to a function call is to take its default value.. - DEFAULT - Static variable in interface org.apache.calcite.sql.parser.SqlParser.Config
-
Default configuration.
- DEFAULT - Static variable in class org.apache.calcite.sql.parser.SqlParserFixture
- DEFAULT - Static variable in class org.apache.calcite.sql.test.SqlValidatorTester
-
Default instance of this tester.
- DEFAULT - Static variable in class org.apache.calcite.sql.type.OperandHandlers
-
The default operand handler visits all operands.
- DEFAULT - Static variable in interface org.apache.calcite.sql.validate.SqlConformance
-
Deprecated.
- DEFAULT - Static variable in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Default configuration.
- DEFAULT - Static variable in class org.apache.calcite.test.RelMetadataFixture
-
Default fixture.
- DEFAULT - Static variable in class org.apache.calcite.test.SqlToRelFixture
- DEFAULT - Static variable in interface org.apache.calcite.tools.RelBuilder.Config
-
Default configuration.
- DEFAULT - Static variable in class org.apache.calcite.util.format.FormatModels
-
The format model consisting of built-in format elements.
- default_() - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a DefaultExpression that has the Type property set to the specified type.
- DEFAULT_AGGREGATE_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_ALLOW_BANG_EQUAL - Static variable in class org.apache.calcite.sql.parser.SqlParser
-
Deprecated.
- DEFAULT_ASOFJOIN_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_BLOAT - Static variable in class org.apache.calcite.plan.RelOptUtil
- DEFAULT_BLOAT - Static variable in class org.apache.calcite.rel.rules.ProjectMergeRule
-
Deprecated.please use
RelOptUtil.DEFAULT_BLOAT
- DEFAULT_CHARSET - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
The name of the default character set.
- DEFAULT_COLLATION - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
The name of the default collation.
- DEFAULT_COLLATION_STRENGTH - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
The strength of the default collation.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.adapter.arrow.ArrowRules.ArrowProjectRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.adapter.cassandra.CassandraToEnumerableConverterRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableBindable.EnumerableToBindableConverterRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableCorrelateRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableInterpreterRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableMatchRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in interface org.apache.calcite.adapter.enumerable.EnumerableMergeUnionRule.Config
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRepeatUnionRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableTableFunctionScanRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableTableModifyRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableTableScanRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableTableSpoolRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableValuesRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.adapter.innodb.InnodbToEnumerableConverterRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.interpreter.Bindables.BindableAggregateRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.interpreter.Bindables.BindableFilterRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.interpreter.Bindables.BindableJoinRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.interpreter.Bindables.BindableMatchRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.interpreter.Bindables.BindableProjectRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.interpreter.Bindables.BindableSetOpRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.interpreter.Bindables.BindableSortRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.interpreter.Bindables.BindableValuesRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.interpreter.Bindables.BindableWindowRule
-
Default configuration.
- DEFAULT_CONFIG - Static variable in class org.apache.calcite.interpreter.NoneToBindableConverterRule
-
Default configuration.
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.AccessSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.AnsiSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.CalciteSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.ClickHouseSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.Db2SqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.DerbySqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.ExasolSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.FirebirdSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.FireboltSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.H2SqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.HiveSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.HsqldbSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.InfobrightSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.InformixSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.IngresSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.InterbaseSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.LucidDbSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.NeoviewSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.NetezzaSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.OracleSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.ParaccelSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.PhoenixSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.RedshiftSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.SnowflakeSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.SparkSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.StarRocksSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.SybaseSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.TeradataSqlDialect
- DEFAULT_CONTEXT - Static variable in class org.apache.calcite.sql.dialect.VerticaSqlDialect
- DEFAULT_CORRELATE_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_EXCHANGE_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_FACTORY - Static variable in interface org.apache.calcite.jdbc.CalcitePrepare
- DEFAULT_FILTER_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_FUNCTIONS_TO_REDUCE - Static variable in interface org.apache.calcite.rel.rules.AggregateReduceFunctionsRule.Config
- DEFAULT_IDENTIFIER_MAX_LENGTH - Static variable in class org.apache.calcite.sql.parser.SqlParser
- DEFAULT_IDENTIFIER_TIMEUNIT_MAP - Static variable in class org.apache.calcite.sql.parser.SqlParser
-
Deprecated.
- DEFAULT_IN_SUB_QUERY_THRESHOLD - Static variable in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Size of the smallest IN list that will be converted to a semijoin to a static table.
- DEFAULT_IN_SUBQUERY_THRESHOLD - Static variable in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Deprecated.
- DEFAULT_INTERVAL - Static variable in class org.apache.calcite.adapter.druid.DruidTable
- DEFAULT_INTERVAL_FRACTIONAL_SECOND_PRECISION - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- DEFAULT_INTERVAL_START_PRECISION - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- DEFAULT_JOIN_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_MATCH_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_NATIONAL_CHARSET - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
The name of the default national character set.
- DEFAULT_NULL_COLLATION - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
How NULL values should be sorted if neither NULLS FIRST nor NULLS LAST are specified.
- DEFAULT_OPERATORS_LIST - Static variable in class org.apache.calcite.adapter.druid.DruidQuery
-
Provides a standard list of supported Calcite operators that can be converted to Druid Expressions.
- DEFAULT_PROJECT_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_PROVIDER - Static variable in class org.apache.calcite.linq4j.Linq4j
-
Query provider that simply executes a
Queryable
by calling its enumerator method; does not attempt optimization. - DEFAULT_REPEAT_UNION_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_RULES - Static variable in class org.apache.calcite.plan.SubstitutionVisitor
- DEFAULT_SAMPLE_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_SET - Static variable in class org.apache.calcite.plan.visualizer.RuleMatchVisualizer
- DEFAULT_SET_OP_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_SNAPSHOT_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_SORT_EXCHANGE_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_SORT_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_SPOOL_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_STRUCT - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_TABLE_FUNCTION_SCAN_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_TABLE_SCAN_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_TIMESTAMP_COLUMN - Static variable in class org.apache.calcite.adapter.druid.DruidTable
- DEFAULT_URL - Static variable in class org.apache.calcite.adapter.druid.DruidSchemaFactory
-
Default Druid URL.
- DEFAULT_VALUES_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- defaultAlias() - Method in class org.apache.calcite.materialize.Lattice.BaseColumn
- defaultAlias() - Method in class org.apache.calcite.materialize.Lattice.Column
-
The alias that SQL would give to this expression.
- defaultAlias() - Method in class org.apache.calcite.materialize.Lattice.DerivedColumn
- defaultCharset() - Method in interface org.apache.calcite.util.SaffronProperties
-
Deprecated.The string property "saffron.default.charset" is the name of the default character set.
- defaultCollation() - Method in interface org.apache.calcite.util.SaffronProperties
-
Deprecated.The string property "saffron.default.collation.name" is the name of the default collation.
- defaultCollationStrength() - Method in interface org.apache.calcite.util.SaffronProperties
-
Deprecated.The string property "saffron.default.collation.strength" is the strength of the default collation.
- DefaultDimensionSpec - Class in org.apache.calcite.adapter.druid
-
Default implementation of DimensionSpec.
- DefaultDimensionSpec(String) - Constructor for class org.apache.calcite.adapter.druid.DefaultDimensionSpec
- DefaultDimensionSpec(String, String, DruidType) - Constructor for class org.apache.calcite.adapter.druid.DefaultDimensionSpec
- DefaultDirectedGraph<V,
E extends DefaultEdge> - Class in org.apache.calcite.util.graph -
Default implementation of
DirectedGraph
. - DefaultDirectedGraph(DirectedGraph.EdgeFactory<V, E>) - Constructor for class org.apache.calcite.util.graph.DefaultDirectedGraph
-
Creates a graph.
- DefaultEdge - Class in org.apache.calcite.util.graph
-
Default implementation of Edge.
- DefaultEdge(Object, Object) - Constructor for class org.apache.calcite.util.graph.DefaultEdge
- DefaultEnumerable<T> - Class in org.apache.calcite.linq4j
-
Implementation of the
Enumerable
interface that implements the extension methods by calling into theExtensions
class. - DefaultEnumerable() - Constructor for class org.apache.calcite.linq4j.DefaultEnumerable
- DefaultExpression - Class in org.apache.calcite.linq4j.tree
-
Represents the default value of a type or an empty expression.
- DefaultExpression(Class) - Constructor for class org.apache.calcite.linq4j.tree.DefaultExpression
- defaultForOptionalParameter() - Method in interface org.apache.calcite.runtime.CalciteResource
- defaultIfEmpty() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- defaultIfEmpty() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- defaultIfEmpty() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the elements of the specified sequence or the type parameter's default value in a singleton collection if the sequence is empty.
- defaultIfEmpty() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns the elements of the specified sequence or the type parameter's default value in a singleton collection if the sequence is empty.
- defaultIfEmpty(T) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- defaultIfEmpty(TSource) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the elements of the specified sequence or the specified value in a singleton collection if the sequence is empty.
- defaultIfEmpty(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the elements of the specified sequence or the type parameter's default value in a singleton collection if the sequence is empty.
- defaultIfEmpty(Enumerable<TSource>, TSource) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the elements of the specified sequence or the specified value in a singleton collection if the sequence is empty.
- defaultIfEmpty(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the elements of the specified sequence or the type parameter's default value in a singleton collection if the sequence is empty.
- defaultIfEmpty(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the elements of the specified sequence or the type parameter's default value in a singleton collection if the sequence is empty.
- defaultIfEmpty(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- defaultIfEmpty(Queryable<T>, T) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the elements of the specified sequence or the specified value in a singleton collection if the sequence is empty.
- defaultIfEmpty(Queryable<T>, T) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- defaultIfEmpty(Queryable<T>, T) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the elements of the specified sequence or the specified value in a singleton collection if the sequence is empty.
- defaultMeasures - Variable in class org.apache.calcite.materialize.Lattice
- defaultMeasures - Variable in class org.apache.calcite.model.JsonLattice
-
List of measures that a tile should have by default.
- defaultNationalCharset() - Method in interface org.apache.calcite.util.SaffronProperties
-
Deprecated.The string property "saffron.default.nationalcharset" is the name of the default national character set which is used with the N'string' construct which may or may not be different from the
SaffronProperties.defaultCharset()
. - defaultNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- defaultNullCollation() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.DEFAULT_NULL_COLLATION
. - defaultNullCollation() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- defaultNullCollation() - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Returns how NULL values should be collated if an ORDER BY item does not contain NULLS FIRST or NULLS LAST.
- defaultNullDirection() - Method in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Returns the null direction if not specified.
- defaultNullDirection(RelFieldCollation.Direction) - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether NULL values are sorted first or last, in this dialect, in an ORDER BY item of a given direction.
- defaultProviderSupplier - Variable in class org.apache.calcite.test.RelMetadataFixture.MetadataConfig
- DefaultRelMetadataProvider - Class in org.apache.calcite.rel.metadata
-
DefaultRelMetadataProvider supplies a default implementation of the
RelMetadataProvider
interface. - DefaultRelMetadataProvider() - Constructor for class org.apache.calcite.rel.metadata.DefaultRelMetadataProvider
-
Creates a new default provider.
- DEFAULTS - Enum constant in enum org.apache.calcite.sql.ddl.SqlCreateTableLike.LikeOption
- defaultSchema - Variable in class org.apache.calcite.model.JsonRoot
-
Name of the schema that will become the default schema for connections to Calcite that use this model.
- defaultSchema(SchemaPlus) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- DefaultTableFactory() - Constructor for class org.apache.calcite.materialize.MaterializationService.DefaultTableFactory
- defaultValue - Variable in class org.apache.calcite.linq4j.tree.LabelStatement
- defaultValue - Variable in enum org.apache.calcite.linq4j.tree.Primitive
-
The default value of this primitive class.
- defaultValue() - Method in enum org.apache.calcite.config.CalciteConnectionProperty
- DEFERRABLE - Enum constant in enum org.apache.calcite.sql.babel.postgresql.SqlBegin.TransactionMode
- defineMaterialization(CalciteSchema, TileKey, String, List<String>, String, boolean, boolean) - Method in class org.apache.calcite.materialize.MaterializationService
-
Defines a new materialization.
- defineMaterialization(CalciteSchema, TileKey, String, List<String>, String, MaterializationService.TableFactory, boolean, boolean) - Method in class org.apache.calcite.materialize.MaterializationService
-
Defines a new materialization.
- defineTile(Lattice, ImmutableBitSet, List<Lattice.Measure>, CalciteSchema, boolean, boolean) - Method in class org.apache.calcite.materialize.MaterializationService
-
Defines a tile.
- defineTile(Lattice, ImmutableBitSet, List<Lattice.Measure>, CalciteSchema, boolean, boolean, String, MaterializationService.TableFactory) - Method in class org.apache.calcite.materialize.MaterializationService
- degrees(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
DEGREES
operator applied to double values. - degrees(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
DEGREES
operator applied to BigDecimal values. - DEGREES - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DEGREES - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
DEGREES(numeric)
function. - dejsonize(String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- DEJSONIZE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- delegate - Variable in class org.apache.calcite.linq4j.DelegatingEnumerator
- DelegatingContext(BuiltInMetadata.Measure.Context) - Constructor for class org.apache.calcite.rel.metadata.RelMdMeasure.DelegatingContext
- DelegatingEnumerator<T> - Class in org.apache.calcite.linq4j
-
Simple enumerator that just delegates all calls to the passed enumerator.
- DelegatingEnumerator(Enumerator<T>) - Constructor for class org.apache.calcite.linq4j.DelegatingEnumerator
- DelegatingInvocationHandler - Class in org.apache.calcite.util
-
A class derived from
DelegatingInvocationHandler
handles a method call by looking for a method in itself with identical parameters. - DelegatingInvocationHandler() - Constructor for class org.apache.calcite.util.DelegatingInvocationHandler
- DelegatingLatticeStatisticProvider - Class in org.apache.calcite.materialize
-
Implementation of
LatticeStatisticProvider
that delegates to an underlying provider. - DelegatingLatticeStatisticProvider(LatticeStatisticProvider) - Constructor for class org.apache.calcite.materialize.DelegatingLatticeStatisticProvider
-
Creates a DelegatingLatticeStatisticProvider.
- DelegatingMetadataRel - Interface in org.apache.calcite.rel.metadata
-
Interface for
RelNode
where the metadata is derived from another node. - DelegatingNamespace - Class in org.apache.calcite.sql.validate
-
An implementation of
SqlValidatorNamespace
that delegates all methods to an underlying object. - DelegatingNamespace(SqlValidatorNamespace) - Constructor for class org.apache.calcite.sql.validate.DelegatingNamespace
-
Creates a DelegatingNamespace.
- DelegatingSchema - Class in org.apache.calcite.schema.impl
-
Implementation of
Schema
that delegates to an underlying schema. - DelegatingSchema(Schema) - Constructor for class org.apache.calcite.schema.impl.DelegatingSchema
-
Creates a DelegatingSchema.
- DelegatingScope - Class in org.apache.calcite.sql.validate
-
A scope which delegates all requests to its parent scope.
- DelegatingSqlValidatorCatalogReader - Class in org.apache.calcite.sql.validate
-
Implementation of
SqlValidatorCatalogReader
that passes all calls to a parent catalog reader. - DelegatingSqlValidatorCatalogReader(SqlValidatorCatalogReader) - Constructor for class org.apache.calcite.sql.validate.DelegatingSqlValidatorCatalogReader
-
Creates a DelegatingSqlValidatorCatalogReader.
- DelegatingSqlValidatorTable - Class in org.apache.calcite.sql.validate
-
Implements
SqlValidatorTable
by delegating to a parent table. - DelegatingSqlValidatorTable(SqlValidatorTable) - Constructor for class org.apache.calcite.sql.validate.DelegatingSqlValidatorTable
-
Creates a DelegatingSqlValidatorTable.
- DelegatingTypeSystem - Class in org.apache.calcite.rel.type
-
Implementation of
RelDataTypeSystem
that sends all methods to an underlying object. - DelegatingTypeSystem(RelDataTypeSystem) - Constructor for class org.apache.calcite.rel.type.DelegatingTypeSystem
-
Creates a
DelegatingTypeSystem
. - DELETE - Enum constant in enum org.apache.calcite.rel.core.TableModify.Operation
- DELETE - Enum constant in enum org.apache.calcite.sql.SqlAccessEnum
- DELETE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DELETE statement.
- delimiterIsRequired(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- Delta - Class in org.apache.calcite.rel.stream
-
Relational operator that converts a relation to a stream.
- Delta(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.rel.stream.Delta
- Delta(RelInput) - Constructor for class org.apache.calcite.rel.stream.Delta
-
Creates a Delta by parsing serialized output.
- DeltaAggregateTransposeRule(StreamRules.DeltaAggregateTransposeRule.DeltaAggregateTransposeRuleConfig) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaAggregateTransposeRule
-
Creates a DeltaAggregateTransposeRule.
- DeltaFilterTransposeRule(StreamRules.DeltaFilterTransposeRule.DeltaFilterTransposeRuleConfig) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaFilterTransposeRule
-
Creates a DeltaFilterTransposeRule.
- DeltaJoinTransposeRule() - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaJoinTransposeRule
-
Deprecated.
- DeltaJoinTransposeRule(StreamRules.DeltaJoinTransposeRule.DeltaJoinTransposeRuleConfig) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaJoinTransposeRule
-
Creates a DeltaJoinTransposeRule.
- DeltaProjectTransposeRule(StreamRules.DeltaProjectTransposeRule.DeltaProjectTransposeRuleConfig) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaProjectTransposeRule
-
Creates a DeltaProjectTransposeRule.
- DeltaSortTransposeRule(StreamRules.DeltaSortTransposeRule.DeltaSortTransposeRuleConfig) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaSortTransposeRule
-
Creates a DeltaSortTransposeRule.
- DeltaTableScanRule(StreamRules.DeltaTableScanRule.DeltaTableScanRuleConfig) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaTableScanRule
-
Creates a DeltaTableScanRule.
- DeltaTableScanToEmptyRule(StreamRules.DeltaTableScanToEmptyRule.DeltaTableScanToEmptyRuleConfig) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaTableScanToEmptyRule
-
Creates a DeltaTableScanToEmptyRule.
- DeltaUnionTransposeRule(StreamRules.DeltaUnionTransposeRule.DeltaUnionTransposeRuleConfig) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaUnionTransposeRule
-
Creates a DeltaUnionTransposeRule.
- Demo - Class in org.apache.calcite
-
Demo.
- DENSE_RANK - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
DENSE_RANK
window function. - DENSE_RANK - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
DENSE_RANK
window function. - Department - Class in org.apache.calcite.test.schemata.hr
-
Department model.
- Department(int, String, List<Employee>, Location) - Constructor for class org.apache.calcite.test.schemata.hr.Department
- DepartmentPlus - Class in org.apache.calcite.test.schemata.hr
-
Department with inception date model.
- DepartmentPlus(int, String, List<Employee>, Location, Timestamp) - Constructor for class org.apache.calcite.test.schemata.hr.DepartmentPlus
- Dependent - Class in org.apache.calcite.test.schemata.hr
-
Employee dependents model.
- Dependent(int, String) - Constructor for class org.apache.calcite.test.schemata.hr.Dependent
- dependents - Variable in class org.apache.calcite.test.schemata.hr.HrSchema
- deprecated(T, boolean) - Static method in class org.apache.calcite.util.Util
-
Deprecated.If a piece of code calls this method, it indicates that the code needs to be cleaned up.
- depth - Variable in exception class org.apache.calcite.sql.validate.CyclicDefinitionException
- DEPTH_FIRST - Enum constant in enum org.apache.calcite.plan.hep.HepMatchOrder
-
Match in depth-first order.
- DepthFirstIterator<V,
E extends DefaultEdge> - Class in org.apache.calcite.util.graph -
Iterates over the vertices in a directed graph in depth-first order.
- DepthFirstIterator(DirectedGraph<V, E>, V) - Constructor for class org.apache.calcite.util.graph.DepthFirstIterator
- deptno - Variable in class org.apache.calcite.test.schemata.hr.Department
- deptno - Variable in class org.apache.calcite.test.schemata.hr.Employee
- DEPTNO - Variable in class org.apache.calcite.test.schemata.lingual.LingualEmp
- depts - Variable in class org.apache.calcite.test.schemata.hr.HierarchySchema
- depts - Variable in class org.apache.calcite.test.schemata.hr.HrSchema
- depts - Variable in class org.apache.calcite.test.schemata.hr.HrSchemaBig
- DERBY - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- DerbySqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Apache Derby database. - DerbySqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.DerbySqlDialect
-
Creates a DerbySqlDialect.
- deref(RexNode) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Dereferences an expression if it is a
RexLocalRef
. - deregisterConverterRule(RelOptPlanner, ConverterRule) - Method in class org.apache.calcite.plan.ConventionTraitDef
- deregisterConverterRule(RelOptPlanner, ConverterRule) - Method in class org.apache.calcite.plan.RelTraitDef
-
Provides notification that a particular
ConverterRule
has been de-registered from aRelOptPlanner
. - derive(List<List<RelTraitSet>>) - Method in interface org.apache.calcite.rel.PhysicalNode
-
Given a list of child traitsets, inputTraits.size() == getInput().size(), returns node list after traits derivation.
- derive(RelTraitSet, int) - Method in interface org.apache.calcite.rel.PhysicalNode
-
Derive traitset from child node, returns new node after traits derivation.
- deriveAlias(SqlNode, int) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Derives an alias for an expression.
- deriveAlias(SqlNode, int) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- deriveAliasFromOrdinal(int) - Static method in class org.apache.calcite.sql.SqlUtil
- deriveAndCollectTypes(SqlValidator, SqlValidatorScope, List<? extends SqlNode>) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Iterates over all operands, derives their types, and collects them into a list.
- deriveAvgAggType(RelDataTypeFactory, RelDataType) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- deriveAvgAggType(RelDataTypeFactory, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns the return type of a call to the
AVG
,STDDEV
orVAR
aggregate functions, inferred from its argument type. - deriveAvgAggType(RelDataTypeFactory, RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- deriveCollectionQueryComponentType(SqlTypeName, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Derives component type for ARRAY, MULTISET, MAP when input is sub-query.
- deriveCollectRowType(SingleRel, String) - Static method in class org.apache.calcite.rel.core.Collect
-
Deprecated.
- deriveConstructorType(SqlValidatorScope, SqlCall, SqlFunction, SqlFunction, List<RelDataType>) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Derives the type of a constructor.
- deriveConstructorType(SqlValidatorScope, SqlCall, SqlFunction, SqlFunction, List<RelDataType>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- deriveCovarType(RelDataTypeFactory, RelDataType, RelDataType) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- deriveCovarType(RelDataTypeFactory, RelDataType, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns the return type of a call to the
COVAR
aggregate function, inferred from its argument types. - deriveCovarType(RelDataTypeFactory, RelDataType, RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- derived - Variable in class org.apache.calcite.rel.metadata.RelColumnMapping
-
Whether the column mapping transforms the input.
- deriveDecimalDivideType(RelDataTypeFactory, RelDataType, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Infers the return type of a decimal division.
- deriveDecimalModType(RelDataTypeFactory, RelDataType, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Infers the return type of a decimal modulus operation.
- deriveDecimalMultiplyType(RelDataTypeFactory, RelDataType, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Infers the return type of a decimal multiplication.
- deriveDecimalPlusType(RelDataTypeFactory, RelDataType, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Infers the return type of a decimal addition.
- deriveFractionalRankType(RelDataTypeFactory) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- deriveFractionalRankType(RelDataTypeFactory) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns the return type of the
CUME_DIST
andPERCENT_RANK
aggregate functions. - deriveFractionalRankType(RelDataTypeFactory) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- deriveJoinRowType(RelDataType, RelDataType, JoinRelType, RelDataTypeFactory, List<String>, List<RelDataTypeField>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Derives the type of a join relational expression.
- deriveJoinRowType(RelDataType, RelDataType, JoinRelType, RelDataTypeFactory, List<String>, List<RelDataTypeField>) - Static method in class org.apache.calcite.rel.core.Join
-
Deprecated.
- DeriveMode - Enum in org.apache.calcite.plan
-
The mode of trait derivation.
- deriveNaturalJoinColumnList(SqlNameMatcher, RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Derives the list of column names suitable for NATURAL JOIN.
- deriveOperandType(SqlValidator, SqlValidatorScope, int, SqlNode) - Method in class org.apache.calcite.sql.SqlOperator
- deriveQuerySpec() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- deriveRankType(RelDataTypeFactory) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- deriveRankType(RelDataTypeFactory) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns the return type of the
NTILE
,RANK
,DENSE_RANK
, andROW_NUMBER
aggregate functions. - deriveRankType(RelDataTypeFactory) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- deriveReturnType(SqlOperator, List<? extends RexNode>) - Method in class org.apache.calcite.rex.RexBuilder
-
Derives the return type of a call to an operator.
- deriveRowType() - Method in class org.apache.calcite.adapter.cassandra.CassandraTableScan
- deriveRowType() - Method in class org.apache.calcite.adapter.csv.CsvTableScan
- deriveRowType() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- deriveRowType() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTableScan
- deriveRowType() - Method in class org.apache.calcite.adapter.file.CsvTableScan
- deriveRowType() - Method in class org.apache.calcite.adapter.geode.rel.GeodeTableScan
- deriveRowType() - Method in class org.apache.calcite.adapter.innodb.InnodbTableScan
- deriveRowType() - Method in class org.apache.calcite.adapter.mongodb.MongoTableScan
- deriveRowType() - Method in class org.apache.calcite.adapter.splunk.SplunkTableScan
- deriveRowType() - Method in class org.apache.calcite.interpreter.Bindables.BindableTableScan
- deriveRowType() - Method in class org.apache.calcite.plan.hep.HepRelVertex
- deriveRowType() - Method in class org.apache.calcite.plan.volcano.RelSubset
- deriveRowType() - Method in class org.apache.calcite.rel.AbstractRelNode
- deriveRowType() - Method in class org.apache.calcite.rel.core.Aggregate
- deriveRowType() - Method in class org.apache.calcite.rel.core.Collect
- deriveRowType() - Method in class org.apache.calcite.rel.core.Correlate
- deriveRowType() - Method in class org.apache.calcite.rel.core.Join
- deriveRowType() - Method in class org.apache.calcite.rel.core.RepeatUnion
- deriveRowType() - Method in class org.apache.calcite.rel.core.SetOp
- deriveRowType() - Method in class org.apache.calcite.rel.core.TableModify
- deriveRowType() - Method in class org.apache.calcite.rel.core.TableScan
- deriveRowType() - Method in class org.apache.calcite.rel.core.Uncollect
- deriveRowType() - Method in class org.apache.calcite.rel.core.Values
- deriveRowType() - Method in class org.apache.calcite.rel.rules.MultiJoin
- deriveRowType() - Method in class org.apache.calcite.rel.SingleRel
- deriveRowType(RelDataTypeFactory, RelDataType, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Static method in class org.apache.calcite.rel.core.Aggregate
-
Computes the row type of an
Aggregate
before it exists. - deriveRowType(RelDataTypeFactory, SqlTypeName, String, RelDataType) - Static method in class org.apache.calcite.rel.core.Collect
-
Derives the output row type of a Collect relational expression.
- deriveSumType(RelDataTypeFactory, RelDataType) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- deriveSumType(RelDataTypeFactory, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns the return type of a call to the
SUM
aggregate function, inferred from its argument type. - deriveSumType(RelDataTypeFactory, RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- deriveTimeFrameSet(TimeFrameSet) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- deriveTimeFrameSet(TimeFrameSet) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns a list of supported time frames.
- deriveTraits(RelTraitSet, int) - Method in class org.apache.calcite.adapter.enumerable.EnumerableAsofJoin
- deriveTraits(RelTraitSet, int) - Method in class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoin
- deriveTraits(RelTraitSet, int) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCalc
- deriveTraits(RelTraitSet, int) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCorrelate
- deriveTraits(RelTraitSet, int) - Method in class org.apache.calcite.adapter.enumerable.EnumerableFilter
- deriveTraits(RelTraitSet, int) - Method in class org.apache.calcite.adapter.enumerable.EnumerableHashJoin
- deriveTraits(RelTraitSet, int) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMergeJoin
- deriveTraits(RelTraitSet, int) - Method in class org.apache.calcite.adapter.enumerable.EnumerableNestedLoopJoin
- deriveTraits(RelTraitSet, int) - Method in class org.apache.calcite.adapter.enumerable.EnumerableProject
- deriveTraits(RelTraitSet, int) - Method in interface org.apache.calcite.adapter.enumerable.EnumerableRel
- deriveTraits(RelTraitSet, int) - Method in interface org.apache.calcite.rel.PhysicalNode
-
Derive traitset from child node, returns a pair of traits after traits derivation.
- deriveType(RelDataTypeFactory, RelDataType, RelDataType, boolean) - Static method in class org.apache.calcite.sql.fun.SqlCastFunction
-
Derives the type of "CAST(expression AS targetType)".
- deriveType(SqlCallBinding) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Derives type of the call via its binding.
- deriveType(SqlCallBinding, List<? extends SqlNode>) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Derives types for the list of nodes.
- deriveType(SqlCallBinding, SqlNode) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Derives type of the given call under given binding.
- deriveType(SqlValidator) - Method in class org.apache.calcite.sql.SqlBasicTypeNameSpec
- deriveType(SqlValidator) - Method in class org.apache.calcite.sql.SqlCollectionTypeNameSpec
- deriveType(SqlValidator) - Method in class org.apache.calcite.sql.SqlDataTypeSpec
-
Converts this type specification to a
RelDataType
. - deriveType(SqlValidator) - Method in class org.apache.calcite.sql.SqlMapTypeNameSpec
- deriveType(SqlValidator) - Method in class org.apache.calcite.sql.SqlRowTypeNameSpec
- deriveType(SqlValidator) - Method in class org.apache.calcite.sql.SqlTypeNameSpec
-
Derive type from this SqlTypeNameSpec.
- deriveType(SqlValidator) - Method in class org.apache.calcite.sql.SqlUserDefinedTypeNameSpec
- deriveType(SqlValidator, boolean) - Method in class org.apache.calcite.sql.SqlDataTypeSpec
-
Converts this type specification to a
RelDataType
. - deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlCaseOperator
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlConvertFunction
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlCountAggFunction
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlCursorConstructor
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlDotOperator
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlFloorFunction
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlInOperator
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlJsonArrayAggAggFunction
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlJsonObjectAggAggFunction
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlMultisetQueryConstructor
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlQuantifyOperator
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlSequenceValueOperator
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.SqlAsOperator
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.SqlBinaryOperator
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.SqlDescriptorOperator
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.SqlFilterOperator
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.SqlFunction
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.SqlInternalOperator
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.SqlOperator
-
Derives the type of a call to this operator.
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.SqlOverOperator
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.SqlSetSemanticsTableOperator
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.SqlWithinDistinctOperator
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.SqlWithinGroupOperator
- deriveType(SqlValidatorScope, SqlNode) - Method in class org.apache.calcite.sql.advise.SqlAdvisorValidator
-
Calls the parent class method and mask Farrago exception thrown.
- deriveType(SqlValidatorScope, SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Derives the type of a node in a given scope.
- deriveType(SqlValidatorScope, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- deriveUncollectRowType(RelNode, boolean, List<String>) - Static method in class org.apache.calcite.rel.core.Uncollect
-
Returns the row type returned by applying the 'UNNEST' operation to a relational expression.
- desc(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Converts a sort expression to descending.
- DESC - Enum constant in enum org.apache.calcite.piglet.Ast.Direction
- DESC - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeSort
- DESC - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- descendants - Variable in class org.apache.calcite.materialize.LatticeRootNode
-
Descendants, in prefix order.
- descendants(MutableRel) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- DESCENDING - Enum constant in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Descending direction: A value is always followed by a lesser or equal value.
- DESCENDING - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DESC
operator inORDER BY
. - describe(PrintWriter, boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Prints the property settings of this pretty-writer to a writer.
- DESCRIBE - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- DESCRIBE_SCHEMA - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DESCRIBE SCHEMA statement.
- DESCRIBE_TABLE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DESCRIBE TABLE statement.
- DescribeStmt(SqlParserPos, Ast.Identifier) - Constructor for class org.apache.calcite.piglet.Ast.DescribeStmt
- describeTo(Description) - Method in class org.apache.calcite.test.Matchers.IsWithin
- description - Variable in class org.apache.calcite.plan.RelOptRule
-
Description of rule, must be unique within planner.
- description() - Method in interface org.apache.calcite.plan.RelRule.Config
-
Description of the rule instance.
- DescriptiveCacheKey - Class in org.apache.calcite.rel.metadata.janino
-
A key used in caching with descriptive to string.
- DescriptiveCacheKey(String) - Constructor for class org.apache.calcite.rel.metadata.janino.DescriptiveCacheKey
- DESCRIPTOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
DESCRIPTOR(column_name, ...)
. - DESCRIPTOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
DESCRIPTOR(column_name, ...).
- destFields - Variable in class org.apache.calcite.plan.RelOptUtil.RexInputConverter
- detailLevel - Variable in class org.apache.calcite.rel.externalize.RelWriterImpl
- Deterministic - Annotation Type in org.apache.calcite.linq4j.function
-
Specifies that function is deterministic (i.e.
- DeterministicAutomaton - Class in org.apache.calcite.runtime
-
A deterministic finite automaton (DFA).
- DeterministicCodeOptimizer - Class in org.apache.calcite.linq4j.tree
-
Factors out deterministic expressions to final static fields.
- DeterministicCodeOptimizer(ClassDeclarationFinder) - Constructor for class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Creates a child optimizer.
- dialect - Variable in class org.apache.calcite.adapter.jdbc.JdbcCatalogSchema
- dialect - Variable in class org.apache.calcite.adapter.jdbc.JdbcConvention
- dialect - Variable in class org.apache.calcite.adapter.jdbc.JdbcSchema
- dialect - Variable in class org.apache.calcite.materialize.Lattice.SqlWriter
- dialect - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor
- dialect - Variable in class org.apache.calcite.sql.parser.SqlParserFixture
- dialect() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the dialect.
- dialectDoesNotSupportFeature(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- diff(File, File) - Static method in class org.apache.calcite.test.DiffTestCase
-
Returns a string containing the difference between the contents of two files.
- diffDate(int, int, TimeFrame) - Method in class org.apache.calcite.rel.type.TimeFrameSet
- difference(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL DIFFERENCE(string, string) function.
- difference(RelTraitSet) - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns a list of traits that are in
traitSet
but not in this RelTraitSet. - DIFFERENCE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DIFFERENCE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- differentCollations(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- differentLengthForBitwiseOperands(int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- diffFile(File, File) - Method in class org.apache.calcite.test.DiffTestCase
-
Compares a log file with its reference log.
- diffLines(List<String>, List<String>) - Static method in class org.apache.calcite.test.DiffTestCase
-
Returns a string containing the difference between the two sets of lines.
- diffRepos() - Method in class org.apache.calcite.test.RelOptFixture
-
Returns the diff repository, checking that it is not null.
- diffRepos() - Method in class org.apache.calcite.test.SqlToRelFixture
- DiffRepository - Class in org.apache.calcite.test
-
A collection of resources used by tests.
- DiffRepository.Filter - Interface in org.apache.calcite.test
-
Callback to filter strings before returning them.
- DiffTestCase - Class in org.apache.calcite.test
-
DiffTestCase is an abstract base for JUnit tests which produce multi-line output to be verified by diffing against a pre-existing reference file.
- DiffTestCase(String) - Constructor for class org.apache.calcite.test.DiffTestCase
-
Initializes a new DiffTestCase.
- diffTestLog() - Method in class org.apache.calcite.test.DiffTestCase
-
Finishes a diff-based test.
- diffTimestamp(long, long, TimeFrame) - Method in class org.apache.calcite.rel.type.TimeFrameSet
- digest - Variable in class org.apache.calcite.materialize.Lattice.Measure
- digest - Variable in class org.apache.calcite.materialize.LatticeNode
- digest - Variable in class org.apache.calcite.rel.AbstractRelNode
-
The digest that uniquely identifies the node.
- digest - Variable in class org.apache.calcite.rel.type.RelDataTypeImpl
- digest - Variable in class org.apache.calcite.rex.RexNode
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.Holder
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableAggregate
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableCalc
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableCollect
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableCorrelate
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableExchange
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableFilter
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableIntersect
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableJoin
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableMatch
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableMinus
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableProject
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableRel
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableSample
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableScan
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableSort
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableTableFunctionScan
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableTableModify
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableUncollect
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableUnion
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableValues
- digest(StringBuilder) - Method in class org.apache.calcite.rel.mutable.MutableWindow
- DIGEST_ATTRIBUTES - Enum constant in enum org.apache.calcite.sql.SqlExplainLevel
-
Display only attributes which contribute to an expression's digest.
- dimension - Variable in class org.apache.calcite.linq4j.tree.NewArrayExpression
- dimensions - Variable in class org.apache.calcite.materialize.Lattice.Tile
- dimensions - Variable in class org.apache.calcite.materialize.TileKey
- dimensions - Variable in class org.apache.calcite.model.JsonTile
-
List of dimensions that define this tile.
- DimensionSpec - Interface in org.apache.calcite.adapter.druid
-
Interface for Druid DimensionSpec.
- DIRECT - Enum constant in enum org.apache.calcite.sql.SqlDialect.CalendarPolicy
- DirectedGraph<V,
E> - Interface in org.apache.calcite.util.graph -
Directed graph.
- DirectedGraph.EdgeFactory<V,
E> - Interface in org.apache.calcite.util.graph -
Factory for edges.
- direction - Variable in class org.apache.calcite.rel.RelFieldCollation
-
Direction of sorting.
- DirectOperatorConversion - Class in org.apache.calcite.adapter.druid
-
Direct operator conversion for expression like Function(exp_1,...exp_n)
- DirectOperatorConversion(SqlOperator, String) - Constructor for class org.apache.calcite.adapter.druid.DirectOperatorConversion
- disallowsNullTreatment(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- disallowsQualifyingCommonColumn(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- discard(boolean) - Static method in class org.apache.calcite.util.Util
-
Does nothing with its argument.
- discard(double) - Static method in class org.apache.calcite.util.Util
-
Does nothing with its argument.
- discard(int) - Static method in class org.apache.calcite.util.Util
-
Does nothing with its argument.
- discard(Object) - Static method in class org.apache.calcite.util.Util
-
Does nothing with its argument.
- discard(Object) - Static method in class org.apache.calcite.linq4j.tree.Types
- disjunctions(RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a condition decomposed by OR.
- dispatch(RelNode) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Dispatches a call to the
visit(Xxx e)
method whereXxx
most closely matches the runtime type of the argument. - dispatcher - Variable in class org.apache.calcite.sql2rel.RelDecorrelator
- dispatchTrimFields(RelNode, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Invokes
RelFieldTrimmer.trimFields(org.apache.calcite.rel.RelNode, org.apache.calcite.util.ImmutableBitSet, java.util.Set<org.apache.calcite.rel.type.RelDataTypeField>)
, or the appropriate method for the type of the rel parameter, using multi-method dispatch. - distinct - Variable in class org.apache.calcite.materialize.Lattice.Measure
- distinct - Variable in class org.apache.calcite.rel.core.Window.RexWinAggCall
-
Whether to eliminate duplicates before applying aggregate function.
- distinct() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- distinct() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- distinct() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns distinct elements from a sequence by using the default equality comparer to compare values.
- distinct() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns distinct elements from a sequence by using the default equality comparer to compare values.
- distinct() - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
-
Returns a copy of this AggCall that is distinct.
- distinct() - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
Aggregate
that makes the relational expression distinct on all fields. - distinct(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
-
Returns a copy of this AggCall that is optionally distinct.
- distinct(List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_DISTINCT function.
- distinct(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns distinct elements from a sequence by using the default
EqualityComparer
to compare values. - distinct(Enumerable<TSource>, EqualityComparer<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns distinct elements from a sequence by using a specified
EqualityComparer
to compare values. - distinct(EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- distinct(EqualityComparer<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- distinct(EqualityComparer<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns distinct elements from a sequence by using a specified
EqualityComparer<TSource>
to compare values. - distinct(EqualityComparer<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns distinct elements from a sequence by using a specified EqualityComparer<TSource> to compare values.
- distinct(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns distinct elements from a sequence by using the default equality comparer to compare values.
- distinct(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns distinct elements from a sequence by using the default equality comparer to compare values.
- distinct(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- distinct(Queryable<T>, EqualityComparer) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns distinct elements from a sequence by using a specified
EqualityComparer<T>
to compare values. - distinct(Queryable<T>, EqualityComparer<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns distinct elements from a sequence by using a specified
EqualityComparer<T>
to compare values. - distinct(Queryable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- distinct(PigRelBuilder.Partitioner, int) - Method in class org.apache.calcite.tools.PigRelBuilder
-
Removes duplicate tuples in a relation.
- DISTINCT - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- DISTINCT - Enum constant in enum org.apache.calcite.sql.SqlSelectKeyword
- DISTINCT - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- DISTINCT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DISTINCT_FIELD_SUFFIX - Static variable in class org.apache.calcite.adapter.pig.PigAggregate
- DISTINCT_ROW_COUNT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- DISTINCT2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- distinctCall - Variable in class org.apache.calcite.sql.validate.SqlValidatorUtil.FlatAggregate
- distinctCopy(Iterable<String>) - Method in interface org.apache.calcite.sql.validate.SqlNameMatcher
-
Returns a copy of a collection, removing duplicates and retaining iteration order.
- distinctKeys - Variable in class org.apache.calcite.rel.core.AggregateCall
- distinctList - Variable in class org.apache.calcite.sql.validate.SqlValidatorUtil.FlatAggregate
- distinctList(Iterable<E>) - Static method in class org.apache.calcite.util.Util
-
Converts an iterable into a list with unique elements.
- distinctList(List<E>) - Static method in class org.apache.calcite.util.Util
-
Converts a list into a list with unique elements.
- DistinctStmt(SqlParserPos, Ast.Identifier, Ast.Identifier) - Constructor for class org.apache.calcite.piglet.Ast.DistinctStmt
- distribution - Variable in class org.apache.calcite.rel.core.Exchange
- distribution - Variable in class org.apache.calcite.rel.mutable.MutableExchange
- distribution() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Distribution
-
Determines how the rows are distributed.
- distribution(BiRel, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdDistribution
- distribution(Exchange, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdDistribution
- distribution(Project, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdDistribution
- distribution(SetOp, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdDistribution
- distribution(TableModify, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdDistribution
- distribution(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdDistribution
- distribution(Values, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdDistribution
- distribution(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.Distribution.distribution()
statistic. - distribution(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Distribution.Handler
- distribution(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdDistribution
-
Fallback method to deduce distribution for any relational expression not handled by a more specific method.
- distribution(SingleRel, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdDistribution
- Distribution(SortedSet<Profiler.Column>, SortedSet<Comparable>, double, int, double, boolean) - Constructor for class org.apache.calcite.profile.Profiler.Distribution
-
Creates a Distribution.
- DISTRIBUTION - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- distributionList - Variable in class org.apache.calcite.profile.Profiler.Profile
- divide(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
/
operator applied to int values. - divide(int, Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
/
operator applied to int values; right side may be null. - divide(int, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
- divide(long, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
- divide(Double, Double) - Static method in class org.apache.calcite.util.NumberUtil
-
Returns the quotient of two numbers, or null if either is null or the divisor is zero.
- divide(Integer, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
/
operator applied to int values; left side may be null. - divide(Integer, Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
/
operator applied to nullable int values. - divide(Integer, Long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
/
operator applied to nullable int and long values. - divide(Long, Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
/
operator applied to nullable long and int values. - divide(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
/
operator applied to BigDecimal values. - divide(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic division operation.
- divide(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic division operation.
- divide(Mapping, Mapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Divides one mapping by another.
- Divide - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A division operation, such as (a / b), for numeric operands.
- DIVIDE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Arithmetic division operator, "/".
- DIVIDE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Arithmetic division operator, '
/
'. - DIVIDE_INTEGER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Internal integer arithmetic division operator, '
/INT
'. - divideAny(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
/
operator applied to Object values (at least one operand has ANY type; either may be null). - divideAssign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a division assignment operation that does not have overflow checking.
- divideAssign(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a division assignment operation that does not have overflow checking.
- divideAssign(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a division assignment operation that does not have overflow checking.
- DivideAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An division compound assignment operation, such as (a /= b), for numeric operands.
- divideBy(RelOptCost) - Method in interface org.apache.calcite.plan.RelOptCost
-
Computes the ratio between this cost and another cost.
- divideBy(RelOptCost) - Method in class org.apache.calcite.plan.RelOptCostImpl
- DIVISION_BY_ZERO_MESSAGE - Static variable in interface org.apache.calcite.sql.test.SqlOperatorFixture
- DIVISION_OPERATOR - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Type-checking strategy for the "/" operator.
- DML - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category consisting of all DML operators.
- DmlNamespace(SqlValidatorImpl, SqlNode, SqlNode, SqlValidatorScope) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.DmlNamespace
- done(RelNode) - Method in class org.apache.calcite.rel.externalize.RelDotWriter
- done(RelNode) - Method in class org.apache.calcite.rel.externalize.RelJsonWriter
- done(RelNode) - Method in class org.apache.calcite.rel.externalize.RelWriterImpl
- done(RelNode) - Method in interface org.apache.calcite.rel.RelWriter
-
Writes the completed explanation.
- dot(RexNode, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an access to a field by ordinal.
- dot(RexNode, Object) - Method in class org.apache.calcite.piglet.PigRelBuilder
- dot(RexNode, String) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an access to a field by name.
- DOT - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- DOT - Enum constant in enum org.apache.calcite.sql.SqlExplainFormat
-
Indicates that the plan should be output in dot format.
- DOT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Dot.
- DOT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Dot operator, '
.
', used for referencing fields of records. - DOUBLE - Enum constant in enum org.apache.calcite.adapter.druid.DruidType
- DOUBLE - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive
- DOUBLE - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- DOUBLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is Double.
- DOUBLE - Static variable in interface org.apache.calcite.util.JdbcType
- DOUBLE_FORCE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is a nullable Double.
- DOUBLE_IF_INTEGERS - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is
ReturnTypes.DOUBLE
if both operands are integer types. - DOUBLE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is Double with nulls allowed if any of the operands allow nulls.
- DOUBLE_NULLABLE - Static variable in interface org.apache.calcite.util.JdbcType
- DoubleFunction1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function that takes one parameter and returns a native
double
value. - DoubleSum() - Constructor for class org.apache.calcite.interpreter.AggregateNode.DoubleSum
- doWithConnection(Consumer<CalciteConnection>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Creates a
CalciteConnection
and executes a callback that returns no result. - doWithConnection(Function<CalciteConnection, T>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Creates a
CalciteConnection
and executes a callback. - doWithDataContext(Function<DataContext, T>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Creates a
DataContext
and executes a callback. - driver - Variable in class org.apache.calcite.test.ConnectionSpec
- Driver - Class in org.apache.calcite.jdbc
-
Calcite JDBC driver.
- Driver() - Constructor for class org.apache.calcite.jdbc.Driver
-
Creates a Driver.
- Driver(Supplier<CalcitePrepare>) - Constructor for class org.apache.calcite.jdbc.Driver
-
Creates a Driver with a factory for
CalcitePrepare
objects; if the factory is null, the driver will callDriver.createPrepareFactory()
. - DRIVER_URL - Static variable in class org.apache.calcite.chinook.CalciteConnectionProvider
- DROP_FUNCTION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DROP FUNCTION
DDL statement. - DROP_INDEX - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DROP INDEX
DDL statement. - DROP_MATERIALIZED_VIEW - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DROP MATERIALIZED VIEW
DDL statement. - DROP_SCHEMA - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DROP SCHEMA
DDL statement. - DROP_SEQUENCE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DROP SEQUENCE
DDL statement. - DROP_TABLE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DROP TABLE
DDL statement. - DROP_TYPE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DROP TYPE
DDL statement. - DROP_VIEW - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DROP VIEW
DDL statement. - dropFunction(SqlParserPos, boolean, SqlIdentifier) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a DROP FUNCTION.
- dropMaterializedView(SqlParserPos, boolean, SqlIdentifier) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a DROP MATERIALIZED VIEW.
- dropSchema(SqlParserPos, boolean, boolean, SqlIdentifier) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a DROP [ FOREIGN ] SCHEMA.
- dropTable(SqlParserPos, boolean, SqlIdentifier) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a DROP TABLE.
- dropType(SqlParserPos, boolean, SqlIdentifier) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a DROP TYPE.
- dropView(SqlParserPos, boolean, SqlIdentifier) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a DROP VIEW.
- DRUID_BETWEEN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Variant of
BETWEEN
for the Druid adapter. - DRUID_BETWEEN - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
A BETWEEN operator for Druid, analogous to
SqlInternalOperators.DRUID_IN
. - DRUID_FETCH - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
How many rows the Druid adapter should fetch at a time when executing "select" queries.
- DRUID_HAVING_FILTER_RULE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- DRUID_IN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Variant of
IN
for the Druid adapter. - DRUID_IN - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
An IN operator for Druid.
- DRUID_NOT_IN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Variant of
NOT_IN
for the Druid adapter. - DRUID_NOT_IN - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
A NOT IN operator for Druid, analogous to
SqlInternalOperators.DRUID_IN
. - DRUID_QUERY_FETCH - Static variable in class org.apache.calcite.adapter.druid.DruidQuery
- DruidAggregateProjectRule(DruidRules.DruidAggregateProjectRule.DruidAggregateProjectRuleConfig) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidAggregateProjectRule
-
Creates a DruidAggregateProjectRule.
- DruidAggregateRule(DruidRules.DruidAggregateRule.DruidAggregateRuleConfig) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidAggregateRule
-
Creates a DruidAggregateRule.
- DruidConnection - Interface in org.apache.calcite.adapter.druid
-
Connection to Druid.
- DruidDateTimeUtils - Class in org.apache.calcite.adapter.druid
-
Utilities for generating intervals from RexNode.
- DruidExpressions - Class in org.apache.calcite.adapter.druid
-
Expression utility class to transform Calcite expressions to Druid expressions when possible.
- DruidFilterRule(DruidRules.DruidFilterRule.DruidFilterRuleConfig) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidFilterRule
-
Creates a DruidFilterRule.
- DruidHavingFilterRule(DruidRules.DruidHavingFilterRule.DruidHavingFilterRuleConfig) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidHavingFilterRule
-
Creates a DruidHavingFilterRule.
- DruidJson - Interface in org.apache.calcite.adapter.druid
-
Object that knows how to write itself to a
JsonGenerator
. - DruidPostAggregationProjectRule(DruidRules.DruidPostAggregationProjectRule.DruidPostAggregationProjectRuleConfig) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidPostAggregationProjectRule
-
Creates a DruidPostAggregationProjectRule.
- DruidProjectRule(DruidRules.DruidProjectRule.DruidProjectRuleConfig) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidProjectRule
-
Creates a DruidProjectRule.
- DruidQuery - Class in org.apache.calcite.adapter.druid
-
Relational expression representing a scan of a Druid data set.
- DruidQuery(RelOptCluster, RelTraitSet, RelOptTable, DruidTable, List<Interval>, List<RelNode>, Map<SqlOperator, DruidSqlOperatorConverter>) - Constructor for class org.apache.calcite.adapter.druid.DruidQuery
-
Creates a DruidQuery.
- DruidQuery.JsonPostAggregation - Class in org.apache.calcite.adapter.druid
-
Post-aggregator abstract writer.
- DruidQuery.QuerySpec - Class in org.apache.calcite.adapter.druid
-
Druid query specification.
- DruidRules - Class in org.apache.calcite.adapter.druid
-
Rules and relational operators for
DruidQuery
. - DruidRules.DruidAggregateProjectRule - Class in org.apache.calcite.adapter.druid
- DruidRules.DruidAggregateProjectRule.DruidAggregateProjectRuleConfig - Interface in org.apache.calcite.adapter.druid
-
Rule configuration.
- DruidRules.DruidAggregateRule - Class in org.apache.calcite.adapter.druid
-
Rule to push an
Aggregate
into aDruidQuery
. - DruidRules.DruidAggregateRule.DruidAggregateRuleConfig - Interface in org.apache.calcite.adapter.druid
-
Rule configuration.
- DruidRules.DruidFilterRule - Class in org.apache.calcite.adapter.druid
-
Rule to push a
Filter
into aDruidQuery
. - DruidRules.DruidFilterRule.DruidFilterRuleConfig - Interface in org.apache.calcite.adapter.druid
-
Rule configuration.
- DruidRules.DruidHavingFilterRule - Class in org.apache.calcite.adapter.druid
-
Rule to Push a Having
Filter
into aDruidQuery
. - DruidRules.DruidHavingFilterRule.DruidHavingFilterRuleConfig - Interface in org.apache.calcite.adapter.druid
-
Rule configuration.
- DruidRules.DruidPostAggregationProjectRule - Class in org.apache.calcite.adapter.druid
-
Rule to push a
Project
into aDruidQuery
as a Post aggregator. - DruidRules.DruidPostAggregationProjectRule.DruidPostAggregationProjectRuleConfig - Interface in org.apache.calcite.adapter.druid
-
Rule configuration.
- DruidRules.DruidProjectRule - Class in org.apache.calcite.adapter.druid
-
Rule to push a
Project
into aDruidQuery
. - DruidRules.DruidProjectRule.DruidProjectRuleConfig - Interface in org.apache.calcite.adapter.druid
-
Rule configuration.
- DruidRules.DruidSortRule - Class in org.apache.calcite.adapter.druid
-
Rule to push a
Sort
into aDruidQuery
. - DruidRules.DruidSortRule.DruidSortRuleConfig - Interface in org.apache.calcite.adapter.druid
-
Rule configuration.
- DruidSchema - Class in org.apache.calcite.adapter.druid
-
Schema mapped onto a Druid instance.
- DruidSchema(String, String, boolean) - Constructor for class org.apache.calcite.adapter.druid.DruidSchema
-
Creates a Druid schema.
- DruidSchemaFactory - Class in org.apache.calcite.adapter.druid
-
Schema factory that creates Druid schemas.
- DruidSchemaFactory() - Constructor for class org.apache.calcite.adapter.druid.DruidSchemaFactory
- DruidSortRule(DruidRules.DruidSortRule.DruidSortRuleConfig) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidSortRule
-
Creates a DruidSortRule.
- DruidSqlCastConverter - Class in org.apache.calcite.adapter.druid
-
Druid cast converter operator; used to translates Calcite casts to Druid expression casts.
- DruidSqlCastConverter() - Constructor for class org.apache.calcite.adapter.druid.DruidSqlCastConverter
- DruidSqlOperatorConverter - Interface in org.apache.calcite.adapter.druid
-
Defines how to convert a
RexNode
with a given Calcite SQL operator to a Druid expression. - DruidTable - Class in org.apache.calcite.adapter.druid
-
Table mapped onto a Druid table.
- DruidTable(DruidSchema, String, RelProtoDataType, Set<String>, String, List<Interval>, Map<String, List<ComplexMetric>>, Map<String, SqlTypeName>) - Constructor for class org.apache.calcite.adapter.druid.DruidTable
-
Creates a Druid table.
- DruidTableFactory - Class in org.apache.calcite.adapter.druid
-
Implementation of
TableFactory
for Druid. - DruidType - Enum in org.apache.calcite.adapter.druid
-
Druid type.
- DT1684_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether dtbug1684 "CURRENT_DATE not implemented in fennel calc" is fixed.
- DT239_FIXED - Static variable in class org.apache.calcite.util.Bug
- DT785_FIXED - Static variable in class org.apache.calcite.util.Bug
- DUMMY - Static variable in class org.apache.calcite.rel.metadata.MetadataFactoryImpl
-
Deprecated.
- DUMMY_TABLE_METHOD_WITH_TWO_PARAMS - Static variable in class org.apache.calcite.util.Smalls
- dummyProject(int, RelNode) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Creates a project with a dummy column, to protect the parts of the system that cannot handle a relational expression with no columns.
- dummyProject(int, RelNode, RelNode) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Creates a project with a dummy column, to protect the parts of the system that cannot handle a relational expression with no columns.
- dummyTableFuncWithTwoParams(long, long) - Static method in class org.apache.calcite.util.Smalls
-
A function that takes 2 param as input.
- dump(PrintWriter) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Dumps the internal state of this VolcanoPlanner to a writer.
- dump(RelNode) - Method in class org.apache.calcite.piglet.Handler
-
Executes a relational expression and prints the output.
- DUMP - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- DUMP_GRAPHVIZ - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to include a GraphViz representation when dumping the state of the Volcano planner.
- DUMP_SETS - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to include
RelSet
information when dumping the state of the Volcano planner. - dumpPlan(String, RelNode, boolean, SqlExplainLevel) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- dumpPlan(String, RelNode, SqlExplainFormat, SqlExplainLevel) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Dumps a plan as a string.
- dumpRuleAttemptsInfo() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- DumpStmt(SqlParserPos, Ast.Identifier) - Constructor for class org.apache.calcite.piglet.Ast.DumpStmt
- dumpType(RelDataType) - Static method in class org.apache.calcite.plan.RelOptUtil
- duplicateArgumentName(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- duplicateColumnAndNoColumnList(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- duplicateColumnName(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- duplicateNameInColumnList(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- duplicateTargetColumn(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- duplicateWindowName() - Method in interface org.apache.calcite.runtime.CalciteResource
- dupWindowSpec() - Method in interface org.apache.calcite.runtime.CalciteResource
- DuTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "du" ("disk usage") command to compute file sizes.
- dy - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- Dy - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- DY - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- DYADIC_STRING_SUM_PRECISION - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy for concatenating two string arguments.
- DYADIC_STRING_SUM_PRECISION_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.DYADIC_STRING_SUM_PRECISION
and usingSqlTypeTransforms.TO_NULLABLE
. - DYADIC_STRING_SUM_PRECISION_NULLABLE_VARYING - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- dynamic(CallSiteBinder, Type, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a DynamicExpression that represents a dynamic operation bound by the provided CallSiteBinder.
- dynamic(CallSiteBinder, Type, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a
DynamicExpression
that represents a dynamic operation bound by the providedCallSiteBinder
, using varargs. - Dynamic - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A dynamic operation.
- DYNAMIC_PARAM - Enum constant in enum org.apache.calcite.sql.SqlKind
-
A dynamic parameter.
- DYNAMIC_ROW_TYPE_TABLE_METHOD - Static variable in class org.apache.calcite.util.Smalls
- DYNAMIC_STAR - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- DYNAMIC_STAR_PREFIX - Static variable in class org.apache.calcite.rel.type.DynamicRecordType
- DynamicExpression - Class in org.apache.calcite.linq4j.tree
-
Represents a dynamic operation.
- DynamicExpression(Class) - Constructor for class org.apache.calcite.linq4j.tree.DynamicExpression
- dynamicInvoke(Object...) - Method in interface org.apache.calcite.linq4j.tree.FunctionExpression.Invokable
- dynamicParam(int) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- dynamicParam(int) - Method in interface org.apache.calcite.sql.SqlWriter
-
Prints a dynamic parameter (e.g.
- dynamicParamIllegal() - Method in interface org.apache.calcite.runtime.CalciteResource
- DynamicRecordType - Class in org.apache.calcite.rel.type
-
Specific type of RelRecordType that corresponds to a dynamic table, where columns are created as they are requested.
- DynamicRecordType() - Constructor for class org.apache.calcite.rel.type.DynamicRecordType
- DynamicRecordTypeImpl - Class in org.apache.calcite.rel.type
-
Implementation of
RelDataType
for a dynamic table. - DynamicRecordTypeImpl(RelDataTypeFactory) - Constructor for class org.apache.calcite.rel.type.DynamicRecordTypeImpl
-
Creates a DynamicRecordTypeImpl.
- dynamicRowTypeTable(String, int) - Static method in class org.apache.calcite.util.Smalls
- DynamicTupleRecordType - Class in org.apache.calcite.piglet
-
Represents Pig Tuples with unknown fields.
- DynamicTypeFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.DynamicTypeFunction
E
- e - Variable in class org.apache.calcite.linq4j.Ord
- e - Variable in class org.apache.calcite.materialize.Lattice.DerivedColumn
- e - Variable in class org.apache.calcite.rex.RexAnalyzer
- E - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- EAGER - Enum constant in enum org.apache.calcite.rel.core.Spool.Type
- edgeSet() - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- edgeSet() - Method in interface org.apache.calcite.util.graph.DirectedGraph
- edit(Coordinate[], Geometry) - Method in class org.apache.calcite.runtime.AddPointOperation
- edit(Coordinate[], Geometry) - Method in class org.apache.calcite.runtime.RemovePointOperation
- ElasticsearchAggregate - Class in org.apache.calcite.adapter.elasticsearch
-
Implementation of
Aggregate
relational expression for ElasticSearch. - ElasticsearchFilter - Class in org.apache.calcite.adapter.elasticsearch
-
Implementation of a
Filter
relational expression in Elasticsearch. - ElasticsearchProject - Class in org.apache.calcite.adapter.elasticsearch
-
Implementation of
Project
relational expression in Elasticsearch. - ElasticsearchRel - Interface in org.apache.calcite.adapter.elasticsearch
-
Relational expression that uses Elasticsearch calling convention.
- ElasticsearchRel.Implementor - Class in org.apache.calcite.adapter.elasticsearch
-
Callback for the implementation process that converts a tree of
ElasticsearchRel
nodes into an Elasticsearch query. - ElasticsearchSchema - Class in org.apache.calcite.adapter.elasticsearch
-
Each table in the schema is an ELASTICSEARCH index.
- ElasticsearchSchema(RestClient, ObjectMapper, String) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchema
-
Allows schema to be instantiated from existing elastic search client.
- ElasticsearchSchemaFactory - Class in org.apache.calcite.adapter.elasticsearch
-
Factory that creates an
ElasticsearchSchema
. - ElasticsearchSchemaFactory() - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchemaFactory
- ElasticsearchSearchResult - Class in org.apache.calcite.adapter.elasticsearch
-
Internal object used to parse elastic search result.
- ElasticsearchSearchResult.SearchHit - Class in org.apache.calcite.adapter.elasticsearch
-
Concrete result record which matched the query.
- ElasticsearchSearchResult.SearchHits - Class in org.apache.calcite.adapter.elasticsearch
-
Similar to
SearchHits
in ES. - ElasticsearchSort - Class in org.apache.calcite.adapter.elasticsearch
-
Implementation of
Sort
relational expression in Elasticsearch. - ElasticsearchTable - Class in org.apache.calcite.adapter.elasticsearch
-
Table based on an Elasticsearch index.
- ElasticsearchTable.ElasticsearchQueryable<T> - Class in org.apache.calcite.adapter.elasticsearch
-
Implementation of
Queryable
based on aElasticsearchTable
. - ElasticsearchTableScan - Class in org.apache.calcite.adapter.elasticsearch
-
Relational expression representing a scan of an Elasticsearch type.
- ElasticsearchToEnumerableConverter - Class in org.apache.calcite.adapter.elasticsearch
-
Relational expression representing a scan of a table in an Elasticsearch data source.
- ElasticsearchToEnumerableConverterRule - Class in org.apache.calcite.adapter.elasticsearch
-
Rule to convert a relational expression from
ElasticsearchRel.CONVENTION
toEnumerableConvention
. - ElasticsearchToEnumerableConverterRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchToEnumerableConverterRule
-
Called from the Config.
- element(List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ELEMENT function.
- ELEMENT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ELEMENT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The ELEMENT operator, used to convert a multiset with only one item to a "regular" type.
- ELEMENT_SLICE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The internal "$ELEMENT_SLICE" operator returns the first field of the only element of a multiset.
- elementAt(int) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- elementAt(int) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the element at a specified index in a sequence.
- elementAt(Enumerable<TSource>, int) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the element at a specified index in a sequence.
- elementAt(Queryable<T>, int) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the element at a specified index in a sequence.
- elementAt(Queryable<T>, int) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the element at a specified index in a sequence.
- elementAt(Queryable<T>, int) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- elementAtOrDefault(int) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- elementAtOrDefault(int) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the element at a specified index in a sequence or a default value if the index is out of range.
- elementAtOrDefault(Enumerable<TSource>, int) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the element at a specified index in a sequence or a default value if the index is out of range.
- elementAtOrDefault(Queryable<T>, int) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the element at a specified index in a sequence or a default value if the index is out of range.
- elementAtOrDefault(Queryable<T>, int) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the element at a specified index in a sequence or a default value if the index is out of range.
- elementAtOrDefault(Queryable<T>, int) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- elementInit(Method, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an
ElementInit
, given anIterable<T>
as the second argument. - elementInit(Method, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an ElementInit, given an array of values as the second argument, using varargs.
- ElementInit - Class in org.apache.calcite.linq4j.tree
-
Represents an initializer for a single element of an
Enumerable
collection. - ElementInit() - Constructor for class org.apache.calcite.linq4j.tree.ElementInit
- elements - Variable in class org.apache.calcite.linq4j.CartesianProductEnumerator
- elementType - Variable in class org.apache.calcite.adapter.java.AbstractQueryableTable
- elementType - Variable in class org.apache.calcite.linq4j.BaseQueryable
- elementType - Variable in class org.apache.calcite.rel.mutable.MutableTableFunctionScan
- ELEVEN - Enum constant in enum org.apache.calcite.util.mapping.MappingType
- embeddedQuery() - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Returns whether to treat the query being validated as embedded (as opposed to top-level).
- emit(List<E>, List<Integer>, List<String>, int, Consumer<TResult>) - Method in interface org.apache.calcite.runtime.Enumerables.Emitter
- EMITTER_EMIT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- empid - Variable in class org.apache.calcite.test.schemata.hr.Dependent
- empid - Variable in class org.apache.calcite.test.schemata.hr.Employee
- Employee - Class in org.apache.calcite.test.schemata.hr
-
Employee model.
- Employee(int, int, String, float, Integer) - Constructor for class org.apache.calcite.test.schemata.hr.Employee
- employees - Variable in class org.apache.calcite.test.schemata.hr.Department
- EMPNO - Variable in class org.apache.calcite.test.schemata.lingual.LingualEmp
- emps - Variable in class org.apache.calcite.test.schemata.hr.HierarchySchema
- emps - Variable in class org.apache.calcite.test.schemata.hr.HrSchema
- emps - Variable in class org.apache.calcite.test.schemata.hr.HrSchemaBig
- EMPS - Variable in class org.apache.calcite.test.schemata.lingual.LingualSchema
- empty() - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an empty expression that has Void type.
- empty() - Static method in class org.apache.calcite.plan.Contexts
-
Returns a context that returns null for all inquiries.
- empty() - Static method in class org.apache.calcite.test.ConnectionFactories
-
Returns an empty connection factory.
- empty() - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a relational expression that reads from an input and throws all of the rows away.
- empty() - Static method in class org.apache.calcite.util.Holder
-
Creates a holder containing null.
- empty() - Static method in class org.apache.calcite.util.MonotonicSupplier
-
Creates a MonotonicSupplier.
- EMPTY - Enum constant in enum org.apache.calcite.sql.SqlHint.HintOptionFormat
-
The hint has no options.
- EMPTY - Enum constant in enum org.apache.calcite.sql.SqlJsonEmptyOrError
- EMPTY - Enum constant in enum org.apache.calcite.test.CalciteAssert.Config
-
Configuration that creates an empty connection.
- EMPTY - Static variable in class org.apache.calcite.DataContexts
-
Instance of
DataContext
that has no variables. - EMPTY - Static variable in class org.apache.calcite.plan.RelOptPredicateList
- EMPTY - Static variable in class org.apache.calcite.rel.hint.HintStrategyTable
-
Empty strategies.
- EMPTY - Static variable in class org.apache.calcite.rel.RelCollationImpl
-
Deprecated.
- EMPTY - Static variable in class org.apache.calcite.rel.RelCollations
-
A collation indicating that a relation is not sorted.
- EMPTY - Static variable in class org.apache.calcite.rel.RelDistributions
- EMPTY - Static variable in interface org.apache.calcite.runtime.Hook.Closeable
-
Closeable that does nothing.
- EMPTY - Static variable in class org.apache.calcite.sql.dialect.JethroDataSqlDialect.JethroInfo
- EMPTY - Static variable in class org.apache.calcite.sql.SqlNodeList
-
An immutable, empty SqlNodeList.
- EMPTY - Static variable in class org.apache.calcite.sql.validate.SqlValidatorScope.Path
-
The empty path.
- EMPTY_ARRAY - Enum constant in enum org.apache.calcite.sql.SqlJsonQueryEmptyOrErrorBehavior
- EMPTY_ARRAY - Static variable in class org.apache.calcite.sql.SqlNode
- EMPTY_CONTEXT - Static variable in class org.apache.calcite.plan.Contexts
- EMPTY_CONTEXT - Static variable in class org.apache.calcite.sql.SqlDialect
-
Empty context.
- EMPTY_ENUMERABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- EMPTY_ENUMERABLE - Static variable in class org.apache.calcite.linq4j.Linq4j
- EMPTY_OBJECT - Enum constant in enum org.apache.calcite.sql.SqlJsonQueryEmptyOrErrorBehavior
- EMPTY_STATEMENT - Static variable in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- EMPTY_TABLE_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts a
TableScan
to empty if the table has no rows in it. - emptyEnumerable() - Static method in class org.apache.calcite.linq4j.Linq4j
-
Returns an
Enumerable
that has no elements. - emptyEnumerator() - Static method in class org.apache.calcite.linq4j.Linq4j
-
Returns an
Enumerator
that has no elements. - EmptyPath() - Constructor for class org.apache.calcite.sql.validate.SqlValidatorScope.EmptyPath
- emptyResultOfJsonQueryFuncNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- emptyResultOfJsonValueFuncNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- emptyTag(String, XmlOutput.XMLAttrVector) - Method in class org.apache.calcite.util.XmlOutput
-
Writes an empty tag to the stream.
- emptyTraitSet() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- emptyTraitSet() - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Creates an empty trait set.
- emptyTraitSet() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- emptyWindowSpec() - Method in interface org.apache.calcite.runtime.CalciteResource
- emulateJoinTypeForCrossJoin() - Method in class org.apache.calcite.sql.dialect.SparkSqlDialect
- emulateJoinTypeForCrossJoin() - Method in class org.apache.calcite.sql.SqlDialect
- emulateNullDirection(SqlNode, boolean, boolean) - Method in class org.apache.calcite.sql.dialect.HiveSqlDialect
- emulateNullDirection(SqlNode, boolean, boolean) - Method in class org.apache.calcite.sql.dialect.JethroDataSqlDialect
- emulateNullDirection(SqlNode, boolean, boolean) - Method in class org.apache.calcite.sql.dialect.MssqlSqlDialect
-
Returns the SqlNode for emulating the null direction for the given field or
null
if no emulation needs to be done. - emulateNullDirection(SqlNode, boolean, boolean) - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- emulateNullDirection(SqlNode, boolean, boolean) - Method in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- emulateNullDirection(SqlNode, boolean, boolean) - Method in class org.apache.calcite.sql.SqlDialect
-
Returns the SqlNode for emulating the null direction for the given field or
null
if no emulation needs to be done. - emulateNullDirectionWithIsNull(SqlNode, boolean, boolean) - Method in class org.apache.calcite.sql.SqlDialect
- enable(boolean) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- enable(boolean) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- ENABLE_BINDABLE - Enum constant in enum org.apache.calcite.runtime.Hook
-
Returns a boolean value, whether the return convention should be
BindableConvention
. - ENABLE_COLLATION_TRAIT - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to enable the collation trait in the default planner configuration.
- ENABLE_ENUMERABLE - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether the enumerable convention is enabled in the default planner configuration.
- ENABLE_ENUMERABLE - Static variable in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Deprecated.
- ENABLE_REX_DIGEST_NORMALIZE - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether RexNode digest should be normalized (e.g.
- ENABLE_STREAM - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether streaming is enabled in the default planner configuration.
- ENABLE_STREAM - Static variable in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Deprecated.
- enableBindable - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Whether the bindable convention should be the root convention of any plan.
- enabled() - Method in class org.apache.calcite.adapter.spark.SparkHandlerImpl
- enabled() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.SparkHandler
- enabled() - Static method in class org.apache.calcite.util.Benchmark
-
Returns whether performance tests are enabled.
- enableDecorrelation() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Deprecated.
- enableMaterializations(boolean) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- enableTypeCoercion(boolean) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns a fixture that tests with implicit type coercion on/off.
- enclosingNode - Variable in class org.apache.calcite.sql.validate.IdentifierNamespace
- encodeIntervalOrDecimal(RexNode, RelDataType, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Casts a decimal's integer representation to a decimal node.
- encodeIntervalOrDecimal(SqlParserPos, RexNode, RelDataType, boolean) - Method in class org.apache.calcite.rex.RexBuilder
- encodeList(List<? extends CharSequence>, char) - Static method in class org.apache.calcite.adapter.splunk.util.StringUtils
- encodeValue(SqlParserPos, RexNode, RelDataType) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Casts a decimal's integer representation to a decimal node.
- encodeValue(SqlParserPos, RexNode, RelDataType, boolean) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Casts a decimal's integer representation to a decimal node.
- end - Variable in class org.apache.calcite.tools.Hoist.Variable
-
Zero-based position within the SQL text after end of node.
- end() - Method in interface org.apache.calcite.interpreter.Sink
- end(RexNode, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- end(RexNode, R) - Method in class org.apache.calcite.rex.RexUnaryBiVisitor
-
Called as the last action of, and providing the result for, each
visitXxx
method; derived classes may override. - end(SqlAbstractParserImpl) - Method in class org.apache.calcite.sql.parser.Span
-
Adds the position of the last token emitted by a parser to the list, and returns a position that covers the whole range.
- end(SqlNode) - Method in class org.apache.calcite.sql.parser.Span
-
Adds a node's position to the list, and returns a position that covers the whole range.
- END - Enum constant in enum org.apache.calcite.adapter.enumerable.WinAggImplementor.SeekType
-
End of window.
- endBeginTag(String) - Method in class org.apache.calcite.util.XmlOutput
- endFunCall(SqlWriter.Frame) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- endFunCall(SqlWriter.Frame) - Method in interface org.apache.calcite.sql.SqlWriter
-
Ends a list which is a call to a function.
- endIndex() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResetContextImpl
- endIndex() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- endIndex() - Method in interface org.apache.calcite.adapter.enumerable.WinAggFrameContext
-
Returns the index of the very last row in partition.
- endList(SqlWriter.Frame) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- endList(SqlWriter.Frame) - Method in interface org.apache.calcite.sql.SqlWriter
-
Ends a list.
- endOrdinal - Variable in class org.apache.calcite.sql.SqlSpecialOperator.ReduceResult
- ENDS_WITH - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ENDS_WITH
function. - ENDS_WITH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ENDS_WITH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ENDS_WITH(value1, value2)" function (BigQuery).
- endsWith(String) - Method in interface org.apache.calcite.util.Puffin.Line
-
Returns whether the current line ends with
suffix
. - endsWith(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ENDS_WITH(string, string)
function. - endsWith(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ENDS_WITH(binary, binary)
function. - ENDSWITH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ENDSWITH(value1, value2)" function (Snowflake).
- endTag(String) - Method in class org.apache.calcite.util.XmlOutput
-
Completes a tag.
- enforce(RelNode, RelTraitSet) - Method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- enforce(RelNode, RelTraitSet) - Method in enum org.apache.calcite.interpreter.BindableConvention
- enforce(RelNode, RelTraitSet) - Method in interface org.apache.calcite.plan.Convention
-
Given an input and required traits, returns the corresponding enforcer rel nodes, like physical Sort, Exchange etc.
- enforce(RelNode, RelTraitSet) - Method in class org.apache.calcite.plan.Convention.Impl
- enrich(PreparedStatement) - Method in interface org.apache.calcite.runtime.ResultSetEnumerable.PreparedStatementEnricher
- ensureRegistered(RelNode, RelNode) - Method in class org.apache.calcite.plan.hep.HepPlanner
- ensureRegistered(RelNode, RelNode) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Registers a relational expression if it is not already registered.
- ensureRegistered(RelNode, RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- ensureRegistered(RelNode, RelNode) - Method in class org.apache.calcite.test.MockRelOptPlanner
- ensureScale(SqlParserPos, RexNode, int, int) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Ensures a value is of a required scale.
- ensureType(RelDataType, RexNode, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Ensures expression is interpreted as a specified type.
- ensureType(SqlParserPos, RelDataType, RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Ensures expression is interpreted as a specified type.
- ensureType(SqlParserPos, RelDataType, RexNode, boolean) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Ensures expression is interpreted as a specified type.
- ensureType(SqlParserPos, RelDataType, RexNode, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Ensures expression is interpreted as a specified type.
- ensuring(Predicate<SqlToRelFixture>, UnaryOperator<SqlToRelFixture>) - Method in class org.apache.calcite.test.SqlToRelFixture
-
Returns a fixture that meets a given condition, applying a remedy if it does not already.
- Entry(CalciteSchema, String) - Constructor for class org.apache.calcite.jdbc.CalciteSchema.Entry
- entrySet() - Method in class org.apache.calcite.util.CompositeMap
- enumConstants(Class<T>) - Static method in class org.apache.calcite.util.Util
-
Creates a map of the values of an enumeration by name.
- enumerable - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- enumerable(DataContext) - Method in class org.apache.calcite.jdbc.CalcitePrepare.CalciteSignature
- enumerable(RelNode, Enumerable<Row>) - Method in interface org.apache.calcite.interpreter.Compiler
-
Tells the interpreter that a given relational expression wishes to give its output as an enumerable.
- enumerable(RelNode, Enumerable<Row>) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- enumerable(FilterableTable, DataContext) - Static method in class org.apache.calcite.schema.Schemas
-
Returns an
Enumerable
over the rows of a given table, not applying any filters, representing each row as an object array. - enumerable(ProjectableFilterableTable, DataContext) - Static method in class org.apache.calcite.schema.Schemas
-
Returns an
Enumerable
over the rows of a given table, not applying any filters and projecting all columns, representing each row as an object array. - enumerable(ScannableTable, DataContext) - Static method in class org.apache.calcite.schema.Schemas
-
Returns an
Enumerable
over the rows of a given table, representing each row as an object array. - Enumerable<T> - Interface in org.apache.calcite.linq4j
-
Exposes the enumerator, which supports a simple iteration over a collection.
- ENUMERABLE_AGGREGATE_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_ASOFJOIN_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalAsofJoin
toenumerable calling convention
. - ENUMERABLE_BATCH_NESTED_LOOP_JOIN_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalJoin
into anEnumerableBatchNestedLoopJoin
. - ENUMERABLE_CALC_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_COLLECT_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts an
Collect
to anEnumerableCollect
. - ENUMERABLE_CORRELATE_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_ENABLE_TABLESCAN_ARRAY - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether the EnumerableTableScan should support ARRAY fields.
- ENUMERABLE_ENABLE_TABLESCAN_MAP - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether the EnumerableTableScan should support MAP fields.
- ENUMERABLE_ENABLE_TABLESCAN_MULTISET - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether the EnumerableTableScan should support MULTISET fields.
- ENUMERABLE_ENUMERATOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ENUMERABLE_FILTER_FACTORY - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRelFactories
- ENUMERABLE_FILTER_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_FILTER_TO_CALC_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_FOREACH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ENUMERABLE_INTERSECT_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalIntersect
to anEnumerableIntersect
. - ENUMERABLE_JOIN_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalJoin
toenumerable calling convention
. - ENUMERABLE_LIMIT_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_LIMIT_SORT_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_MATCH_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalMatch
to anEnumerableMatch
. - ENUMERABLE_MERGE_JOIN_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalJoin
toenumerable calling convention
. - ENUMERABLE_MERGE_UNION_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_MINUS_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalMinus
to anEnumerableMinus
. - ENUMERABLE_PROJECT_FACTORY - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRelFactories
- ENUMERABLE_PROJECT_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalProject
to anEnumerableProject
. - ENUMERABLE_PROJECT_TO_CALC_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Variant of
ProjectToCalcRule
forenumerable calling convention
. - ENUMERABLE_REPEAT_UNION_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalRepeatUnion
into anEnumerableRepeatUnion
. - ENUMERABLE_RULES - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_RULES - Static variable in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Deprecated.
- ENUMERABLE_SORT_FACTORY - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRelFactories
- ENUMERABLE_SORT_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
Sort
to anEnumerableSort
. - ENUMERABLE_SORTED_AGGREGATE_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule to convert a
LogicalAggregate
to anEnumerableSortedAggregate
. - ENUMERABLE_TABLE_FUNCTION_SCAN_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalTableFunctionScan
toenumerable calling convention
. - ENUMERABLE_TABLE_MODIFICATION_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalTableModify
toenumerable calling convention
. - ENUMERABLE_TABLE_SCAN_FACTORY - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRelFactories
- ENUMERABLE_TABLE_SCAN_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalTableScan
toenumerable calling convention
. - ENUMERABLE_TABLE_SPOOL_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalTableSpool
into anEnumerableTableSpool
. - ENUMERABLE_TO_LIST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ENUMERABLE_TO_MAP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ENUMERABLE_TO_SPARK - Static variable in class org.apache.calcite.adapter.spark.SparkRules
-
Rule that converts from enumerable to Spark convention.
- ENUMERABLE_UNCOLLECT_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts an
Uncollect
to anEnumerableUncollect
. - ENUMERABLE_UNION_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalUnion
to anEnumerableUnion
. - ENUMERABLE_VALUES_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalValues
toenumerable calling convention
. - ENUMERABLE_WINDOW_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts a
LogicalWindow
to anEnumerableWindow
. - EnumerableAggregate - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Aggregate
inenumerable calling convention
. - EnumerableAggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableAggregate
-
Deprecated.
- EnumerableAggregate(RelOptCluster, RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableAggregate
- EnumerableAggregateBase - Class in org.apache.calcite.adapter.enumerable
-
Base class for EnumerableAggregate and EnumerableSortedAggregate.
- EnumerableAggregateBase(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase
- EnumerableAggregateBase.AggContextImpl - Class in org.apache.calcite.adapter.enumerable
-
An implementation of
AggContext
. - EnumerableAsofJoin - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
LogicalAsofJoin
inenumerable calling convention
. - EnumerableAsofJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableAsofJoin
-
Creates an EnumerableAsofJoin.
- enumerableBatchNestedLoopJoin(RelMetadataQuery, RelNode, RelNode, JoinRelType) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
- EnumerableBatchNestedLoopJoin - Class in org.apache.calcite.adapter.enumerable
-
Implementation of batch nested loop join in
enumerable calling convention
. - EnumerableBatchNestedLoopJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, ImmutableBitSet, JoinRelType) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoin
- EnumerableBatchNestedLoopJoinRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert a
LogicalJoin
to anEnumerableBatchNestedLoopJoin
. - EnumerableBatchNestedLoopJoinRule(Class<? extends Join>, RelBuilderFactory, int) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoinRule
-
Deprecated.
- EnumerableBatchNestedLoopJoinRule(EnumerableBatchNestedLoopJoinRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoinRule
-
Creates an EnumerableBatchNestedLoopJoinRule.
- EnumerableBatchNestedLoopJoinRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoinRule
-
Deprecated.
- EnumerableBatchNestedLoopJoinRule(RelBuilderFactory, int) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoinRule
-
Deprecated.
- EnumerableBatchNestedLoopJoinRule.Config - Interface in org.apache.calcite.adapter.enumerable
-
Rule configuration.
- EnumerableBindable - Class in org.apache.calcite.adapter.enumerable
-
Relational expression that converts an enumerable input to interpretable calling convention.
- EnumerableBindable(RelOptCluster, RelNode) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableBindable
- EnumerableBindable.EnumerableToBindableConverterRule - Class in org.apache.calcite.adapter.enumerable
-
Rule that converts any enumerable relational expression to bindable.
- EnumerableCalc - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Calc
inenumerable calling convention
. - EnumerableCalc(RelOptCluster, RelTraitSet, RelNode, RexProgram) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableCalc
-
Creates an EnumerableCalc.
- EnumerableCalc(RelOptCluster, RelTraitSet, RelNode, RexProgram, List<RelCollation>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableCalc
-
Deprecated.
- EnumerableCollect - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Collect
inenumerable calling convention
. - EnumerableCollect(RelOptCluster, RelTraitSet, RelNode, String) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableCollect
-
Deprecated.
- EnumerableCollect(RelOptCluster, RelTraitSet, RelNode, RelDataType) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableCollect
-
Creates an EnumerableCollect.
- EnumerableConvention - Enum in org.apache.calcite.adapter.enumerable
-
Family of calling conventions that return results as an
Enumerable
. - enumerableCorrelate(RelMetadataQuery, RelNode, RelNode, JoinRelType) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
- EnumerableCorrelate - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Correlate
inenumerable calling convention
. - EnumerableCorrelate(RelOptCluster, RelTraitSet, RelNode, RelNode, CorrelationId, ImmutableBitSet, JoinRelType) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableCorrelate
- EnumerableCorrelateRule - Class in org.apache.calcite.adapter.enumerable
-
Implementation of nested loops over enumerable inputs.
- EnumerableCorrelateRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableCorrelateRule
-
Creates an EnumerableCorrelateRule.
- EnumerableDefaults - Class in org.apache.calcite.linq4j
-
Default implementations of methods in the
Enumerable
interface. - EnumerableDefaults() - Constructor for class org.apache.calcite.linq4j.EnumerableDefaults
- EnumerableFilter - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Filter
inenumerable calling convention
. - EnumerableFilter(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableFilter
-
Creates an EnumerableFilter.
- EnumerableFilterToCalcRule - Class in org.apache.calcite.adapter.enumerable
-
Variant of
FilterToCalcRule
forenumerable calling convention
. - EnumerableFilterToCalcRule(EnumerableFilterToCalcRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableFilterToCalcRule
-
Creates an EnumerableFilterToCalcRule.
- EnumerableFilterToCalcRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableFilterToCalcRule
-
Deprecated.
- EnumerableFilterToCalcRule.Config - Interface in org.apache.calcite.adapter.enumerable
-
Rule configuration.
- enumerableHashJoin(RelMetadataQuery, RelNode, RelNode, JoinRelType) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Returns the collation of
EnumerableHashJoin
based on its inputs and the join type. - EnumerableHashJoin - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Join
inenumerable calling convention
. - EnumerableHashJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableHashJoin
-
Creates an EnumerableHashJoin.
- EnumerableHashJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList, JoinRelType, Set<String>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableHashJoin
-
Deprecated.
- EnumerableInterpretable - Class in org.apache.calcite.adapter.enumerable
-
Relational expression that converts an enumerable input to interpretable calling convention.
- EnumerableInterpretable(RelOptCluster, RelNode) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableInterpretable
- EnumerableInterpreter - Class in org.apache.calcite.adapter.enumerable
-
Relational expression that executes its children using an interpreter.
- EnumerableInterpreter(RelOptCluster, RelTraitSet, RelNode, double) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableInterpreter
-
Creates an EnumerableInterpreter.
- EnumerableInterpreterRule - Class in org.apache.calcite.adapter.enumerable
- EnumerableInterpreterRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableInterpreterRule
- EnumerableIntersect - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Intersect
inenumerable calling convention
. - EnumerableIntersect(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableIntersect
- EnumerableLimit - Class in org.apache.calcite.adapter.enumerable
-
Relational expression that applies a limit and/or offset to its input.
- EnumerableLimit(RelOptCluster, RelTraitSet, RelNode, RexNode, RexNode) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableLimit
-
Creates an EnumerableLimit.
- EnumerableLimitRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert an
Sort
that hasoffset
orfetch
set to anEnumerableLimit
on top of a "pure"Sort
that has no offset or fetch. - EnumerableLimitRule(EnumerableLimitRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableLimitRule
-
Creates an EnumerableLimitRule.
- EnumerableLimitRule.Config - Interface in org.apache.calcite.adapter.enumerable
-
Rule configuration.
- EnumerableLimitSort - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Sort
inenumerable calling convention
. - EnumerableLimitSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableLimitSort
-
Creates an EnumerableLimitSort.
- EnumerableLimitSortRule - Class in org.apache.calcite.adapter.enumerable
- EnumerableLimitSortRule(EnumerableLimitSortRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableLimitSortRule
-
Creates a EnumerableLimitSortRule.
- EnumerableLimitSortRule.Config - Interface in org.apache.calcite.adapter.enumerable
-
Rule configuration.
- EnumerableMatch - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Match
inenumerable calling convention
. - EnumerableMatch(RelOptCluster, RelTraitSet, RelNode, RelDataType, RexNode, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, ImmutableBitSet, RelCollation, RexNode) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableMatch
-
Creates an EnumerableMatch.
- EnumerableMatchRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert a
LogicalMatch
to anEnumerableMatch
. - EnumerableMatchRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableMatchRule
-
Creates an EnumerableMatchRule.
- EnumerableMergeJoin - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Join
inenumerable calling convention
using a merge algorithm. - EnumerableMergeJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableMergeJoin
- EnumerableMergeUnion - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Union
inenumerable calling convention
. - EnumerableMergeUnion(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableMergeUnion
- EnumerableMergeUnionRule - Class in org.apache.calcite.adapter.enumerable
- EnumerableMergeUnionRule(EnumerableMergeUnionRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableMergeUnionRule
- EnumerableMergeUnionRule.Config - Interface in org.apache.calcite.adapter.enumerable
-
Rule configuration.
- EnumerableMinus - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Minus
inenumerable calling convention
. - EnumerableMinus(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableMinus
- enumerableNestedLoopJoin(RelMetadataQuery, RelNode, RelNode, JoinRelType) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Returns the collation of
EnumerableNestedLoopJoin
based on its inputs and the join type. - EnumerableNestedLoopJoin - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Join
inenumerable calling convention
that allows conditions that are not just=
(equals). - EnumerableNestedLoopJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableNestedLoopJoin
-
Creates an EnumerableNestedLoopJoin.
- EnumerableNestedLoopJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, Set<String>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableNestedLoopJoin
-
Deprecated.
- EnumerableProject - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Project
inenumerable calling convention
. - EnumerableProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableProject
-
Creates an EnumerableProject.
- EnumerableProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType, int) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableProject
-
Deprecated.
- EnumerableProjectToCalcRule - Class in org.apache.calcite.adapter.enumerable
-
Variant of
ProjectToCalcRule
forenumerable calling convention
. - EnumerableProjectToCalcRule(EnumerableProjectToCalcRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableProjectToCalcRule
-
Creates an EnumerableProjectToCalcRule.
- EnumerableProjectToCalcRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableProjectToCalcRule
-
Deprecated.
- EnumerableProjectToCalcRule.Config - Interface in org.apache.calcite.adapter.enumerable
-
Rule configuration.
- EnumerableRel - Interface in org.apache.calcite.adapter.enumerable
-
A relational expression of one of the
EnumerableConvention
calling conventions. - EnumerableRel.Prefer - Enum in org.apache.calcite.adapter.enumerable
-
Preferred physical type.
- EnumerableRel.Result - Class in org.apache.calcite.adapter.enumerable
-
Result of implementing an enumerable relational expression by generating Java code.
- EnumerableRelFactories - Class in org.apache.calcite.adapter.enumerable
-
Contains factory interface and default implementation for creating various rel nodes.
- EnumerableRelImplementor - Class in org.apache.calcite.adapter.enumerable
-
Subclass of
RelImplementor
for relational operators ofEnumerableConvention
calling convention. - EnumerableRelImplementor(RexBuilder, Map<String, Object>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- EnumerableRepeatUnion - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
RepeatUnion
inenumerable calling convention
. - EnumerableRepeatUnionRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert a
LogicalRepeatUnion
into anEnumerableRepeatUnion
. - EnumerableRepeatUnionRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableRepeatUnionRule
-
Called from the Config.
- EnumerableRules - Class in org.apache.calcite.adapter.enumerable
-
Rules and relational operators for the
enumerable calling convention
. - Enumerables - Class in org.apache.calcite.runtime
-
Utilities for processing
Enumerable
collections. - Enumerables.Emitter<E,
TResult> - Interface in org.apache.calcite.runtime -
Given a match (a list of rows, and their states) produces a list of rows to be output.
- enumerableSemiJoin(RelMetadataQuery, RelNode, RelNode) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
- EnumerableSort - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Sort
inenumerable calling convention
. - EnumerableSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableSort
-
Creates an EnumerableSort.
- EnumerableSortedAggregate - Class in org.apache.calcite.adapter.enumerable
-
Sort based physical implementation of
Aggregate
inenumerable calling convention
. - EnumerableSortedAggregate(RelOptCluster, RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableSortedAggregate
- EnumerableTableFunctionScan - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
TableFunctionScan
inenumerable calling convention
. - EnumerableTableFunctionScan(RelOptCluster, RelTraitSet, List<RelNode>, Type, RelDataType, RexNode, Set<RelColumnMapping>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableTableFunctionScan
- EnumerableTableFunctionScanRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert a
LogicalTableFunctionScan
to anEnumerableTableFunctionScan
. - EnumerableTableFunctionScanRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableTableFunctionScanRule
-
Creates an EnumerableTableFunctionScanRule.
- EnumerableTableModify - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
TableModify
inenumerable calling convention
. - EnumerableTableModify(RelOptCluster, RelTraitSet, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableTableModify
- EnumerableTableModifyRule - Class in org.apache.calcite.adapter.enumerable
-
Planner rule that converts a
LogicalTableModify
to anEnumerableTableModify
. - EnumerableTableModifyRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableTableModifyRule
-
Creates an EnumerableTableModifyRule.
- EnumerableTableScan - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
TableScan
inenumerable calling convention
. - EnumerableTableScan(RelOptCluster, RelTraitSet, RelOptTable, Class) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableTableScan
-
Creates an EnumerableTableScan.
- EnumerableTableScanRule - Class in org.apache.calcite.adapter.enumerable
-
Planner rule that converts a
LogicalTableScan
to anEnumerableTableScan
. - EnumerableTableScanRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableTableScanRule
- EnumerableTableSpool - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
TableSpool
inenumerable calling convention
that writes into aModifiableTable
(which must exist in the current schema). - EnumerableTableSpoolRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert a
LogicalTableSpool
into anEnumerableTableSpool
. - EnumerableTableSpoolRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableTableSpoolRule
-
Called from the Config.
- EnumerableToBindableConverterRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableBindable.EnumerableToBindableConverterRule
- EnumerableToSparkConverter - Class in org.apache.calcite.adapter.spark
-
Relational expression that converts input of
EnumerableConvention
intoSpark convention
. - EnumerableToSparkConverter(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.adapter.spark.EnumerableToSparkConverter
- EnumerableUncollect - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Uncollect
inenumerable calling convention
. - EnumerableUncollect(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableUncollect
-
Deprecated.
- EnumerableUncollect(RelOptCluster, RelTraitSet, RelNode, boolean) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableUncollect
-
Creates an EnumerableUncollect.
- EnumerableUnion - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Union
inenumerable calling convention
. - EnumerableUnion(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableUnion
- EnumerableValues - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Values
inenumerable calling convention
. - EnumerableValuesRule - Class in org.apache.calcite.adapter.enumerable
-
Planner rule that converts a
LogicalValues
to anEnumerableValues
. - EnumerableValuesRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableValuesRule
-
Creates an EnumerableValuesRule.
- EnumerableWindow - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Window
inenumerable calling convention
. - enumerator - Variable in class org.apache.calcite.linq4j.TransformedEnumerator
- enumerator() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- enumerator() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable.ElasticsearchQueryable
- enumerator() - Method in class org.apache.calcite.adapter.geode.rel.GeodeTable.GeodeQueryable
- enumerator() - Method in class org.apache.calcite.adapter.innodb.InnodbTable.InnodbQueryable
- enumerator() - Method in class org.apache.calcite.adapter.mongodb.MongoTable.MongoQueryable
- enumerator() - Method in class org.apache.calcite.adapter.splunk.SplunkQuery
- enumerator() - Method in class org.apache.calcite.interpreter.Interpreter
- enumerator() - Method in class org.apache.calcite.linq4j.AbstractEnumerable2
- enumerator() - Method in class org.apache.calcite.linq4j.BaseQueryable
- enumerator() - Method in class org.apache.calcite.linq4j.MemoryEnumerable
- enumerator() - Method in class org.apache.calcite.linq4j.QueryableDefaults.ReplayableQueryable
- enumerator() - Method in interface org.apache.calcite.linq4j.RawEnumerable
-
Returns an enumerator that iterates through a collection.
- enumerator() - Method in class org.apache.calcite.runtime.ResultSetEnumerable
- enumerator() - Method in class org.apache.calcite.runtime.SpatialTypeFunctions.GridEnumerable
- enumerator() - Method in class org.apache.calcite.util.Smalls.SimpleTable
- enumerator(Collection<? extends V>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Adapter that converts a collection into an enumerator.
- Enumerator<T> - Interface in org.apache.calcite.linq4j
-
Supports a simple iteration over a collection.
- ENUMERATOR_CLOSE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ENUMERATOR_CURRENT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ENUMERATOR_MOVE_NEXT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ENUMERATOR_RESET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- EnumeratorCursor<T> - Class in org.apache.calcite.runtime
-
Implementation of
Cursor
on top of anEnumerator
that returns a record for each row. - EnumeratorCursor(Enumerator<T>) - Constructor for class org.apache.calcite.runtime.EnumeratorCursor
-
Creates an
EnumeratorCursor
. - enumeratorIterator(Enumerator<T>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Adapter that converts an enumerator into an iterator.
- EnumUtils - Class in org.apache.calcite.adapter.enumerable
-
Utilities for generating programs in the Enumerable (functional) style.
- enumVal(Class<T>, String) - Static method in class org.apache.calcite.util.Util
-
Returns the value of an enumeration with a particular name.
- enumVal(T, String) - Static method in class org.apache.calcite.util.Util
-
Returns the value of an enumeration with a particular or default value if not found.
- EnvironmentFairy - Class in org.apache.calcite.chinook
-
Fairy simulates environment around Calcite.
- EnvironmentFairy.User - Enum in org.apache.calcite.chinook
-
Describes who is emulated to being logged in.
- EPOCH - Static variable in class org.apache.calcite.util.TimestampString
-
The Unix epoch.
- EPSILON - Static variable in class org.apache.calcite.plan.RelOptUtil
- EPSILON - Static variable in class org.apache.calcite.test.Matchers
-
A small positive value.
- eq(Object[], Object[]) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
=
operator applied to Object[] values (neither may be null). - eq(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
=
operator applied to Object values (including String; neither side may be null). - eq(String, String, Comparator<String>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
=
operator applied to String values with a certain Comparator. - eq(String, RelDataType, String, RelDataType, Litmus) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns whether two types are equal using 'equals'.
- eq(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
=
operator applied to BigDecimal values (neither may be null). - eq(RexNode, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- eq(RexNode, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- EQ - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- eqAny(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
=
operator applied to Object values (at least one operand has ANY type; neither may be null). - equal(Object, Object) - Static method in class org.apache.calcite.runtime.Utilities
-
Deprecated.
- equal(String, RelDataType, String, RelDataType, Litmus) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns whether two types are equal using
RelOptUtil.areRowTypesEqual(RelDataType, RelDataType, boolean)
. - equal(List<RelCollation>, List<RelCollation>) - Static method in class org.apache.calcite.rel.RelCollationImpl
-
Deprecated.
- equal(List<RelCollation>, List<RelCollation>) - Static method in class org.apache.calcite.rel.RelCollations
- equal(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an equality comparison.
- equal(Expression, Expression, boolean, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an equality comparison.
- equal(T, T) - Method in interface org.apache.calcite.linq4j.function.EqualityComparer
- Equal - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A node that represents an equality comparison, such as
a == b
in Java. - equalAsCollectionSansNullability(RelDataTypeFactory, RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether two collection types are equal, ignoring nullability.
- equalAsMapSansNullability(RelDataTypeFactory, RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether two map types are equal, ignoring nullability.
- equalAsStructSansNullability(RelDataTypeFactory, RelDataType, RelDataType, SqlNameMatcher) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether two struct types are equal, ignoring nullability.
- equalDeep(List<? extends SqlNode>, List<? extends SqlNode>, Litmus) - Static method in class org.apache.calcite.sql.SqlNode
-
Returns whether two lists of operands are equal, comparing using
SqlNode.equalsDeep(SqlNode, Litmus)
. - equalDeep(SqlNode, SqlNode, Litmus) - Static method in class org.apache.calcite.sql.SqlNode
-
Returns whether two nodes are equal (using
SqlNode.equalsDeep(SqlNode, Litmus)
) or are both null. - EqualityComparer<T> - Interface in org.apache.calcite.linq4j.function
-
Compares values for equality.
- equals(Object) - Method in class org.apache.calcite.interpreter.Row
- equals(Object) - Method in class org.apache.calcite.jdbc.JavaRecordType
- equals(Object) - Method in class org.apache.calcite.linq4j.Ord
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.AbstractNode
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.ArrayLengthRecordField
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.BinaryExpression
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.BlockStatement
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.CatchBlock
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.ClassDeclaration
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.ConditionalExpression
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.ConditionalStatement
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.ConstantExpression
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.ConstantUntypedNull
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.ConstructorDeclaration
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.DeclarationStatement
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.FieldDeclaration
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.ForEachStatement
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.ForStatement
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.FunctionExpression
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.GotoStatement
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.IndexExpression
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.LabelStatement
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.LabelTarget
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.MemberExpression
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.MethodCallExpression
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.MethodDeclaration
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.NewArrayExpression
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.NewExpression
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.ParameterExpression
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.ReflectedPseudoField
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.TernaryExpression
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.ThrowStatement
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.TryStatement
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.TypeBinaryExpression
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.UnaryExpression
- equals(Object) - Method in class org.apache.calcite.linq4j.tree.WhileStatement
- equals(Object) - Method in class org.apache.calcite.materialize.Lattice.Column
- equals(Object) - Method in class org.apache.calcite.materialize.Lattice.Measure
- equals(Object) - Method in class org.apache.calcite.materialize.LatticeTable
- equals(Object) - Method in class org.apache.calcite.materialize.MaterializationKey
- equals(Object) - Method in class org.apache.calcite.materialize.TileKey
- equals(Object) - Method in class org.apache.calcite.plan.RelOptCostImpl
- equals(Object) - Method in class org.apache.calcite.plan.RelOptRule
- equals(Object) - Method in class org.apache.calcite.plan.RelOptRuleOperand
- equals(Object) - Method in interface org.apache.calcite.plan.RelTrait
- equals(Object) - Method in class org.apache.calcite.plan.RelTraitSet
-
Compares two RelTraitSet objects for equality.
- equals(Object) - Method in class org.apache.calcite.plan.volcano.VolcanoRelMetadataProvider
-
Deprecated.
- equals(Object) - Method in class org.apache.calcite.prepare.RelOptTableImpl
- equals(Object) - Method in class org.apache.calcite.profile.Profiler.Column
- equals(Object) - Method in class org.apache.calcite.rel.AbstractRelNode
- equals(Object) - Method in class org.apache.calcite.rel.core.AggregateCall
- equals(Object) - Method in class org.apache.calcite.rel.core.CorrelationId
- equals(Object) - Method in class org.apache.calcite.rel.core.Match.RexMRAggCall
- equals(Object) - Method in class org.apache.calcite.rel.core.Window.Group
- equals(Object) - Method in class org.apache.calcite.rel.core.Window.RexWinAggCall
- equals(Object) - Method in class org.apache.calcite.rel.hint.RelHint
- equals(Object) - Method in class org.apache.calcite.rel.metadata.ChainedRelMetadataProvider
- equals(Object) - Method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- equals(Object) - Method in class org.apache.calcite.rel.metadata.RelColumnOrigin
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableAggregate
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableCalc
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableCollect
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableCorrelate
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableExchange
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableFilter
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableJoin
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableMatch
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableProject
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableSample
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableScan
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableSetOp
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableSort
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableTableFunctionScan
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableTableModify
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableUncollect
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableValues
- equals(Object) - Method in class org.apache.calcite.rel.mutable.MutableWindow
- equals(Object) - Method in class org.apache.calcite.rel.RelCollationImpl
- equals(Object) - Method in class org.apache.calcite.rel.RelFieldCollation
- equals(Object) - Method in class org.apache.calcite.rel.type.RelDataTypeFieldImpl
- equals(Object) - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- equals(Object) - Method in class org.apache.calcite.rex.RexCall
- equals(Object) - Method in class org.apache.calcite.rex.RexCorrelVariable
- equals(Object) - Method in class org.apache.calcite.rex.RexDynamicParam
- equals(Object) - Method in class org.apache.calcite.rex.RexFieldAccess
- equals(Object) - Method in class org.apache.calcite.rex.RexInputRef
- equals(Object) - Method in class org.apache.calcite.rex.RexLambda
- equals(Object) - Method in class org.apache.calcite.rex.RexLambdaRef
- equals(Object) - Method in class org.apache.calcite.rex.RexLiteral
- equals(Object) - Method in class org.apache.calcite.rex.RexLocalRef
- equals(Object) - Method in class org.apache.calcite.rex.RexNode
- equals(Object) - Method in class org.apache.calcite.rex.RexOver
- equals(Object) - Method in class org.apache.calcite.rex.RexRangeRef
- equals(Object) - Method in class org.apache.calcite.rex.RexSubQuery
- equals(Object) - Method in class org.apache.calcite.rex.RexTableInputRef
- equals(Object) - Method in class org.apache.calcite.rex.RexTableInputRef.RelTableRef
- equals(Object) - Method in class org.apache.calcite.rex.RexWindow
- equals(Object) - Method in class org.apache.calcite.runtime.ConsList
- equals(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat1List
- equals(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat2List
- equals(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat3List
- equals(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat4List
- equals(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat5List
- equals(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- equals(Object) - Method in class org.apache.calcite.runtime.JsonFunctions.JsonValueContext
- equals(Object) - Method in class org.apache.calcite.runtime.MapEntry
- equals(Object) - Method in class org.apache.calcite.schema.impl.LongSchemaVersion
- equals(Object) - Method in class org.apache.calcite.sql.parser.SqlParserPos
- equals(Object) - Method in class org.apache.calcite.sql.parser.StringAndPos
- equals(Object) - Method in class org.apache.calcite.sql.SqlCollation
- equals(Object) - Method in class org.apache.calcite.sql.SqlIntervalLiteral.IntervalValue
- equals(Object) - Method in class org.apache.calcite.sql.SqlLiteral
- equals(Object) - Method in class org.apache.calcite.sql.SqlNodeList
- equals(Object) - Method in class org.apache.calcite.sql.SqlOperator
- equals(Object) - Method in class org.apache.calcite.sql.TableCharacteristic
- equals(Object) - Method in class org.apache.calcite.sql.util.IdPair
- equals(Object) - Method in class org.apache.calcite.sql.util.SqlString
- equals(Object) - Method in class org.apache.calcite.sql.validate.SqlMonikerImpl
- equals(Object) - Method in class org.apache.calcite.sql.validate.SqlQualified
- equals(Object) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMap
- equals(Object) - Method in class org.apache.calcite.util.BitString
- equals(Object) - Method in class org.apache.calcite.util.DateString
- equals(Object) - Method in class org.apache.calcite.util.graph.DefaultEdge
- equals(Object) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Compares this object against the specified object.
- equals(Object) - Method in class org.apache.calcite.util.ImmutableIntList
- equals(Object) - Method in class org.apache.calcite.util.mapping.IntPair
- equals(Object) - Method in class org.apache.calcite.util.mapping.Mappings.FiniteAbstractMapping
- equals(Object) - Method in class org.apache.calcite.util.NameMap
- equals(Object) - Method in class org.apache.calcite.util.NameMultimap
- equals(Object) - Method in class org.apache.calcite.util.NameSet
- equals(Object) - Method in class org.apache.calcite.util.NlsString
- equals(Object) - Method in class org.apache.calcite.util.Pair
- equals(Object) - Method in class org.apache.calcite.util.Permutation
- equals(Object) - Method in class org.apache.calcite.util.Sarg
- equals(Object) - Method in class org.apache.calcite.util.TimestampString
- equals(Object) - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
- equals(Object) - Method in class org.apache.calcite.util.TimeString
- equals(Object) - Method in class org.apache.calcite.util.TimeWithTimeZoneString
- equals(Object) - Method in class org.apache.calcite.adapter.druid.DruidQuery.QuerySpec
- equals(Object) - Method in class org.apache.calcite.test.schemata.foodmart.FoodmartSchema.SalesFact
- equals(Object) - Method in class org.apache.calcite.test.schemata.hr.Department
- equals(Object) - Method in class org.apache.calcite.test.schemata.hr.Dependent
- equals(Object) - Method in class org.apache.calcite.test.schemata.hr.Employee
- equals(Object) - Method in class org.apache.calcite.test.schemata.hr.Event
- equals(Object) - Method in class org.apache.calcite.test.schemata.hr.HierarchySchema.Hierarchy
- equals(Object) - Method in class org.apache.calcite.test.schemata.hr.Location
- equals(Object) - Method in class org.apache.calcite.test.schemata.hr.NullableTest
- equals(Object) - Method in class org.apache.calcite.test.schemata.lingual.LingualEmp
- equals(RelOptCost) - Method in interface org.apache.calcite.plan.RelOptCost
-
Compares this to another cost.
- equals(RelOptCost) - Method in class org.apache.calcite.plan.RelOptCostImpl
- equals(RelOptRule) - Method in class org.apache.calcite.plan.RelOptRule
-
Returns whether this rule is equal to another rule.
- equals(RexNode, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
=
. - equals(T, T) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Deprecated.
- EQUALS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Equals operator, "=".
- EQUALS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Logical equals operator, '
=
'. - equalSansNullability(RelDataTypeFactory, RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether two types are equal, ignoring nullability.
- equalSansNullability(RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
This is a poorman's
SqlTypeUtil.equalSansNullability(RelDataTypeFactory, RelDataType, RelDataType)
. - equalsDeep(SqlNode, boolean) - Method in class org.apache.calcite.sql.SqlNode
-
Deprecated.
- equalsDeep(SqlNode, Litmus) - Method in class org.apache.calcite.sql.SqlCall
- equalsDeep(SqlNode, Litmus) - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- equalsDeep(SqlNode, Litmus) - Method in class org.apache.calcite.sql.SqlDynamicParam
- equalsDeep(SqlNode, Litmus) - Method in class org.apache.calcite.sql.SqlIdentifier
- equalsDeep(SqlNode, Litmus) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- equalsDeep(SqlNode, Litmus) - Method in class org.apache.calcite.sql.SqlLiteral
- equalsDeep(SqlNode, Litmus) - Method in class org.apache.calcite.sql.SqlNode
-
Returns whether this node is structurally equivalent to another node.
- equalsDeep(SqlNode, Litmus) - Method in class org.apache.calcite.sql.SqlNodeList
- equalsDeep(SqlNode, Litmus) - Method in class org.apache.calcite.sql.SqlWindow
-
Overridden method to specifically check only the right subtree of a window definition.
- equalsDeep(SqlTypeNameSpec, Litmus) - Method in class org.apache.calcite.sql.SqlAlienSystemTypeNameSpec
- equalsDeep(SqlTypeNameSpec, Litmus) - Method in class org.apache.calcite.sql.SqlBasicTypeNameSpec
- equalsDeep(SqlTypeNameSpec, Litmus) - Method in class org.apache.calcite.sql.SqlCollectionTypeNameSpec
- equalsDeep(SqlTypeNameSpec, Litmus) - Method in class org.apache.calcite.sql.SqlMapTypeNameSpec
- equalsDeep(SqlTypeNameSpec, Litmus) - Method in class org.apache.calcite.sql.SqlRowTypeNameSpec
- equalsDeep(SqlTypeNameSpec, Litmus) - Method in class org.apache.calcite.sql.SqlTypeNameSpec
-
Returns whether this spec is structurally equivalent to another spec.
- equalsDeep(SqlTypeNameSpec, Litmus) - Method in class org.apache.calcite.sql.SqlUserDefinedTypeNameSpec
- equalShallow(List<? extends T>, List<? extends T>) - Static method in class org.apache.calcite.util.Util
-
Returns whether two lists are equal to each other using shallow comparisons.
- equalsSansConvention(RelTraitSet) - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns whether all the traits except
Convention
equals with traits inother
traitSet. - equalsSansFieldNames(RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataType
-
Returns whether the field types are equal with each other by ignoring the field names.
- equalsSansFieldNamesAndNullability(RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataType
-
Same as
RelDataType.equalsSansFieldNames(org.apache.calcite.rel.type.RelDataType)
, but ignore nullability also. - equalsUnordered(E...) - Static method in class org.apache.calcite.test.Matchers
- equalType(String, MutableRel, String, MutableRel, Litmus) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
-
Returns whether two relational expressions have the same row-type.
- equalType(String, RelNode, String, RelNode, Litmus) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns whether two relational expressions have the same row-type.
- EquiJoin - Class in org.apache.calcite.rel.core
-
Deprecated.This class is no longer needed; if you are writing a sub-class of Join that only accepts equi conditions, it is sufficient that it extends
Join
. It will be evident that it is an equi-join when itsJoinInfo.nonEquiConditions
is an empty list. - EquiJoin - Class in org.apache.calcite.rel.rules
-
Deprecated.
- EquiJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.rel.core.EquiJoin
-
Deprecated.Creates an EquiJoin.
- EquiJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.rel.core.EquiJoin
-
Deprecated.
- EquiJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList, JoinRelType, Set<String>) - Constructor for class org.apache.calcite.rel.core.EquiJoin
-
Deprecated.
- EquiJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList, JoinRelType, Set<String>) - Constructor for class org.apache.calcite.rel.rules.EquiJoin
-
Deprecated.
- equiv(E, E) - Method in class org.apache.calcite.util.EquivalenceSet
-
Marks two elements as equivalent.
- EquivalenceClasses() - Constructor for class org.apache.calcite.rel.rules.materialize.MaterializedViewRule.EquivalenceClasses
- EquivalenceSet<E extends Comparable<E>> - Class in org.apache.calcite.util
-
Set of elements organized into equivalence classes.
- EquivalenceSet() - Constructor for class org.apache.calcite.util.EquivalenceSet
- ERAS - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- ERROR - Enum constant in enum org.apache.calcite.sql.SqlJsonEmptyOrError
- ERROR - Enum constant in enum org.apache.calcite.sql.SqlJsonExistsErrorBehavior
- ERROR - Enum constant in enum org.apache.calcite.sql.SqlJsonQueryEmptyOrErrorBehavior
- ERROR - Enum constant in enum org.apache.calcite.sql.SqlJsonValueEmptyOrErrorBehavior
- errorHandler(Litmus) - Method in class org.apache.calcite.rel.hint.HintStrategyTable.Builder
-
Sets an error handler to customize the hints error handling.
- ESCAPE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Escape operator (always part of LIKE or SIMILAR TO expression).
- ESCAPE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Internal operator used to represent the ESCAPE clause of a LIKE or SIMILAR TO expression.
- escapeString(String) - Static method in class org.apache.calcite.util.TestUtil
-
Quotes a string for Java or JSON.
- escapeString(StringBuilder, String) - Static method in class org.apache.calcite.util.TestUtil
-
Quotes a string for Java or JSON, into a builder.
- estimateFilteredRows(RelNode, RexNode, RelMetadataQuery) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
- estimateFilteredRows(RelNode, RexNode) - Static method in class org.apache.calcite.rel.core.Filter
-
Deprecated.
- estimateFilteredRows(RelNode, RexProgram) - Static method in class org.apache.calcite.rel.core.Filter
-
Deprecated.
- estimateFilteredRows(RelNode, RexProgram, RelMetadataQuery) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
- estimateJoinedRows(Join, RexNode) - Static method in class org.apache.calcite.rel.core.Join
-
Deprecated.
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcCalc
-
Deprecated.
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcJoin
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.adapter.spark.SparkRules.SparkCalc
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.plan.hep.HepRelVertex
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.RelSubset
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.rel.AbstractRelNode
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Aggregate
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Calc
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Correlate
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Filter
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Intersect
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Join
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Minus
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.rel.core.RepeatUnion
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.rel.core.TableFunctionScan
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.rel.core.TableScan
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Union
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Values
- estimateRowCount(RelMetadataQuery) - Method in interface org.apache.calcite.rel.RelNode
-
Returns an estimate of the number of rows this relational expression will return.
- estimateRowCount(RelMetadataQuery) - Method in class org.apache.calcite.rel.SingleRel
- estimateRowCount(RelNode) - Static method in class org.apache.calcite.rel.core.Union
-
Deprecated.
- eval() - Method in class org.apache.calcite.chinook.ChosenCustomerEmail
- eval() - Static method in class org.apache.calcite.util.Smalls.CountArgs0Function
- eval() - Method in class org.apache.calcite.util.Smalls.FibonacciTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.CpuInfoTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.CpuTimeTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.DuTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.GitCommitsTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.InterfaceAddressesTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.InterfaceDetailsTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.JavaInfoTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.JpsTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.MemoryInfoTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.MountsTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.OsVersionTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.PsTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.StdinTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.SystemInfoTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.VmstatTableFunction
- eval(boolean) - Static method in class org.apache.calcite.test.schemata.countries.CountriesTableFunction
- eval(int) - Method in class org.apache.calcite.util.Smalls.AwkwardFunction
- eval(int) - Static method in class org.apache.calcite.util.Smalls.CountArgs1Function
- eval(int) - Static method in class org.apache.calcite.util.Smalls.MyDoubleFunction
- eval(int) - Static method in class org.apache.calcite.util.Smalls.MyExceptionFunction
- eval(int, int) - Static method in class org.apache.calcite.util.Smalls.CountArgs2Function
- eval(int, int) - Method in class org.apache.calcite.util.Smalls.MyIncrement
- eval(int, int) - Method in class org.apache.calcite.util.Smalls.MyPlusFunction
- eval(int, int) - Method in class org.apache.calcite.util.Smalls.MyPlusInitFunction
- eval(Integer) - Static method in class org.apache.calcite.util.Smalls.IdentityTableFunction
- eval(Integer) - Method in class org.apache.calcite.util.Smalls.SimpleTableFunction
- eval(Integer, Integer) - Method in class org.apache.calcite.util.Smalls.MyDeterministicPlusFunction
- eval(Integer, Integer, Integer, Integer, Integer) - Method in class org.apache.calcite.util.Smalls.MyAbcdeFunction
- eval(Object) - Static method in class org.apache.calcite.util.Smalls.MyToStringFunction
- eval(Short) - Static method in class org.apache.calcite.util.Smalls.CountArgs1NullableFunction
- eval(String) - Static method in class org.apache.calcite.adapter.os.FilesTableFunction
-
Evaluates the function.
- eval(String) - Method in class org.apache.calcite.adapter.os.OsQuery
- eval(String) - Method in class org.apache.calcite.util.Smalls.MyTableFunction
- eval(String) - Static method in class org.apache.calcite.util.Smalls.Null4Function
- eval(String) - Static method in class org.apache.calcite.util.Smalls.Null8Function
- eval(String) - Static method in class org.apache.calcite.util.Smalls.StaticTableMacroFunction
- eval(String) - Method in class org.apache.calcite.util.Smalls.TableMacroFunction
- eval(String) - Static method in class org.apache.calcite.util.Smalls.TestStaticTableFunction
- eval(String, int) - Method in class org.apache.calcite.util.Smalls.MyLeftFunction
- eval(String, String) - Method in class org.apache.calcite.chinook.StringConcatFunction
- eval(String, String, Integer) - Method in class org.apache.calcite.util.Smalls.TableMacroFunctionWithNamedParameters
- eval(String, String, Integer, String) - Method in class org.apache.calcite.util.Smalls.AnotherTableMacroFunctionWithNamedParameters
- evaluate(Object, Class<T>) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
-
Converts a value to a given class.
- evaluate(Object, List<Object>) - Method in interface org.apache.calcite.schema.Member
-
Evaluates this member to yield a result.
- evaluate(Evaluator) - Method in class org.apache.calcite.linq4j.tree.AbstractNode
- evaluate(Evaluator) - Method in class org.apache.calcite.linq4j.tree.BinaryExpression
- evaluate(Evaluator) - Method in class org.apache.calcite.linq4j.tree.BlockStatement
- evaluate(Evaluator) - Method in class org.apache.calcite.linq4j.tree.ConstantExpression
- evaluate(Evaluator) - Method in class org.apache.calcite.linq4j.tree.GotoStatement
- evaluate(Evaluator) - Method in class org.apache.calcite.linq4j.tree.MemberExpression
- evaluate(Evaluator) - Method in class org.apache.calcite.linq4j.tree.MethodCallExpression
- evaluate(Evaluator) - Method in class org.apache.calcite.linq4j.tree.ParameterExpression
- evaluate(Node) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Evaluates an expression and returns the result.
- evaluate(RexNode, Map<RexNode, Comparable>) - Static method in class org.apache.calcite.rex.RexInterpreter
-
Evaluates an expression in an environment.
- evaluateIntervalLiteral(String, SqlParserPos, RelDataTypeSystem) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Validates an INTERVAL literal according to the rules specified by the interval qualifier.
- Event - Class in org.apache.calcite.test.schemata.hr
-
Event.
- Event(int, Timestamp) - Constructor for class org.apache.calcite.test.schemata.hr.Event
- eventid - Variable in class org.apache.calcite.test.schemata.hr.Event
- EVERY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
EVERY
aggregate function. - EveryType(boolean, byte, char, short, int, long, float, double, Boolean, Byte, Character, Short, Integer, Long, Float, Double, Date, Time, Timestamp, Date, String, BigDecimal) - Constructor for class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- everyTypes - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- evolveLattice(boolean) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- EXACT_NUMERIC - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- EXACT_NUMERIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
- EXACT_NUMERIC_EXACT_NUMERIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
- EXACT_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- exactly(RelOptRuleOperand) - Method in interface org.apache.calcite.plan.RelRule.OperandBuilder
-
Supplies an operand that has been built manually.
- EXASOL - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- ExasolSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Exasol database. - ExasolSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.ExasolSqlDialect
-
Creates a ExasolSqlDialect.
- exc - Variable in class org.apache.calcite.runtime.JsonFunctions.JsonPathContext
- exc - Variable in class org.apache.calcite.runtime.JsonFunctions.JsonValueContext
- except(Enumerable<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- except(Enumerable<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- except(Enumerable<T>, boolean) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- except(Enumerable<T>, boolean) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- except(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- except(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- except(Enumerable<T>, EqualityComparer<T>, boolean) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- except(Enumerable<T>, EqualityComparer<T>, boolean) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- except(Enumerable<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Produces the set difference of two sequences by using the default equality comparer to compare values, eliminate duplicates.
- except(Enumerable<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Produces the set difference of two sequences by using the default equality comparer to compare values, eliminate duplicates.
- except(Enumerable<TSource>, boolean) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Produces the set difference of two sequences by using the default equality comparer to compare values, using
all
to indicate whether to eliminate duplicates. - except(Enumerable<T>, boolean) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Produces the set difference of two sequences by using the default equality comparer to compare values, using
all
to indicate whether to eliminate duplicates. - except(Enumerable<TSource>, Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Produces the set difference of two sequences by using the default equality comparer to compare values, eliminate duplicates.
- except(Enumerable<TSource>, Enumerable<TSource>, boolean) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Produces the set difference of two sequences by using the default equality comparer to compare values, using
all
to indicate whether to eliminate duplicates. - except(Enumerable<TSource>, Enumerable<TSource>, EqualityComparer<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Produces the set difference of two sequences by using the specified
EqualityComparer<TSource>
to compare values, eliminate duplicates. - except(Enumerable<TSource>, Enumerable<TSource>, EqualityComparer<TSource>, boolean) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Produces the set difference of two sequences by using the specified
EqualityComparer<TSource>
to compare values, usingall
to indicate whether to eliminate duplicates. - except(Enumerable<TSource>, EqualityComparer<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Produces the set difference of two sequences by using the specified
EqualityComparer<TSource>
to compare values, eliminate duplicates. - except(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Produces the set difference of two sequences by using the specified
EqualityComparer<TSource>
to compare values, eliminate duplicates. - except(Enumerable<TSource>, EqualityComparer<TSource>, boolean) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Produces the set difference of two sequences by using the specified
EqualityComparer<TSource>
to compare values, usingall
to indicate whether to eliminate duplicates. - except(Enumerable<T>, EqualityComparer<T>, boolean) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Produces the set difference of two sequences by using the specified
EqualityComparer<TSource>
to compare values, usingall
to indicate whether to eliminate duplicates. - except(Queryable<T>, Enumerable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Produces the set difference of two sequences by using the default equality comparer to compare values.
- except(Queryable<T>, Enumerable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Produces the set difference of two sequences by using the default equality comparer to compare values, eliminate duplicates.
- except(Queryable<T>, Enumerable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- except(Queryable<T>, Enumerable<T>, boolean) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Produces the set difference of two sequences by using the default equality comparer to compare values, using
all
to indicate whether to eliminate duplicates. - except(Queryable<T>, Enumerable<T>, boolean) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- except(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Produces the set difference of two sequences by using the specified
EqualityComparer<T>
to compare values. - except(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Produces the set difference of two sequences by using the specified
EqualityComparer<T>
to compare values, eliminate duplicates. - except(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- except(Queryable<T>, Enumerable<T>, EqualityComparer<T>, boolean) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Produces the set difference of two sequences by using the specified
EqualityComparer<T>
to compare values, usingall
to indicate whether to eliminate duplicates. - except(Queryable<T>, Enumerable<T>, EqualityComparer<T>, boolean) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- except(ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns a bit set with all the bits in this set that are not in another.
- EXCEPT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
EXCEPT
relational operator (known asMINUS
in some SQL dialects). - EXCEPT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- EXCEPT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- EXCEPT_ALL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- exceptionWhilePerformingQueryOnJdbcSubSchema(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- exceptionWhileSerializingToJson(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- exceptLibraries() - Element in annotation type org.apache.calcite.sql.fun.LibraryOperator
-
The set of libraries that this function should be excluded from.
- exchange(RelDistribution) - Static method in class org.apache.calcite.rel.metadata.RelMdDistribution
-
Helper method to determine an
Exchange
's orSortExchange
's distribution. - exchange(RelDistribution) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an Exchange by distribution.
- Exchange - Class in org.apache.calcite.rel.core
-
Relational expression that imposes a particular distribution on its input without otherwise changing its content.
- Exchange(RelOptCluster, RelTraitSet, RelNode, RelDistribution) - Constructor for class org.apache.calcite.rel.core.Exchange
-
Creates an Exchange.
- Exchange(RelInput) - Constructor for class org.apache.calcite.rel.core.Exchange
-
Creates an Exchange by parsing serialized output.
- EXCHANGE_FACTORY - Static variable in class org.apache.calcite.adapter.jdbc.JdbcRules
- EXCHANGE_REMOVE_CONSTANT_KEYS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that removes constants inside a
LogicalExchange
. - exchangeFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- ExchangeRemoveConstantKeysRule - Class in org.apache.calcite.rel.rules
-
Planner rule that removes keys from a
Exchange
if those keys are known to be constant. - ExchangeRemoveConstantKeysRule(ExchangeRemoveConstantKeysRule.Config) - Constructor for class org.apache.calcite.rel.rules.ExchangeRemoveConstantKeysRule
-
Creates an ExchangeRemoveConstantKeysRule.
- ExchangeRemoveConstantKeysRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- exclude - Variable in class org.apache.calcite.rel.core.Window.Group
- exclude(RexWindowExclusion) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets the frame to EXCLUDE rows; default to EXCLUDE_NO_OTHER.
- EXCLUDE_CURRENT_ROW - Enum constant in enum org.apache.calcite.rex.RexWindowExclusion
- EXCLUDE_GROUP - Enum constant in enum org.apache.calcite.rex.RexWindowExclusion
- EXCLUDE_NO_OTHER - Enum constant in enum org.apache.calcite.rex.RexWindowExclusion
- EXCLUDE_TIES - Enum constant in enum org.apache.calcite.rex.RexWindowExclusion
- excludedRules - Variable in class org.apache.calcite.rel.hint.HintStrategy
- excludedRules(RelOptRule...) - Method in class org.apache.calcite.rel.hint.HintStrategy.Builder
-
Registers an array of rules to exclude during the
RelOptPlanner
planning. - excludingOptions - Variable in class org.apache.calcite.sql.ddl.SqlCreateTableLike
- EXCLUSION_PATTERN - Static variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Regular expression that matches the description of all instances of this rule and
ValuesReduceRule
also. - exclusiveOr(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise XOR operation, using op_ExclusiveOr for user-defined types.
- exclusiveOr(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise XOR operation, using op_ExclusiveOr for user-defined types.
- ExclusiveOr - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise or logical XOR operation, such as
a ^ b
in Java. - exclusiveOrAssign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise XOR assignment operation, using op_ExclusiveOr for user-defined types.
- exclusiveOrAssign(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise XOR assignment operation, using op_ExclusiveOr for user-defined types.
- exclusiveOrAssign(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise XOR assignment operation, using op_ExclusiveOr for user-defined types.
- ExclusiveOrAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise or logical XOR compound assignment operation, such as (a ^= b) in C#.
- execute() - Method in class org.apache.calcite.jdbc.CalciteResultSet
- execute() - Method in class org.apache.calcite.rex.RexExecutable
- execute(Stream<? extends Source>, OutputStream) - Method in interface org.apache.calcite.util.Puffin.Program
-
Executes this program, writing to an output stream such as
System.out
. - execute(Stream<? extends Source>, PrintWriter) - Method in interface org.apache.calcite.util.Puffin.Program
-
Executes this program.
- execute(Meta.StatementHandle, List<TypedValue>, int) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- execute(Meta.StatementHandle, List<TypedValue>, long) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- execute(Context) - Method in interface org.apache.calcite.interpreter.Scalar
- execute(Context, Object[]) - Method in interface org.apache.calcite.interpreter.Scalar
- execute(CalcitePrepare.Context) - Method in class org.apache.calcite.sql.ddl.SqlDropObject
- execute(Expression, Class<T>) - Method in interface org.apache.calcite.linq4j.QueryProvider
-
Executes the query represented by a specified expression tree.
- execute(Expression, Class<T>) - Method in class org.apache.calcite.linq4j.QueryProviderImpl
- execute(Expression, Type) - Method in interface org.apache.calcite.linq4j.QueryProvider
-
Executes the query represented by a specified expression tree.
- execute(Expression, Type) - Method in class org.apache.calcite.linq4j.QueryProviderImpl
- execute(SqlCreateForeignSchema, CalcitePrepare.Context) - Method in class org.apache.calcite.server.ServerDdlExecutor
-
Executes a
CREATE FOREIGN SCHEMA
command. - execute(SqlCreateFunction, CalcitePrepare.Context) - Method in class org.apache.calcite.server.ServerDdlExecutor
-
Executes a
CREATE FUNCTION
command. - execute(SqlCreateMaterializedView, CalcitePrepare.Context) - Method in class org.apache.calcite.server.ServerDdlExecutor
-
Executes a
CREATE MATERIALIZED VIEW
command. - execute(SqlCreateSchema, CalcitePrepare.Context) - Method in class org.apache.calcite.server.ServerDdlExecutor
-
Executes a
CREATE SCHEMA
command. - execute(SqlCreateTableLike, CalcitePrepare.Context) - Method in class org.apache.calcite.server.ServerDdlExecutor
-
Executes a
CREATE TABLE LIKE
command. - execute(SqlCreateTable, CalcitePrepare.Context) - Method in class org.apache.calcite.server.ServerDdlExecutor
-
Executes a
CREATE TABLE
command. - execute(SqlCreateTable, CalcitePrepare.Context) - Method in class org.apache.calcite.test.MockDdlExecutor
-
Executes a
CREATE TABLE
command. - execute(SqlCreateType, CalcitePrepare.Context) - Method in class org.apache.calcite.server.ServerDdlExecutor
-
Executes a
CREATE TYPE
command. - execute(SqlCreateView, CalcitePrepare.Context) - Method in class org.apache.calcite.server.ServerDdlExecutor
-
Executes a
CREATE VIEW
command. - execute(SqlCreateView, CalcitePrepare.Context) - Method in class org.apache.calcite.test.MockDdlExecutor
-
Executes a
CREATE VIEW
command. - execute(SqlDropObject, CalcitePrepare.Context) - Method in class org.apache.calcite.server.ServerDdlExecutor
-
Executes
DROP FUNCTION
,DROP TABLE
,DROP MATERIALIZED VIEW
,DROP TYPE
,DROP VIEW
commands. - execute(SqlDropSchema, CalcitePrepare.Context) - Method in class org.apache.calcite.server.ServerDdlExecutor
-
Executes a
DROP SCHEMA
command. - execute(SqlTruncateTable, CalcitePrepare.Context) - Method in class org.apache.calcite.server.ServerDdlExecutor
-
Executes a
TRUNCATE TABLE
command. - execute(SqlNode, CalcitePrepare.Context) - Method in class org.apache.calcite.server.DdlExecutorImpl
-
Template for methods that execute DDL commands.
- execute(Source, OutputStream) - Method in interface org.apache.calcite.util.Puffin.Program
-
Executes this program on a single source.
- executeBatch(Meta.StatementHandle, List<List<TypedValue>>) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- executeDdl(CalcitePrepare.Context, SqlNode) - Method in interface org.apache.calcite.jdbc.CalcitePrepare
-
Executes a DDL statement.
- executeDdl(CalcitePrepare.Context, SqlNode) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- executeDdl(CalcitePrepare.Context, SqlNode) - Method in interface org.apache.calcite.server.DdlExecutor
-
Executes a DDL statement.
- executeDdl(CalcitePrepare.Context, SqlNode) - Method in class org.apache.calcite.server.DdlExecutorImpl
- executeMethod(String, String, CharSequence, Map<String, String>, int, int) - Static method in class org.apache.calcite.runtime.HttpUtils
- executeQuery(Queryable<T>) - Method in class org.apache.calcite.adapter.jdbc.JdbcQueryProvider
- executeQuery(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryProvider
-
Executes a queryable, and returns an enumerator over the rows that it yields.
- executor - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- executor(RexExecutor) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- EXECUTOR - Static variable in class org.apache.calcite.rex.RexUtil
-
Executor for a bit of constant reduction.
- existingWindowName(String) - Method in class org.apache.calcite.sql.validate.SelectScope
- exists(Function<RelBuilder, RelNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an EXISTS predicate.
- exists(List<? extends E>, Predicate1<E>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns whether there is an element in
list
for whichpredicate
is true. - exists(List<? extends E>, Predicate1<E>) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether there is an element in
list
for whichpredicate
is true. - exists(List, Function1<Object, Boolean>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the EXISTS(list, function1) function.
- exists(List, Predicate1) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the EXISTS(list, predicate1) function.
- exists(RelNode) - Static method in class org.apache.calcite.rex.RexSubQuery
-
Creates an EXISTS sub-query.
- EXISTS - Enum constant in enum org.apache.calcite.plan.RelOptUtil.SubQueryType
- EXISTS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
EXISTS
operator. - EXISTS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- EXISTS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "EXISTS(array, lambda)" function (Spark); returns whether a predicate holds for one or more elements in the array.
- EXISTS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- EXISTS - Static variable in class org.apache.calcite.sql.type.OperandTypes
- EXISTS_NODE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- EXISTS_NODE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- existsNode(String, String) - Static method in class org.apache.calcite.runtime.XmlFunctions
- existsNode(String, String, String) - Static method in class org.apache.calcite.runtime.XmlFunctions
- exitBlock() - Method in interface org.apache.calcite.adapter.enumerable.NestedBlockBuilder
-
Leaves the current code block.
- exitBlock() - Method in class org.apache.calcite.adapter.enumerable.NestedBlockBuilderImpl
-
Leaves the current code block.
- exp(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
EXP
operator applied to double values. - exp(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
- EXP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- EXP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
EXP(numeric)
function. - expand(int, BuiltInMetadata.Measure.Context) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Measure
-
Expands a measure to an expression.
- expand(Iterable<? extends SqlLibrary>) - Static method in enum org.apache.calcite.sql.fun.SqlLibrary
-
Expands libraries in place.
- expand(String, String) - Method in class org.apache.calcite.test.DiffRepository
-
Expands a string containing one or more variables.
- expand(RelSubset, RelMetadataQuery, int, BuiltInMetadata.Measure.Context) - Method in class org.apache.calcite.rel.metadata.RelMdMeasure
-
Refines
expand
forRelSubset
; called via reflection. - expand(Aggregate, RelMetadataQuery, int, BuiltInMetadata.Measure.Context) - Method in class org.apache.calcite.rel.metadata.RelMdMeasure
-
Refines
expand
forAggregate
; called via reflection. - expand(Filter, RelMetadataQuery, int, BuiltInMetadata.Measure.Context) - Method in class org.apache.calcite.rel.metadata.RelMdMeasure
-
Refines
expand
forFilter
; called via reflection. - expand(Project, RelMetadataQuery, int, BuiltInMetadata.Measure.Context) - Method in class org.apache.calcite.rel.metadata.RelMdMeasure
-
Refines
expand
forProject
; called via reflection. - expand(RelNode, int, BuiltInMetadata.Measure.Context) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.Measure.expand(int, BuiltInMetadata.Measure.Context)
statistic. - expand(RelNode, RelMetadataQuery, int, BuiltInMetadata.Measure.Context) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Measure.Handler
- expand(RelNode, RelMetadataQuery, int, BuiltInMetadata.Measure.Context) - Method in class org.apache.calcite.rel.metadata.RelMdMeasure
-
Catch-all implementation for
BuiltInMetadata.Measure.expand(int, BuiltInMetadata.Measure.Context)
, invoked using reflection. - expand(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Rewrites an expression containing decimals.
- expand(SqlNode, SqlValidatorScope) - Method in class org.apache.calcite.sql.advise.SqlAdvisorValidator
- expand(SqlNode, SqlValidatorScope) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Expands an expression.
- expand(SqlNode, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- EXPAND - Enum constant in enum org.apache.calcite.sql.test.SqlOperatorFixture.VmName
- EXPAND - Enum constant in enum org.apache.calcite.sql.test.SqlTester.VmName
- ExpandConversionRule(AbstractConverter.ExpandConversionRule.Config) - Constructor for class org.apache.calcite.plan.volcano.AbstractConverter.ExpandConversionRule
-
Creates an ExpandConversionRule.
- ExpandConversionRule(RelBuilderFactory) - Constructor for class org.apache.calcite.plan.volcano.AbstractConverter.ExpandConversionRule
-
Deprecated.
- expandList(List<? extends RexNode>) - Method in class org.apache.calcite.rex.RexProgram
-
Expands a list of expressions that may contain
RexLocalRef
s. - expandLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexProgram
-
Fully expands a RexLocalRef back into a pure RexNode tree containing no RexLocalRefs (reversing the effect of common subexpression elimination).
- expandOrderExpr(SqlSelect, SqlNode) - Method in class org.apache.calcite.sql.advise.SqlAdvisorValidator
- expandOrderExpr(SqlSelect, SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Expands an expression in the ORDER BY clause into an expression with the same semantics as expressions in the SELECT clause.
- expandOrderExpr(SqlSelect, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- expandSearch(RexBuilder, RexProgram, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Expands all the calls to
SqlStdOperatorTable.SEARCH
in an expression. - expandSearch(RexBuilder, RexProgram, RexNode, int) - Static method in class org.apache.calcite.rex.RexUtil
-
Expands calls to
SqlStdOperatorTable.SEARCH
whose complexity is greater thanmaxComplexity
in an expression. - expandSelectExpr(SqlNode, SelectScope, SqlSelect) - Method in class org.apache.calcite.sql.advise.SqlAdvisorValidator
- expandSelectExpr(SqlNode, SelectScope, SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- expandStar(SqlNodeList, SqlSelect, boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns a list of expressions, with every occurrence of "*" or "TABLE.*" expanded.
- expandStar(SqlNodeList, SqlSelect, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- expandUp(Iterable<? extends SqlLibrary>) - Static method in enum org.apache.calcite.sql.fun.SqlLibrary
-
Expands libraries in place.
- expandView(RelDataType, String, List<String>, List<String>) - Method in interface org.apache.calcite.plan.RelOptTable.ViewExpander
-
Returns a relational expression that is to be substituted for an access to a SQL view.
- expandView(RelDataType, String, List<String>, List<String>) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- expandView(RelDataType, String, List<String>, List<String>) - Method in class org.apache.calcite.prepare.PlannerImpl
- expandView(RelDataType, String, List<String>, List<String>) - Method in class org.apache.calcite.prepare.PlannerImpl.ViewExpanderImpl
-
Deprecated.
- expectedBoolean() - Method in interface org.apache.calcite.runtime.CalciteResource
- expectedCharacter() - Method in interface org.apache.calcite.runtime.CalciteResource
- expectedQueryOrJoinExpression() - Method in interface org.apache.calcite.runtime.CalciteResource
- expectThrowable(Throwable) - Static method in class org.apache.calcite.test.Matchers
-
Creates a matcher that matches if the examined value is expected throwable.
- Experimental - Annotation Type in org.apache.calcite.linq4j.function
-
Annotation that indicates that a class, interface, field or method is experimental, not part of the public API, and subject to change or removal.
- explain() - Method in interface org.apache.calcite.rel.RelNode
-
Returns a relational expression string of this
RelNode
. - explain(RelNode, List<Pair<String, Object>>) - Method in class org.apache.calcite.rel.externalize.RelJsonWriter
- explain(RelNode, List<Pair<String, Object>>) - Method in class org.apache.calcite.rel.externalize.RelWriterImpl
- explain(RelNode, List<Pair<String, Object>>) - Method in interface org.apache.calcite.rel.RelWriter
-
Prints an explanation of a node, with a list of (term, value) pairs.
- explain(RelWriter) - Method in class org.apache.calcite.plan.hep.HepRelVertex
- explain(RelWriter) - Method in class org.apache.calcite.plan.volcano.RelSubset
- explain(RelWriter) - Method in class org.apache.calcite.rel.AbstractRelNode
- explain(RelWriter) - Method in interface org.apache.calcite.rel.RelNode
-
Describes the inputs and attributes of this relational expression.
- EXPLAIN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
EXPLAIN statement.
- explain_(RelNode, List<Pair<String, Object>>) - Method in class org.apache.calcite.rel.externalize.RelDotWriter
- explain_(RelNode, List<Pair<String, Object>>) - Method in class org.apache.calcite.rel.externalize.RelJsonWriter
- explain_(RelNode, List<Pair<String, Object>>) - Method in class org.apache.calcite.rel.externalize.RelWriterImpl
- explain_(RelNode, List<Pair<String, Object>>) - Method in class org.apache.calcite.rel.externalize.RelXmlWriter
- EXPLAIN_VISIBILITY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- explainCalc(MutableCalc) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
-
Explain filtering condition and projections from MutableCalc.
- explainCalc(RelWriter) - Method in class org.apache.calcite.rex.RexProgram
-
Writes an explanation of the expressions in this program to a plan writer.
- explainContains(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- explainHookContains(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
This enables to assert the optimized plan without issuing a separate
explain ...
command. - explainHookContains(SqlExplainLevel, String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
This enables to assert the optimized plan without issuing a separate
explain ...
command. - explainHookMatches(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
This enables to assert the optimized plan without issuing a separate
explain ...
command. - explainHookMatches(SqlExplainLevel, Matcher<String>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
This enables to assert the optimized plan without issuing a separate
explain ...
command. - explainHookMatches(Matcher<String>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
This enables to assert the optimized plan without issuing a separate
explain ...
command. - explainMatches(String, Consumer<ResultSet>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- explainTerms(RelWriter) - Method in class org.apache.calcite.adapter.cassandra.CassandraLimit
- explainTerms(RelWriter) - Method in class org.apache.calcite.adapter.csv.CsvTableScan
- explainTerms(RelWriter) - Method in class org.apache.calcite.adapter.druid.DruidQuery
- explainTerms(RelWriter) - Method in class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoin
- explainTerms(RelWriter) - Method in class org.apache.calcite.adapter.enumerable.EnumerableLimit
- explainTerms(RelWriter) - Method in class org.apache.calcite.adapter.file.CsvTableScan
- explainTerms(RelWriter) - Method in class org.apache.calcite.adapter.innodb.InnodbFilter
- explainTerms(RelWriter) - Method in class org.apache.calcite.adapter.innodb.InnodbTableScan
- explainTerms(RelWriter) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcCalc
-
Deprecated.
- explainTerms(RelWriter) - Method in class org.apache.calcite.adapter.spark.SparkRules.SparkCalc
- explainTerms(RelWriter) - Method in class org.apache.calcite.adapter.splunk.SplunkTableScan
- explainTerms(RelWriter) - Method in class org.apache.calcite.interpreter.Bindables.BindableTableScan
- explainTerms(RelWriter) - Method in class org.apache.calcite.plan.volcano.AbstractConverter
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.AbstractRelNode
-
Describes the inputs and attributes of this relational expression.
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.BiRel
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Aggregate
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.AsofJoin
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Calc
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Collect
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Correlate
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Exchange
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Filter
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Join
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Match
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Project
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.RepeatUnion
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Sample
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.SetOp
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Snapshot
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Sort
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.SortExchange
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Spool
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.TableFunctionScan
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.TableModify
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.TableScan
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.TableSpool
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Uncollect
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Values
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.Window
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.logical.LogicalFilter
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.logical.LogicalJoin
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.rules.MultiJoin
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.SingleRel
- explicit(List<RelDataType>) - Static method in class org.apache.calcite.sql.type.InferTypes
-
Returns an
SqlOperandTypeInference
that returns a given list of types. - explicit(RelDataType) - Static method in class org.apache.calcite.sql.type.ReturnTypes
-
Creates an inference rule which returns a copy of a given data type.
- explicit(RelProtoDataType) - Static method in class org.apache.calcite.sql.type.ReturnTypes
- explicit(SqlTypeName) - Static method in class org.apache.calcite.sql.type.ReturnTypes
-
Creates an inference rule which returns a type with no precision or scale, such as
DATE
. - explicit(SqlTypeName, int) - Static method in class org.apache.calcite.sql.type.ReturnTypes
-
Creates an inference rule which returns a type with precision but no scale, such as
VARCHAR(100)
. - EXPLICIT - Enum constant in enum org.apache.calcite.sql.SqlCollation.Coercibility
-
Strongest coercibility.
- EXPLICIT_TABLE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Explicit table, e.g.
- EXPLICIT_TABLE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Keyword which allows an identifier to be explicitly flagged as a table.
- ExplicitOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Parameter type-checking strategy for Explicit Type.
- ExplicitOperandTypeChecker(RelDataType) - Constructor for class org.apache.calcite.sql.type.ExplicitOperandTypeChecker
- ExplicitOperandTypeInference - Class in org.apache.calcite.sql.type
-
ExplicitOperandTypeInferences implements
SqlOperandTypeInference
by explicitly supplying a type for each parameter. - ExplicitOperatorBinding - Class in org.apache.calcite.sql
-
ExplicitOperatorBinding
implementsSqlOperatorBinding
via an underlying array of known operand types. - ExplicitOperatorBinding(RelDataTypeFactory, SqlOperator, List<RelDataType>) - Constructor for class org.apache.calcite.sql.ExplicitOperatorBinding
- ExplicitOperatorBinding(SqlOperatorBinding, List<RelDataType>) - Constructor for class org.apache.calcite.sql.ExplicitOperatorBinding
- ExplicitReturnTypeInference - Class in org.apache.calcite.sql.type
-
A
SqlReturnTypeInference
which always returns the same SQL type. - ExplicitReturnTypeInference(RelProtoDataType) - Constructor for class org.apache.calcite.sql.type.ExplicitReturnTypeInference
-
Creates an inference rule which always returns the same type object.
- ExplodeTable(Geometry) - Constructor for class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions.ExplodeTable
- EXPPLAN_ATTRIBUTES - Enum constant in enum org.apache.calcite.sql.SqlExplainLevel
-
Display only attributes which contribute to the plan output.
- expr(String) - Method in class org.apache.calcite.sql.parser.SqlParserTest
- expr(String) - Method in interface org.apache.calcite.test.IntervalTest.Fixture
- expr(String) - Method in class org.apache.calcite.test.SqlToRelTestBase
- expr(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
-
Creates a test context with a SQL expression.
- EXPR_SUGGESTER - Static variable in class org.apache.calcite.sql.validate.SqlValidatorUtil
- expression - Variable in class org.apache.calcite.adapter.jdbc.JdbcConvention
- expression - Variable in class org.apache.calcite.linq4j.BaseQueryable
- expression - Variable in class org.apache.calcite.linq4j.tree.GotoStatement
- expression - Variable in class org.apache.calcite.linq4j.tree.MemberExpression
- expression - Variable in class org.apache.calcite.linq4j.tree.ThrowStatement
- expression - Variable in class org.apache.calcite.linq4j.tree.TypeBinaryExpression
- expression - Variable in class org.apache.calcite.linq4j.tree.UnaryExpression
- expression - Variable in class org.apache.calcite.sql.ddl.SqlColumnDeclaration
- expression - Variable in class org.apache.calcite.sql.parser.SqlParserFixture
- expression - Variable in class org.apache.calcite.test.SqlValidatorFixture
- expression() - Method in class org.apache.calcite.sql.parser.SqlParserFixture
-
Flags that this is an expression, not a whole query.
- expression(boolean) - Method in class org.apache.calcite.sql.parser.SqlParserFixture
-
Sets whether this is an expression (as opposed to a whole query).
- expression(boolean) - Method in class org.apache.calcite.test.SqlToRelFixture
-
Sets whether this is an expression (as opposed to a whole query).
- expression(RexNode, String, List<String>) - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Adds a lattice column based on a SQL expression, or returns a column based on the same expression seen previously.
- expression(SchemaPlus) - Static method in class org.apache.calcite.schema.Schemas
-
Returns the expression for a schema.
- Expression - Class in org.apache.calcite.linq4j.tree
-
Analogous to LINQ's System.Linq.Expression.
- Expression(ExpressionType, Type) - Constructor for class org.apache.calcite.linq4j.tree.Expression
-
Creates an Expression.
- EXPRESSION - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category consisting of all expression operators.
- EXPRESSION_LINEAGE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- EXPRESSION_REDUCER - Enum constant in enum org.apache.calcite.runtime.Hook
-
Called when a constant expression is being reduced.
- expression0 - Variable in class org.apache.calcite.linq4j.tree.BinaryExpression
- expression0 - Variable in class org.apache.calcite.linq4j.tree.TernaryExpression
- expression1 - Variable in class org.apache.calcite.linq4j.tree.BinaryExpression
- expression1 - Variable in class org.apache.calcite.linq4j.tree.TernaryExpression
- expression2 - Variable in class org.apache.calcite.linq4j.tree.TernaryExpression
- expressionList - Variable in class org.apache.calcite.linq4j.tree.ConditionalStatement
- expressions - Variable in class org.apache.calcite.linq4j.tree.MethodCallExpression
- expressions - Variable in class org.apache.calcite.linq4j.tree.NewArrayExpression
- Expressions - Class in org.apache.calcite.linq4j.tree
-
Utility methods for expressions, including a lot of factory methods.
- Expressions.FluentList<T> - Interface in org.apache.calcite.linq4j.tree
-
Fluent list.
- ExpressionType - Enum in org.apache.calcite.linq4j.tree
-
Analogous to LINQ's System.Linq.Expressions.ExpressionType.
- ExpressionVisitor - Interface in org.apache.calcite.linq4j.tree
-
Represents a visitor or rewriter for expression trees.
- ExprSimplifier(RexSimplify) - Constructor for class org.apache.calcite.rex.RexUtil.ExprSimplifier
-
Deprecated.
- ExprSimplifier(RexSimplify, boolean) - Constructor for class org.apache.calcite.rex.RexUtil.ExprSimplifier
-
Deprecated.
- ExprSimplifier(RexSimplify, RexUnknownAs, boolean) - Constructor for class org.apache.calcite.rex.RexUtil.ExprSimplifier
-
Deprecated.
- exps - Variable in class org.apache.calcite.rel.core.Project
- extend() - Method in class org.apache.calcite.test.MockSqlOperatorTable
-
Returns this table with a few mock operators added.
- extend(List<RelDataTypeField>) - Method in class org.apache.calcite.plan.RelOptAbstractTable
- extend(List<RelDataTypeField>) - Method in interface org.apache.calcite.plan.RelOptTable
-
Returns a table with the given extra fields.
- extend(List<RelDataTypeField>) - Method in class org.apache.calcite.prepare.Prepare.AbstractPreparingTable
- extend(List<RelDataTypeField>) - Method in interface org.apache.calcite.schema.ExtensibleTable
-
Returns a table that has the row type of this table plus the given fields.
- extend(List<RelDataTypeField>, RelDataTypeFactory) - Method in class org.apache.calcite.schema.impl.ModifiableViewTable
-
Extends the underlying table and returns a new view with updated row-type and column-mapping.
- extend(Table) - Method in class org.apache.calcite.prepare.Prepare.AbstractPreparingTable
-
Implementation-specific code to instantiate a new
RelOptTable
based on aTable
that has been extended. - extend(Table) - Method in class org.apache.calcite.prepare.RelOptTableImpl
- extend(Table) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable
- extend(Table) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- extend(Table, RelProtoDataType, ImmutableIntList) - Method in class org.apache.calcite.schema.impl.ModifiableViewTable
- extend(Table, RelProtoDataType, ImmutableIntList) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable.MockModifiableViewTable
- EXTEND - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The internal
EXTEND
operator that qualifies a table name in theFROM
clause. - EXTEND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
EXTEND
operator. - extended - Variable in class org.apache.calcite.linq4j.tree.ClassDeclaration
- EXTENDED - Static variable in interface org.apache.calcite.rel.rules.AggregateJoinTransposeRule.Config
-
Extended instance that can push down aggregate functions.
- ExtendedEnumerable<TSource> - Interface in org.apache.calcite.linq4j
-
Extension methods in
Enumerable
. - extendedExpandGroupBy(SqlNode, SqlValidatorScope, SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- ExtendedOrderedEnumerable<T> - Interface in org.apache.calcite.linq4j
-
Extension methods for
OrderedEnumerable
. - ExtendedOrderedQueryable<T> - Interface in org.apache.calcite.linq4j
-
Extension methods for
OrderedQueryable
. - extendList - Variable in class org.apache.calcite.sql.validate.IdentifierNamespace
- extendNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- extendQuery(DruidQuery, List<Interval>) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Extends a DruidQuery.
- extendQuery(DruidQuery, RelNode) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Extends a DruidQuery.
- ExtensibleTable - Interface in org.apache.calcite.schema
-
Table whose row type can be extended to include extra fields.
- Extension - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An extension expression.
- Extensions - Class in org.apache.calcite.linq4j
-
Contains what, in LINQ.NET, would be extension methods.
- extra(RelDataType) - Static method in class org.apache.calcite.rel.type.RelDataTypeImpl
-
Returns the "extra" field in a row type whose presence signals that fields will come into existence just by asking for them.
- extraCondition() - Method in interface org.apache.calcite.rel.rules.AggregateReduceFunctionsRule.Config
-
A test that must pass before attempting to reduce any aggregate function.
- EXTRACT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
EXTRACT
function. - EXTRACT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
EXTRACT
operator. - EXTRACT_VALUE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- EXTRACT_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- EXTRACT_XML - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- EXTRACT_XML - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- extractColumnName(RexNode, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Returns Druid column name or null when it is not possible to translate.
- extractGranularity(RexNode, String) - Static method in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
-
Infers granularity from a time unit.
- ExtractionDimensionSpec - Class in org.apache.calcite.adapter.druid
-
Implementation of extraction function DimensionSpec.
- ExtractionDimensionSpec(String, ExtractionFunction, String) - Constructor for class org.apache.calcite.adapter.druid.ExtractionDimensionSpec
- ExtractionDimensionSpec(String, ExtractionFunction, String, DruidType) - Constructor for class org.apache.calcite.adapter.druid.ExtractionDimensionSpec
- ExtractionFunction - Interface in org.apache.calcite.adapter.druid
-
Interface for Druid extraction functions.
- extractLastNFields(RelDataTypeFactory, RelDataType, int) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Keeps only the last N fields and returns the new struct type.
- ExtractOperatorConversion - Class in org.apache.calcite.adapter.druid
-
Time extract operator conversion for expressions like
EXTRACT(timeUnit FROM arg)
. - ExtractOperatorConversion() - Constructor for class org.apache.calcite.adapter.druid.ExtractOperatorConversion
- extractPossibleMapping(List<Set<RexTableInputRef>>, List<Set<RexTableInputRef>>) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
Given the source and target equivalence classes, it extracts the possible mappings from each source equivalence class to each target equivalence class.
- extractRanges(RexNode, boolean) - Static method in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
- extractReferences(RexBuilder, RelNode) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
If the node is an Aggregate, it returns a list of references to the grouping columns.
- extractValue(String, String) - Static method in class org.apache.calcite.runtime.XmlFunctions
- extractXml(String, String) - Static method in class org.apache.calcite.runtime.XmlFunctions
- extractXml(String, String, String) - Static method in class org.apache.calcite.runtime.XmlFunctions
- extraExprList - Variable in class org.apache.calcite.sql.validate.AggregatingSelectScope.Resolved
- extraSelectItems(SqlToRelConverter.Blackboard, SqlSelect, List<RexNode>, List<String>, Collection<String>, List<SqlMonotonicity>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Adds extra select items.
- ExtraSqlTypes - Interface in org.apache.calcite.sql.type
-
Holds constants associated with SQL types introduced after the earliest version of Java supported by Farrago (this currently means anything introduced in JDK 1.6 or later).
F
- F_SUGGESTER - Static variable in class org.apache.calcite.sql.validate.SqlValidatorUtil
- FACADE_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Provide a unified interface to a set of interfaces in a subsystem.
- factorial(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
FACTORIAL
operator. - FACTORIAL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FACTORIAL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
FACTORIAL(integer)
function. - factory - Variable in class org.apache.calcite.model.JsonCustomSchema
-
Name of the factory class for this schema.
- factory - Variable in class org.apache.calcite.model.JsonCustomTable
-
Name of the factory class for this table.
- factory - Variable in class org.apache.calcite.sql.parser.SqlParserFixture
- factory - Variable in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
- factory - Variable in class org.apache.calcite.test.RelMetadataFixture
- factory - Variable in class org.apache.calcite.test.SqlValidatorFixture
- factory() - Static method in class org.apache.calcite.util.graph.DefaultEdge
- Factory() - Constructor for class org.apache.calcite.adapter.clone.CloneSchema.Factory
- Factory() - Constructor for class org.apache.calcite.adapter.java.ReflectiveSchema.Factory
- Factory() - Constructor for class org.apache.calcite.linq4j.util.Compatible.Factory
- Factory() - Constructor for class org.apache.calcite.util.Compatible.Factory
- FACTORY - Static variable in class org.apache.calcite.plan.RelOptCostImpl
- FACTORY - Static variable in class org.apache.calcite.sql.parser.SqlParserFixture
- FACTORY_METHOD_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Define an interface for creating an object, but let subclasses decide which class to instantiate.
- fail(String, Object...) - Method in class org.apache.calcite.rel.hint.HintStrategyTable.HintErrorLogger
- fail(String, Object...) - Method in interface org.apache.calcite.util.Litmus
-
Called when test fails.
- failCount - Variable in class org.apache.calcite.rex.RexChecker
- failedToAccessField(String, int, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- fails(String) - Method in class org.apache.calcite.sql.parser.SqlParserFixture
- fails(String) - Method in interface org.apache.calcite.test.IntervalTest.Fixture2
-
Checks that the expression is valid in the parser but invalid (with the given error message) in the validator.
- fails(String) - Method in class org.apache.calcite.test.SqlValidatorFixture
-
Checks that a SQL expression gives a particular error.
- failsAtValidation() - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Utility method so that one doesn't have to call
CalciteAssert.AssertQuery.failsAtValidation(java.lang.String)
withnull
. - failsAtValidation(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Used to check whether a sql statement fails at the SQL Validation phase.
- failsIf(boolean, String) - Method in class org.apache.calcite.test.SqlValidatorFixture
-
Checks that a SQL expression fails, giving an
expected
error, ifb
is true, otherwise succeeds. - FAKE_FOODMART - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- FakeUtil() - Constructor for class org.apache.calcite.sql.SqlDialect.FakeUtil
-
Deprecated.
- FALSE - Enum constant in enum org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
If one of the arguments is null, the function returns false.
- FALSE - Enum constant in enum org.apache.calcite.plan.RelOptUtil.Logic
-
An anti-semi-join will have been applied, so that only rows for which the value is FALSE will have been returned.
- FALSE - Enum constant in enum org.apache.calcite.rex.RexUnknownAs
-
Policy that indicates that the expression is being used in a context Where an UNKNOWN value is treated in the same way as FALSE.
- FALSE - Enum constant in enum org.apache.calcite.sql.SqlJsonExistsErrorBehavior
- FALSE - Static variable in interface org.apache.calcite.linq4j.function.Predicate1
-
Predicate that always evaluates to
false
. - FALSE - Static variable in interface org.apache.calcite.linq4j.function.Predicate2
-
Predicate that always evaluates to
false
. - FALSE - Static variable in interface org.apache.calcite.rel.rules.PushProjector.ExprCondition
-
Constant condition that replies
false
for all expressions. - FALSE_EXPR - Static variable in class org.apache.calcite.adapter.enumerable.RexImpTable
- FALSE_EXPR - Static variable in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- falseIf(boolean) - Static method in enum org.apache.calcite.rex.RexUnknownAs
- falsePredicate1() - Static method in class org.apache.calcite.linq4j.function.Functions
-
A predicate with one parameter that always returns
true
. - falsePredicate2() - Static method in class org.apache.calcite.linq4j.function.Functions
-
A predicate with two parameters that always returns
false
. - families - Variable in class org.apache.calcite.sql.type.FamilyOperandTypeChecker
- families(List<RelDataType>) - Static method in class org.apache.calcite.rex.RexUtil
- family - Variable in enum org.apache.calcite.sql.SqlSyntax
-
Syntax to treat this syntax as equivalent to when resolving operators.
- family(List<SqlTypeFamily>) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a checker that passes if each operand is a member of a corresponding family.
- family(List<SqlTypeFamily>, Predicate<Integer>) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a checker that passes if each operand is a member of a corresponding family, and allows specified parameters to be optional.
- family(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- family(SqlTypeFamily...) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a checker that passes if each operand is a member of a corresponding family.
- FamilyOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Operand type-checking strategy which checks operands for inclusion in type families.
- fastBailOut() - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewRule.Config
-
Whether we should create the rewriting in the minimal subtree of plan operators.
- Feature - Class in org.apache.calcite.runtime
-
SQL language feature.
- Feature(String, Locale, Method, Object...) - Constructor for class org.apache.calcite.runtime.Feature
- fetch - Variable in class org.apache.calcite.adapter.cassandra.CassandraLimit
- fetch - Variable in class org.apache.calcite.adapter.enumerable.EnumerableLimit
- fetch - Variable in class org.apache.calcite.rel.core.Sort
- fetch - Variable in class org.apache.calcite.rel.mutable.MutableSort
- fetch - Variable in class org.apache.calcite.sql.SqlOrderBy
- fetch(Meta.StatementHandle, long, int) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- FETCH - Enum constant in enum org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- FETCH - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
FETCH clause.
- FETCH - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
Fetch operator is ONLY used for its precedence during unparsing.
- fetchOffset(SqlNode, SqlNode) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- fetchOffset(SqlNode, SqlNode) - Method in interface org.apache.calcite.sql.SqlWriter
-
Prints the OFFSET/FETCH clause.
- FF1 - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- FF2 - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- FF3 - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- FF4 - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- FF5 - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- FF6 - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- FF7 - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- FF8 - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- FF9 - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- FIBONACCI_INSTANCE_TABLE_METHOD - Static variable in class org.apache.calcite.util.Smalls
- FIBONACCI_LIMIT_100_TABLE_METHOD - Static variable in class org.apache.calcite.util.Smalls
- FIBONACCI_LIMIT_TABLE_METHOD - Static variable in class org.apache.calcite.util.Smalls
- FIBONACCI_TABLE_METHOD - Static variable in class org.apache.calcite.util.Smalls
- fibonacciTable() - Static method in class org.apache.calcite.util.Smalls
-
A function that generates the Fibonacci sequence.
- FibonacciTableFunction(int) - Constructor for class org.apache.calcite.util.Smalls.FibonacciTableFunction
- fibonacciTableWithLimit(long) - Static method in class org.apache.calcite.util.Smalls
-
A function that generates the Fibonacci sequence.
- fibonacciTableWithLimit100() - Static method in class org.apache.calcite.util.Smalls
-
A function that generates the first 100 terms of the Fibonacci sequence.
- field - Variable in class org.apache.calcite.linq4j.tree.MemberExpression
- field - Variable in enum org.apache.calcite.util.BuiltInMethod
- field(int) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Returns the physical type of a field.
- field(int) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- field(int) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.AliasContext
- field(int) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- field(int) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.SimpleContext
- field(int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a reference to an input field by ordinal.
- field(int, int, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a reference to a field of a given input relational expression by ordinal.
- field(int, int, String) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a reference to a field of given input relational expression by name.
- field(int, String, String) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a reference to a field which originated in a relation with the given alias.
- field(Field) - Static method in class org.apache.calcite.linq4j.tree.Types
- field(String) - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- field(String) - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- field(String) - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns a field of a given name, or null.
- field(String) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a reference to a field by name.
- field(String, String) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a reference to a field of the current record which originated in a relation with a given alias.
- field(Expression, Field) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberExpression that represents accessing a field.
- field(Expression, Type, String) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberExpression that represents accessing a field.
- field(Expression, PseudoField) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberExpression that represents accessing a field.
- field(BlockBuilder, int, Type) - Method in interface org.apache.calcite.adapter.enumerable.RexToLixTranslator.InputGetter
- field(BlockBuilder, int, Type) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator.InputGetterImpl
- field(Expression, int, Type, Type) - Method in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
-
Returns a reference to a particular field.
- field(Expression, String) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberExpression that represents accessing a field given the name of the field.
- field(RelDataType, String) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- field(RelDataType, String) - Method in interface org.apache.calcite.sql.validate.SqlNameMatcher
-
Finds a field with a given name, using the current case-sensitivity, returning null if not found.
- field(RelDataType, String) - Method in interface org.apache.calcite.sql.validate.SqlValidatorCatalogReader
- field(RexNode, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns a reference to a given field (by ordinal) of a record-valued expression.
- field(RexNode, String) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns a reference to a given field (by name, case-insensitive) of a record-valued expression.
- FIELD_ACCESS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The field access operator, ".".
- FIELD_SCHEMA - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- FieldAccessFinder() - Constructor for class org.apache.calcite.rex.RexUtil.FieldAccessFinder
- fieldClass(int) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Returns the Java class of the field with the given ordinal.
- fieldClass(int) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- fieldCounts - Variable in class org.apache.calcite.schema.impl.StarTable
-
Number of fields in each table's row type.
- fieldDecl(int, ParameterExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Declares a field.
- fieldDecl(int, ParameterExpression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Declares a field with an initializer.
- FieldDeclaration - Class in org.apache.calcite.linq4j.tree
-
Declaration of a field.
- FieldDeclaration(int, ParameterExpression, Expression) - Constructor for class org.apache.calcite.linq4j.tree.FieldDeclaration
- fieldExists(String) - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns whether this namespace has a field of a given name.
- FieldInfoBuilder(RelDataTypeFactory) - Constructor for class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- fieldIsNullable(int) - Method in interface org.apache.calcite.rel.RelNode
-
Returns whether a field is nullable.
- fieldList - Variable in class org.apache.calcite.rel.type.RelDataTypeImpl
- fieldList() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- fieldName - Variable in class org.apache.calcite.rel.mutable.MutableCollect
- fieldNullable(int) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Returns whether a given field allows null values.
- fieldNullable(int) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- fieldOrigins - Variable in class org.apache.calcite.prepare.Prepare
- fieldOrigins - Variable in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- fieldReference(Expression, int) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Generates a reference to a given field in an expression.
- fieldReference(Expression, int) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- fieldReference(Expression, int, Type) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Generates a reference to a given field in an expression.
- fieldReference(Expression, int, Type) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- fields - Variable in class org.apache.calcite.rel.RelRoot
- fields() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHit
- fields() - Static method in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- fields() - Method in class org.apache.calcite.tools.RelBuilder
-
Returns references to the fields of the top input.
- fields(int, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns references to the fields of a given input.
- fields(Iterable<String>) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns references to fields identified by name.
- fields(List<? extends Number>) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns references to fields for a given list of input ordinals.
- fields(RelCollation) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns references to fields for a given collation.
- fields(ImmutableBitSet) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns references to fields for a given bit set of input ordinals.
- fields(Mappings.TargetMapping) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns references to fields identified by a mapping.
- fieldsByName - Variable in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
The map of all the added final static fields.
- FieldSchema(SqlParserPos, Ast.Identifier, Ast.Type) - Constructor for class org.apache.calcite.piglet.Ast.FieldSchema
- file() - Method in interface org.apache.calcite.util.Source
- file(File, String) - Static method in class org.apache.calcite.util.Sources
- FILE - Enum constant in enum org.apache.calcite.sql.ddl.SqlDdlNodes.FileType
- FILE_SEPARATOR - Static variable in class org.apache.calcite.util.Util
-
System-dependent file separator, for example, "/" or "\."
- FILE_TIMESTAMP_FORMAT - Static variable in class org.apache.calcite.util.Util
-
Datetime format string for generating a timestamp string to be used as part of a filename.
- fileContents(File) - Static method in class org.apache.calcite.test.DiffTestCase
-
Returns the contents of a file as a string.
- filename() - Method in interface org.apache.calcite.util.Puffin.Line
-
Returns the filename of the current source.
- fileOpt() - Method in interface org.apache.calcite.util.Source
- FileReader - Class in org.apache.calcite.adapter.file
-
Scrapes HTML tables from URLs using Jsoup.
- FileReader(Source) - Constructor for class org.apache.calcite.adapter.file.FileReader
- FileReader(Source, String, Integer) - Constructor for class org.apache.calcite.adapter.file.FileReader
- FileReader(Source, String) - Constructor for class org.apache.calcite.adapter.file.FileReader
- FileReaderException - Exception Class in org.apache.calcite.adapter.file
-
Indicates that the FileReader failed.
- FileRules - Class in org.apache.calcite.adapter.file
-
Planner rules relating to the File adapter.
- FileSchemaFactory - Class in org.apache.calcite.adapter.file
-
Factory that creates a
FileSchema
. - FilesTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "find" command to find files under a particular path.
- fillInStackTrace() - Method in exception class org.apache.calcite.util.ControlFlowException
- filter - Variable in class org.apache.calcite.sql.validate.SqlValidatorUtil.FlatAggregate
- filter(Iterable<?>, Class<E>) - Static method in class org.apache.calcite.util.Util
-
Makes a collection of untyped elements appear as a list of strictly typed elements, by filtering out those which are not of the correct type.
- filter(Iterable<? extends E>, Predicate<? super E>) - Static method in class org.apache.calcite.util.Util
-
Filters an iterable.
- filter(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Filter
of a list of predicates. - filter(Iterable<CorrelationId>, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Filter
of a list of correlation variables and a list of predicates. - filter(Iterable<CorrelationId>, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Filter
of a list of correlation variables and an array of predicates. - filter(Collection<?>, Class<E>) - Static method in class org.apache.calcite.util.Util
- filter(Iterator<? extends E>, Predicate<? super E>) - Static method in class org.apache.calcite.util.Util
-
Filters an iterator.
- filter(List<?>, Class<E>) - Static method in class org.apache.calcite.util.Util
-
Returns a subset of a list containing only elements of a given type.
- filter(List<E>, Predicate1<E>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns a list that contains only elements of
list
that matchpredicate
. - filter(RelMetadataQuery, RelNode) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Helper method to determine a
Filter
's collation. - filter(RelMetadataQuery, RelNode) - Static method in class org.apache.calcite.rel.metadata.RelMdDistribution
-
Helper method to determine a
Filter
's distribution. - filter(RexNode) - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
-
Returns a copy of this AggCall that applies a filter before aggregating values.
- filter(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Filter
of an array of predicates. - filter(DiffRepository, String, String, String, String) - Method in interface org.apache.calcite.test.DiffRepository.Filter
-
Filters a string.
- Filter - Class in org.apache.calcite.rel.core
-
Relational expression that iterates over its input and returns elements for which
condition
evaluates totrue
. - Filter(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RexNode) - Constructor for class org.apache.calcite.rel.core.Filter
-
Creates a filter.
- Filter(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.calcite.rel.core.Filter
-
Creates a filter.
- Filter(RelInput) - Constructor for class org.apache.calcite.rel.core.Filter
-
Creates a Filter by parsing serialized output.
- FILTER - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- FILTER - Enum constant in enum org.apache.calcite.sql.SqlKind
-
FILTER
operator. - FILTER - Static variable in class org.apache.calcite.adapter.cassandra.CassandraRules
- FILTER - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- FILTER - Static variable in class org.apache.calcite.adapter.innodb.InnodbRules
-
Rule to convert a
LogicalFilter
to aInnodbFilter
. - FILTER - Static variable in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- FILTER - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
Filter
nodes. - FILTER - Static variable in class org.apache.calcite.rel.rules.materialize.MaterializedViewRules
-
Rule that matches
Filter
. - FILTER - Static variable in interface org.apache.calcite.rel.rules.PruneEmptyRules.RemoveEmptySingleRule.RemoveEmptySingleRuleConfig
- FILTER - Static variable in interface org.apache.calcite.rel.rules.SubQueryRemoveRule.Config
- FILTER - Static variable in interface org.apache.calcite.rel.rules.ValuesReduceRule.Config
- FILTER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
FILTER
operator filters which rows are included in an aggregate function. - FILTER_AGGREGATE_TRANSPOSE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- FILTER_AGGREGATE_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- FILTER_CALC_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that merges a
Filter
and aLogicalCalc
. - FILTER_CORRELATE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- FILTER_EXPAND_IS_NOT_DISTINCT_FROM - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that replaces
IS NOT DISTINCT FROM
in aFilter
with logically equivalent operations. - FILTER_INSTANCE - Static variable in class org.apache.calcite.rel.rules.DateRangeRules
-
Rule that matches a
Filter
and converts calls toEXTRACT
,FLOOR
andCEIL
functions to date ranges (typically using theBETWEEN
operator). - FILTER_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts a
Filter
to empty if its child is empty. - FILTER_INTERPRETER_SCAN - Static variable in class org.apache.calcite.rel.rules.CoreRules
- FILTER_INTO_JOIN - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that tries to push filter expressions into a join condition and into the inputs of the join.
- FILTER_INTO_JOIN_DUMB - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Dumber version of
CoreRules.FILTER_INTO_JOIN
. - FILTER_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that combines two
LogicalFilter
s. - FILTER_MULTI_JOIN_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- FILTER_ON_PROJECT - Static variable in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- FILTER_PREDICATE - Static variable in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- FILTER_PREDICATE - Static variable in class org.apache.calcite.rex.RexUtil.SubQueryFinder
-
Deprecated.
- FILTER_PROJECT_TRANSPOSE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- FILTER_PROJECT_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
The default instance of
FilterProjectTransposeRule
. - FILTER_REDUCE_EXPRESSIONS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that reduces constants inside a
LogicalFilter
. - FILTER_SAMPLE_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- FILTER_SCAN - Static variable in class org.apache.calcite.adapter.arrow.ArrowRules
- FILTER_SCAN - Static variable in class org.apache.calcite.rel.rules.CoreRules
- FILTER_SCAN - Static variable in class org.apache.calcite.rel.rules.materialize.MaterializedViewRules
- FILTER_SET_OP_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- FILTER_SORT - Static variable in class org.apache.calcite.rel.rules.MeasureRules
- FILTER_SUB_QUERY_TO_CORRELATE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that converts a sub-queries from filter expressions into
Correlate
instances. - FILTER_TABLE_FUNCTION_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that pushes a
LogicalFilter
past aLogicalTableFunctionScan
. - FILTER_TO_CALC - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that converts a
LogicalFilter
to aLogicalCalc
. - FILTER_VALUES_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that merges a
Filter
onto an underlyingLogicalValues
, resulting in aValues
with potentially fewer rows. - FILTER_WINDOW_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- FILTERABLE - Enum constant in enum org.apache.calcite.adapter.csv.CsvTable.Flavor
- FILTERABLE - Enum constant in enum org.apache.calcite.adapter.file.CsvTable.Flavor
- FilterableTable - Interface in org.apache.calcite.schema
-
Table that can be scanned, optionally applying supplied filter expressions, without creating an intermediate relational expression.
- filterableTableInventedFilter(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- filterableTableScanReturnedNull() - Method in interface org.apache.calcite.runtime.CalciteResource
- filterAggregateTransposeRule() - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule.Config
-
Instance of rule to push filter through aggregate.
- FilterAggregateTransposeRule - Class in org.apache.calcite.rel.rules
- FilterAggregateTransposeRule(Class<? extends Filter>, RelFactories.FilterFactory, Class<? extends Aggregate>) - Constructor for class org.apache.calcite.rel.rules.FilterAggregateTransposeRule
-
Deprecated.
- FilterAggregateTransposeRule(Class<? extends Filter>, RelBuilderFactory, Class<? extends Aggregate>) - Constructor for class org.apache.calcite.rel.rules.FilterAggregateTransposeRule
-
Deprecated.
- FilterAggregateTransposeRule(RelOptRuleOperand, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterAggregateTransposeRule
-
Deprecated.
- FilterAggregateTransposeRule(FilterAggregateTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.FilterAggregateTransposeRule
-
Creates a FilterAggregateTransposeRule.
- FilterAggregateTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- filterArg - Variable in class org.apache.calcite.rel.core.AggregateCall
- Filterator<E> - Class in org.apache.calcite.util
-
Filtered iterator class: an iterator that includes only elements that are instanceof a specified class.
- Filterator(Iterator<?>, Class<E>) - Constructor for class org.apache.calcite.util.Filterator
- FilterCalcMergeRule - Class in org.apache.calcite.rel.rules
- FilterCalcMergeRule(FilterCalcMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.FilterCalcMergeRule
-
Creates a FilterCalcMergeRule.
- FilterCalcMergeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterCalcMergeRule
-
Deprecated.
- FilterCalcMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- filterCall - Variable in class org.apache.calcite.sql.validate.SqlValidatorUtil.FlatAggregate
- FilterCorrelateRule - Class in org.apache.calcite.rel.rules
- FilterCorrelateRule(RelFactories.FilterFactory, RelFactories.ProjectFactory) - Constructor for class org.apache.calcite.rel.rules.FilterCorrelateRule
-
Deprecated.
- FilterCorrelateRule(FilterCorrelateRule.Config) - Constructor for class org.apache.calcite.rel.rules.FilterCorrelateRule
-
Creates a FilterCorrelateRule.
- FilterCorrelateRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterCorrelateRule
-
Deprecated.
- FilterCorrelateRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- FilterDateRangeRule(DateRangeRules.FilterDateRangeRule.FilterDateRangeRuleConfig) - Constructor for class org.apache.calcite.rel.rules.DateRangeRules.FilterDateRangeRule
-
Creates a FilterDateRangeRule.
- FilterDateRangeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.DateRangeRules.FilterDateRangeRule
-
Deprecated.
- filterFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- FilterFlattenCorrelatedConditionRule - Class in org.apache.calcite.rel.rules
-
Planner rule that matches a
Filter
expression with correlated variables, and rewrites the condition in a simpler form that is more convenient for the decorrelation logic. - FilterFlattenCorrelatedConditionRule(FilterFlattenCorrelatedConditionRule.Config) - Constructor for class org.apache.calcite.rel.rules.FilterFlattenCorrelatedConditionRule
- FilterFlattenCorrelatedConditionRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- FilterHilbertRule(SpatialRules.FilterHilbertRule.Config) - Constructor for class org.apache.calcite.rel.rules.SpatialRules.FilterHilbertRule
- FilterIntoJoinRule(boolean, RelFactories.FilterFactory, RelFactories.ProjectFactory, FilterJoinRule.Predicate) - Constructor for class org.apache.calcite.rel.rules.FilterJoinRule.FilterIntoJoinRule
-
Deprecated.
- FilterIntoJoinRule(boolean, RelBuilderFactory, FilterJoinRule.Predicate) - Constructor for class org.apache.calcite.rel.rules.FilterJoinRule.FilterIntoJoinRule
-
Deprecated.
- FilterIntoJoinRule(FilterJoinRule.FilterIntoJoinRule.FilterIntoJoinRuleConfig) - Constructor for class org.apache.calcite.rel.rules.FilterJoinRule.FilterIntoJoinRule
-
Creates a FilterIntoJoinRule.
- FilterJoinRule<C extends FilterJoinRule.Config> - Class in org.apache.calcite.rel.rules
-
Planner rule that pushes filters above and within a join node into the join node and/or its children nodes.
- FilterJoinRule(C) - Constructor for class org.apache.calcite.rel.rules.FilterJoinRule
-
Creates a FilterJoinRule.
- FilterJoinRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- FilterJoinRule.FilterIntoJoinRule - Class in org.apache.calcite.rel.rules
-
Rule that tries to push filter expressions into a join condition and into the inputs of the join.
- FilterJoinRule.FilterIntoJoinRule.FilterIntoJoinRuleConfig - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- FilterJoinRule.JoinConditionPushRule - Class in org.apache.calcite.rel.rules
-
Rule that pushes parts of the join condition to its inputs.
- FilterJoinRule.JoinConditionPushRule.JoinConditionPushRuleConfig - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- FilterJoinRule.Predicate - Interface in org.apache.calcite.rel.rules
-
Predicate that returns whether a filter is valid in the ON clause of a join for this particular kind of join.
- FilterMergeRule - Class in org.apache.calcite.rel.rules
-
Planner rule that combines two
LogicalFilter
s. - FilterMergeRule(RelFactories.FilterFactory) - Constructor for class org.apache.calcite.rel.rules.FilterMergeRule
-
Deprecated.
- FilterMergeRule(FilterMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.FilterMergeRule
-
Creates a FilterMergeRule.
- FilterMergeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterMergeRule
-
Deprecated.
- FilterMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- FilterMultiJoinMergeRule - Class in org.apache.calcite.rel.rules
- FilterMultiJoinMergeRule(Class<? extends Filter>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterMultiJoinMergeRule
-
Deprecated.
- FilterMultiJoinMergeRule(FilterMultiJoinMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.FilterMultiJoinMergeRule
-
Creates a FilterMultiJoinMergeRule.
- FilterMultiJoinMergeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterMultiJoinMergeRule
-
Deprecated.
- FilterMultiJoinMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- filterMustBeBoolean() - Method in interface org.apache.calcite.runtime.CalciteResource
- FilterNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
Filter
. - FilterNode(Compiler, Filter) - Constructor for class org.apache.calcite.interpreter.FilterNode
- filterNonAggregate() - Method in interface org.apache.calcite.runtime.CalciteResource
- filterProjectTransposeRule() - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule.Config
-
Instance of rule to push filter through project.
- FilterProjectTransposeRule - Class in org.apache.calcite.rel.rules
- FilterProjectTransposeRule(Class<? extends Filter>, Class<? extends Project>, boolean, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterProjectTransposeRule
-
Deprecated.
- FilterProjectTransposeRule(Class<? extends Filter>, RelFactories.FilterFactory, Class<? extends Project>, RelFactories.ProjectFactory) - Constructor for class org.apache.calcite.rel.rules.FilterProjectTransposeRule
-
Deprecated.
- FilterProjectTransposeRule(Class<F>, Predicate<? super F>, Class<P>, Predicate<? super P>, boolean, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterProjectTransposeRule
-
Deprecated.
- FilterProjectTransposeRule(RelOptRuleOperand, boolean, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterProjectTransposeRule
-
Deprecated.
- FilterProjectTransposeRule(FilterProjectTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.FilterProjectTransposeRule
-
Creates a FilterProjectTransposeRule.
- FilterProjectTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- FilterReduceExpressionsRule(Class<? extends Filter>, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.FilterReduceExpressionsRule
-
Deprecated.
- FilterReduceExpressionsRule(Class<? extends Filter>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.FilterReduceExpressionsRule
-
Deprecated.
- FilterReduceExpressionsRule(ReduceExpressionsRule.FilterReduceExpressionsRule.FilterReduceExpressionsRuleConfig) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.FilterReduceExpressionsRule
-
Creates a FilterReduceExpressionsRule.
- FilterRemoveIsNotDistinctFromRule - Class in org.apache.calcite.rel.rules
-
Planner rule that replaces
IS NOT DISTINCT FROM
in aFilter
with logically equivalent operations. - FilterRemoveIsNotDistinctFromRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterRemoveIsNotDistinctFromRule
-
Deprecated.
- FilterRemoveIsNotDistinctFromRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- filters - Variable in class org.apache.calcite.interpreter.Bindables.BindableTableScan
- FilterSampleTransposeRule - Class in org.apache.calcite.rel.rules
- FilterSampleTransposeRule(FilterSampleTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.FilterSampleTransposeRule
- FilterSampleTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- FilterSetOpTransposeRule - Class in org.apache.calcite.rel.rules
- FilterSetOpTransposeRule(RelFactories.FilterFactory) - Constructor for class org.apache.calcite.rel.rules.FilterSetOpTransposeRule
-
Deprecated.
- FilterSetOpTransposeRule(FilterSetOpTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.FilterSetOpTransposeRule
-
Creates a FilterSetOpTransposeRule.
- FilterSetOpTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterSetOpTransposeRule
-
Deprecated.
- FilterSetOpTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- FilterSortMeasureRule(MeasureRules.FilterSortMeasureRuleConfig) - Constructor for class org.apache.calcite.rel.rules.MeasureRules.FilterSortMeasureRule
-
Creates a FilterSortMeasureRule.
- FilterStmt(SqlParserPos, Ast.Identifier, Ast.Identifier, Ast.Node) - Constructor for class org.apache.calcite.piglet.Ast.FilterStmt
- FilterTableFunctionTransposeRule - Class in org.apache.calcite.rel.rules
-
Planner rule that pushes a
LogicalFilter
past aLogicalTableFunctionScan
. - FilterTableFunctionTransposeRule(FilterTableFunctionTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.FilterTableFunctionTransposeRule
-
Creates a FilterTableFunctionTransposeRule.
- FilterTableFunctionTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterTableFunctionTransposeRule
-
Deprecated.
- FilterTableFunctionTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- FilterTableScanRule - Class in org.apache.calcite.rel.rules
-
Planner rule that converts a
Filter
on aTableScan
of aFilterableTable
or aProjectableFilterableTable
to aBindables.BindableTableScan
. - FilterTableScanRule(RelOptRuleOperand, String) - Constructor for class org.apache.calcite.rel.rules.FilterTableScanRule
-
Deprecated.
- FilterTableScanRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.FilterTableScanRule
-
Deprecated.
- FilterTableScanRule(FilterTableScanRule.Config) - Constructor for class org.apache.calcite.rel.rules.FilterTableScanRule
-
Creates a FilterTableScanRule.
- FilterTableScanRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- FilterToCalcRule - Class in org.apache.calcite.rel.rules
-
Planner rule that converts a
LogicalFilter
to aLogicalCalc
. - FilterToCalcRule(FilterToCalcRule.Config) - Constructor for class org.apache.calcite.rel.rules.FilterToCalcRule
-
Creates a FilterToCalcRule.
- FilterToCalcRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterToCalcRule
-
Deprecated.
- FilterToCalcRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- FilterWindowTransposeRule - Class in org.apache.calcite.rel.rules
- FilterWindowTransposeRule(FilterWindowTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.FilterWindowTransposeRule
- FilterWindowTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- FINAL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
FINAL
operator inMATCH_RECOGNIZE
. - FINAL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
FINAL
function to be used withinMATCH_RECOGNIZE
. - find(Iterable<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil.SubQueryFinder
- find(String, String, List<Map.Entry<String, Class>>) - Method in class org.apache.calcite.adapter.mongodb.MongoTable.MongoQueryable
-
Called via code-generation.
- find(List<String>, List<Map.Entry<String, Class>>, List<Map.Entry<String, RelFieldCollation.Direction>>, List<String>, List<Map.Entry<String, String>>, Map<String, String>, Long, Long) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable.ElasticsearchQueryable
-
Called via code-generation.
- find(NavigableMap<String, V>, String) - Static method in class org.apache.calcite.jdbc.CalciteSchema
-
Deprecated.use NameMap
- find(NavigableSet<String>, String) - Static method in class org.apache.calcite.jdbc.CalciteSchema
-
Deprecated.use NameSet
- find(Set<SqlKind>) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns a visitor that finds nodes of given
SqlKind
s. - find(RelOptUtil.Logic, List<RexNode>, RexNode) - Static method in class org.apache.calcite.rex.LogicVisitor
-
Finds a suitable logic for evaluating
seek
within a list of expressions. - find(RexInputRef) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns a visitor that finds a particular
RexInputRef
. - find(RexNode) - Static method in class org.apache.calcite.rex.RexUtil.SubQueryFinder
- find(SqlKind) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns a visitor that finds nodes of a given
SqlKind
. - FIND_IN_SET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FIND_IN_SET - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "FIND_IN_SET(matchStr, textStr)" function.
- findAliases(Collection<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- findAliases(Collection<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.ParameterScope
- findAliases(Collection<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.ListScope
- findAliases(Collection<SqlMoniker>) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Collects the
SqlMoniker
s of all table aliases (uses of tables in query FROM clauses) available in this scope. - findAllColumnNames(List<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- findAllColumnNames(List<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.ParameterScope
- findAllColumnNames(List<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.ListScope
- findAllColumnNames(List<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.OrderByScope
- findAllColumnNames(List<SqlMoniker>) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Collects the
SqlMoniker
s of all possible columns in this scope. - findAllTableNames(List<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.ParameterScope
- findAllTableQualifiedNames(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a list of all table qualified names used by this expression or its children.
- findAllTables(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a list of all tables used by this expression or its children.
- findBestExp() - Method in class org.apache.calcite.plan.hep.HepPlanner
- findBestExp() - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Finds the most efficient expression to implement this query.
- findBestExp() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Finds the most efficient expression to implement the query given via
RelOptPlanner.setRoot(org.apache.calcite.rel.RelNode)
. - findBestExp() - Method in class org.apache.calcite.test.MockRelOptPlanner
- findCycles() - Method in class org.apache.calcite.util.graph.CycleDetector
- findDeclaredExpression(Expression) - Method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Finds if there exists ready for reuse declaration for given expression.
- findDeclaredExpression(Expression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Finds if there exists ready for reuse declaration for given expression.
- findField(RelDataType, String) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns the ordinal of a given field in a record type, or -1 if the field is not found.
- findFirstMultiset(RexNode, boolean) - Static method in class org.apache.calcite.rex.RexMultisetUtil
-
Returns a reference to the first found multiset call or null if none was found.
- findInSet(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL FIND_IN_SET(matchStr, textStr) function.
- findMatch(List<String>, String, boolean) - Static method in class org.apache.calcite.util.Util
-
Looks for a string within a list of strings, using a given case-sensitivity policy, and returns the position at which the first match is found, or -1 if there are no matches.
- findOperatorCall(SqlOperator, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a given node contains a RexCall with a specified operator.
- findPos(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Deprecated.
- findQualifyingTableName(String, SqlNode) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- findQualifyingTableName(String, SqlNode) - Method in class org.apache.calcite.sql.validate.ParameterScope
- findQualifyingTableName(String, SqlNode) - Method in class org.apache.calcite.sql.validate.ListScope
- findQualifyingTableName(String, SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
- findQualifyingTableNames(String, SqlNode, SqlNameMatcher) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- findQualifyingTableNames(String, SqlNode, SqlNameMatcher) - Method in class org.apache.calcite.sql.validate.ParameterScope
- findQualifyingTableNames(String, SqlNode, SqlNameMatcher) - Method in class org.apache.calcite.sql.validate.ListScope
- findQualifyingTableNames(String, SqlNode, SqlNameMatcher) - Method in class org.apache.calcite.sql.validate.MatchRecognizeScope
- findQualifyingTableNames(String, SqlNode, SqlNameMatcher) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Finds all table aliases which are implicitly qualifying an unqualified column name.
- findReducibleExps(RelDataTypeFactory, List<RexNode>, ImmutableMap<RexNode, RexNode>, List<RexNode>, List<Boolean>, boolean) - Static method in class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Locates expressions that can be reduced to literals or converted to expressions with redundant casts removed.
- findRef(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Determines the join factor corresponding to a RexInputRef.
- findRex(RelNode, RexUtil.RexFinder, Predicate<AggregateCall>, BiConsumer<RelNode, RexNode>) - Static method in class org.apache.calcite.rel.RelNodes
-
Searches for expressions in a tree of
RelNode
s. - findTable(RelNode, String) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns the relational table node for
tableName
if it occurs within a relational expressionroot
otherwise an empty option is returned. - findTables(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a set of tables used by this expression or its children.
- findValidOptions(SqlValidator, SqlValidatorScope, SqlParserPos, Collection<SqlMoniker>) - Method in class org.apache.calcite.sql.SqlCall
- findValidOptions(SqlValidator, SqlValidatorScope, SqlParserPos, Collection<SqlMoniker>) - Method in class org.apache.calcite.sql.SqlNode
-
Lists all the valid alternatives for this node if the parse position of the node matches that of pos.
- FiniteAbstractMapping() - Constructor for class org.apache.calcite.util.mapping.Mappings.FiniteAbstractMapping
- FIREBIRD - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- FirebirdSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Firebird database. - FirebirdSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.FirebirdSqlDialect
-
Creates a FirebirdSqlDialect.
- FIREBOLT - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- FireboltSqlDialect - Class in org.apache.calcite.sql.dialect
-
A SqlDialect implementation for the Firebolt database.
- FireboltSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.FireboltSqlDialect
-
Creates a FireboltSqlDialect.
- fireRule(RelOptRuleCall) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Fires a rule, taking care of tracing and listener notification.
- first() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- first() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the first element of a sequence.
- first(T, T) - Static method in class org.apache.calcite.util.Util
-
Returns the first value if it is not null, otherwise the second value.
- first(Boolean, boolean) - Static method in class org.apache.calcite.util.Util
-
Unboxes a
Boolean
value, using a given default value if it is null. - first(Byte, byte) - Static method in class org.apache.calcite.util.Util
-
Unboxes a
Byte
value, using a given default value if it is null. - first(Character, char) - Static method in class org.apache.calcite.util.Util
-
Unboxes a
Character
value, using a given default value if it is null. - first(Double, double) - Static method in class org.apache.calcite.util.Util
-
Unboxes a
Double
value, using a given default value if it is null. - first(Float, float) - Static method in class org.apache.calcite.util.Util
-
Unboxes a
Float
value, using a given default value if it is null. - first(Integer, int) - Static method in class org.apache.calcite.util.Util
-
Unboxes a
Integer
value, using a given default value if it is null. - first(Long, long) - Static method in class org.apache.calcite.util.Util
-
Unboxes a
Long
value, using a given default value if it is null. - first(Short, short) - Static method in class org.apache.calcite.util.Util
-
Unboxes a
Short
value, using a given default value if it is null. - first(List<E>) - Method in class org.apache.calcite.util.Util
-
Returns the first element of a list.
- first(List<E>, int) - Static method in class org.apache.calcite.util.Util
-
Returns the first
n
elements of a list. - first(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the first element of a sequence.
- first(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the first element in a sequence that satisfies a specified condition.
- first(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- first(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the first element in a sequence that satisfies a specified condition.
- first(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the first element of a sequence.
- first(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the first element of a sequence.
- first(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- first(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the first element of a sequence that satisfies a specified condition.
- first(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the first element of a sequence that satisfies a specified condition.
- first(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- first(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- first(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns the first element of a sequence that satisfies a specified condition.
- FIRST - Enum constant in enum org.apache.calcite.config.NullCollation
-
Nulls first for DESC and ASC.
- FIRST - Enum constant in enum org.apache.calcite.rel.RelFieldCollation.NullDirection
- FIRST - Enum constant in enum org.apache.calcite.sql.SqlKind
-
FIRST
operator inMATCH_RECOGNIZE
. - FIRST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
FIRST
function to be used withinMATCH_RECOGNIZE
. - FIRST_KNOWN - Static variable in class org.apache.calcite.sql.type.InferTypes
-
Operand type-inference strategy where an unknown operand type is derived from the first operand with a known type.
- FIRST_VALUE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
FIRST_VALUE
aggregate function. - FIRST_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
FIRST_VALUE
aggregate function. - firstAnd(Iterable<? extends T>) - Static method in class org.apache.calcite.util.Pair
-
Returns an iterator that iterates over (0, i) pairs in an iterable for i > 0.
- firstColumn(String) - Method in class org.apache.calcite.materialize.Lattice
-
Returns the ordinal, within all of the columns in this Lattice, of the first column in the table with a given alias.
- firstColumnOfOrderByMustBeTimestamp() - Method in interface org.apache.calcite.runtime.CalciteResource
- firstDuplicate(List<E>) - Static method in class org.apache.calcite.util.Util
-
Returns the ordinal of the first element in the list which is equal to a previous element in the list.
- firstOrDefault() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- firstOrDefault() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the first element of a sequence, or a default value if the sequence contains no elements.
- firstOrDefault(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the first element of a sequence, or a default value if the sequence contains no elements.
- firstOrDefault(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the first element of the sequence that satisfies a condition or a default value if no such element is found.
- firstOrDefault(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- firstOrDefault(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the first element of the sequence that satisfies a condition or a default value if no such element is found.
- firstOrDefault(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the first element of a sequence, or a default value if the sequence contains no elements.
- firstOrDefault(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the first element of a sequence, or a default value if the sequence contains no elements.
- firstOrDefault(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- firstOrDefault(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the first element of a sequence that satisfies a specified condition or a default value if no such element is found.
- firstOrDefault(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the first element of a sequence that satisfies a specified condition or a default value if no such element is found.
- firstOrDefault(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- firstOrDefault(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- firstOrDefault(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns the first element of a sequence that satisfies a specified condition or a default value if no such element is found.
- firstParameterOfAdd(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- FixNullabilityShuttle(RexBuilder, List<RelDataType>) - Constructor for class org.apache.calcite.rex.RexUtil.FixNullabilityShuttle
- fixture() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Creates the test fixture that determines the behavior of tests.
- fixture() - Method in class org.apache.calcite.test.SqlOperatorTest
-
Sub-classes should override to run tests in a different environment.
- fixture() - Method in class org.apache.calcite.test.SqlToRelTestBase
-
Creates the test fixture that determines the behavior of tests.
- fixture() - Method in class org.apache.calcite.test.SqlValidatorTestCase
-
Creates a test fixture.
- Fixture() - Constructor for class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- FIXTURE - Static variable in class org.apache.calcite.test.SqlValidatorTestCase
- Fixtures - Class in org.apache.calcite.test
-
Fluent test fixtures for typical Calcite tests (parser, validator, sql-to-rel and rel-rules) that can easily be used in dependent projects.
- fixUp(RexBuilder, List<RexNode>, List<RelDataType>) - Static method in class org.apache.calcite.rex.RexUtil
-
Fixes up the type of all
RexInputRef
s in an expression to match differences in nullability. - fixUp(RexBuilder, List<RexNode>, RelDataType) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- fl - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- flag - Variable in class org.apache.calcite.sql.fun.SqlBetweenOperator
- Flags() - Constructor for class org.apache.calcite.rel.core.Project.Flags
-
Deprecated.
- FLAT_LIST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FLAT_MAP_FUNCTION_CALL - Enum constant in enum org.apache.calcite.adapter.spark.SparkMethod
- FLAT_PRODUCT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- flatList() - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Function that, given a certain List containing single-item structs (i.e.
- FlatLists - Class in org.apache.calcite.runtime
-
Space-efficient, comparable, immutable lists.
- FlatLists.AbstractFlatList<T> - Class in org.apache.calcite.runtime
-
Base class for flat lists.
- FlatLists.ComparableList<T> - Interface in org.apache.calcite.runtime
-
List that is also comparable.
- FlatLists.Flat1List<T> - Class in org.apache.calcite.runtime
-
List that stores its one elements in the one members of the class.
- FlatLists.Flat2List<T> - Class in org.apache.calcite.runtime
-
List that stores its two elements in the two members of the class.
- FlatLists.Flat3List<T> - Class in org.apache.calcite.runtime
-
List that stores its three elements in the three members of the class.
- FlatLists.Flat4List<T> - Class in org.apache.calcite.runtime
-
List that stores its four elements in the four members of the class.
- FlatLists.Flat5List<T> - Class in org.apache.calcite.runtime
-
List that stores its five elements in the five members of the class.
- FlatLists.Flat6List<T> - Class in org.apache.calcite.runtime
-
List that stores its six elements in the six members of the class.
- flatProduct(int[], boolean, SqlFunctions.FlatProductInputType[]) - Static method in class org.apache.calcite.runtime.SqlFunctions
- flatten(Consumer<FormatElement>) - Method in interface org.apache.calcite.util.format.FormatElement
-
Applies a consumer to a format element.
- flatten(List<? extends RexNode>, SqlOperator) - Static method in class org.apache.calcite.rex.RexUtil
-
Converts a list of operands into a list that is flat with respect to the given operator.
- flatten(List<RelNode>, int, int[], BiConsumer<RelNode, Integer>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- flatten(RexBuilder, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Flattens an expression.
- flatten(SqlCall) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Flattens an aggregate call.
- flattenAnd(Iterable<? extends RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Flattens a list of AND nodes.
- flattened - Variable in class org.apache.calcite.rel.mutable.MutableTableModify
- flattenOr(Iterable<? extends RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Flattens a list of OR nodes.
- flattenRecordType(RelDataTypeFactory, RelDataType, int[]) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Flattens a record type by recursively expanding any fields which are themselves record types.
- flattenRel(RelStructuredTypeFlattener) - Method in interface org.apache.calcite.sql2rel.RelStructuredTypeFlattener.SelfFlatteningRel
- flattenTypes(RelOptPlanner, RelNode, boolean) - Method in class org.apache.calcite.adapter.spark.SparkHandlerImpl
- flattenTypes(RelOptPlanner, RelNode, boolean) - Method in interface org.apache.calcite.jdbc.CalcitePrepare.SparkHandler
- flattenTypes(RelNode, boolean) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- flattenTypes(RelNode, boolean) - Method in class org.apache.calcite.prepare.Prepare
- flattenTypes(RelNode, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- flavor() - Method in interface org.apache.calcite.sql2rel.RelDecorrelator.AdjustProjectForCountAggregateRule.AdjustProjectForCountAggregateRuleConfig
-
Returns the flavor of the rule (true for 4 operands, false for 3 operands).
- flavor(Type) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Returns whether this type is a primitive, box or other type.
- FlipCoordinatesTransformer - Class in org.apache.calcite.runtime
-
Flips the coordinates of a geometry.
- FlipCoordinatesTransformer() - Constructor for class org.apache.calcite.runtime.FlipCoordinatesTransformer
- FLOAT - Enum constant in enum org.apache.calcite.adapter.druid.DruidType
- FLOAT - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive
- FLOAT - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- floatDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- FloatFunction1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function that takes one parameter and returns a native
float
value. - floatLiteral(double) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- floatPrecisionTest() - Method in class org.apache.calcite.test.SqlOperatorTest
- floor(byte, byte) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
FLOOR
operator applied to byte values. - floor(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
- floor(float) - Static method in class org.apache.calcite.runtime.SqlFunctions
- floor(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
FLOOR
operator applied to int values. - floor(int, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
- floor(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
FLOOR
operator applied to long values. - floor(short, short) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
FLOOR
operator applied to short values. - floor(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
- floor(BigDecimal, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- floor(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
- FLOOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
FLOOR
function. - FLOOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FLOOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
FLOOR
function. - FLOOR_BIG_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "FLOOR(value)" function.
- FLOOR_DIV - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FLOOR_MOD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- floorCeil(boolean, SqlConformance) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Returns the operator for
FLOOR
andCEIL
with given floor flag and library. - floorDate(int, TimeFrame) - Method in class org.apache.calcite.rel.type.TimeFrameSet
-
Computes "FLOOR(date TO frame)", where
date
is the number of days since UNIX Epoch. - FloorOperatorConversion - Class in org.apache.calcite.adapter.druid
-
DruidSqlOperatorConverter implementation that handles Floor operations conversions.
- FloorOperatorConversion() - Constructor for class org.apache.calcite.adapter.druid.FloorOperatorConversion
- floorTimestamp(long, TimeFrame) - Method in class org.apache.calcite.rel.type.TimeFrameSet
-
Computes "FLOOR(timestamp TO frame)", where
ts
is the number of milliseconds since UNIX Epoch. - FLYWEIGHT_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Use sharing to support large numbers of fine-grained objects efficiently.
- FM - Enum constant in enum org.apache.calcite.util.format.postgresql.PatternModifier
- FNL25_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether issue FNL-25 is fixed.
- fnr() - Method in interface org.apache.calcite.util.Puffin.Line
-
Returns the ordinal of the current line in its source.
- fold(String...) - Static method in class org.apache.calcite.util.TestUtil
-
Combines an array of strings, each representing a line, into a single string containing line separators.
- FOLD - Enum constant in enum org.apache.calcite.sql.SqlWriterConfig.LineFolding
-
Wrap if long.
- foldAnd(List<Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Combines a list of expressions using AND.
- foldLength() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the line length at which items are chopped or folded (for clauses that have chosen
SqlWriterConfig.LineFolding.CHOP
orSqlWriterConfig.LineFolding.FOLD
). - foldOr(List<Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Combines a list of expressions using OR.
- following(RexNode) - Static method in class org.apache.calcite.rex.RexWindowBounds
- following(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
bound FOLLOWING
window bound, for use in methods such asRelBuilder.OverCall.rowsFrom(RexWindowBound)
andRelBuilder.OverCall.rangeBetween(RexWindowBound, RexWindowBound)
. - FOLLOWING - Enum constant in enum org.apache.calcite.sql.SqlKind
-
FOLLOWING
qualifier of an interval end-point in a window specification. - FOLLOWING_OPERATOR - Static variable in class org.apache.calcite.sql.SqlWindow
-
The FOLLOWING operator used exclusively in a window specification.
- followingBeforePrecedingError() - Method in interface org.apache.calcite.runtime.CalciteResource
- foo(int) - Method in class org.apache.calcite.test.schemata.hr.HrSchema
- foodmart - Variable in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
- FOODMART_CLONE - Enum constant in enum org.apache.calcite.test.CalciteAssert.Config
-
Configuration that contains an in-memory clone of the FoodMart database.
- FOODMART_MODEL - Static variable in class org.apache.calcite.test.schemata.foodmart.FoodmartSchema
- FOODMART_SCHEMA - Static variable in class org.apache.calcite.test.schemata.foodmart.FoodmartSchema
- FoodmartSchema - Class in org.apache.calcite.test.schemata.foodmart
-
Foodmart schema.
- FoodmartSchema() - Constructor for class org.apache.calcite.test.schemata.foodmart.FoodmartSchema
- FoodmartSchema.SalesFact - Class in org.apache.calcite.test.schemata.foodmart
-
Sales fact model.
- For - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
For loop.
- for_(Iterable<? extends DeclarationStatement>, Expression, Expression, Statement) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a LoopExpression with the given body.
- for_(DeclarationStatement, Expression, Expression, Statement) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a LoopExpression with the given body.
- forAggregate(Aggregate, Supplier<RelBuilder>, RexCorrelVariable) - Static method in class org.apache.calcite.rel.metadata.RelMdMeasure.Contexts
-
Creates a context for an
Aggregate
. - forAggregation(JavaTypeFactory, BlockBuilder, RexToLixTranslator.InputGetter, SqlConformance) - Static method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Creates a translator for translating aggregate functions.
- FORBIDDEN - Enum constant in enum org.apache.calcite.util.Optionality
-
A property is forbidden if an instance must not possess it; it is an error if the instance has the property.
- force() - Method in interface org.apache.calcite.rel.rules.ProjectMergeRule.Config
-
Whether to always merge projects, default true.
- FORCE_DECORRELATE - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
If the planner should try de-correlating as much as it is possible.
- FORCE_NULLABLE - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy where a derived type is transformed into the same type with nulls allowed.
- forceDecorrelate() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.FORCE_DECORRELATE
. - forceDecorrelate() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- forCharset(Charset) - Static method in class org.apache.calcite.util.SerializableCharset
-
Returns a SerializableCharset wrapping the given Charset, or null if the
charset
is null. - foreach(Function1<T, R>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- foreach(Function1<TSource, R>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Performs an operation for each member of this enumeration.
- forEach(Range<C>, RangeSets.Consumer<C>) - Static method in class org.apache.calcite.util.RangeSets
- forEach(RangeSet<C>, RangeSets.Consumer<C>) - Static method in class org.apache.calcite.util.RangeSets
- forEach(Iterable<? extends Map.Entry<? extends K, ? extends V>>, BiConsumer<? super K, ? super V>) - Static method in class org.apache.calcite.util.Pair
-
Applies an action to every element of an iterable of pairs.
- forEach(Iterable<? extends K>, Iterable<? extends V>, BiConsumer<? super K, ? super V>) - Static method in class org.apache.calcite.util.Pair
-
Applies an action to every element of a pair of iterables.
- forEach(Iterable<T>, ObjIntConsumer<? super T>) - Static method in class org.apache.calcite.linq4j.Ord
-
Applies an action to every element of an iterable, passing the zero-based ordinal of the element to the action.
- forEach(BiConsumer<T, U>) - Method in interface org.apache.calcite.runtime.PairList
-
Calls a BiConsumer with each pair in this list.
- forEach(Consumer<? super Integer>) - Method in class org.apache.calcite.util.ImmutableBitSet
- forEach(Consumer<? super Integer>) - Method in class org.apache.calcite.util.ImmutableIntList
- forEach(Consumer<? super SqlNode>) - Method in class org.apache.calcite.sql.SqlNodeList
- forEach(ParameterExpression, Expression, Statement) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ForEachExpression with the given body.
- forEach(T[], ObjIntConsumer<? super T>) - Static method in class org.apache.calcite.linq4j.Ord
-
Applies an action to every element of an array, passing the zero-based ordinal of the element to the action.
- ForEach - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
For-each loop, "for (Type i : expression) body".
- FOREACH - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- FOREACH_NESTED - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- forEachAgg(BiConsumer<String, SqlNode>) - Method in class org.apache.calcite.sql.SqlPivot
-
Returns the aggregate list as (alias, call) pairs.
- forEachConformance(Iterable<? extends SqlConformanceEnum>, Consumer<SqlOperatorFixture>) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Applies this fixture to some code for each of the given conformances.
- forEachIndexed(Iterable<? extends Map.Entry<K, V>>, Pair.PairWithOrdinalConsumer<K, V>) - Static method in class org.apache.calcite.util.Pair
-
Calls a consumer with an ordinal for each pair of items in an iterable of pairs.
- forEachIndexed(Iterable<K>, Iterable<V>, Pair.PairWithOrdinalConsumer<K, V>) - Static method in class org.apache.calcite.util.Pair
-
Calls a consumer with an ordinal for each pair of items in two iterables.
- forEachIndexed(Map<K, V>, Pair.PairWithOrdinalConsumer<K, V>) - Static method in class org.apache.calcite.util.Pair
-
Calls a consumer for each entry in a map.
- forEachIndexed(PairList.IndexedBiConsumer<T, U>) - Method in interface org.apache.calcite.runtime.PairList
-
Calls a BiConsumer with each pair in this list.
- forEachInt(IntConsumer) - Method in class org.apache.calcite.util.ImmutableBitSet
-
As
ImmutableBitSet.forEach(Consumer)
but on primitiveint
values. - forEachInt(IntConsumer) - Method in class org.apache.calcite.util.ImmutableIntList
-
As
ImmutableIntList.forEach(Consumer)
but on primitiveint
values. - forEachLibrary(Iterable<? extends SqlLibrary>, Consumer<SqlOperatorFixture>) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Applies this fixture to some code for each of the given libraries.
- forEachMeasure(Consumer<SqlIdentifier>) - Method in class org.apache.calcite.sql.SqlUnpivot
-
Returns the measure list as SqlIdentifiers.
- forEachNameType(SqlCreateTable, BiConsumer<SqlIdentifier, SqlDataTypeSpec>) - Method in class org.apache.calcite.test.MockDdlExecutor
-
Calls an action for each (name, type) pair from
SqlCreateTable::columnList
, in which they alternate. - forEachNameValues(BiConsumer<String, SqlNodeList>) - Method in class org.apache.calcite.sql.SqlPivot
-
Returns the value list as (alias, node list) pairs.
- forEachNameValues(BiConsumer<SqlNodeList, SqlNodeList>) - Method in class org.apache.calcite.sql.SqlUnpivot
-
Returns contents of the IN clause
(nodeList, valueList)
pairs. - ForeachNestedStmt(SqlParserPos, Ast.Identifier, Ast.Identifier, List<Ast.Stmt>, List<Ast.Node>, Ast.Schema) - Constructor for class org.apache.calcite.piglet.Ast.ForeachNestedStmt
- forEachQuery(SqlTestFactory, String, Consumer<String>) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- forEachQuery(SqlTestFactory, String, Consumer<String>) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Given a scalar expression, generates a sequence of SQL queries that evaluate it, and calls a given action with each.
- ForEachStatement - Class in org.apache.calcite.linq4j.tree
-
Represents a "for-each" loop, "for (T v : iterable) { f(v); }".
- ForEachStatement(ParameterExpression, Expression, Statement) - Constructor for class org.apache.calcite.linq4j.tree.ForEachStatement
- ForeachStmt(SqlParserPos, Ast.Identifier, Ast.Identifier, List<Ast.Node>, Ast.Schema) - Constructor for class org.apache.calcite.piglet.Ast.ForeachStmt
- FOREIGN_KEY - Enum constant in enum org.apache.calcite.sql.SqlKind
-
FOREIGN KEY
constraint. - FOREIGN_TABLE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
Foreign table.
- format - Variable in class org.apache.calcite.adapter.enumerable.EnumerableRel.Result
- format(StringBuilder, Date) - Method in interface org.apache.calcite.util.format.FormatElement
-
Formats a date to its appropriate string representation for the element.
- format(String, Object...) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Equivalent of String.format(Locale.ENGLISH, message, formatArgs).
- format(Map<Object, Object>) - Method in class org.apache.calcite.util.Template
-
Formats a set of arguments to produce a string.
- format(SqlNode) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- FORMAT_DATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FORMAT_DATE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "FORMAT_DATE(string, date)" function (BigQuery); Formats a date object according to the specified string.
- FORMAT_DATETIME - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "FORMAT_DATETIME(string, timestamp)" function (BigQuery); formats a timestamp object according to the specified string.
- FORMAT_NUMBER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FORMAT_NUMBER - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "FORMAT_NUMBER(value, decimalOrFormat)" function.
- FORMAT_TIME - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FORMAT_TIME - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "FORMAT_TIME(string, time)" function (BigQuery); Formats a time object according to the specified string.
- FORMAT_TIMESTAMP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FORMAT_TIMESTAMP - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "FORMAT_TIMESTAMP(string, timestamp)" function (BigQuery); Formats a timestamp object according to the specified string.
- formatByName(String, Map<Object, Object>) - Static method in class org.apache.calcite.util.Template
-
Creates a Template with the given pattern and uses it to format the given arguments.
- formatDate(String, int) - Method in class org.apache.calcite.runtime.SqlFunctions.DateFormatFunction
- formatDateTime(ZonedDateTime, Locale) - Method in class org.apache.calcite.util.format.postgresql.CompiledDateTimeFormat
-
Converts a date/time value to a string.
- FormatElement - Interface in org.apache.calcite.util.format
-
A format element in a format string.
- FormatElementEnum - Enum in org.apache.calcite.util.format
-
Implementation of
FormatElement
containing the standard format elements. - FormatModel - Interface in org.apache.calcite.util.format
-
Describes the format strings used by a formatting function such as
FORMAT_TIMESTAMP
orCAST(string AS DATE FORMAT formatString)
. - FormatModels - Class in org.apache.calcite.util.format
-
Utilities for
FormatModel
. - formatNumber(double, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- formatNumber(double, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- formatNumber(long, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL FORMAT_NUMBER(value, decimalOrFormat) function.
- formatNumber(long, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- formatNumber(BigDecimal, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- formatNumber(BigDecimal, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- FormatPattern - Class in org.apache.calcite.util.format.postgresql.format
-
A single component of a date/time format pattern such as YYYY or MI.
- FormatPattern(String) - Constructor for class org.apache.calcite.util.format.postgresql.format.FormatPattern
-
Base class constructor that stores the pattern.
- formatTime(String, int) - Method in class org.apache.calcite.runtime.SqlFunctions.DateFormatFunction
- formatTimestamp(String, long) - Method in class org.apache.calcite.runtime.SqlFunctions.DateFormatFunction
- forMetadata() - Static method in class org.apache.calcite.test.Fixtures
-
Creates a fixture for metadata tests.
- forOperators(boolean) - Static method in class org.apache.calcite.test.Fixtures
-
Creates a fixture for operator tests.
- forOracle(SqlConformance) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- forParser() - Static method in class org.apache.calcite.test.Fixtures
-
Creates a fixture for parser tests.
- forProgram(RexProgram, RexBuilder, boolean) - Static method in class org.apache.calcite.rex.RexProgramBuilder
-
Creates a program builder and initializes it from an existing program.
- forRules() - Static method in class org.apache.calcite.test.Fixtures
-
Creates a fixture for rule tests.
- forSqlToRel() - Static method in class org.apache.calcite.test.Fixtures
-
Creates a fixture for SQL-to-Rel tests.
- ForStatement - Class in org.apache.calcite.linq4j.tree
-
Represents an infinite loop.
- ForStatement(List<DeclarationStatement>, Expression, Expression, Statement) - Constructor for class org.apache.calcite.linq4j.tree.ForStatement
- forValidator() - Static method in class org.apache.calcite.test.Fixtures
-
Creates a fixture for validation tests.
- found(SqlValidatorNamespace, boolean, SqlValidatorScope, SqlValidatorScope.Path, List<String>) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope.Resolved
- found(SqlValidatorNamespace, boolean, SqlValidatorScope, SqlValidatorScope.Path, List<String>) - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.ResolvedImpl
- FoundOne(Object) - Constructor for exception class org.apache.calcite.util.Util.FoundOne
- FOURTEEN - Enum constant in enum org.apache.calcite.util.mapping.MappingType
- FP_DECIMAL_CAST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FP_DECIMAL_CAST_ROUNDING_MODE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- fpDecimalCast(Number, int, int) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Called from BuiltInMethod.FP_DECIMAL_CAST
- fpDecimalCast(Number, int, int, RoundingMode) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Called from BuiltInMethod.FP_DECIMAL_CAST_ROUNDING_MODE
- FRACTIONAL_RANK - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy for the
CUME_DIST
andPERCENT_RANK
aggregate functions. - FRACTIONAL_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- frame - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- frameSet() - Method in interface org.apache.calcite.rel.type.TimeFrame
-
Returns the time frame set that this frame belongs to.
- FrameworkConfig - Interface in org.apache.calcite.tools
-
Interface that describes how to configure planning sessions generated using the Frameworks tools.
- Frameworks - Class in org.apache.calcite.tools
-
Tools for invoking Calcite functionality without initializing a container / server first.
- Frameworks.BasePrepareAction<R> - Interface in org.apache.calcite.tools
-
Piece of code to be run in a context where a planner and statement are available.
- Frameworks.ConfigBuilder - Class in org.apache.calcite.tools
-
A builder to help you build a
FrameworkConfig
using defaults where values aren't required. - Frameworks.PlannerAction<R> - Interface in org.apache.calcite.tools
-
Piece of code to be run in a context where a planner is available.
- Frameworks.PrepareAction<R> - Class in org.apache.calcite.tools
-
Deprecated.
- frequency(Iterable<String>, String) - Method in interface org.apache.calcite.sql.validate.SqlNameMatcher
-
Returns how many times a string occurs in a collection.
- FRG189_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether issue FRG-189: FarragoAutoVmOperatorTest.testSelect fails is fixed.
- FRG254_FIXED - Static variable in class org.apache.calcite.util.Bug
- FRG296_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether issue FRG-296: SUBSTRING(string FROM regexp FOR regexp) is fixed.
- FRG375_FIXED - Static variable in class org.apache.calcite.util.Bug
- FRG377_FIXED - Static variable in class org.apache.calcite.util.Bug
- FRG73_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether issue FRG-73: miscellaneous bugs with nested comments is fixed.
- FRG78_FIXED - Static variable in class org.apache.calcite.util.Bug
- from(int) - Static method in class org.apache.calcite.sql.type.SqlOperandCountRanges
- from(SchemaPlus) - Static method in class org.apache.calcite.jdbc.CalciteSchema
- FROM - Enum constant in enum org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- FROM_BASE32 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FROM_BASE32 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- FROM_BASE64 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FROM_BASE64 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- FROM_BIT_SET - Static variable in class org.apache.calcite.util.ImmutableBitSet
-
Deprecated.
- FROM_HEX - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FROM_HEX - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "FROM_HEX(varchar)" function; converts a hexadecimal-encoded
varchar
into bytes. - FROM_LIST - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
FROM clause (containing various kinds of JOIN).
- FROM_MEASURE - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform that transforms
MEASURE<T>
toT
for some type T. - FROM_MEASURE_IF - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform that transforms
MEASURE<T>
toT
for some type T, and does nothing to other types. - FROM_NONE_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
-
Rule that converts a relational expression from
Convention.NONE
toBindableConvention
. - FROM_OPERAND - Static variable in class org.apache.calcite.sql.SqlSelect
- fromAliasDuplicate(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- fromBase32(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL FROM_BASE32(string) function.
- fromBase64(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL FROM_BASE64(string) function.
- fromBitSet(BitSet) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Returns a new immutable bit set containing all the bits in the given
BitSet
. - fromCalendarFields(Calendar) - Static method in class org.apache.calcite.util.DateString
-
Creates a DateString from a Calendar.
- fromCalendarFields(Calendar) - Static method in class org.apache.calcite.util.TimestampString
-
Creates a TimestampString from a Calendar.
- fromCalendarFields(Calendar) - Static method in class org.apache.calcite.util.TimestampWithTimeZoneString
-
Creates a TimestampWithTimeZoneString from a Calendar.
- fromCalendarFields(Calendar) - Static method in class org.apache.calcite.util.TimeString
-
Creates a TimeString from a Calendar.
- fromCalendarFields(Calendar) - Static method in class org.apache.calcite.util.TimeWithTimeZoneString
-
Creates a TimeWithTimeZoneString from a Calendar.
- fromCharSource(CharSource) - Static method in class org.apache.calcite.util.Sources
-
Creates a
Source
from a generic text source such as string,CharBuffer
or text file. - fromColumn(String) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- fromContext(Context) - Static method in class org.apache.calcite.rel.core.RelFactories.Struct
- fromDaysSinceEpoch(int) - Static method in class org.apache.calcite.util.DateString
-
Creates a DateString that is a given number of days since the epoch.
- fromEnum(Object) - Static method in class org.apache.calcite.rel.externalize.RelEnumTypes
-
Converts a literal into a value that can be serialized to JSON.
- fromEnum(Enum) - Static method in class org.apache.calcite.rel.externalize.RelEnumTypes
-
Converts an enum into its name.
- fromEwkt(String) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Constructs a geometry from an Extended Well-Known text (EWKT) representation.
- fromFolding() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the line-folding policy for the FROM clause (and JOIN).
- fromGeoJson(String) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Constructs a geometry from a GeoJson representation.
- fromGeometry(Geometry) - Static method in enum org.apache.calcite.runtime.SpatialTypeUtils.SpatialType
-
Returns the OGC type of a geometry.
- fromGml(String) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Constructs a geometry from a GML representation.
- fromHex(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL FROM_HEX(varchar) function.
- fromJdbcString(RelDataType, SqlTypeName, String) - Static method in class org.apache.calcite.rex.RexLiteral
-
Converts a Jdbc string into a RexLiteral.
- fromMeasure(RelDataTypeFactory, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Strips MEASURE wrappers from a type.
- fromMillisOfDay(int) - Static method in class org.apache.calcite.util.TimeString
- fromMillisOfDay(int) - Static method in class org.apache.calcite.util.TimeWithTimeZoneString
- fromMillisSinceEpoch(long) - Static method in class org.apache.calcite.util.TimestampString
-
Creates a TimestampString that is a given number of milliseconds since the epoch.
- fromMillisSinceEpoch(long) - Static method in class org.apache.calcite.util.TimestampWithTimeZoneString
-
Creates a TimestampWithTimeZoneString that is a given number of milliseconds since the epoch UTC.
- fromMutable(MutableRel) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- fromMutable(MutableRel, RelBuilder) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- fromNotZero() - Method in interface org.apache.calcite.runtime.CalciteResource
- fromStatement(Statement) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Create an expression from a statement.
- fromTypeName(String) - Static method in enum org.apache.calcite.adapter.redis.RedisDataFormat
- fromTypeName(String) - Static method in enum org.apache.calcite.adapter.redis.RedisDataType
- fromWkb(ByteString) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Constructs a geometry from a Well-Known binary (WKB) representation.
- fromWkt(String) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Constructs a geometry from a Well-Known text (WKT) representation.
- FULL - Enum constant in enum org.apache.calcite.linq4j.JoinType
-
Full-outer join.
- FULL - Enum constant in enum org.apache.calcite.rel.core.JoinRelType
-
Full-outer join.
- FULL - Enum constant in enum org.apache.calcite.sql.JoinType
-
Full outer join.
- FULLY_QUALIFIED - Enum constant in enum org.apache.calcite.rel.type.StructKind
-
This is a traditional structured type, where each field must be referenced explicitly.
- fullyQualify(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.DelegatingScope
-
Converts an identifier into a fully-qualified identifier.
- fullyQualify(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.MeasureScope
- fullyQualify(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.OrderByScope
- fullyQualify(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.ParameterScope
- fullyQualify(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlLambdaScope
- fullyQualify(SqlIdentifier) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Converts an identifier into a fully-qualified identifier.
- fun - Variable in enum org.apache.calcite.sql.fun.SqlLibrary
-
Name of this library when it appears in the connect string; see
CalciteConnectionProperty.FUN
. - fun(Class<T>, T) - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.FUN
, or a default operator table if not set. - fun(Class<T>, T) - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- FUN - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Collection of built-in functions and operators.
- FUN_CALL - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Function call or datatype declaration.
- FUN_DECL - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Function declaration.
- fun1(int) - Static method in class org.apache.calcite.util.Smalls.MultipleFunction
- fun1(int, int) - Static method in class org.apache.calcite.util.Smalls.MultipleFunction
- fun1(String) - Static method in class org.apache.calcite.util.Smalls.MultipleFunction
- fun2(int) - Static method in class org.apache.calcite.util.Smalls.MultipleFunction
- funcNeedsOrderBy() - Method in interface org.apache.calcite.runtime.CalciteResource
- funcSpec - Variable in class org.apache.calcite.piglet.PigUserDefinedFunction
- function - Variable in class org.apache.calcite.linq4j.tree.FunctionExpression
- function - Variable in class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
- function - Variable in class org.apache.calcite.sql.validate.SqlUserDefinedFunction
- function(SqlTypeFamily, List<SqlTypeFamily>) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a checker that passes if the operand is a function with a given return type and parameter types.
- function(SqlTypeFamily, SqlTypeFamily...) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a checker that passes if the operand is a function with a given return type and parameter types.
- Function<R> - Interface in org.apache.calcite.linq4j.function
-
Base interface for all functions.
- Function - Interface in org.apache.calcite.schema
-
Named expression that accepts parameters and returns a result.
- FUNCTION - Enum constant in enum org.apache.calcite.sql.SqlSyntax
-
Function syntax, as in "Foo(x, y)".
- FUNCTION - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- FUNCTION - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- FUNCTION - Enum constant in enum org.apache.calcite.sql.validate.SqlMonikerType
- FUNCTION - Enum constant in enum org.apache.calcite.util.mapping.MappingType
- FUNCTION - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category consisting of regular and special functions.
- FUNCTION_APPLY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FUNCTION_COLUMNS - Static variable in class org.apache.calcite.jdbc.CalciteMetaImpl
-
The columns returned by
DatabaseMetaData.getFunctions(java.lang.String, java.lang.String, java.lang.String)
. - FUNCTION_CONTEXTS_OF - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- FUNCTION_ID - Enum constant in enum org.apache.calcite.sql.SqlSyntax
-
Function syntax which takes no parentheses if there are no arguments, for example "CURRENTTIME".
- FUNCTION_LEVEL_CACHE_MAX_SIZE - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
The maximum number of items in a function-level cache.
- FUNCTION_RESULT_TYPES - Static variable in class org.apache.calcite.linq4j.function.Functions
- FUNCTION_STAR - Enum constant in enum org.apache.calcite.sql.SqlSyntax
-
Function syntax, as in "Foo(x, y)", but uses "*" if there are no arguments, for example "COUNT(*)".
- Function0<R> - Interface in org.apache.calcite.linq4j.function
-
Function with no parameters.
- FUNCTION0_APPLY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- Function1<T0,
R> - Interface in org.apache.calcite.linq4j.function -
Function with one parameter.
- FUNCTION1_APPLY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- Function2<T0,
T1, R> - Interface in org.apache.calcite.linq4j.function -
Function with two parameters.
- functionalDependencyList - Variable in class org.apache.calcite.profile.Profiler.Profile
- functionCall(String, List<String>) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- functionCallStack - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Stack of objects that maintain information about function calls.
- functionClass(Type) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns the appropriate interface for a lambda function with 1 argument and the given return type.
- FunctionContext - Interface in org.apache.calcite.schema
-
Information about a function call that is passed to the constructor of a function instance.
- FunctionContexts - Class in org.apache.calcite.runtime
-
Runtime support for
FunctionContext
. - FunctionEntry(CalciteSchema, String) - Constructor for class org.apache.calcite.jdbc.CalciteSchema.FunctionEntry
- FunctionEntryImpl(CalciteSchema, String, Function) - Constructor for class org.apache.calcite.jdbc.CalciteSchema.FunctionEntryImpl
-
Creates a FunctionEntryImpl.
- FunctionExpression<F extends Function<?>> - Class in org.apache.calcite.linq4j.tree
-
Represents a strongly typed lambda expression as a data structure in the form of an expression tree.
- FunctionExpression(F) - Constructor for class org.apache.calcite.linq4j.tree.FunctionExpression
- FunctionExpression(Class<F>, BlockStatement, List<ParameterExpression>) - Constructor for class org.apache.calcite.linq4j.tree.FunctionExpression
- FunctionExpression.Invokable - Interface in org.apache.calcite.linq4j.tree
-
Function that can be invoked with a variable number of arguments.
- functionMap - Variable in class org.apache.calcite.jdbc.CalciteSchema
- functionMatchRecognizeOnly(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- functionNames - Variable in class org.apache.calcite.jdbc.CalciteSchema
- functionNotFound(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- FunctionParameter - Interface in org.apache.calcite.schema
-
Parameter to a
Function
. - FunctionParamInfo() - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.FunctionParamInfo
- functionQuantifierNotAllowed(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- functions - Variable in class org.apache.calcite.model.JsonMapSchema
-
Functions in this schema.
- functions(Class<?>) - Static method in class org.apache.calcite.schema.impl.ScalarFunctionImpl
-
Returns a map of all functions based on the methods in a given class.
- Functions - Class in org.apache.calcite.linq4j.function
-
Utilities relating to functions.
- FUNCTIONS_MAPS - Static variable in enum org.apache.calcite.util.BuiltInMethod
- functionScan(SqlOperator, int, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
TableFunctionScan
. - functionScan(SqlOperator, int, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
TableFunctionScan
. - FunctionSqlType - Class in org.apache.calcite.sql.type
-
Function type.
- FunctionSqlType(RelDataType, RelDataType) - Constructor for class org.apache.calcite.sql.type.FunctionSqlType
- functionsToReduce() - Method in interface org.apache.calcite.rel.rules.AggregateReduceFunctionsRule.Config
-
The set of aggregate function types to try to reduce.
- functionUndefined(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- FUSION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
FUSION
aggregate function. - FUSION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The FUSION operator.
- fynally - Variable in class org.apache.calcite.linq4j.tree.TryStatement
G
- gatherExpr(RexNode) - Method in class org.apache.calcite.rex.RexProgram
- gatherOrderExprs(SqlToRelConverter.Blackboard, SqlSelect, SqlNodeList, List<SqlNode>, List<RelFieldCollation>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Creates a list of collations required to implement the ORDER BY clause, if there is one.
- gatherTableReferences(List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Gather all table references in input expressions.
- ge(boolean, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≥
operator applied to boolean values. - ge(Object[], Object[]) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≥
operator applied to Object[] values. - ge(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≥
operator applied to String values. - ge(String, String, Comparator<String>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≥
operator applied to String values. - ge(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≥
operator applied to BigDecimal values. - ge(List<?>, List<?>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≥
operator applied to List values. - ge(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≥
operator applied to ByteString values. - ge(RexNode, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- geAny(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≥
operator applied to Object values (at least one operand has ANY type; neither may be null). - generate(int, int, int) - Static method in class org.apache.calcite.example.maze.MazeTable
-
Table function that generates a maze.
- generate(int, int, int) - Static method in class org.apache.calcite.util.Smalls.MazeTable
- generate(int, IntFunction<E>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns a list generated by applying a function to each index between 0 and
size
- 1. - GENERATE_STRINGS_METHOD - Static variable in class org.apache.calcite.util.Smalls
- GENERATE_STRINGS_OF_INPUT_MAP_SIZE_METHOD - Static variable in class org.apache.calcite.util.Smalls
- GENERATE_STRINGS_OF_INPUT_SIZE_METHOD - Static variable in class org.apache.calcite.util.Smalls
- generate2(int, int, Integer) - Static method in class org.apache.calcite.util.Smalls.MazeTable
- generate3(String) - Static method in class org.apache.calcite.util.Smalls.MazeTable
- generateAccessor(List<Integer>) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Generates an accessor function for a given list of fields.
- generateAccessor(List<Integer>) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- generateAccessorWithoutNulls(List<Integer>) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
- generateAccessorWithoutNulls(List<Integer>) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- generateAggQuery(String, String[]) - Static method in class org.apache.calcite.sql.test.SqlTests
- generateAggQueryWithMultipleArgs(String, String[][]) - Static method in class org.apache.calcite.sql.test.SqlTests
- generateCastExpressions(RexBuilder, RelDataType, List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Generates a cast for a row type.
- generateCastExpressions(RexBuilder, RelDataType, RelDataType) - Static method in class org.apache.calcite.rex.RexUtil
-
Generates a cast from one row type to another.
- generateCollationKey(List<RelFieldCollation>) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Returns a lambda to create a collation key and a comparator.
- generateCollationKey(List<RelFieldCollation>) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- generateCollationName(Charset) - Method in class org.apache.calcite.jdbc.JavaCollation
- generateCollationName(Charset) - Method in class org.apache.calcite.sql.SqlCollation
- generateCollator(Locale, int) - Static method in class org.apache.calcite.runtime.Utilities
- generateCollatorExpression(SqlCollation) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
- generateComparator(RelCollation) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Returns a comparator.
- generateComparator(RelCollation) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- GENERATED - Enum constant in enum org.apache.calcite.sql.ddl.SqlCreateTableLike.LikeOption
- GENERATED_EXPR_ALIAS_PREFIX - Static variable in class org.apache.calcite.sql.SqlUtil
-
Prefix for generated column aliases.
- generatedCorRels - Variable in class org.apache.calcite.sql2rel.RelDecorrelator
- generateEnum(String, E[]) - Static method in class org.apache.calcite.rel.metadata.janino.CacheUtil
- generateEquivalenceClasses(RexBuilder, MaterializedViewRule.EquivalenceClasses, MaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
Given the equi-column predicates of the source and the target and the computed equivalence classes, it extracts possible mappings between the equivalence classes.
- generateHandler(Class<? extends MetadataHandler<?>>, List<? extends MetadataHandler<?>>) - Static method in class org.apache.calcite.rel.metadata.janino.RelMetadataHandlerGeneratorUtil
- generateMapping(RexBuilder, RexSimplify, RelMetadataQuery, RelNode, RelNode, ImmutableBitSet, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses, List<RexNode>) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule
-
Mapping from node expressions to target expressions.
- generateMergeJoinComparator(RelCollation) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Similar to
PhysType.generateComparator(RelCollation)
, but with some specificities for MergeJoin algorithm: it will not consider twonull
values as equal. - generateMergeJoinComparator(RelCollation) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- generateRange(String, int, int) - Static method in class org.apache.calcite.rel.metadata.janino.CacheUtil
- generateSelector(ParameterExpression, List<Integer>) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Generates a selector for the given fields from an expression, with the default row format.
- generateSelector(ParameterExpression, List<Integer>) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- generateSelector(ParameterExpression, List<Integer>, List<Integer>, JavaRowFormat) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Generates a lambda expression that is a selector for the given fields from an expression.
- generateSelector(ParameterExpression, List<Integer>, List<Integer>, JavaRowFormat) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- generateSelector(ParameterExpression, List<Integer>, JavaRowFormat) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Generates a lambda expression that is a selector for the given fields from an expression.
- generateSelector(ParameterExpression, List<Integer>, JavaRowFormat) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- generatesNullsOn(int) - Method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns whether this join type generates nulls on side #
i
. - generatesNullsOnLeft() - Method in enum org.apache.calcite.linq4j.JoinType
-
Returns whether a join of this type may generate NULL values on the left-hand side.
- generatesNullsOnLeft() - Method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns whether a join of this type may generate NULL values on the left-hand side.
- generatesNullsOnLeft() - Method in enum org.apache.calcite.sql.JoinType
-
Returns whether a join of this type may generate NULL values on the left-hand side.
- generatesNullsOnRight() - Method in enum org.apache.calcite.linq4j.JoinType
-
Returns whether a join of this type may generate NULL values on the right-hand side.
- generatesNullsOnRight() - Method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns whether a join of this type may generate NULL values on the right-hand side.
- generatesNullsOnRight() - Method in enum org.apache.calcite.sql.JoinType
-
Returns whether a join of this type may generate NULL values on the right-hand side.
- generateStrings(Integer) - Static method in class org.apache.calcite.util.Smalls
-
A function that generates a table that generates a sequence of
Smalls.IntString
values. - generateStringsOfInputMapSize(Map<Integer, Integer>) - Static method in class org.apache.calcite.util.Smalls
- generateStringsOfInputSize(List<Integer>) - Static method in class org.apache.calcite.util.Smalls
- generateSwapColumnTableReferencesLineage(RexBuilder, RelMetadataQuery, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses, List<RexNode>) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
It swaps the column references and then the table references of the input expressions using the equivalence classes and the table mapping.
- generateSwapTableColumnReferencesLineage(RexBuilder, RelMetadataQuery, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses, List<RexNode>) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
It swaps the table references and then the column references of the input expressions using the table mapping and the equivalence classes.
- generateTableMappings(Multimap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
It will flatten a multimap containing table references to table references, producing all possible combinations of mappings.
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.rel.type.DynamicRecordTypeImpl
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.rel.type.RelCrossType
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
-
Generates a string representation of this type.
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.rel.type.RelRecordType
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.sql.type.MeasureSqlType
-
Generates a string representation of this type.
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.sql.type.ArraySqlType
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.sql.type.BasicSqlType
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.sql.type.FunctionSqlType
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.sql.type.IntervalSqlType
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.sql.type.MapSqlType
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.sql.type.MultisetSqlType
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.sql.type.ObjectSqlType
- generateUnionRewriting() - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewRule.Config
-
Whether to generate rewritings containing union if the query results are contained within the view results.
- generateWinAggQuery(String, String, String[]) - Static method in class org.apache.calcite.sql.test.SqlTests
- generationStrategy(RelOptTable, int) - Method in interface org.apache.calcite.sql2rel.InitializerExpressionFactory
-
Returns how a column is populated.
- generationStrategy(RelOptTable, int) - Method in class org.apache.calcite.sql2rel.NullInitializerExpressionFactory
- generationStrategy(RelOptTable, int) - Method in class org.apache.calcite.test.catalog.CountingFactory
- generationStrategy(RelOptTable, int) - Method in class org.apache.calcite.test.catalog.VirtualColumnsExpressionFactory
- GEO - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- GEO - Enum constant in enum org.apache.calcite.test.CalciteAssert.Config
-
Configuration that contains geo-spatial functions.
- GEO - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- GeodeAggregate - Class in org.apache.calcite.adapter.geode.rel
-
Implementation of
Aggregate
relational expression in Geode. - GeodeAggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeAggregate
-
Deprecated.
- GeodeAggregate(RelOptCluster, RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeAggregate
-
Creates a GeodeAggregate.
- GeodeFilter - Class in org.apache.calcite.adapter.geode.rel
-
Implementation of
Filter
relational expression in Geode. - GeodeFilterRule(GeodeRules.GeodeFilterRule.GeodeFilterRuleConfig) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeFilterRule
-
Creates a GeodeFilterRule.
- GeodeImplementContext() - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- GeodeProject - Class in org.apache.calcite.adapter.geode.rel
-
Implementation of
Project
relational expression in Geode. - GeodeQueryable(QueryProvider, SchemaPlus, GeodeTable, String) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeTable.GeodeQueryable
- GeodeRel - Interface in org.apache.calcite.adapter.geode.rel
-
Relational expression that uses Geode calling convention.
- GeodeRel.GeodeImplementContext - Class in org.apache.calcite.adapter.geode.rel
-
Shared context used by the
GeodeRel
relations. - GeodeRules - Class in org.apache.calcite.adapter.geode.rel
-
Rules and relational operators for
GeodeRel.CONVENTION
calling convention. - GeodeRules.GeodeFilterRule - Class in org.apache.calcite.adapter.geode.rel
-
Rule to convert a
LogicalFilter
to aGeodeFilter
. - GeodeRules.GeodeFilterRule.GeodeFilterRuleConfig - Interface in org.apache.calcite.adapter.geode.rel
-
Rule configuration.
- GeodeRules.GeodeSortLimitRule - Class in org.apache.calcite.adapter.geode.rel
- GeodeRules.GeodeSortLimitRule.GeodeSortLimitRuleConfig - Interface in org.apache.calcite.adapter.geode.rel
-
Rule configuration.
- GeodeSchema - Class in org.apache.calcite.adapter.geode.rel
-
Schema mapped onto a Geode Region.
- GeodeSchema(GemFireCache, Iterable<String>) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeSchema
- GeodeSchemaFactory - Class in org.apache.calcite.adapter.geode.rel
-
Factory that creates a
GeodeSchema
. - GeodeSchemaFactory() - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeSchemaFactory
- GeodeSimpleEnumerator<E> - Class in org.apache.calcite.adapter.geode.simple
-
Geode Simple Enumerator.
- GeodeSimpleEnumerator(ClientCache, String) - Constructor for class org.apache.calcite.adapter.geode.simple.GeodeSimpleEnumerator
- GeodeSimpleScannableTable - Class in org.apache.calcite.adapter.geode.simple
-
Geode Simple Scannable Table abstraction.
- GeodeSimpleScannableTable(String, RelDataType, ClientCache) - Constructor for class org.apache.calcite.adapter.geode.simple.GeodeSimpleScannableTable
- GeodeSimpleSchema - Class in org.apache.calcite.adapter.geode.simple
-
Geode Simple Schema.
- GeodeSimpleSchema(String, int, String[], String) - Constructor for class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchema
- GeodeSimpleSchemaFactory - Class in org.apache.calcite.adapter.geode.simple
-
Geode Simple Table Schema Factory.
- GeodeSimpleSchemaFactory() - Constructor for class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchemaFactory
- GeodeSort - Class in org.apache.calcite.adapter.geode.rel
-
Implementation of
Sort
relational expression in Geode. - GeodeSortLimitRule(GeodeRules.GeodeSortLimitRule.GeodeSortLimitRuleConfig) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeSortLimitRule
-
Creates a GeodeSortLimitRule.
- GeodeTable - Class in org.apache.calcite.adapter.geode.rel
-
Table based on a Geode Region.
- GeodeTable.GeodeQueryable<T> - Class in org.apache.calcite.adapter.geode.rel
-
Implementation of
Queryable
based on aGeodeTable
. - GeodeTableScan - Class in org.apache.calcite.adapter.geode.rel
-
Relational expression representing a scan of a Geode collection.
- GeodeToEnumerableConverter - Class in org.apache.calcite.adapter.geode.rel
-
Relational expression representing a scan of a table in a Geode data source.
- GeodeToEnumerableConverter(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeToEnumerableConverter
- GeodeToEnumerableConverterRule - Class in org.apache.calcite.adapter.geode.rel
-
Rule to convert a relational expression from
GeodeRel.CONVENTION
toEnumerableConvention
. - GeodeToEnumerableConverterRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeToEnumerableConverterRule
- GeodeUtils - Class in org.apache.calcite.adapter.geode.util
-
Utilities for the Geode adapter.
- GEOMETRY - Enum constant in enum org.apache.calcite.runtime.SpatialTypeUtils.SpatialType
- GEOMETRY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
-
Spatial type.
- GEOMETRY - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- GEOMETRY - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that always returns GEOMETRY.
- GEOMETRY_FACTORY - Static variable in class org.apache.calcite.runtime.SpatialTypeUtils
- GEOMETRY_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- GEOMETRYCOLLECTION - Enum constant in enum org.apache.calcite.runtime.SpatialTypeUtils.SpatialType
- geometryDisabled() - Method in interface org.apache.calcite.runtime.CalciteResource
- get() - Method in class org.apache.calcite.linq4j.MemoryFactory.Memory
- get() - Method in class org.apache.calcite.util.Holder
-
Gets the value.
- get() - Method in class org.apache.calcite.util.MonotonicSupplier
- get() - Method in class org.apache.calcite.util.TryThreadLocal
- get(int) - Method in class org.apache.calcite.linq4j.MemoryFactory.Memory
- get(int) - Method in class org.apache.calcite.plan.RelTraitSet
- get(int) - Method in class org.apache.calcite.rex.RexSlot.SelfPopulatingList
- get(int) - Method in class org.apache.calcite.runtime.ConsList
- get(int) - Method in class org.apache.calcite.runtime.FlatLists.Flat1List
- get(int) - Method in class org.apache.calcite.runtime.FlatLists.Flat2List
- get(int) - Method in class org.apache.calcite.runtime.FlatLists.Flat3List
- get(int) - Method in class org.apache.calcite.runtime.FlatLists.Flat4List
- get(int) - Method in class org.apache.calcite.runtime.FlatLists.Flat5List
- get(int) - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- get(int) - Method in class org.apache.calcite.sql.SqlNodeList
- get(int) - Method in class org.apache.calcite.util.CastingList
- get(int) - Method in class org.apache.calcite.util.CompositeList
- get(int) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
- get(int) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns the value of the bit with the specified index.
- get(int) - Method in class org.apache.calcite.util.ImmutableIntList
- get(int) - Method in class org.apache.calcite.util.ImmutableNullableList
- get(int) - Method in class org.apache.calcite.util.UnmodifiableArrayList
- get(int, int) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns a new
ImmutableBitSet
composed of bits from thisImmutableBitSet
fromfromIndex
(inclusive) totoIndex
(exclusive). - get(int, ResultSet) - Method in interface org.apache.calcite.util.JdbcType
-
Returns the value of column
column
from a JDBC result set. - get(Object) - Method in class org.apache.calcite.linq4j.tree.ArrayLengthRecordField
- get(Object) - Method in interface org.apache.calcite.linq4j.tree.PseudoField
- get(Object) - Method in class org.apache.calcite.linq4j.tree.ReflectedPseudoField
- get(Object) - Method in class org.apache.calcite.util.CompositeMap
- get(String) - Method in interface org.apache.calcite.DataContext
-
Returns a context variable.
- get(String) - Method in class org.apache.calcite.plan.VisitorDataContext
- get(String) - Method in interface org.apache.calcite.rel.RelInput
- get(String) - Method in class org.apache.calcite.rel.type.TimeFrameSet
-
Returns the time frame with the given name, or throws
IllegalArgumentException
if not found. - get(String) - Static method in enum org.apache.calcite.sql.type.SqlTypeName
-
Looks up a type name from its name.
- get(DatabaseMetaData) - Method in interface org.apache.calcite.sql.dialect.JethroDataSqlDialect.JethroInfoCache
- get(Map<K, V>, List<String>, List<String>) - Method in interface org.apache.calcite.sql.validate.SqlNameMatcher
-
Looks up an item in a map.
- get(TimeUnit) - Method in class org.apache.calcite.rel.type.TimeFrameSet
-
Returns the time frame with the given name, or throws
IllegalArgumentException
. - get(DataContext) - Method in enum org.apache.calcite.DataContext.Variable
-
Returns the value of this variable in a given data context.
- get(RexCall) - Method in interface org.apache.calcite.rex.RexSqlConvertletTable
-
Returns the convertlet applicable to a given expression.
- get(RexCall) - Method in class org.apache.calcite.rex.RexSqlReflectiveConvertletTable
- get(SqlAggFunction, boolean) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable
- get(SqlCall) - Method in class org.apache.calcite.sql2rel.ReflectiveConvertletTable
- get(SqlCall) - Method in interface org.apache.calcite.sql2rel.SqlRexConvertletTable
-
Returns the convertlet applicable to a given expression.
- get(SqlMatchFunction) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable
- get(SqlOperator) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable
- get(SqlWindowTableFunction) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable
- get(V) - Method in enum org.apache.calcite.runtime.Hook
-
Returns the value of a property hook.
- GET_OPERATOR - Static variable in class org.apache.calcite.rex.RexBuilder
-
Special operator that accesses an unadvertised field of an input record.
- GET_SPARK_CONTEXT - Enum constant in enum org.apache.calcite.adapter.spark.SparkMethod
- getAcceptedIssuers() - Method in class org.apache.calcite.util.UnsafeX509ExtendedTrustManager
- getActionType(Class...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a Type object that represents a generic System.Action delegate type that has specific type arguments.
- getAdjustments() - Method in class org.apache.calcite.rel.rules.PushProjector
-
Determines how much each input reference needs to be adjusted as a result of projection.
- getAfter() - Method in class org.apache.calcite.rel.core.Match
- getAfter() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getAggCallList() - Method in class org.apache.calcite.rel.core.Aggregate
-
Returns a list of calls to aggregate functions.
- getAggOperator() - Method in class org.apache.calcite.rex.RexOver
-
Returns the aggregate operator for this expression.
- getAggregate(RelOptPlanner, ImmutableBitSet, List<Lattice.Measure>) - Method in class org.apache.calcite.plan.RelOptLattice
-
Retrieves a materialized table that will satisfy an aggregate query on the star table.
- getAggregate(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Returns the parse tree node (GROUP BY, HAVING, or an aggregate function call) that causes
select
to be an aggregate query, or null if it is not an aggregate query. - getAggregateCalls(String) - Method in interface org.apache.calcite.rel.RelInput
- getAggregateCalls(Window) - Method in class org.apache.calcite.rel.core.Window.Group
-
Presents a view of the
Window.RexWinAggCall
list as a list ofAggregateCall
. - getAggregation() - Method in class org.apache.calcite.rel.core.AggregateCall
-
Returns the aggregate function.
- getAlias() - Method in class org.apache.calcite.piglet.PigRelBuilder
- getAlias() - Method in class org.apache.calcite.sql.SqlDelete
-
Returns the alias for the target table of the deletion.
- getAlias() - Method in class org.apache.calcite.sql.SqlMerge
-
Returns the alias for the target table of this MERGE.
- getAlias() - Method in class org.apache.calcite.sql.SqlUpdate
-
Returns the alias for the target table of this UPDATE.
- getAlias() - Method in class org.apache.calcite.tools.PigRelBuilder
- getAlias(SqlNode, int) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Deprecated.Use
SqlValidatorUtil.alias(SqlNode)
ifordinal
is negative, orSqlValidatorUtil.alias(SqlNode, int)
ifordinal
is non-negative. - getAliasContext(RexCorrelVariable) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.BaseContext
- getAliasContext(RexCorrelVariable) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- getAliasedProjects(RelBuilder) - Method in class org.apache.calcite.rel.core.Project
-
Returns a list of project expressions, each of which is wrapped in a call to
AS
if its field name differs from the default. - getAliasedSignature(SqlOperator, String, List<?>) - Static method in class org.apache.calcite.sql.SqlUtil
-
Constructs an operator signature from a type list, substituting an alias for the operator name.
- getAllFields(Aggregate) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Gets all fields in an aggregate.
- getAllFields2(ImmutableBitSet, List<AggregateCall>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Gets all fields in an aggregate.
- getAllowedAccess() - Method in class org.apache.calcite.prepare.RelOptTableImpl
- getAllowedAccess() - Method in class org.apache.calcite.sql.validate.DelegatingSqlValidatorTable
- getAllowedAccess() - Method in interface org.apache.calcite.sql.validate.SqlValidatorTable
-
Returns the access type of the table.
- getAllowedAccess() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getAllowedSignatures() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns a string describing the expected operand types of a call, e.g.
- getAllowedSignatures(String) - Method in class org.apache.calcite.sql.fun.SqlDotOperator
- getAllowedSignatures(String) - Method in class org.apache.calcite.sql.fun.SqlItemOperator
- getAllowedSignatures(String) - Method in class org.apache.calcite.sql.fun.SqlJsonExistsFunction
- getAllowedSignatures(String) - Method in class org.apache.calcite.sql.fun.SqlJsonRemoveFunction
- getAllowedSignatures(String) - Method in class org.apache.calcite.sql.fun.SqlJsonValueFunction
- getAllowedSignatures(String) - Method in class org.apache.calcite.sql.fun.SqlLiteralChainOperator
- getAllowedSignatures(String) - Method in class org.apache.calcite.sql.fun.SqlOverlapsOperator
- getAllowedSignatures(String) - Method in class org.apache.calcite.sql.fun.SqlSubstringFunction
- getAllowedSignatures(String) - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall
- getAllowedSignatures(String) - Method in class org.apache.calcite.sql.SqlOperator
-
Returns a string describing the expected operand types of a call, e.g.
- getAllowedSignatures(SqlOperator, String) - Method in class org.apache.calcite.sql.type.ArrayElementOperandTypeChecker
- getAllowedSignatures(SqlOperator, String) - Method in class org.apache.calcite.sql.type.AssignableOperandTypeChecker
- getAllowedSignatures(SqlOperator, String) - Method in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- getAllowedSignatures(SqlOperator, String) - Method in class org.apache.calcite.sql.type.ExplicitOperandTypeChecker
- getAllowedSignatures(SqlOperator, String) - Method in class org.apache.calcite.sql.type.FamilyOperandTypeChecker
- getAllowedSignatures(SqlOperator, String) - Method in class org.apache.calcite.sql.type.IntervalOperandTypeChecker
- getAllowedSignatures(SqlOperator, String) - Method in class org.apache.calcite.sql.type.LiteralOperandTypeChecker
- getAllowedSignatures(SqlOperator, String) - Method in class org.apache.calcite.sql.type.MultisetOperandTypeChecker
- getAllowedSignatures(SqlOperator, String) - Method in class org.apache.calcite.sql.type.SameOperandTypeChecker
- getAllowedSignatures(SqlOperator, String) - Method in class org.apache.calcite.sql.type.SameOperandTypeExceptLastOperandChecker
- getAllowedSignatures(SqlOperator, String) - Method in class org.apache.calcite.sql.type.SetopOperandTypeChecker
- getAllowedSignatures(SqlOperator, String) - Method in interface org.apache.calcite.sql.type.SqlOperandTypeChecker
-
Returns a string describing the allowed formal signatures of a call, e.g.
- getAllPredicates() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.AllPredicates
-
Derives the predicates that hold on rows emitted from a relational expression.
- getAllPredicates(HepRelVertex, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
- getAllPredicates(RelSubset, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
- getAllPredicates(Aggregate, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Extracts predicates for an Aggregate.
- getAllPredicates(Calc, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Extracts predicates for a Calc.
- getAllPredicates(Exchange, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Extracts predicates for an Exchange.
- getAllPredicates(Filter, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Extracts predicates for a Filter.
- getAllPredicates(Join, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Add the Join condition to the list obtained from the input.
- getAllPredicates(Project, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Extracts predicates for a project.
- getAllPredicates(Sample, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Extracts predicates for a Sample.
- getAllPredicates(SetOp, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Extracts predicates for a SetOp.
- getAllPredicates(Sort, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Extracts predicates for a Sort.
- getAllPredicates(TableModify, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Extracts predicates for an TableModify.
- getAllPredicates(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Extracts predicates for a table scan.
- getAllPredicates(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.AllPredicates.getAllPredicates()
statistic. - getAllPredicates(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.AllPredicates.Handler
- getAllPredicates(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Catch-all implementation for
BuiltInMetadata.AllPredicates.getAllPredicates()
, invoked using reflection. - getAllSchemaObjectNames(List<String>) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- getAllSchemaObjectNames(List<String>) - Method in class org.apache.calcite.sql.validate.DelegatingSqlValidatorCatalogReader
- getAllSchemaObjectNames(List<String>) - Method in interface org.apache.calcite.sql.validate.SqlValidatorCatalogReader
-
Given fully qualified schema name, returns schema object names as specified.
- getAlpha() - Method in class org.apache.calcite.rex.RexPatternFieldRef
- getAncestors(E) - Method in class org.apache.calcite.util.PartiallyOrderedSet
-
Returns a list of values in the set that are less-than a given value.
- getAncestry(SqlNode, Predicate<SqlNode>, Predicate<SqlNode>) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns a list of ancestors of
predicate
within a givenSqlNode
tree. - getApplicableMaterializations(RelNode, List<RelOptMaterialization>) - Static method in class org.apache.calcite.plan.RelOptMaterializations
-
Returns a list of materializations that can potentially be used by the query.
- getApproxFormatter(boolean) - Static method in class org.apache.calcite.util.NumberUtil
- getArgList() - Method in class org.apache.calcite.rel.core.AggregateCall
-
Returns the ordinals of the arguments to this call.
- getArgs() - Method in class org.apache.calcite.util.javac.JaninoCompiler
- getArgs() - Method in interface org.apache.calcite.util.javac.JavaCompiler
- getArgumentValueAs(int, Class<V>) - Method in interface org.apache.calcite.schema.FunctionContext
-
Returns the value of an argument to this function, null if the argument is the NULL literal.
- getArity() - Method in class org.apache.calcite.sql.SqlRowTypeNameSpec
- getAsByteArray() - Method in class org.apache.calcite.util.BitString
- getAuxiliaryFunctions() - Method in class org.apache.calcite.sql.SqlGroupedWindowFunction
-
Returns a list of this grouped window function's auxiliary functions.
- getAverageColumnSizes(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.Size.averageColumnSizes()
statistic. - getAverageColumnSizesNotNull(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
As
RelMetadataQuery.getAverageColumnSizes(org.apache.calcite.rel.RelNode)
but never returns a null list, only ever a list of nulls. - getAverageRowSize(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.Size.averageRowSize()
statistic. - getBaseDir(Class<?>) - Static method in class org.apache.calcite.util.TestUtil
-
Returns the root directory of the source tree.
- getBaseFormatPatternLength() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.AmPmCompiledPattern
- getBaseFormatPatternLength() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.BcAdCompiledPattern
- getBaseFormatPatternLength() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.CompiledPattern
-
Returns the length of the format pattern without modifiers.
- getBaseFormatPatternLength() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.DayOfWeekCompiledPattern
- getBaseFormatPatternLength() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.MonthCompiledPattern
- getBaseFormatPatternLength() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.NumberCompiledPattern
- getBaseFormatPatternLength() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.RomanNumeralsCompiledPattern
- getBaseFormatPatternLength() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneCompiledPattern
- getBaseFormatPatternLength() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneHoursCompiledPattern
- getBaseFormatPatternLength() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneMinutesCompiledPattern
- getBaseFormatPatternLength() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneOffsetCompiledPattern
- getBaseFormatPatternLength() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.YearWithCommasCompiledPattern
- getBest() - Method in class org.apache.calcite.plan.volcano.RelSubset
- getBestOrOriginal() - Method in class org.apache.calcite.plan.volcano.RelSubset
- getBigDecimal(String) - Method in interface org.apache.calcite.rel.RelInput
-
Returns a
BigDecimal
value. - getBindable(Meta.CursorFactory) - Method in interface org.apache.calcite.prepare.Prepare.PreparedResult
-
Executes the prepared result.
- GETBIT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
Alias for
SqlLibraryOperators.BIT_GET
. - getBitCount() - Method in class org.apache.calcite.util.BitString
- getBitSet(String) - Method in interface org.apache.calcite.rel.RelInput
- getBitSetList(String) - Method in interface org.apache.calcite.rel.RelInput
- getBitString() - Method in class org.apache.calcite.sql.SqlBinaryStringLiteral
-
Deprecated.
- getBoolean() - Method in interface org.apache.calcite.linq4j.tree.Primitive.Source
- getBoolean(String, boolean) - Method in interface org.apache.calcite.rel.RelInput
- getBootstrapServers() - Method in class org.apache.calcite.adapter.kafka.KafkaTableOptions
- getBoxClass() - Method in enum org.apache.calcite.linq4j.tree.Primitive
- getBoxingClass(Class) - Static method in class org.apache.calcite.util.ReflectUtil
-
Gets the Java boxing class for a primitive class.
- getBoxName() - Method in enum org.apache.calcite.linq4j.tree.Primitive
- getBuilder() - Method in class org.apache.calcite.piglet.PigConverter
- getByte() - Method in interface org.apache.calcite.linq4j.tree.Primitive.Source
- getByteBufferReadMethod(Class) - Static method in class org.apache.calcite.util.ReflectUtil
-
Uses reflection to find the correct java.nio.ByteBuffer "absolute get" method for a given primitive type.
- getByteBufferWriteMethod(Class) - Static method in class org.apache.calcite.util.ReflectUtil
-
Uses reflection to find the correct java.nio.ByteBuffer "absolute put" method for a given primitive type.
- getCalendarNotTooNear(int) - Static method in class org.apache.calcite.test.SqlOperatorTest
-
Returns a Calendar that is the current time, pausing if we are within 2 minutes of midnight or the top of the hour.
- getCalendarPolicy() - Method in class org.apache.calcite.sql.dialect.ClickHouseSqlDialect
- getCalendarPolicy() - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- getCalendarPolicy() - Method in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- getCalendarPolicy() - Method in class org.apache.calcite.sql.SqlDialect
- getCalendars() - Method in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
-
Get the set of calendars that this value can be in.
- getCall() - Method in class org.apache.calcite.rel.core.TableFunctionScan
-
Returns function invocation expression.
- getCall() - Method in class org.apache.calcite.sql.SqlCallBinding
-
Returns the call node.
- getCallSignature(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlCall
-
Returns a string describing the actual argument types of a call, e.g.
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
-
Returns SqlNode for type in "cast(column as type)", which might be different between databases by type name, precision etc.
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.dialect.ClickHouseSqlDialect
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.dialect.FireboltSqlDialect
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.dialect.HiveSqlDialect
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.dialect.OracleSqlDialect
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.dialect.RedshiftSqlDialect
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.dialect.SparkSqlDialect
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.dialect.StarRocksSqlDialect
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.SqlDialect
-
Returns SqlNode for type in "cast(column as type)", which might be different between databases by type name, precision etc.
- getCastString(String, String, boolean, SqlOperatorFixture.CastType) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- getCatalogName() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockSchema
- getCatalogReader() - Method in class org.apache.calcite.rel.core.TableModify
- getCatalogReader() - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the catalog reader used by this validator.
- getCatalogReader() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getCatalogs(Meta.ConnectionHandle) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- getCause() - Method in exception class org.apache.calcite.sql.parser.SqlParseException
- getCeilSqlFunction(TimeUnitRange) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule
-
Get ceil function datetime.
- getChar() - Method in interface org.apache.calcite.linq4j.tree.Primitive.Source
- getCharacterSet(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Returns the character-set prefix of a SQL string literal; returns null if there is none.
- getCharset() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets this type's character set, or null if this type cannot carry a character set or has no character set defined.
- getCharset() - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- getCharset() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getCharset() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getCharset() - Method in class org.apache.calcite.sql.parser.SqlParserUtil.ParsedCollation
- getCharset() - Method in class org.apache.calcite.sql.SqlCollation
- getCharset() - Method in class org.apache.calcite.sql.type.BasicSqlType
- getCharset() - Method in class org.apache.calcite.util.NlsString
- getCharset() - Method in class org.apache.calcite.util.SerializableCharset
-
Returns the wrapped
Charset
. - getCharset(String) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns the Java-level
Charset
based on given SQL-level name. - getCharset(RelDataType) - Static method in class org.apache.calcite.sql.type.NonNullableAccessors
- getCharsetName() - Method in class org.apache.calcite.util.NlsString
- getCharSetName() - Method in class org.apache.calcite.sql.SqlBasicTypeNameSpec
- getChild() - Method in class org.apache.calcite.sql.validate.PivotScope
-
By analogy with
ListScope.getChildren()
, but this scope only has one namespace, and it is anonymous. - getChild() - Method in class org.apache.calcite.sql.validate.UnpivotScope
-
By analogy with
ListScope.getChildren()
, but this scope only has one namespace, and it is anonymous. - getChildFactors(LoptJoinTree, ImmutableBitSet.Builder) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Deprecated.
- getChildOperands() - Method in class org.apache.calcite.plan.RelOptRuleOperand
-
Returns the child operands.
- getChildRels(RelNode) - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Returns the children of a given relational expression node matched in a rule.
- getChildren() - Method in class org.apache.calcite.sql.validate.ListScope
-
Returns an immutable list of child namespaces.
- getChildren(E) - Method in class org.apache.calcite.util.PartiallyOrderedSet
-
Returns the values in this partially-ordered set that are less-than a given value and there are no intervening values.
- getChildren(E, boolean) - Method in class org.apache.calcite.util.PartiallyOrderedSet
-
Returns the values in this partially-ordered set that are less-than a given value and there are no intervening values.
- getChosenSemiJoin(int) - Method in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
-
Returns the optimal semijoin for the specified factor; may be the factor itself if semijoins are not chosen for the factor.
- getChronoUnit() - Method in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
-
Get the ChronoUnit value that corresponds to this value.
- getChronoUnit() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.CompiledPattern
-
Get the ChronoUnitEnum value that this pattern is for.
- getClassLoader() - Method in class org.apache.calcite.util.javac.JaninoCompiler
- getClassLoader() - Method in interface org.apache.calcite.util.javac.JavaCompiler
- getClassLoader() - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- getClassTracer(Class) - Static method in class org.apache.calcite.adapter.splunk.util.StringUtils
- getCluster() - Method in interface org.apache.calcite.plan.RelOptNode
-
Returns the cluster this relational expression belongs to.
- getCluster() - Method in interface org.apache.calcite.plan.RelOptTable.ToRelContext
- getCluster() - Method in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRuleCall
- getCluster() - Method in class org.apache.calcite.rel.AbstractRelNode
- getCluster() - Method in interface org.apache.calcite.rel.RelInput
- getCluster() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Returns the RelOptCluster in use.
- getCluster() - Method in class org.apache.calcite.tools.RelBuilder
- getClusteringKeys() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable
- getClusteringOrder() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable
- getClusteringOrder(String, boolean) - Method in class org.apache.calcite.adapter.cassandra.CassandraSchema
-
Get the collation of all clustering key columns.
- getCode() - Method in class org.apache.calcite.prepare.Prepare.PreparedExplain
- getCode() - Method in interface org.apache.calcite.prepare.Prepare.PreparedResult
-
Returns the code generated by preparation.
- getCoercibility() - Method in class org.apache.calcite.sql.SqlCollation
- getCoercibilityDyadic(SqlCollation, SqlCollation) - Static method in class org.apache.calcite.sql.SqlCollation
- getCoercibilityDyadicComparison(SqlCollation, SqlCollation) - Static method in class org.apache.calcite.sql.SqlCollation
-
Returns the collating sequence (the collation name) to use for the resulting value of a comparison.
- getCoercibilityDyadicOperator(SqlCollation, SqlCollation) - Static method in class org.apache.calcite.sql.SqlCollation
-
Returns the collating sequence (the collation name) and the coercibility for the resulting value of a dyadic operator.
- getCoercibilityDyadicOperatorThrows(SqlCollation, SqlCollation) - Static method in class org.apache.calcite.sql.SqlCollation
-
Returns the collating sequence (the collation name) and the coercibility for the resulting value of a dyadic operator.
- getCohorts() - Method in class org.apache.calcite.rel.rules.CalcRelSplitter
-
Returns a list of sets of expressions that should be on the same level.
- getCollation() - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns
RelCollation
trait defined byRelCollationTraitDef.INSTANCE
, or null if theRelCollationTraitDef.INSTANCE
is not registered in this traitSet. - getCollation() - Method in class org.apache.calcite.rel.core.AggregateCall
-
Returns the aggregate ordering definition (the
WITHIN GROUP
clause in SQL), or the empty list if not specified. - getCollation() - Method in class org.apache.calcite.rel.core.Sort
-
Returns the array of
RelFieldCollation
s asked for by the sort specification, from most significant to least significant. - getCollation() - Method in class org.apache.calcite.rel.core.SortExchange
-
Returns the array of
RelFieldCollation
s asked for by the sort specification, from most significant to least significant. - getCollation() - Method in interface org.apache.calcite.rel.RelInput
- getCollation() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets this type's collation, or null if this type cannot carry a collation or has no collation defined.
- getCollation() - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- getCollation() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getCollation() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getCollation() - Method in class org.apache.calcite.sql.SqlCharStringLiteral
-
Returns the collation.
- getCollation() - Method in class org.apache.calcite.sql.SqlIdentifier
- getCollation() - Method in class org.apache.calcite.sql.type.BasicSqlType
- getCollation() - Method in class org.apache.calcite.util.NlsString
- getCollation(List<RexFieldCollation>) - Static method in class org.apache.calcite.rel.core.Window
- getCollation(RelDataType) - Static method in class org.apache.calcite.sql.type.NonNullableAccessors
- getCollationList() - Method in class org.apache.calcite.jdbc.CalcitePrepare.CalciteSignature
- getCollationList() - Method in class org.apache.calcite.plan.RelOptAbstractTable
- getCollationList() - Method in interface org.apache.calcite.plan.RelOptTable
-
Returns a description of the physical ordering (or orderings) of the rows returned from this table.
- getCollationList() - Method in class org.apache.calcite.prepare.RelOptTableImpl
- getCollationList() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getCollationName() - Method in class org.apache.calcite.sql.SqlCollation
- getCollations() - Method in interface org.apache.calcite.schema.Statistic
-
Returns the collections of columns on which this table is sorted.
- getCollations(List<RelCollation>) - Method in class org.apache.calcite.rex.RexProgram
-
Given a list of collations which hold for the input to this program, returns a list of collations which hold for its output.
- getCollationType() - Method in class org.apache.calcite.rel.core.Aggregate.PercentileDiscAggCallBinding
- getCollationType() - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Returns the collation type.
- getCollationType() - Method in class org.apache.calcite.sql.SqlWithinGroupOperator.PercentileDiscCallBinding
- getCollator() - Method in class org.apache.calcite.jdbc.JavaCollation
- getCollator() - Method in class org.apache.calcite.sql.SqlCollation
-
Returns the
Collator
to compare values having the current collation, ornull
if no specificCollator
is needed, in which caseString.compareTo(java.lang.String)
will be used. - getCollectionsTypeName() - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- getCollectionType() - Method in class org.apache.calcite.rel.core.Collect
-
Returns the collection type (ARRAY, MAP, or MULTISET).
- getColumn() - Method in class org.apache.calcite.sql.SqlDescribeTable
- getColumnConstraints(ModifiableView, RelDataType, RelDataTypeFactory) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a mapping of the column ordinal in the underlying table to a column constraint of the modifiable view.
- getColumnListParamInfo(int, String, List<String>) - Method in class org.apache.calcite.sql.SqlCallBinding
- getColumnListParamInfo(int, String, List<String>) - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Retrieves information about a column list parameter.
- getColumnMapping() - Method in class org.apache.calcite.schema.impl.ModifiableViewTable
- getColumnMapping() - Method in interface org.apache.calcite.schema.ModifiableView
-
Returns the column mapping onto another table.
- getColumnMappings() - Method in class org.apache.calcite.rel.core.TableFunctionScan
-
Returns set of mappings known for this table function, or null if unknown (not the same as empty!).
- getColumnMappings() - Method in class org.apache.calcite.sql.type.TableFunctionReturnTypeInference
- getColumnMonotonicities() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- getColumnNames() - Method in interface org.apache.calcite.jdbc.CalciteMetaColumnFactory
-
Returns the list of expected column names.
- getColumnNames() - Method in interface org.apache.calcite.jdbc.CalciteMetaTableFactory
-
Returns the list of expected column names.
- getColumnNum() - Method in class org.apache.calcite.sql.parser.SqlParserPos
-
Returns 1-based starting column number.
- getColumnOrigin(RelNode, int) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Determines the origin of a column.
- getColumnOrigins(int) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ColumnOrigin
-
For a given output column of an expression, determines all columns of underlying tables which contribute to result values.
- getColumnOrigins(Aggregate, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getColumnOrigins(Calc, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getColumnOrigins(Exchange, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getColumnOrigins(Filter, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getColumnOrigins(Join, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getColumnOrigins(Project, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getColumnOrigins(Sample, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getColumnOrigins(SetOp, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getColumnOrigins(Snapshot, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getColumnOrigins(Sort, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getColumnOrigins(TableFunctionScan, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getColumnOrigins(TableModify, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getColumnOrigins(TableScan, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getColumnOrigins(RelNode, int) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.ColumnOrigin.getColumnOrigins(int)
statistic. - getColumnOrigins(RelNode, RelMetadataQuery, int) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ColumnOrigin.Handler
- getColumnOrigins(RelNode, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getColumnPairs() - Method in interface org.apache.calcite.rel.RelReferentialConstraint
-
The (source, target) column ordinals.
- getColumnPairs() - Method in class org.apache.calcite.rel.RelReferentialConstraintImpl
- getColumns(Meta.ConnectionHandle, String, Meta.Pat, Meta.Pat, Meta.Pat) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- getColumnStrategies() - Method in class org.apache.calcite.plan.RelOptAbstractTable
- getColumnStrategies() - Method in interface org.apache.calcite.plan.RelOptTable
-
Returns a list describing how each column is populated.
- getColumnStrategies() - Method in class org.apache.calcite.prepare.Prepare.AbstractPreparingTable
- getColumnType(SqlTestFactory, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- getColumnType(SqlTestFactory, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Returns the data type of the sole column of a SQL query.
- getCompact() - Method in class org.apache.calcite.util.XmlOutput
- getComparability() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Returns the category of comparison operators that make sense when applied to values of this type.
- getComparability() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getComparability() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getComparability() - Method in class org.apache.calcite.sql.type.ObjectSqlType
- getCompletionHints(String, int, String[]) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
-
Gets completion hints for a partially completed or syntactically incorrect sql statement with cursor pointing to the position where completion hints are requested.
- getCompletionHints(String, SqlParserPos) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
-
Gets completion hints for a syntactically correct SQL statement with dummy
SqlIdentifier
. - getCompletionHints(SqlAdvisor, String, int) - Static method in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction
-
Returns completion hints for a given SQL statement.
- getCompletionHints(SqlAdvisor, String, int) - Static method in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction2
-
Returns completion hints for a given SQL statement.
- getCompletionHints0(String, int) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
- getComplexMetricsFrom(String) - Method in class org.apache.calcite.adapter.druid.DruidTable
-
Returns the list of
ComplexMetric
that match the givenalias
if it exists, otherwise returns an empty list, nevernull
. - getComponent(int) - Method in class org.apache.calcite.sql.SqlIdentifier
-
Creates an identifier which contains only the
ordinal
th component of this compound identifier. - getComponent(int, int) - Method in class org.apache.calcite.sql.SqlIdentifier
- getComponentParserPosition(int) - Method in class org.apache.calcite.sql.SqlIdentifier
-
Returns the position of the
i
th component of a compound identifier, or the position of the whole identifier if that information is not present. - getComponentType() - Method in class org.apache.calcite.linq4j.tree.Types.ArrayType
-
Returns the type of elements in the array.
- getComponentType() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets the component type if this type is a collection, otherwise null.
- getComponentType() - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- getComponentType() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getComponentType() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getComponentType() - Method in class org.apache.calcite.sql.type.ArraySqlType
- getComponentType() - Method in class org.apache.calcite.sql.type.MultisetSqlType
- getComponentType(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
-
Returns the component type of an array.
- getComponentType(RelDataTypeFactory, List<RelDataType>) - Method in class org.apache.calcite.sql.fun.SqlMultisetValueConstructor
- getComponentTypeOrThrow(RelDataType) - Static method in class org.apache.calcite.sql.type.NonNullableAccessors
- getComponentTypeSpec() - Method in class org.apache.calcite.sql.SqlDataTypeSpec
-
Returns a new SqlDataTypeSpec corresponding to the component type if the type spec is a collections type spec.
Collection types areARRAY
andMULTISET
. - getComputedExpression(Expression) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Returns the reference to ParameterExpression if given expression was already computed and stored to local variable.
- getCondition() - Method in class org.apache.calcite.rel.core.Filter
- getCondition() - Method in class org.apache.calcite.rel.core.Join
- getCondition() - Method in class org.apache.calcite.rex.RexProgram
-
Returns the field reference of this program's filter condition, or null if there is no condition.
- getCondition() - Method in class org.apache.calcite.sql.SqlDelete
-
Gets the filter condition for rows to be deleted.
- getCondition() - Method in class org.apache.calcite.sql.SqlJoin
- getCondition() - Method in class org.apache.calcite.sql.SqlMerge
-
Returns the condition expression to determine whether to UPDATE or INSERT.
- getCondition() - Method in class org.apache.calcite.sql.SqlUpdate
-
Gets the filter condition for rows to be updated.
- getCondition(SqlJoin) - Static method in class org.apache.calcite.sql.validate.SqlNonNullableAccessors
- getConditionType() - Method in class org.apache.calcite.sql.SqlJoin
-
Returns a
JoinConditionType
, never null. - getConditionTypeNode() - Method in class org.apache.calcite.sql.SqlJoin
- getConfig() - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- getConfig() - Method in interface org.apache.calcite.sql.validate.SqlValidatorCatalogReader
-
Returns Config settings.
- getConfig() - Method in class org.apache.calcite.tools.Frameworks.PrepareAction
-
Deprecated.
- getConformance() - Method in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- getConformance() - Method in interface org.apache.calcite.plan.RelImplementor
-
Returns the desired SQL conformance.
- getConformance() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns the
SqlConformance
that matches this dialect. - getConformance() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getConformance() - Method in class org.apache.calcite.test.SqlToRelFixture
- getConnection() - Method in class org.apache.calcite.jdbc.CalciteStatement
- getConnection() - Method in interface org.apache.calcite.server.CalciteServerStatement
-
Returns the connection.
- getConnectionConfig() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getConnectionProperties() - Method in class org.apache.calcite.jdbc.Driver
- getConnectStringPrefix() - Method in class org.apache.calcite.adapter.splunk.SplunkDriver
- getConnectStringPrefix() - Method in class org.apache.calcite.jdbc.Driver
- getConsistency() - Method in class org.apache.calcite.sql.type.ComparableOperandTypeChecker
- getConsistency() - Method in interface org.apache.calcite.sql.type.SqlOperandTypeChecker
-
Returns the strategy for making the arguments have consistency types.
- getConstants() - Method in class org.apache.calcite.rel.core.Window
-
Returns constants that are additional inputs of current relation.
- getConstraint(RexBuilder, RelDataType) - Method in class org.apache.calcite.schema.impl.ModifiableViewTable
- getConstraint(RexBuilder, RelDataType) - Method in interface org.apache.calcite.schema.ModifiableView
-
Returns a constraint that each candidate row must satisfy.
- getConstraint(RexBuilder, RelDataType) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable
- getConstructor(String) - Method in class org.apache.calcite.rel.externalize.RelJson
- getConsumer() - Method in class org.apache.calcite.adapter.kafka.KafkaTableOptions
- getConsumerParams() - Method in class org.apache.calcite.adapter.kafka.KafkaTableOptions
- getContext() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- getContext() - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Provides the Context created when this planner was constructed.
- getContext() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns the PlannerContext that should be made available during planning by calling
RelOptPlanner.getContext()
. - getContext(RelOptCluster) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- getConvention() - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns
Convention
trait defined byConventionTraitDef.INSTANCE
, or null if theConventionTraitDef.INSTANCE
is not registered in this traitSet. - getConvention() - Method in class org.apache.calcite.rel.AbstractRelNode
- getConvention() - Method in interface org.apache.calcite.rel.RelNode
-
Return the CallingConvention trait from this RelNode's
trait set
. - getConvertletTable() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns the convertlet table that should be used when converting from SQL to row expressions.
- getCopyJoinFieldRefCountsMap() - Method in class org.apache.calcite.rel.rules.MultiJoin
-
Returns a copy of the map of reference counts for each input, representing the fields accessed in join conditions.
- getCorrelationId() - Method in class org.apache.calcite.rel.core.Correlate
-
Returns the correlating expressions.
- getCorrelOrdinal(String) - Static method in class org.apache.calcite.plan.RelOptQuery
-
Deprecated.
- getCorrelVariable() - Method in class org.apache.calcite.rel.AbstractRelNode
- getCorrelVariable() - Method in class org.apache.calcite.rel.core.Correlate
- getCorrelVariable() - Method in interface org.apache.calcite.rel.RelNode
-
Returns the name of the variable which is to be implicitly set at runtime each time a row is returned from the first input of this relational expression; or null if there is no variable.
- getCorrelVariableGetter(String) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- getCorrelVariableNames() - Method in class org.apache.calcite.rex.RexProgram
-
Returns the set of correlation variables used (read) by this program.
- getCost(RelNode) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Deprecated.
- getCost(RelNode) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Deprecated.Use
RelOptPlanner.getCost(RelNode, RelMetadataQuery)
or, better, callRelMetadataQuery.getCumulativeCost(RelNode)
. - getCost(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- getCost(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Computes the cost of a RelNode.
- getCost(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- getCostFactory() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- getCostFactory() - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Returns the factory that creates
RelOptCost
s. - getCostFactory() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns the cost factory that should be used when creating the planner.
- getCpu() - Method in interface org.apache.calcite.plan.RelOptCost
-
Returns usage of CPU resources.
- getCpu() - Method in class org.apache.calcite.plan.RelOptCostImpl
- getCpuInfo() - Static method in class org.apache.calcite.adapter.utils.OsQueryTableUtil
- getCpuTimeInfo() - Static method in class org.apache.calcite.adapter.utils.OsQueryTableUtil
- getCumulativeCost() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.CumulativeCost
-
Estimates the cost of executing a relational expression, including the cost of its inputs.
- getCumulativeCost(EnumerableInterpreter, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPercentageOriginalRows
- getCumulativeCost(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.CumulativeCost.getCumulativeCost()
statistic. - getCumulativeCost(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.CumulativeCost.Handler
- getCumulativeCost(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPercentageOriginalRows
- getCurrentRel() - Method in class org.apache.calcite.plan.hep.HepRelVertex
-
Returns current implementation chosen for this vertex.
- getCursorOperand(int) - Method in class org.apache.calcite.sql.SqlCallBinding
- getCursorOperand(int) - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Returns the rowtype of the
ordinal
th operand, which is a cursor. - getCursorScope(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getDatabase() - Method in class org.apache.calcite.adapter.redis.RedisConfig
- getDatabaseProduct() - Method in class org.apache.calcite.sql.SqlDialect
-
Deprecated.To be removed without replacement
- getDatabaseProductName() - Method in class org.apache.calcite.sql.SqlUtil.DatabaseMetaDataInvocationHandler
- getDatabaseProperties(Meta.ConnectionHandle) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- getDataContext() - Method in interface org.apache.calcite.interpreter.Compiler
- getDataContext() - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- getDataContext() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.Context
- getDataFormat() - Method in class org.apache.calcite.adapter.redis.RedisTableFieldInfo
- getDataList(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.file.JsonTable
-
Returns the data list of the table.
- getDataSource() - Method in class org.apache.calcite.adapter.jdbc.JdbcCatalogSchema
-
Returns the data source.
- getDataSource() - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getDate() - Method in class org.apache.calcite.sql.SqlDateLiteral
-
Converts this literal to a
DateString
. - getDateFormatter(String) - Static method in class org.apache.calcite.util.DateTimeStringUtils
-
Create a SimpleDateFormat with format string with default time zone UTC.
- getDateFormatter(String, TimeZone) - Static method in class org.apache.calcite.util.DateTimeStringUtils
-
Create a SimpleDateFormat with format string and time zone.
- getDaysSinceEpoch() - Method in class org.apache.calcite.util.DateString
-
Returns the number of days since the epoch.
- getDdlExecutor() - Method in interface org.apache.calcite.sql.parser.SqlParserImplFactory
-
Returns a DDL executor.
- getDeclaringClass() - Method in class org.apache.calcite.linq4j.tree.ArrayLengthRecordField
- getDeclaringClass() - Method in interface org.apache.calcite.linq4j.tree.PseudoField
- getDeclaringClass() - Method in class org.apache.calcite.linq4j.tree.ReflectedPseudoField
- getDeclName() - Method in class org.apache.calcite.sql.SqlWindow
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.AllPredicates.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Collation.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ColumnOrigin.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ColumnUniqueness.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.CumulativeCost.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.DistinctRowCount.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Distribution.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ExplainVisibility.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ExpressionLineage.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.LowerBoundCost.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.MaxRowCount.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Measure.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Memory.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.MinRowCount.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.NodeTypes.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.NonCumulativeCost.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Parallelism.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.PercentageOriginalRows.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.PopulationSize.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Predicates.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.RowCount.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Selectivity.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Size.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.TableReferences.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.UniqueKeys.Handler
- getDef() - Method in interface org.apache.calcite.rel.metadata.MetadataHandler
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdCollation
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdDistribution
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdExplainVisibility
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdLowerBoundCost
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdMeasure
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdMemory
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdParallelism
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdPopulationSize
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdSelectivity
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdSize
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
- getDef() - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getDef() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getDefault() - Method in class org.apache.calcite.plan.ConventionTraitDef
- getDefault() - Method in class org.apache.calcite.plan.RelTraitDef
-
Returns the default member of this trait.
- getDefault() - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns a new traitSet with same traitDefs with current traitSet, but each trait is the default trait value.
- getDefault() - Method in class org.apache.calcite.rel.RelCollationTraitDef
- getDefault() - Method in class org.apache.calcite.rel.RelDistributionTraitDef
- getDefault() - Static method in class org.apache.calcite.runtime.SocketFactoryImpl
-
Returns a copy of the environment's default socket factory.
- getDefaultCharset() - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Returns the default
Charset
(valid if this is a string type). - getDefaultCharset() - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- getDefaultCharset() - Static method in class org.apache.calcite.util.Util
-
Returns the
Charset
object representing the value ofCalciteSystemProperty.DEFAULT_CHARSET
. - getDefaultConcreteType(RelDataTypeFactory) - Method in enum org.apache.calcite.sql.type.SqlTypeFamily
-
Return the default
RelDataType
that belongs to this family. - getDefaultHandlerProvider() - Method in class org.apache.calcite.test.RelMetadataFixture.MetadataConfig
- getDefaultPrecision(SqlTypeName) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- getDefaultPrecision(SqlTypeName) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns default precision for this type if supported, otherwise
RelDataType.PRECISION_NOT_SPECIFIED
if precision is either unsupported or must be specified explicitly. - getDefaultPrecision(SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- getDefaultSansConvention() - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns a new traitSet with same traitDefs with current traitSet, but each trait except
Convention
is the default trait value. - getDefaultScale() - Method in enum org.apache.calcite.sql.type.SqlTypeName
-
Deprecated.Use
RelDataTypeSystem.getDefaultScale(SqlTypeName)
but return Integer.MIN_VALUE if scale is unsupported. - getDefaultScale(SqlTypeName) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- getDefaultScale(SqlTypeName) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns default scale for this type if supported, otherwise
RelDataType.SCALE_NOT_SPECIFIED
if scale is either unsupported or must be specified explicitly. - getDefaultScale(SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
-
Returns the default scale for this type if supported, otherwise
RelDataType.SCALE_NOT_SPECIFIED
if scale is either unsupported or must be specified explicitly. - getDefaultSchema() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns the default schema that should be checked before looking at the root schema.
- getDefaultSchemaPath() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.Context
- getDefaultSubSchemaName() - Method in class org.apache.calcite.adapter.jdbc.JdbcCatalogSchema
-
Returns the name of the default sub-schema.
- getDelegateType(Class...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Gets a Type object that represents a generic System.Func or System.Action delegate type that has specific type arguments.
- getDepth() - Method in class org.apache.calcite.sql.SqlExplain
-
Returns the level of abstraction at which this plan should be displayed.
- getDeriveMode() - Method in class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoin
- getDeriveMode() - Method in class org.apache.calcite.adapter.enumerable.EnumerableCorrelate
- getDeriveMode() - Method in class org.apache.calcite.adapter.enumerable.EnumerableHashJoin
- getDeriveMode() - Method in class org.apache.calcite.adapter.enumerable.EnumerableMergeJoin
- getDeriveMode() - Method in class org.apache.calcite.adapter.enumerable.EnumerableNestedLoopJoin
- getDeriveMode() - Method in interface org.apache.calcite.adapter.enumerable.EnumerableRel
- getDeriveMode() - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
- getDeriveMode() - Method in class org.apache.calcite.adapter.enumerable.EnumerableValues
- getDeriveMode() - Method in interface org.apache.calcite.rel.PhysicalNode
-
Returns mode of derivation.
- getDescendants(E) - Method in class org.apache.calcite.util.PartiallyOrderedSet
-
Returns a list of values in the set that are less-than a given value.
- getDescription() - Method in interface org.apache.calcite.plan.RelOptNode
-
Deprecated.
- getDescription() - Method in class org.apache.calcite.rel.AbstractRelNode
-
Deprecated.
- getDescription() - Method in interface org.apache.calcite.util.format.FormatElement
-
Returns the description of an element.
- getDescription() - Method in enum org.apache.calcite.util.format.FormatElementEnum
- getDesiredRootTraitSet(RelRoot) - Method in class org.apache.calcite.prepare.Prepare
- getDetailLevel() - Method in class org.apache.calcite.rel.externalize.RelJsonWriter
- getDetailLevel() - Method in class org.apache.calcite.rel.externalize.RelWriterImpl
- getDetailLevel() - Method in interface org.apache.calcite.rel.RelWriter
-
Returns detail level at which plan should be generated.
- getDetailLevel() - Method in class org.apache.calcite.sql.SqlExplain
-
Return the detail level to be generated.
- getDialect() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- getDialect() - Method in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
-
Returns a dummy dialect for this database.
- getDialect() - Method in interface org.apache.calcite.sql.SqlWriter
-
Returns the dialect of SQL.
- getDialect() - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Returns the dialect.
- getDialect() - Method in class org.apache.calcite.sql.util.SqlString
-
Returns the dialect.
- getDigest() - Method in class org.apache.calcite.plan.hep.HepRelVertex
- getDigest() - Method in interface org.apache.calcite.plan.RelOptNode
-
Returns a string which concisely describes the definition of this relational expression.
- getDigest() - Method in class org.apache.calcite.plan.volcano.RelSubset
- getDigest() - Method in class org.apache.calcite.rel.AbstractRelNode
- getDigest() - Method in interface org.apache.calcite.rel.RelNode
-
Returns a digest string of this
RelNode
. - getDimension() - Method in class org.apache.calcite.adapter.druid.DefaultDimensionSpec
- getDimension() - Method in interface org.apache.calcite.adapter.druid.DimensionSpec
- getDimension() - Method in class org.apache.calcite.adapter.druid.ExtractionDimensionSpec
- getDimensionCount() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Measure.Context
-
Returns the number of dimension columns.
- getDimensionCount() - Method in class org.apache.calcite.rel.metadata.RelMdMeasure.DelegatingContext
- getDirection() - Method in class org.apache.calcite.rel.RelFieldCollation
- getDirection() - Method in class org.apache.calcite.rex.RexFieldCollation
- getDistinctOptionality() - Method in class org.apache.calcite.sql.fun.SqlAnyValueAggFunction
- getDistinctOptionality() - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- getDistinctOptionality() - Method in class org.apache.calcite.sql.fun.SqlBitOpAggFunction
- getDistinctOptionality() - Method in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
- getDistinctOptionality() - Method in class org.apache.calcite.sql.fun.SqlSingleValueAggFunction
- getDistinctOptionality() - Method in class org.apache.calcite.sql.SqlAggFunction
-
Returns whether this aggregate function allows the
DISTINCT
keyword. - getDistinctRowCount(RelSubset, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
- getDistinctRowCount(Aggregate, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
- getDistinctRowCount(Exchange, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
- getDistinctRowCount(Filter, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
- getDistinctRowCount(Join, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
- getDistinctRowCount(Project, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
- getDistinctRowCount(Sort, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
- getDistinctRowCount(TableModify, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
- getDistinctRowCount(TableScan, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
- getDistinctRowCount(Union, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
- getDistinctRowCount(Values, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
- getDistinctRowCount(RelNode, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.DistinctRowCount.Handler
- getDistinctRowCount(RelNode, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
-
Catch-all implementation for
BuiltInMetadata.DistinctRowCount.getDistinctRowCount(ImmutableBitSet, RexNode)
, invoked using reflection. - getDistinctRowCount(RelNode, ImmutableBitSet, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.DistinctRowCount.getDistinctRowCount(ImmutableBitSet, RexNode)
statistic. - getDistinctRowCount(ImmutableBitSet, RexNode) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.DistinctRowCount
-
Estimates the number of rows which would be produced by a GROUP BY on the set of columns indicated by groupKey, where the input to the GROUP BY has been pre-filtered by predicate.
- getDistribution() - Method in class org.apache.calcite.plan.RelOptAbstractTable
- getDistribution() - Method in interface org.apache.calcite.plan.RelOptTable
-
Returns a description of the physical distribution of the rows in this table.
- getDistribution() - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns
RelDistribution
trait defined byRelDistributionTraitDef.INSTANCE
, or null if theRelDistributionTraitDef.INSTANCE
is not registered in this traitSet. - getDistribution() - Method in class org.apache.calcite.prepare.RelOptTableImpl
- getDistribution() - Method in class org.apache.calcite.rel.core.Exchange
-
Returns the distribution of the rows returned by this Exchange.
- getDistribution() - Method in interface org.apache.calcite.rel.RelInput
- getDistribution() - Method in interface org.apache.calcite.schema.Statistic
-
Returns the distribution of the data in this table.
- getDistribution() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getDistribution(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.Distribution.distribution()
statistic. - getDouble() - Method in interface org.apache.calcite.linq4j.tree.Primitive.Source
- getDruidTable() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getDruidType() - Method in class org.apache.calcite.adapter.druid.ComplexMetric
- getDynamicHandler() - Static method in class org.apache.calcite.util.trace.CalciteTrace
-
Thread-local handler that is called with dynamically generated Java code.
- getDynamicParamCount() - Method in class org.apache.calcite.sql.SqlExplain
-
Returns the number of dynamic parameters in the statement.
- getDynamicParamCount() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Returns the number of dynamic parameters encountered during translation; this must only be called after
SqlToRelConverter.convertQuery(org.apache.calcite.sql.SqlNode, boolean, boolean)
. - getDynamicParamCountInExplain(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Returns the current count of the number of dynamic parameters in an EXPLAIN PLAN statement.
- getDynamicParameters() - Method in class org.apache.calcite.sql.util.SqlString
-
Returns indices of dynamic parameters.
- getDynamicParamType(int) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Returns the type inferred for a dynamic parameter.
- getEdge(V, V) - Method in class org.apache.calcite.util.graph.AttributedDirectedGraph
-
Returns the first edge between one vertex to another.
- getEdge(V, V) - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- getEdge(V, V) - Method in interface org.apache.calcite.util.graph.DirectedGraph
- getEdges(V, V) - Method in class org.apache.calcite.util.graph.AttributedDirectedGraph
-
Returns all edges between one vertex to another.
- getElementMap() - Method in interface org.apache.calcite.util.format.FormatModel
-
Returns the map used to create the
FormatModel
instance. - getElementType() - Method in class org.apache.calcite.adapter.arrow.ArrowTable
- getElementType() - Method in class org.apache.calcite.adapter.csv.CsvTranslatableTable
- getElementType() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getElementType() - Method in class org.apache.calcite.adapter.enumerable.EnumerableBindable
- getElementType() - Method in class org.apache.calcite.adapter.file.CsvTranslatableTable
- getElementType() - Method in class org.apache.calcite.adapter.java.AbstractQueryableTable
- getElementType() - Method in class org.apache.calcite.interpreter.Bindables.BindableAggregate
- getElementType() - Method in class org.apache.calcite.interpreter.Bindables.BindableFilter
- getElementType() - Method in class org.apache.calcite.interpreter.Bindables.BindableIntersect
- getElementType() - Method in class org.apache.calcite.interpreter.Bindables.BindableJoin
- getElementType() - Method in class org.apache.calcite.interpreter.Bindables.BindableMatch
- getElementType() - Method in class org.apache.calcite.interpreter.Bindables.BindableMinus
- getElementType() - Method in class org.apache.calcite.interpreter.Bindables.BindableProject
- getElementType() - Method in class org.apache.calcite.interpreter.Bindables.BindableSort
- getElementType() - Method in class org.apache.calcite.interpreter.Bindables.BindableTableScan
- getElementType() - Method in class org.apache.calcite.interpreter.Bindables.BindableUnion
- getElementType() - Method in class org.apache.calcite.interpreter.Bindables.BindableValues
- getElementType() - Method in class org.apache.calcite.interpreter.Bindables.BindableWindow
- getElementType() - Method in class org.apache.calcite.interpreter.InterpretableConverter
- getElementType() - Method in class org.apache.calcite.linq4j.BaseQueryable
- getElementType() - Method in class org.apache.calcite.linq4j.QueryableDefaults.NonLeafReplayableQueryable
- getElementType() - Method in interface org.apache.calcite.linq4j.RawQueryable
-
Gets the type of the element(s) that are returned when the expression tree associated with this Queryable is executed.
- getElementType() - Method in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- getElementType() - Method in class org.apache.calcite.rel.core.TableFunctionScan
-
Returns element type of the collection that will implement this table.
- getElementType() - Method in interface org.apache.calcite.runtime.ArrayBindable
- getElementType() - Method in interface org.apache.calcite.runtime.Typed
-
Gets the type of the element(s) that are returned in this collection.
- getElementType() - Method in class org.apache.calcite.schema.impl.AbstractTableQueryable
- getElementType() - Method in class org.apache.calcite.schema.impl.ListTransientTable
- getElementType() - Method in interface org.apache.calcite.schema.QueryableTable
-
Returns the element type of the collection that will implement this table.
- getElementType(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
-
Returns the element type of a
Collection
,Iterable
(includingQueryable
andEnumerable
),Iterator
,Enumerator
, or an array. - getElementType(List<? extends Object>) - Method in class org.apache.calcite.schema.impl.TableFunctionImpl
- getElementType(List<? extends Object>) - Method in interface org.apache.calcite.schema.TableFunction
-
Returns the row type of the table yielded by this function when applied to given arguments.
- getElementType(List<? extends Object>) - Method in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction
- getElementType(List<? extends Object>) - Method in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction2
- getElementType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.validate.SqlUserDefinedTableFunction
-
Returns the row type of the table yielded by this function when applied to given arguments.
- getElementTypeName() - Method in class org.apache.calcite.sql.SqlCollectionTypeNameSpec
- getElseOperand() - Method in class org.apache.calcite.sql.fun.SqlCase
- getEmptyScope() - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns a scope that cannot see anything.
- getEmptyScope() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getEmptyTraitSet() - Method in class org.apache.calcite.prepare.PlannerImpl
- getEmptyTraitSet() - Method in interface org.apache.calcite.tools.Planner
- getEnclosingAggregateSelectScope(SqlValidatorScope) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
- getEnclosingNode() - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- getEnclosingNode() - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- getEnclosingNode() - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns the parse tree node that at is at the root of this namespace and includes all decorations.
- getEnclosingSelectScope(SqlValidatorScope) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
- getEndColumnNum() - Method in class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
-
Returns 1-based end column number.
- getEndColumnNum() - Method in class org.apache.calcite.sql.parser.SqlParserPos
-
Returns 1-based end column number (same as starting column number if the ParserPos is a point, not a range).
- getEndLineNum() - Method in class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
-
Returns 1-based end line number.
- getEndLineNum() - Method in class org.apache.calcite.sql.parser.SqlParserPos
-
Returns 1-based end line number (same as starting line number if the ParserPos is a point, not a range).
- getEndPosColumn() - Method in exception class org.apache.calcite.runtime.CalciteContextException
-
Returns the 1-based ending column number, or 0 for missing position information.
- getEndPosLine() - Method in exception class org.apache.calcite.runtime.CalciteContextException
-
Returns the 1-based ending line number, or 0 for missing position information.
- getEndStates() - Method in class org.apache.calcite.runtime.DeterministicAutomaton
- getEndUnit() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- getEndUnit() - Method in enum org.apache.calcite.sql.type.SqlTypeName
-
Returns
SECOND
for bothHOUR TO SECOND
andSECOND
. - getEntityNumber() - Method in class org.apache.calcite.rex.RexTableInputRef.RelTableRef
- getEnum(String, Class<E>) - Method in interface org.apache.calcite.rel.RelInput
-
Returns an enum value.
- getEnumerator() - Method in class org.apache.calcite.adapter.os.OsQuery
- getEpsilonTransitions() - Method in class org.apache.calcite.runtime.Automaton
- getEquiCondition(RelNode, RelNode, RexBuilder) - Method in class org.apache.calcite.rel.core.JoinInfo
- getEquivalenceClass() - Method in class org.apache.calcite.plan.RelOptListener.RelEquivalenceEvent
- getEquivalenceClasses() - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule.EquivalenceClasses
- getEquivalenceClassesMap() - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule.EquivalenceClasses
- getExclude() - Method in interface org.apache.calcite.adapter.enumerable.WinAggContext
-
The exclude clause of the group of the window function.
- getExclude() - Method in class org.apache.calcite.rex.RexWindow
- getExclude() - Method in class org.apache.calcite.sql.SqlWindow
- getExecutable(RexBuilder, List<RexNode>, RelDataType) - Static method in class org.apache.calcite.rex.RexExecutorImpl
-
Creates an
RexExecutable
that allows to apply the generated code during query processing (filter, projection). - getExecutor() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- getExecutor() - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Returns the executor used to evaluate constant expressions.
- getExecutor() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns the executor used to evaluate constant expressions.
- getExpandedSelectList() - Method in class org.apache.calcite.sql.validate.SelectScope
- getExpectedInputRowType(int) - Method in class org.apache.calcite.rel.AbstractRelNode
- getExpectedInputRowType(int) - Method in class org.apache.calcite.rel.core.TableModify
- getExpectedInputRowType(int) - Method in interface org.apache.calcite.rel.RelNode
-
Returns the type of the rows expected for an input.
- getExpectedTokenNames() - Method in exception class org.apache.calcite.sql.parser.SqlParseException
-
Returns a list of the token names which could have legally occurred at this point.
- getExpectedTokenSequences() - Method in exception class org.apache.calcite.sql.parser.SqlParseException
-
Returns the expected token sequences.
- getExplicandum() - Method in class org.apache.calcite.sql.SqlExplain
-
Returns the underlying SQL statement to be explained.
- getExprCount() - Method in class org.apache.calcite.rex.RexProgram
-
Returns the number of expressions in this program.
- getExpression() - Method in class org.apache.calcite.adapter.druid.VirtualColumn
- getExpression() - Method in class org.apache.calcite.linq4j.BaseQueryable
- getExpression() - Method in class org.apache.calcite.linq4j.QueryableDefaults.NonLeafReplayableQueryable
- getExpression() - Method in interface org.apache.calcite.linq4j.RawQueryable
-
Gets the expression tree that is associated with this Queryable.
- getExpression() - Method in class org.apache.calcite.rex.RexLambda
- getExpression() - Method in class org.apache.calcite.schema.impl.AbstractTableQueryable
- getExpression() - Method in class org.apache.calcite.sql.SqlLambda
- getExpression(Class) - Method in class org.apache.calcite.plan.RelOptAbstractTable
- getExpression(Class) - Method in interface org.apache.calcite.plan.RelOptTable
-
Generates code for this table.
- getExpression(Class) - Method in class org.apache.calcite.prepare.RelOptTableImpl
- getExpression(Class) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getExpression(String) - Method in interface org.apache.calcite.rel.RelInput
-
Returns an expression.
- getExpression(SchemaPlus, String) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getExpression(SchemaPlus, String) - Method in class org.apache.calcite.schema.impl.AbstractSchema
- getExpression(SchemaPlus, String) - Method in class org.apache.calcite.schema.impl.DelegatingSchema
- getExpression(SchemaPlus, String) - Method in interface org.apache.calcite.schema.Schema
-
Returns the expression by which this schema can be referenced in generated code.
- getExpression(SchemaPlus, String, Class) - Method in class org.apache.calcite.adapter.arrow.ArrowTable
- getExpression(SchemaPlus, String, Class) - Method in class org.apache.calcite.adapter.csv.CsvTranslatableTable
- getExpression(SchemaPlus, String, Class) - Method in class org.apache.calcite.adapter.file.CsvTranslatableTable
- getExpression(SchemaPlus, String, Class) - Method in class org.apache.calcite.adapter.java.AbstractQueryableTable
- getExpression(SchemaPlus, String, Class) - Method in class org.apache.calcite.schema.impl.ListTransientTable
- getExpression(SchemaPlus, String, Class) - Method in interface org.apache.calcite.schema.QueryableTable
-
Generates an expression with which this table can be referenced in generated code.
- getExpression(SchemaPlus, String, Class) - Method in class org.apache.calcite.util.Smalls.SimpleTable
- getExpressionLineage(RelSubset, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
- getExpressionLineage(Aggregate, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
-
Expression lineage from
Aggregate
. - getExpressionLineage(Calc, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
-
Expression lineage from Calc.
- getExpressionLineage(Exchange, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
-
Expression lineage from Exchange.
- getExpressionLineage(Filter, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
-
Expression lineage from Filter.
- getExpressionLineage(Join, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
-
Expression lineage from
Join
. - getExpressionLineage(Project, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
-
Expression lineage from Project.
- getExpressionLineage(Sample, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
-
Expression lineage from Sample.
- getExpressionLineage(Snapshot, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
-
Expression lineage from Snapshot.
- getExpressionLineage(Sort, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
-
Expression lineage from Sort.
- getExpressionLineage(TableModify, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
-
Expression lineage from TableModify.
- getExpressionLineage(TableScan, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
-
Expression lineage from
TableScan
. - getExpressionLineage(Union, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
-
Expression lineage from
Union
. - getExpressionLineage(RelNode, RelMetadataQuery, RexNode) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ExpressionLineage.Handler
- getExpressionLineage(RelNode, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
- getExpressionLineage(RelNode, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Determines the origin of a column.
- getExpressionLineage(RexNode) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ExpressionLineage
-
Given the input expression applied on the given
RelNode
, this provider returns the expression with its lineage resolved. - getExpressionList(String) - Method in interface org.apache.calcite.rel.RelInput
- getExprList() - Method in class org.apache.calcite.rex.RexProgram
-
Returns the common sub-expressions of this program.
- getExtendedColumnOffset() - Method in interface org.apache.calcite.schema.ExtensibleTable
-
Returns the starting offset of the first extended column, which may differ from the field count when the table stores metadata columns that are not counted in the row-type field count.
- getExtendedColumns(SqlValidator, SqlValidatorTable, SqlNodeList) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Gets a list of extended columns with field indices to the underlying table.
- getExtractionFn() - Method in class org.apache.calcite.adapter.druid.DefaultDimensionSpec
- getExtractionFn() - Method in interface org.apache.calcite.adapter.druid.DimensionSpec
- getExtractionFn() - Method in class org.apache.calcite.adapter.druid.ExtractionDimensionSpec
- getFactorsRefByFactor(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns a bitmap corresponding to the factors referenced by the specified factor in the various join filters that correspond to comparisons.
- getFactorsRefByJoinFilter(RexNode) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns a bitmap corresponding to the factors referenced within the specified join filter.
- getFactorTree() - Method in class org.apache.calcite.rel.rules.LoptJoinTree
- getFactorWeights() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns weights of the different factors relative to one another.
- getFactory() - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns the test factory.
- getFactoryClassName(UnregisteredDriver.JdbcVersion) - Method in class org.apache.calcite.jdbc.Driver
- getFactRowCount() - Method in class org.apache.calcite.materialize.Lattice
-
Returns an estimate of the number of rows in the un-aggregated star.
- getFailureCount() - Method in class org.apache.calcite.rex.RexChecker
-
Returns the number of failures encountered.
- getFamily() - Method in class org.apache.calcite.rel.type.DynamicRecordTypeImpl
- getFamily() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets a canonical object representing the family of this type.
- getFamily() - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- getFamily() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getFamily() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getFamily() - Method in class org.apache.calcite.sql.type.AbstractSqlType
- getFamily() - Method in class org.apache.calcite.sql.type.ArraySqlType
- getFamily() - Method in class org.apache.calcite.sql.type.FunctionSqlType
- getFamily() - Method in class org.apache.calcite.sql.type.MapSqlType
- getFamily() - Method in class org.apache.calcite.sql.type.MultisetSqlType
- getFamily() - Method in class org.apache.calcite.sql.type.ObjectSqlType
- getFamily() - Method in enum org.apache.calcite.sql.type.SqlTypeName
-
Gets the SqlTypeFamily containing this SqlTypeName.
- getFamilyForJdbcType(int) - Static method in enum org.apache.calcite.sql.type.SqlTypeFamily
-
Gets the primary family containing a JDBC type.
- getFetch() - Method in class org.apache.calcite.sql.SqlSelect
- getField() - Method in class org.apache.calcite.rex.RexFieldAccess
- getField(String, boolean, boolean) - Method in class org.apache.calcite.piglet.DynamicTupleRecordType
- getField(String, boolean, boolean) - Method in class org.apache.calcite.rel.type.DynamicRecordTypeImpl
- getField(String, boolean, boolean) - Method in interface org.apache.calcite.rel.type.RelDataType
-
Looks up a field by name.
- getField(String, boolean, boolean) - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getField(String, boolean, boolean) - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getFieldAccessList() - Method in class org.apache.calcite.rex.RexUtil.FieldAccessFinder
- getFieldCollations() - Method in interface org.apache.calcite.rel.RelCollation
-
Returns the ordinals and directions of the columns in this ordering.
- getFieldCollations() - Method in class org.apache.calcite.rel.RelCollationImpl
- getFieldCount() - Method in class org.apache.calcite.rel.type.DynamicRecordTypeImpl
- getFieldCount() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Returns the number of fields in a struct type.
- getFieldCount() - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Returns the number of fields.
- getFieldCount() - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfo
-
Deprecated.Returns the number of fields.
- getFieldCount() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getFieldCount() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getFieldIndex() - Method in class org.apache.calcite.rel.RelFieldCollation
- getFieldList() - Method in class org.apache.calcite.rel.type.DynamicRecordTypeImpl
- getFieldList() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets the fields in a struct type.
- getFieldList() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getFieldList() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getFieldMap() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
-
Returns a map from field names to fields.
- getFieldMap() - Method in class org.apache.calcite.rel.type.RelRecordType
- getFieldName() - Method in class org.apache.calcite.rel.core.Collect
-
Returns the name of the sole output field.
- getFieldName(int) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Returns the name of a given field.
- getFieldName(int) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfo
-
Deprecated.Returns the name of a given field.
- getFieldName(RelNode, int) - Method in class org.apache.calcite.adapter.pig.PigRel.Implementor
- getFieldNames() - Method in class org.apache.calcite.rel.type.DynamicRecordTypeImpl
- getFieldNames() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Returns the names of the fields in a struct type.
- getFieldNames() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getFieldNames() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getFieldNames() - Method in class org.apache.calcite.sql.SqlRowTypeNameSpec
- getFieldOrigins() - Method in class org.apache.calcite.prepare.Prepare.PreparedExplain
- getFieldOrigins() - Method in interface org.apache.calcite.prepare.Prepare.PreparedResult
-
Returns a list describing, for each result field, the origin of the field as a 4-element list of (database, schema, table, column).
- getFieldOrigins() - Method in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- getFieldOrigins(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns a description of how each field in the row type maps to a catalog, schema, table and column in the schema.
- getFieldOrigins(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getFields() - Method in class org.apache.calcite.adapter.redis.RedisTableFieldInfo
- getFields(int, int, int) - Method in class org.apache.calcite.piglet.PigRelBuilder
- getFieldsRefByJoinFilter(RexNode) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns a bitmap corresponding to the fields referenced by a join filter.
- getFieldsString(RelDataType) - Static method in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- getFieldType(int) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Returns the type of a given field.
- getFieldType(int) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfo
-
Deprecated.Returns the type of a given field.
- getFieldTypeList(RelDataType) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a list of the types of the fields in a given struct type.
- getFieldTypes() - Method in class org.apache.calcite.sql.SqlRowTypeNameSpec
- getFieldTypes(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.csv.CsvTable
-
Returns the field types of this CSV table.
- getFieldTypes(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.file.CsvTable
-
Returns the field types of this CSV table.
- getFileNames() - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- getFilePath() - Method in class org.apache.calcite.adapter.pig.PigTable
- getFileTimestamp() - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- getFilter(int) - Method in interface org.apache.calcite.sql.validate.SemanticTable
-
Returns the filter expression for
column
if it is amust-filter
column, or null if it is not a must-filter column. - getFilter(int) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MustFilterMockTable
- getFilters(RelBuilder) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Measure.Context
-
Returns a (conjunctive) list of filters.
- getFilters(RelBuilder) - Method in class org.apache.calcite.rel.metadata.RelMdMeasure.DelegatingContext
- getFlags() - Method in class org.apache.calcite.adapter.spark.SparkRules.SparkCalc
-
Deprecated.
- getFlags() - Method in class org.apache.calcite.rel.core.Project
-
Deprecated.
- getFloat() - Method in interface org.apache.calcite.linq4j.tree.Primitive.Source
- getFloat(String) - Method in interface org.apache.calcite.rel.RelInput
-
Returns a
float
value. - getFloorSqlFunction(TimeUnitRange) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule
-
Get floor function datetime.
- getForceIndexName() - Method in class org.apache.calcite.adapter.innodb.InnodbTableScan
- getFormat() - Method in class org.apache.calcite.adapter.druid.TimeExtractionFunction
- getFormat() - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Returns the format.
- getFormat() - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- getFormat() - Method in class org.apache.calcite.sql.SqlExplain
-
Returns the desired output format.
- getFormatModel() - Method in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
-
Returns a description of the format string used by functions in this dialect.
- getFormatModel() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns a description of the format string used by functions in this dialect.
- getFormatPattern(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- getFormatPatternLength() - Method in interface org.apache.calcite.util.format.postgresql.format.compiled.CompiledItem
-
Returns the length of the format pattern.
- getFormatPatternLength() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.CompiledPattern
- getFormatPatternLength() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.LiteralCompiledItem
- getFractionalSecondPrecision(RelDataTypeSystem) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- getFractionalSecondPrecisionPreservingDefault() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- getFrameRowCount() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResetContextImpl
- getFrameRowCount() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- getFrameRowCount() - Method in interface org.apache.calcite.adapter.enumerable.WinAggFrameContext
-
Returns the number of rows in the current frame (subject to framing clause).
- getFrom() - Method in class org.apache.calcite.sql.SqlSelect
- getFromNode(SqlSelect, int) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns the
n
th (0-based) input to a join expression. - getFromScope(SqlSelect) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns a scope containing the objects visible from the FROM clause of a query.
- getFromScope(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getFullTypeDifferenceString(String, RelDataType, String, RelDataType) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns the detailed difference of two types.
- getFullTypeString() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets a string representation of this type with full detail such as character set and nullability.
- getFullTypeString() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getFullTypeString() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getFullyQualifiedNames() - Method in class org.apache.calcite.sql.validate.SqlIdentifierMoniker
- getFullyQualifiedNames() - Method in interface org.apache.calcite.sql.validate.SqlMoniker
-
Returns the array of component names.
- getFullyQualifiedNames() - Method in class org.apache.calcite.sql.validate.SqlMonikerImpl
- getFunction() - Method in class org.apache.calcite.jdbc.CalciteSchema.FunctionEntry
- getFunction() - Method in class org.apache.calcite.jdbc.CalciteSchema.FunctionEntryImpl
- getFunction() - Method in class org.apache.calcite.linq4j.tree.FunctionExpression
- getFunction() - Method in class org.apache.calcite.rex.RexExecutable
- getFunction() - Method in class org.apache.calcite.sql.validate.SqlUserDefinedFunction
-
Returns function that implements given operator call.
- getFunction() - Method in class org.apache.calcite.sql.validate.SqlUserDefinedTableFunction
-
Returns function that implements given operator call.
- getFunctionKind() - Method in enum org.apache.calcite.sql.SqlKind
-
If this kind represents a non-standard function, return OTHER_FUNCTION, otherwise return this.
- getFunctionMultimap() - Method in class org.apache.calcite.adapter.java.ReflectiveSchema
- getFunctionMultimap() - Method in class org.apache.calcite.schema.impl.AbstractSchema
-
Returns a multi-map of functions in this schema by name.
- getFunctionNames() - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getFunctionNames() - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns the list of function names in this schema, both implicit and explicit, never null.
- getFunctionNames() - Method in class org.apache.calcite.schema.impl.AbstractSchema
- getFunctionNames() - Method in class org.apache.calcite.schema.impl.DelegatingSchema
- getFunctionNames() - Method in interface org.apache.calcite.schema.Schema
-
Returns the names of the functions in this schema.
- getFunctionQuantifier() - Method in class org.apache.calcite.sql.SqlBasicCall
- getFunctionQuantifier() - Method in class org.apache.calcite.sql.SqlCall
- getFunctions() - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getFunctions(String) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getFunctions(String) - Method in class org.apache.calcite.schema.impl.AbstractSchema
- getFunctions(String) - Method in class org.apache.calcite.schema.impl.DelegatingSchema
- getFunctions(String) - Method in interface org.apache.calcite.schema.Schema
-
Returns a list of functions in this schema with the given name, or an empty list if there is no such function.
- getFunctions(String, boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns a collection of all functions, explicit and implicit, with a given name.
- getFunctions(Meta.ConnectionHandle, String, Meta.Pat, Meta.Pat) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- getFunctionType() - Method in class org.apache.calcite.sql.SqlFunction
-
Return function category.
- getFuncType(Class...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a Type object that represents a generic System.Func delegate type that has specific type arguments.
- getGeneratedCode() - Method in interface org.apache.calcite.rel.metadata.janino.RelMetadataHandlerGeneratorUtil.HandlerNameAndGeneratedCode
- getGranularity() - Method in class org.apache.calcite.adapter.druid.TimeExtractionFunction
- getGroup() - Method in class org.apache.calcite.sql.SqlSelect
- getGroupCount() - Method in class org.apache.calcite.rel.core.Aggregate.AggCallBinding
- getGroupCount() - Method in class org.apache.calcite.rel.core.Aggregate
-
Returns the number of grouping fields.
- getGroupCount() - Method in class org.apache.calcite.sql.SqlCallBinding
- getGroupCount() - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
If the operator call occurs in an aggregate query, returns the number of columns in the GROUP BY clause.
- getGroupCount() - Method in interface org.apache.calcite.sql2rel.SqlRexContext
-
If the operator call occurs in an aggregate query, returns the number of columns in the GROUP BY clause.
- getGroupCount() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- getGroupScope(SqlSelect) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns a scope containing the objects visible from the GROUP BY clause of a query.
- getGroupScope(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getGroupSet() - Method in class org.apache.calcite.rel.core.Aggregate
-
Returns a bit set of the grouping fields.
- getGroupSets() - Method in class org.apache.calcite.rel.core.Aggregate
-
Returns the list of grouping sets computed by this Aggregate.
- getGroupType() - Method in class org.apache.calcite.rel.core.Aggregate
-
Returns the type of roll-up.
- getGroupType() - Method in class org.apache.calcite.rel.mutable.MutableAggregate
- getGuavaMajorVersion() - Static method in class org.apache.calcite.util.TestUtil
-
Returns the Guava major version.
- getHandlerName() - Method in interface org.apache.calcite.rel.metadata.janino.RelMetadataHandlerGeneratorUtil.HandlerNameAndGeneratedCode
- getHaving() - Method in class org.apache.calcite.sql.SqlSelect
- getHavingScope(SqlSelect) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns a scope containing the objects visible from the HAVING clause of a query.
- getHavingScope(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getHints() - Method in class org.apache.calcite.rel.core.Aggregate
- getHints() - Method in class org.apache.calcite.rel.core.Calc
- getHints() - Method in class org.apache.calcite.rel.core.Correlate
- getHints() - Method in class org.apache.calcite.rel.core.Filter
- getHints() - Method in class org.apache.calcite.rel.core.Join
- getHints() - Method in class org.apache.calcite.rel.core.Project
- getHints() - Method in class org.apache.calcite.rel.core.SetOp
- getHints() - Method in class org.apache.calcite.rel.core.Snapshot
- getHints() - Method in class org.apache.calcite.rel.core.Sort
- getHints() - Method in class org.apache.calcite.rel.core.TableFunctionScan
- getHints() - Method in class org.apache.calcite.rel.core.TableScan
- getHints() - Method in class org.apache.calcite.rel.core.Values
- getHints() - Method in class org.apache.calcite.rel.core.Window
- getHints() - Method in interface org.apache.calcite.rel.hint.Hintable
-
Returns the hints of this relational expressions as an immutable list.
- getHints() - Method in class org.apache.calcite.sql.SqlSelect
- getHintStrategies() - Method in class org.apache.calcite.plan.RelOptCluster
-
Returns the hint strategies of this cluster.
- getHintStrategyTable() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns the hint strategies used to decide how the hints are propagated to the relational expressions.
- getHost() - Method in class org.apache.calcite.adapter.redis.RedisConfig
- getId() - Method in interface org.apache.calcite.plan.RelOptNode
-
Returns the ID of this relational expression, unique among all relational expressions created since the server was started.
- getId() - Method in class org.apache.calcite.rel.AbstractRelNode
- getId() - Method in class org.apache.calcite.rel.core.CorrelationId
-
Returns the identifier.
- getId() - Method in class org.apache.calcite.rel.rules.LoptJoinTree.Leaf
-
Returns the id associated with a leaf node in a binary tree.
- getId() - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- getIdentifier() - Method in class org.apache.calcite.rex.RexTableInputRef
- getIdentifierQuoteString() - Method in class org.apache.calcite.sql.SqlUtil.DatabaseMetaDataInvocationHandler
- getIgnorePcdata() - Method in class org.apache.calcite.util.XmlOutput
- getImplementor() - Method in class org.apache.calcite.schema.impl.ScalarFunctionImpl
- getImplementor() - Method in class org.apache.calcite.schema.impl.TableFunctionImpl
- getImplementor() - Method in interface org.apache.calcite.schema.ImplementableFunction
-
Returns implementor that translates the function to linq4j expression.
- getImplementor() - Method in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction
- getImplementor() - Method in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction2
- getImplementor(boolean) - Method in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- getImplementor(boolean) - Method in interface org.apache.calcite.schema.ImplementableAggFunction
-
Returns implementor that translates the function to linq4j expression.
- getImplicitCollation() - Method in class org.apache.calcite.adapter.cassandra.CassandraFilter
-
Get the resulting collation by the clustering keys after filtering.
- getImplicitCollation() - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- getImplicitCollation() - Method in class org.apache.calcite.adapter.innodb.InnodbFilter
-
Returns the resulting collation by the primary or secondary indexes after filtering.
- getImplicitCollation() - Method in class org.apache.calcite.adapter.innodb.InnodbTableScan
-
Infer the implicit collation from index.
- getImplicitSubSchema(String, boolean) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- getImplicitSubSchema(String, boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns a sub-schema with a given name that is defined implicitly (that is, by the underlying
Schema
object, not explicitly by a call toCalciteSchema.add(String, Schema)
), or null. - getImplicitTable(String, boolean) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- getImplicitTable(String, boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns a table with a given name that is defined implicitly (that is, by the underlying
Schema
object, not explicitly by a call toCalciteSchema.add(String, Table)
), or null. - getImplicitTableBasedOnNullaryFunction(String, boolean) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- getImplicitTableBasedOnNullaryFunction(String, boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns table function with a given name and zero arguments that is defined implicitly (that is, by the underlying
Schema
object, not explicitly by a call toCalciteSchema.add(String, Function)
), or null. - getImplicitType(String, boolean) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- getImplicitType(String, boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns a type with a given name that is defined implicitly (that is, by the underlying
Schema
object, not explicitly by a call toCalciteSchema.add(String, RelProtoDataType)
), or null. - getIndentation() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- getIndentation() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- getIndentation() - Method in interface org.apache.calcite.sql.SqlWriter
-
Returns the offset for each level of indentation.
- getIndex() - Method in interface org.apache.calcite.rel.type.RelDataTypeField
-
Gets the ordinal of this field within its containing type.
- getIndex() - Method in class org.apache.calcite.rel.type.RelDataTypeFieldImpl
- getIndex() - Method in class org.apache.calcite.rex.RexDynamicParam
- getIndex() - Method in class org.apache.calcite.rex.RexSlot
- getIndex() - Method in class org.apache.calcite.sql.SqlDynamicParam
- getIndexesNameSet() - Method in class org.apache.calcite.adapter.innodb.InnodbTable
-
Get index name set.
- getIndexName() - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- getIndexToFieldMap(List<RelDataTypeField>, RelDataType) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Gets a map of indexes from the source to fields in the target for the intersecting set of source and target fields.
- getIndicatorCount() - Method in class org.apache.calcite.rel.core.Aggregate
-
Deprecated.
- getInfo() - Method in enum org.apache.calcite.adapter.os.OsQueryType
- getInitializerExpressionFactory() - Method in interface org.apache.calcite.sql2rel.SqlRexContext
-
Returns the factory which supplies default values for INSERT, UPDATE, and NEW.
- getInitializerExpressionFactory() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- getInput() - Method in interface org.apache.calcite.rel.convert.Converter
-
Returns the sole input relational expression.
- getInput() - Method in class org.apache.calcite.rel.mutable.MutableSort
- getInput() - Method in interface org.apache.calcite.rel.RelInput
-
Returns the input relational expression.
- getInput() - Method in class org.apache.calcite.rel.SingleRel
- getInput(int) - Method in class org.apache.calcite.rel.AbstractRelNode
- getInput(int) - Method in interface org.apache.calcite.rel.RelNode
-
Returns the
i
th input relational expression. - getInputRowType() - Method in class org.apache.calcite.rex.RexProgram
-
Returns the type of the input row to the program.
- getInputRowType() - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Returns the row type of the input to the program.
- getInputs() - Method in interface org.apache.calcite.plan.RelOptNode
-
Returns an array of this relational expression's inputs.
- getInputs() - Method in class org.apache.calcite.rel.AbstractRelNode
- getInputs() - Method in class org.apache.calcite.rel.BiRel
- getInputs() - Method in class org.apache.calcite.rel.core.SetOp
- getInputs() - Method in class org.apache.calcite.rel.core.TableFunctionScan
- getInputs() - Method in class org.apache.calcite.rel.mutable.MutableJoin
- getInputs() - Method in class org.apache.calcite.rel.mutable.MutableScan
- getInputs() - Method in class org.apache.calcite.rel.mutable.MutableUnion
- getInputs() - Method in class org.apache.calcite.rel.mutable.MutableRel
- getInputs() - Method in class org.apache.calcite.rel.mutable.MutableSort
- getInputs() - Method in interface org.apache.calcite.rel.RelInput
- getInputs() - Method in interface org.apache.calcite.rel.RelNode
-
Returns an array of this relational expression's inputs.
- getInputs() - Method in class org.apache.calcite.rel.rules.MultiJoin
- getInputs() - Method in class org.apache.calcite.rel.SingleRel
- getInputTraits() - Method in interface org.apache.calcite.rel.convert.Converter
-
Returns the trait of the input relational expression.
- getInputTraits() - Method in class org.apache.calcite.rel.convert.ConverterImpl
- getInsertCall() - Method in class org.apache.calcite.sql.SqlMerge
-
Returns the INSERT statement for this MERGE.
- getInstance() - Static method in class org.apache.calcite.util.UnsafeX509ExtendedTrustManager
- getInSubqueryThreshold() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Deprecated.
- getInSubQueryThreshold() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns the
inSubQueryThreshold
option, defaultSqlToRelConverter.DEFAULT_IN_SUB_QUERY_THRESHOLD
. - getInt() - Method in interface org.apache.calcite.linq4j.tree.Primitive.Source
- getInt(int) - Method in class org.apache.calcite.util.ImmutableIntList
- getIntegerList(String) - Method in interface org.apache.calcite.rel.RelInput
- getIntegerListList(String) - Method in interface org.apache.calcite.rel.RelInput
- getInterface() - Method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- getInterface() - Method in enum org.apache.calcite.interpreter.BindableConvention
- getInterface() - Method in enum org.apache.calcite.interpreter.InterpretableConvention
- getInterface() - Method in interface org.apache.calcite.plan.Convention
- getInterface() - Method in class org.apache.calcite.plan.Convention.Impl
- getInterfaceAddressesInfo() - Static method in class org.apache.calcite.adapter.utils.OsQueryTableUtil
- getInterfaceDetailsInfo() - Static method in class org.apache.calcite.adapter.utils.OsQueryTableUtil
- getInterval() - Method in class org.apache.calcite.rel.core.Match
- getInterval() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getIntervalLiteral() - Method in class org.apache.calcite.sql.SqlIntervalLiteral.IntervalValue
- getIntervalQualifier() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets this type's interval qualifier, or null if this is not an interval type.
- getIntervalQualifier() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getIntervalQualifier() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getIntervalQualifier() - Method in class org.apache.calcite.sql.SqlIntervalLiteral.IntervalValue
- getIntervalQualifier() - Method in class org.apache.calcite.sql.type.IntervalSqlType
- getIntervalSign(String) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Returns 1 or -1.
- getIntLiteralOperand(int) - Method in class org.apache.calcite.rex.RexCallBinding
- getIntLiteralOperand(int) - Method in class org.apache.calcite.sql.SqlCallBinding
- getIntLiteralOperand(int) - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Deprecated.
- getInTrait() - Method in class org.apache.calcite.rel.convert.ConverterRule
- getInvoke(RelNode, boolean, RelNode) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- getInwardEdges(V) - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- getInwardEdges(V) - Method in interface org.apache.calcite.util.graph.DirectedGraph
- getIo() - Method in interface org.apache.calcite.plan.RelOptCost
-
Returns usage of I/O resources.
- getIo() - Method in class org.apache.calcite.plan.RelOptCostImpl
- getIPAddressesString(String[]) - Static method in class org.apache.calcite.adapter.utils.OsQueryTableUtil
- getIterativeRel() - Method in class org.apache.calcite.rel.core.RepeatUnion
- getJavaClass() - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- getJavaClass(RelDataType) - Method in interface org.apache.calcite.adapter.java.JavaTypeFactory
- getJavaClass(RelDataType) - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl
- getJavaFieldType(int) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Returns the Java class that is used to store the field with the given ordinal.
- getJavaFieldType(int) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- getJavaInfo() - Static method in class org.apache.calcite.adapter.utils.OsQueryTableUtil
- getJavaMajorVersion() - Static method in class org.apache.calcite.util.TestUtil
-
Returns the Java major version: 7 for JDK 1.7, 8 for JDK 8, 10 for JDK 10, etc.
- getJavaRowType() - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Returns the Java type (often a Class) that represents a row.
- getJavaRowType() - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- getJavaVirtualMachineVendor() - Static method in class org.apache.calcite.util.TestUtil
-
Returns the JVM vendor.
- getJdbcMajorVersion() - Method in class org.apache.calcite.jdbc.CalciteFactory
- getJdbcMinorVersion() - Method in class org.apache.calcite.jdbc.CalciteFactory
- getJdbcOrdinal() - Method in enum org.apache.calcite.sql.type.SqlTypeName
-
Returns the ordinal from
Types
corresponding to this SqlTypeName. - getJdbcTableType() - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- getJdbcTableType() - Method in class org.apache.calcite.adapter.kafka.KafkaStreamTable
- getJdbcTableType() - Method in class org.apache.calcite.schema.impl.AbstractTable
- getJdbcTableType() - Method in class org.apache.calcite.schema.impl.StarTable
- getJdbcTableType() - Method in class org.apache.calcite.schema.impl.ViewTable
- getJdbcTableType() - Method in interface org.apache.calcite.schema.Table
-
Type of table.
- getJdbcTableType() - Method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions.ExplodeTable
- getJdbcTableType() - Method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions.GridTable
- getJdbcTableType() - Method in class org.apache.calcite.test.schemata.orderstream.BaseOrderStreamTable
- getJdbcTableType() - Method in class org.apache.calcite.test.schemata.orderstream.ProductsTable
- getJdbcTableType() - Method in class org.apache.calcite.test.schemata.orderstream.ProductsTemporalTable
- getJedisPool() - Method in class org.apache.calcite.adapter.redis.RedisJedisManager
- getJoinDistinctRowCount(RelMetadataQuery, RelNode, JoinRelType, ImmutableBitSet, RexNode, boolean) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Computes the number of distinct rows for a set of keys returned from a join.
- getJoinFactor(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns the factor corresponding to the given factor index.
- getJoinFieldRefCounts(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns the join field reference counts for a factor.
- getJoinFieldRefCountsMap() - Method in class org.apache.calcite.rel.rules.MultiJoin
-
Returns the map of reference counts for each input, representing the fields accessed in join conditions.
- getJoinFields(LoptJoinTree, LoptJoinTree) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Retrieves the fields corresponding to a join between a left and right tree.
- getJoinFilter() - Method in class org.apache.calcite.rel.rules.MultiJoin
-
Returns join filters associated with this MultiJoin.
- getJoinFilters() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns all non-outer join filters in this multi-join.
- getJoinPopulationSize(RelMetadataQuery, RelNode, ImmutableBitSet) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Computes the population size for a set of keys returned from a join.
- getJoinRemovalFactor(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns the factor id of the fact table corresponding to a dimension table in a semi-join, in the case where the join with the dimension table can be removed.
- getJoinRemovalSemiJoin(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns the semi-join that allows the join of a dimension table to be removed.
- getJoinRowCount(RelMetadataQuery, Join, RexNode) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Returns an estimate of the number of rows returned by a
Join
. - getJoinScope(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns a scope containing the objects visible from the ON and USING sections of a JOIN clause.
- getJoinScope(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getJoinStart(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns the starting offset within the multi-join for the specified factor.
- getJoinTree() - Method in class org.apache.calcite.rel.rules.LoptJoinTree
- getJoinType() - Method in class org.apache.calcite.rel.core.Correlate
- getJoinType() - Method in class org.apache.calcite.rel.core.Join
- getJoinType() - Method in class org.apache.calcite.sql.SqlJoin
-
Returns a
JoinType
, never null. - getJoinTypeNode() - Method in class org.apache.calcite.sql.SqlJoin
- getJoinTypes() - Method in class org.apache.calcite.rel.rules.MultiJoin
-
Returns join types of each input.
- getJsonStringResult() - Method in class org.apache.calcite.plan.visualizer.RuleMatchVisualizer
- getKey() - Method in interface org.apache.calcite.linq4j.Grouping
-
Gets the key of this Grouping.
- getKey() - Method in class org.apache.calcite.linq4j.Ord
- getKey() - Method in class org.apache.calcite.rel.type.RelDataTypeFieldImpl
- getKey() - Method in class org.apache.calcite.runtime.MapEntry
- getKey() - Method in class org.apache.calcite.util.Pair
- getKeyDelimiter() - Method in class org.apache.calcite.adapter.redis.RedisTableFieldInfo
- getKeys() - Method in class org.apache.calcite.plan.RelOptAbstractTable
- getKeys() - Method in interface org.apache.calcite.plan.RelOptTable
-
Returns a list of unique keys, empty list if no key exist, the result should be consistent with
isKey
. - getKeys() - Method in class org.apache.calcite.prepare.RelOptTableImpl
- getKeys() - Method in interface org.apache.calcite.rel.RelCollation
-
Returns the ordinals of the key columns.
- getKeys() - Method in interface org.apache.calcite.rel.RelDistribution
-
Returns the ordinals of the key columns.
- getKeys() - Method in interface org.apache.calcite.schema.Statistic
-
Returns a list of unique keys, or null if no key exist.
- getKeys() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getKeyType() - Method in class org.apache.calcite.linq4j.tree.Types.MapType
-
Returns the type of keys.
- getKeyType() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets the key type if this type is a map, otherwise null.
- getKeyType() - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
-
For
RelDataTypeFactoryImpl.JavaType
created withMap
class, we cannot get the key type. - getKeyType() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getKeyType() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getKeyType() - Method in class org.apache.calcite.sql.SqlMapTypeNameSpec
- getKeyType() - Method in class org.apache.calcite.sql.type.MapSqlType
- getKeyTypeOrThrow(RelDataType) - Static method in class org.apache.calcite.sql.type.NonNullableAccessors
- getKind() - Method in class org.apache.calcite.rex.RexCall
- getKind() - Method in class org.apache.calcite.rex.RexCorrelVariable
- getKind() - Method in class org.apache.calcite.rex.RexDynamicParam
- getKind() - Method in class org.apache.calcite.rex.RexFieldAccess
- getKind() - Method in class org.apache.calcite.rex.RexInputRef
- getKind() - Method in class org.apache.calcite.rex.RexLambda
- getKind() - Method in class org.apache.calcite.rex.RexLambdaRef
- getKind() - Method in class org.apache.calcite.rex.RexLiteral
- getKind() - Method in class org.apache.calcite.rex.RexLocalRef
- getKind() - Method in class org.apache.calcite.rex.RexNode
-
Returns the kind of node this is.
- getKind() - Method in class org.apache.calcite.rex.RexPatternFieldRef
- getKind() - Method in class org.apache.calcite.rex.RexTableInputRef
- getKind() - Method in class org.apache.calcite.sql.fun.SqlCase
- getKind() - Method in class org.apache.calcite.sql.SqlBasicCall
- getKind() - Method in class org.apache.calcite.sql.SqlCall
- getKind() - Method in class org.apache.calcite.sql.SqlDelete
- getKind() - Method in class org.apache.calcite.sql.SqlDynamicParam
- getKind() - Method in class org.apache.calcite.sql.SqlExplain
- getKind() - Method in class org.apache.calcite.sql.SqlIdentifier
- getKind() - Method in class org.apache.calcite.sql.SqlInsert
- getKind() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- getKind() - Method in class org.apache.calcite.sql.SqlJoin
- getKind() - Method in class org.apache.calcite.sql.SqlLambda
- getKind() - Method in class org.apache.calcite.sql.SqlLiteral
- getKind() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getKind() - Method in class org.apache.calcite.sql.SqlMerge
- getKind() - Method in class org.apache.calcite.sql.SqlNode
-
Returns the type of node this is, or
SqlKind.OTHER
if it's nothing special. - getKind() - Method in class org.apache.calcite.sql.SqlOperator
- getKind() - Method in class org.apache.calcite.sql.SqlOrderBy
- getKind() - Method in class org.apache.calcite.sql.SqlSelect
- getKind() - Method in class org.apache.calcite.sql.SqlSetOption
- getKind() - Method in class org.apache.calcite.sql.SqlUpdate
- getKind() - Method in class org.apache.calcite.sql.SqlWindow
- getKind() - Method in class org.apache.calcite.sql.SqlWith
- getKind() - Method in class org.apache.calcite.sql.SqlWithItem
- getKind() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getLambdaScope(SqlLambda) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the lambda expression scope.
- getLambdaScope(SqlLambda) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getLattice() - Method in class org.apache.calcite.jdbc.CalciteSchema.LatticeEntry
- getLattice() - Method in class org.apache.calcite.jdbc.CalciteSchema.LatticeEntryImpl
- getLattice(RelOptTable) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- getLattice(RelOptTable) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Retrieves a lattice, given its star table.
- getLattice(RelOptTable) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- getLatticeEntries(CalciteSchema) - Static method in class org.apache.calcite.schema.Schemas
-
Returns the lattices defined in a schema.
- getLatticeMap() - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns a collection of lattices.
- getLattices() - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- getLattices() - Method in class org.apache.calcite.prepare.Prepare
- getLattices(CalciteSchema) - Static method in class org.apache.calcite.schema.Schemas
-
Returns the lattices defined in a schema.
- getLatticeSet() - Method in class org.apache.calcite.materialize.LatticeSuggester
-
Returns the minimal set of lattices necessary to cover all of the queries seen.
- getLeft() - Method in class org.apache.calcite.rel.BiRel
- getLeft() - Method in class org.apache.calcite.rel.mutable.MutableJoin
- getLeft() - Method in class org.apache.calcite.rel.rules.LoptJoinTree
- getLeft() - Method in class org.apache.calcite.rel.rules.LoptJoinTree.Node
- getLeft() - Method in enum org.apache.calcite.sql.fun.SqlTrimFunction.Flag
- getLeft() - Method in class org.apache.calcite.sql.SqlJoin
- getLeftKeys() - Method in class org.apache.calcite.rel.core.EquiJoin
-
Deprecated.
- getLeftPrec() - Method in class org.apache.calcite.sql.SqlOperator
- getLimit(boolean, SqlTypeName.Limit, boolean) - Method in class org.apache.calcite.sql.type.BasicSqlType
-
Returns a value which is a limit for this type.
- getLimit(boolean, SqlTypeName.Limit, boolean, int, int) - Method in enum org.apache.calcite.sql.type.SqlTypeName
-
Returns the limit of this datatype.
- getLineLength() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- getLineLength() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- getLineNum() - Method in class org.apache.calcite.sql.parser.SqlParserPos
-
Returns 1-based starting line number.
- getList() - Method in class org.apache.calcite.sql.SqlNodeList
- getListener() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- getLiteral(SqlTypeName, boolean) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- getLiteral(SqlTypeName, boolean) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns the LITERAL string for the type, either PREFIX/SUFFIX.
- getLiteral(SqlTypeName, boolean) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- getLocalDateString() - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
- getLocale() - Method in class org.apache.calcite.sql.parser.SqlParserUtil.ParsedCollation
- getLocale() - Method in class org.apache.calcite.sql.SqlCollation
- getLocalTimestampString() - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
- getLocalTimeString() - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
- getLocalTimeString() - Method in class org.apache.calcite.util.TimeWithTimeZoneString
- getLogger() - Method in class org.apache.calcite.util.trace.CalciteLogger
- getLogicalSourceRowType(RelDataType, SqlInsert) - Method in class org.apache.calcite.prepare.CalciteSqlValidator
- getLogicalSourceRowType(RelDataType, SqlInsert) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getLogicalTargetRowType(RelDataType, SqlInsert) - Method in class org.apache.calcite.prepare.CalciteSqlValidator
- getLogicalTargetRowType(RelDataType, SqlInsert) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getLong() - Method in interface org.apache.calcite.linq4j.tree.Primitive.Source
- getLookupCall() - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall
- getLowerBound() - Method in class org.apache.calcite.rex.RexWindow
- getLowerBound() - Method in class org.apache.calcite.sql.SqlWindow
- getLowerBound(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Gets the lower bound cost of a relational operator.
- getLowerBoundCost(RelSubset, RelMetadataQuery, VolcanoPlanner) - Method in class org.apache.calcite.rel.metadata.RelMdLowerBoundCost
- getLowerBoundCost(VolcanoPlanner) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.LowerBoundCost
-
Returns the lower bound cost of a RelNode.
- getLowerBoundCost(RelNode, VolcanoPlanner) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the lower bound cost of a RelNode.
- getLowerBoundCost(RelNode, RelMetadataQuery, VolcanoPlanner) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.LowerBoundCost.Handler
- getLowerBoundCost(RelNode, RelMetadataQuery, VolcanoPlanner) - Method in class org.apache.calcite.rel.metadata.RelMdLowerBoundCost
- getMapConvertedNonCorrSubqs() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Returns the mapping of non-correlated sub-queries that have been converted to the constants that they evaluate to.
- getMapCorToCorRel() - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMap
- getMapping() - Method in class org.apache.calcite.rel.core.Project
-
Returns a mapping, or null if this projection is not a mapping.
- getMapping() - Method in class org.apache.calcite.rel.mutable.MutableProject
- getMapping(int, List<? extends RexNode>) - Static method in class org.apache.calcite.rel.core.Project
-
Returns a mapping of a set of project expressions.
- getMappingType() - Method in class org.apache.calcite.util.mapping.AbstractSourceMapping
- getMappingType() - Method in class org.apache.calcite.util.mapping.AbstractTargetMapping
- getMappingType() - Method in interface org.apache.calcite.util.mapping.Mapping
- getMappingType() - Method in interface org.apache.calcite.util.mapping.Mappings.CoreMapping
-
Returns the mapping type.
- getMappingType() - Method in interface org.apache.calcite.util.mapping.Mappings.FunctionMapping
- getMappingType() - Method in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
- getMappingType() - Method in class org.apache.calcite.util.mapping.Mappings.OverridingSourceMapping
- getMappingType() - Method in class org.apache.calcite.util.mapping.Mappings.OverridingTargetMapping
- getMappingType() - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- getMappingType() - Method in interface org.apache.calcite.util.mapping.Mappings.SourceMapping
- getMappingType() - Method in class org.apache.calcite.util.Permutation
- getMatchCondition() - Method in class org.apache.calcite.rel.core.AsofJoin
- getMatchCondition() - Method in class org.apache.calcite.sql.SqlAsofJoin
-
The match condition of the ASOF JOIN.
- getMatchCondition(SqlAsofJoin) - Static method in class org.apache.calcite.sql.validate.SqlNonNullableAccessors
- getMatchedClass() - Method in class org.apache.calcite.plan.RelOptRuleOperand
-
Returns relational expression class matched by this operand.
- getMatchRecognize() - Method in class org.apache.calcite.sql.validate.MatchRecognizeScope
- getMatchRecognizeScope(SqlMatchRecognize) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns a scope match recognize clause.
- getMatchRecognizeScope(SqlMatchRecognize) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getMaterializations() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- getMaterializations() - Method in class org.apache.calcite.plan.hep.HepPlanner
- getMaterializations() - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Returns the materializations that have been registered with the planner.
- getMaterializations() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- getMaterializations() - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- getMaterializations() - Method in class org.apache.calcite.prepare.Prepare
- getMax() - Method in interface org.apache.calcite.sql.SqlOperandCountRange
-
Returns an upper bound.
- getMaxByteSize(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Computes the maximum number of bytes required to represent a value of a type having user-defined precision.
- getMaxNumericPrecision() - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- getMaxNumericPrecision() - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Deprecated.Replaced by
RelDataTypeSystem.getMaxScale(org.apache.calcite.sql.type.SqlTypeName)
(DECIMAL).From Calcite release 1.38 onwards, instead of calling this method, you should call
getMaxPrecision(DECIMAL)
.In Calcite release 1.38, if you wish to change the maximum precision of
SqlTypeName.DECIMAL
values, you should do two things:- Override the
RelDataTypeSystem.getMaxPrecision(SqlTypeName)
method, changing its behavior forDECIMAL
; - Make sure that the implementation of your
#getMaxNumericPrecision
method callsgetMaxPrecision(DECIMAL)
.
In Calcite release 1.39, Calcite will cease calling this method, and will remove the override of the method in
RelDataTypeSystemImpl
. You should remove all calls to and overrides of this method. - Override the
- getMaxNumericPrecision() - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- getMaxNumericScale() - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- getMaxNumericScale() - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Deprecated.Replaced by
RelDataTypeSystem.getMaxScale(org.apache.calcite.sql.type.SqlTypeName)
(DECIMAL).From Calcite release 1.38 onwards, instead of calling this method, you should call
getMaxScale(DECIMAL)
.In Calcite release 1.38, if you wish to change the maximum scale of
SqlTypeName.DECIMAL
values, you should do two things:- Override the
RelDataTypeSystem.getMaxScale(SqlTypeName)
method, changing its behavior forDECIMAL
; - Make sure that the implementation of your
#getMaxNumericScale
method callsgetMaxScale(DECIMAL)
.
In Calcite release 1.39, Calcite will cease calling this method, and will remove the override of the method in
RelDataTypeSystemImpl
. You should remove all calls to and overrides of this method. - Override the
- getMaxNumericScale() - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- getMaxPrecision(SqlTypeName) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- getMaxPrecision(SqlTypeName) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns the maximum precision (or length) allowed for this type, or
RelDataType.PRECISION_NOT_SPECIFIED
if precision/length are not applicable for this type. - getMaxPrecision(SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- getMaxPrecisionScaleDecimal(RelDataTypeFactory) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns a DECIMAL type with the maximum precision for the current type system.
- getMaxRowCount() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.MaxRowCount
-
Estimates the max number of rows which will be returned by a relational expression.
- getMaxRowCount(EnumerableLimit, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(RelSubset, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(Aggregate, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(Calc, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(Exchange, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(Filter, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(Intersect, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(Join, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(Minus, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(Project, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(Sample, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(Sort, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(TableModify, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(Union, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(Values, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.MaxRowCount.getMaxRowCount()
statistic. - getMaxRowCount(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.MaxRowCount.Handler
- getMaxRowCount(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- getMaxRowCount(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getMaxScale(SqlTypeName) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- getMaxScale(SqlTypeName) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns the maximum scale allowed for this type, or
RelDataType.SCALE_NOT_SPECIFIED
if scale is not applicable for this type. - getMaxScale(SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- getMaxUnscaled(int) - Static method in class org.apache.calcite.util.NumberUtil
- getMaxValue(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns the maximum unscaled value of a numeric type.
- getMeasure(SqlNode) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Returns the measure expression if a select item is a measure, null otherwise.
- getMeasureElementType() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets the element type if this type is a measure, otherwise null.
- getMeasureElementType() - Method in class org.apache.calcite.sql.type.MeasureSqlType
- getMeasureList() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getMeasures() - Method in class org.apache.calcite.rel.core.Match
- getMeasureScope(SqlSelect) - Method in interface org.apache.calcite.sql.validate.SqlValidator
- getMeasureScope(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getMemoryInfo() - Static method in class org.apache.calcite.adapter.utils.OsQueryTableUtil
- getMergeAggFunctionOfTopSplit() - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.AbstractSumSplitter
- getMergeAggFunctionOfTopSplit() - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.Sum0Splitter
- getMergeAggFunctionOfTopSplit() - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.SumSplitter
- getMessage() - Method in exception class org.apache.calcite.runtime.CalciteContextException
- getMessage() - Method in class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
-
Returns the error message.
- getMessages(Throwable) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- getMetaColumnClass() - Method in interface org.apache.calcite.jdbc.CalciteMetaColumnFactory
-
Returns the type of object created.
- getMetaColumnClass() - Method in class org.apache.calcite.jdbc.CalciteMetaColumnFactoryImpl
- getMetadata() - Method in class org.apache.calcite.sql.parser.SqlParser
-
Get the parser metadata.
- getMetadataDelegateRel() - Method in class org.apache.calcite.plan.hep.HepRelVertex
-
Returns
RelNode
for metadata. - getMetadataDelegateRel() - Method in interface org.apache.calcite.rel.metadata.DelegatingMetadataRel
- getMetadataFactory() - Method in class org.apache.calcite.plan.RelOptCluster
-
Deprecated.
- getMetadataProvider() - Method in class org.apache.calcite.plan.RelOptCluster
- getMetadataQuery() - Method in class org.apache.calcite.plan.RelOptCluster
-
Returns the current RelMetadataQuery.
- getMetadataQuery() - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Returns the current RelMetadataQuery to be used for instance by
RelOptRule.onMatch(RelOptRuleCall)
. - getMetadataQuerySupplier() - Method in class org.apache.calcite.plan.RelOptCluster
-
Returns the supplier of RelMetadataQuery.
- getMetaTableClass() - Method in interface org.apache.calcite.jdbc.CalciteMetaTableFactory
-
Returns the type of object created.
- getMetaTableClass() - Method in class org.apache.calcite.jdbc.CalciteMetaTableFactoryImpl
- getMethod(String, String, Class...) - Static method in class org.apache.calcite.linq4j.Linq4j
- getMethodName() - Method in enum org.apache.calcite.util.BuiltInMethod
- getMetricName() - Method in class org.apache.calcite.adapter.druid.ComplexMetric
- getMetricType() - Method in class org.apache.calcite.adapter.druid.ComplexMetric
- getMillisOfDay() - Method in class org.apache.calcite.util.TimeString
- getMillisSinceEpoch() - Method in class org.apache.calcite.util.DateString
-
Returns the number of milliseconds since the epoch.
- getMillisSinceEpoch() - Method in class org.apache.calcite.util.TimestampString
-
Returns the number of milliseconds since the epoch.
- getMin() - Method in interface org.apache.calcite.sql.SqlOperandCountRange
-
Returns an lower bound.
- getMinMaxKind() - Method in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
-
Deprecated.
- getMinPrecision() - Method in enum org.apache.calcite.sql.type.SqlTypeName
-
Deprecated.
- getMinPrecision(SqlTypeName) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- getMinPrecision(SqlTypeName) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns the minimum precision (or length) allowed for this type, or
RelDataType.PRECISION_NOT_SPECIFIED
if precision/length are not applicable for this type. - getMinPrecision(SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
-
Returns the minimum precision (or length) allowed for this type, or
RelDataType.PRECISION_NOT_SPECIFIED
if precision/length are not applicable for this type. - getMinRowCount() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.MinRowCount
-
Estimates the minimum number of rows which will be returned by a relational expression.
- getMinRowCount(EnumerableLimit, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(RelSubset, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(Aggregate, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(Calc, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(Exchange, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(Filter, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(Intersect, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(Join, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(Minus, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(Project, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(Sample, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(Sort, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(TableModify, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(Union, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(Values, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinRowCount(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.MinRowCount.getMinRowCount()
statistic. - getMinRowCount(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.MinRowCount.Handler
- getMinRowCount(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- getMinScale() - Method in enum org.apache.calcite.sql.type.SqlTypeName
-
Deprecated.Use
RelDataTypeSystem.getMinScale(SqlTypeName)
but return Integer.MIN_VALUE if scale is unsupported. - getMinScale(SqlTypeName) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- getMinScale(SqlTypeName) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns the minimum scale allowed for this type, or
RelDataType.SCALE_NOT_SPECIFIED
if scale are not applicable for this type. - getMinScale(SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
-
Returns the minimum scale (or fractional second precision in the case of intervals) allowed for this type, or
RelDataType.SCALE_NOT_SPECIFIED
if precision/length are not applicable for this type. - getMinUnscaled(int) - Static method in class org.apache.calcite.util.NumberUtil
- getMinusRowCount(RelMetadataQuery, Minus) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Returns an estimate of the number of rows returned by a
Minus
. - getMinValue(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns the minimum unscaled value of a numeric type.
- getModality() - Method in class org.apache.calcite.sql.fun.SqlCollectionTableOperator
- getModifiableCollection() - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- getModifiableCollection() - Method in class org.apache.calcite.schema.impl.ListTransientTable
- getModifiableCollection() - Method in interface org.apache.calcite.schema.ModifiableTable
-
Returns the modifiable collection.
- getModifierNode(SqlInsertKeyword) - Method in class org.apache.calcite.sql.SqlInsert
- getModifierNode(SqlSelectKeyword) - Method in class org.apache.calcite.sql.SqlSelect
- getModifiers() - Method in class org.apache.calcite.linq4j.tree.ArrayLengthRecordField
- getModifiers() - Method in interface org.apache.calcite.linq4j.tree.PseudoField
- getModifiers() - Method in class org.apache.calcite.linq4j.tree.ReflectedPseudoField
- getModifierString() - Method in enum org.apache.calcite.util.format.postgresql.PatternModifier
-
Get the text for this modifier.
- getMonotonicExprs() - Method in class org.apache.calcite.sql.validate.MatchRecognizeNamespace
- getMonotonicExprs() - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- getMonotonicExprs() - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- getMonotonicExprs() - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns a list of expressions which are monotonic in this namespace.
- getMonotonicity(String) - Method in class org.apache.calcite.prepare.RelOptTableImpl
- getMonotonicity(String) - Method in class org.apache.calcite.sql.validate.MatchRecognizeNamespace
- getMonotonicity(String) - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- getMonotonicity(String) - Method in class org.apache.calcite.sql.validate.DelegatingSqlValidatorTable
- getMonotonicity(String) - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- getMonotonicity(String) - Method in class org.apache.calcite.sql.validate.SelectNamespace
- getMonotonicity(String) - Method in class org.apache.calcite.sql.validate.SetopNamespace
- getMonotonicity(String) - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns whether and how a given column is sorted.
- getMonotonicity(String) - Method in interface org.apache.calcite.sql.validate.SqlValidatorTable
-
Returns whether a given column is monotonic.
- getMonotonicity(String) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getMonotonicity(SqlCall, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlOperator
-
Deprecated.
- getMonotonicity(SqlNode) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- getMonotonicity(SqlNode) - Method in class org.apache.calcite.sql.validate.ParameterScope
- getMonotonicity(SqlNode) - Method in class org.apache.calcite.sql.validate.OverScope
- getMonotonicity(SqlNode) - Method in class org.apache.calcite.sql.validate.SelectScope
- getMonotonicity(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Returns whether an expression is monotonic in this scope.
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlAbstractTimeFunction
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlBaseContextVariable
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlCastFunction
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlCurrentDateFunction
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlDatetimePlusOperator
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlDatetimeSubtractionOperator
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlExtractFunction
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlFloorFunction
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlMonotonicBinaryOperator
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlMonotonicUnaryFunction
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlSubstringFunction
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.SqlAsOperator
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.SqlBasicFunction
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.SqlBinaryOperator
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.SqlGroupedWindowFunction
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether a call to this operator is monotonic.
- getMonotonicity(SqlOperatorBinding) - Method in class org.apache.calcite.sql.SqlPrefixOperator
- getMonotonicity(SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlCall
- getMonotonicity(SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- getMonotonicity(SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlDynamicParam
- getMonotonicity(SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlIdentifier
- getMonotonicity(SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlLiteral
- getMonotonicity(SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlNode
-
Returns whether expression is always ascending, descending or constant.
- getMountsInfo() - Static method in class org.apache.calcite.adapter.utils.OsQueryTableUtil
- getMultiJoinFields() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns an array of fields contained within the multi-join.
- getMultiJoinRel() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns the MultiJoin corresponding to this multi-join.
- getMustFilterFields() - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- getMustFilterFields() - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns the ordinals (in the row type) of the "must-filter" fields, fields that that must be filtered in a query.
- getMutableRootSchema() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.Context
-
Returns the root schema for statements that need to be able to modify schemas and have the results available to other statements.
- getName() - Method in class org.apache.calcite.adapter.druid.VirtualColumn
- getName() - Method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- getName() - Method in enum org.apache.calcite.interpreter.BindableConvention
- getName() - Method in enum org.apache.calcite.interpreter.InterpretableConvention
- getName() - Method in class org.apache.calcite.jdbc.CalciteSchema
- getName() - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl.SyntheticRecordType
- getName() - Method in class org.apache.calcite.linq4j.tree.ArrayLengthRecordField
- getName() - Method in interface org.apache.calcite.linq4j.tree.PseudoField
- getName() - Method in class org.apache.calcite.linq4j.tree.ReflectedPseudoField
- getName() - Method in interface org.apache.calcite.linq4j.tree.Types.RecordType
- getName() - Method in interface org.apache.calcite.plan.Convention
- getName() - Method in class org.apache.calcite.plan.Convention.Impl
- getName() - Method in class org.apache.calcite.plan.RelOptAbstractTable
- getName() - Method in class org.apache.calcite.rel.core.AggregateCall
-
Returns the name.
- getName() - Method in class org.apache.calcite.rel.core.CorrelationId
-
Returns the preferred name of the variable.
- getName() - Method in interface org.apache.calcite.rel.type.RelDataTypeField
-
Gets the name of this field, which is unique within its containing type.
- getName() - Method in class org.apache.calcite.rel.type.RelDataTypeFieldImpl
- getName() - Method in class org.apache.calcite.rex.RexVariable
-
Returns the name of this variable.
- getName() - Method in interface org.apache.calcite.schema.FunctionParameter
-
Name of the parameter.
- getName() - Method in interface org.apache.calcite.schema.Member
-
The name of this function.
- getName() - Method in interface org.apache.calcite.schema.SchemaPlus
-
Returns the name of this schema.
- getName() - Method in class org.apache.calcite.sql.babel.postgresql.SqlShow
- getName() - Method in class org.apache.calcite.sql.fun.SqlBetweenOperator
- getName() - Method in class org.apache.calcite.sql.fun.SqlFloorFunction
- getName() - Method in class org.apache.calcite.sql.SqlHint
-
Returns the sql hint name.
- getName() - Method in class org.apache.calcite.sql.SqlOperator
- getName() - Method in class org.apache.calcite.sql.SqlSampleSpec.SqlSubstitutionSampleSpec
- getName() - Method in class org.apache.calcite.sql.SqlSetOption
- getName() - Method in interface org.apache.calcite.sql.SqlWriter.FrameType
-
Returns the name of this frame type.
- getName() - Method in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
- getName() - Method in enum org.apache.calcite.sql.type.SqlTypeName
-
Returns the name of this type.
- getName() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockSchema
- getNameAsId() - Method in class org.apache.calcite.sql.SqlFunction
- getNameAsId() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns the fully-qualified name of this operator.
- getNamedAggCalls() - Method in class org.apache.calcite.rel.core.Aggregate
-
Returns a list of calls to aggregate functions together with their output field names.
- getNamedProjects() - Method in class org.apache.calcite.rel.core.Project
-
Returns a list of (expression, name) pairs.
- getNamedProjects() - Method in class org.apache.calcite.rel.mutable.MutableProject
-
Returns a list of (expression, name) pairs.
- getNamedProjects() - Method in class org.apache.calcite.rex.RexProgram
-
Returns a list of project expressions and their field names.
- getNamedType(SqlIdentifier) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- getNamedType(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.DelegatingSqlValidatorCatalogReader
- getNamedType(SqlIdentifier) - Method in interface org.apache.calcite.sql.validate.SqlValidatorCatalogReader
-
Finds a user-defined type with the given name, possibly qualified.
- getNamedType(SqlIdentifier) - Method in class org.apache.calcite.test.catalog.MockCatalogReaderSimple
- getNameForJdbcType(int) - Static method in enum org.apache.calcite.sql.type.SqlTypeName
-
Gets the SqlTypeName corresponding to a JDBC type.
- getNamespace(SqlCallBinding) - Static method in class org.apache.calcite.sql.validate.SqlNonNullableAccessors
- getNamespace(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Finds the namespace corresponding to a given node.
- getNamespace(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getNamespaceURI(String) - Method in class org.apache.calcite.util.SimpleNamespaceContext
- getNetFileSizeDescription(long) - Static method in class org.apache.calcite.adapter.utils.OsQueryTableUtil
- getNewFieldForOldInput(int) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
-
Maps the ordinal of a field pre-flattening to the ordinal of the corresponding field post-flattening, and also returns its type.
- getNewForOldInput(int) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
-
Maps the ordinal of a field pre-flattening to the ordinal of the corresponding field post-flattening.
- getNewForOldRel(RelNode) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- getNlsString() - Method in class org.apache.calcite.sql.SqlCharStringLiteral
-
Deprecated.
- getNode() - Method in class org.apache.calcite.sql.validate.AggregatingSelectScope
- getNode() - Method in class org.apache.calcite.sql.validate.AliasNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.CollectNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.ParameterScope
- getNode() - Method in class org.apache.calcite.sql.validate.GroupByScope
- getNode() - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.JoinScope
- getNode() - Method in class org.apache.calcite.sql.validate.LambdaNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.MatchRecognizeNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.MatchRecognizeScope
- getNode() - Method in class org.apache.calcite.sql.validate.MeasureScope
- getNode() - Method in class org.apache.calcite.sql.validate.OrderByScope
- getNode() - Method in class org.apache.calcite.sql.validate.OverScope
- getNode() - Method in class org.apache.calcite.sql.validate.PivotNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.PivotScope
- getNode() - Method in class org.apache.calcite.sql.validate.ProcedureNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.SelectNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.SelectScope
- getNode() - Method in class org.apache.calcite.sql.validate.SetopNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.SqlLambdaScope
- getNode() - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns the parse tree node at the root of this namespace.
- getNode() - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Returns the root node of this scope.
- getNode() - Method in class org.apache.calcite.sql.validate.TableConstructorNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.UnpivotNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.UnpivotScope
- getNode() - Method in class org.apache.calcite.sql.validate.WithNamespace
- getNode() - Method in exception class org.apache.calcite.util.Util.FoundOne
- getNodeType() - Method in class org.apache.calcite.linq4j.tree.AbstractNode
-
Gets the node type of this Expression.
- getNodeTypes() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.NodeTypes
-
Returns a multimap from the class to the nodes instantiating that class.
- getNodeTypes(RelSubset, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Aggregate, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Calc, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Correlate, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Exchange, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Filter, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Intersect, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Join, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Match, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Minus, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Project, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Sample, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Sort, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(TableModify, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Union, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Values, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Window, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.NodeTypes.getNodeTypes()
statistic. - getNodeTypes(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.NodeTypes.Handler
- getNodeTypes(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
-
Catch-all implementation for
BuiltInMetadata.NodeTypes.getNodeTypes()
, invoked using reflection. - getNonChildren() - Method in class org.apache.calcite.util.PartiallyOrderedSet
- getNonConstColumns(List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Given some expressions, gets the indices of the non-constant ones.
- getNonConstColumns(ImmutableBitSet, List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Given some expressions and columns, gets the indices of the non-constant ones.
- getNonCumulativeCost() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.NonCumulativeCost
-
Estimates the cost of executing a relational expression, not counting the cost of its inputs.
- getNonCumulativeCost(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.NonCumulativeCost.getNonCumulativeCost()
statistic. - getNonCumulativeCost(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.NonCumulativeCost.Handler
- getNonCumulativeCost(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPercentageOriginalRows
- getNonParents() - Method in class org.apache.calcite.util.PartiallyOrderedSet
- getNotNullState(AggContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.UserDefinedAggReflectiveImplementor
- getNotNullState(AggContext) - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- getNotNullState(AggContext) - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- getNotNullState(WinAggContext) - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- getNullable() - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- getNullClause() - Method in class org.apache.calcite.sql.fun.SqlJsonArrayAggAggFunction
- getNullClause() - Method in class org.apache.calcite.sql.fun.SqlJsonObjectAggAggFunction
- getNullCollation() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns how NULL values are sorted if an ORDER BY item does not contain NULLS ASCENDING or NULLS DESCENDING.
- getNullDirection() - Method in class org.apache.calcite.rex.RexFieldCollation
- getNumColumns() - Method in interface org.apache.calcite.rel.RelReferentialConstraint
-
Deprecated.Use
getColumnPairs().size()
- getNumericFunctions() - Static method in class org.apache.calcite.sql.SqlJdbcFunctionCall
- getNumericJavaClassName(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Deprecated.
- getNumFieldsInJoinFactor(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns the number of fields in a given factor.
- getNumJoinFactors() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns the number of factors in this multi-join.
- getNumTotalFields() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns the total number of fields in the multi-join.
- getNumTypeRadix(SqlTypeName) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- getNumTypeRadix(SqlTypeName) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns the numeric type radix, typically 2 or 10.
- getNumTypeRadix(SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- getObject() - Method in interface org.apache.calcite.linq4j.tree.Primitive.Source
- getObject(int) - Method in class org.apache.calcite.interpreter.Row
- getObjectPath() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.Context
-
Returns the path of the object being analyzed, or null.
- getOffset() - Method in class org.apache.calcite.rex.RexRangeRef
- getOffset() - Method in class org.apache.calcite.rex.RexWindowBound
-
Returns offset from XX PRECEDING/FOLLOWING.
- getOffset() - Method in class org.apache.calcite.sql.SqlSelect
- getOperand() - Method in class org.apache.calcite.plan.RelOptRule
-
Returns the root operand of this rule.
- getOperand0() - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Returns the root operand matched by this rule.
- getOperandCount() - Method in class org.apache.calcite.rel.core.Aggregate.AggCallBinding
- getOperandCount() - Method in class org.apache.calcite.rex.RexCallBinding
- getOperandCount() - Method in class org.apache.calcite.sql.ExplicitOperatorBinding
- getOperandCount() - Method in class org.apache.calcite.sql.SqlCallBinding
- getOperandCount() - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Returns the number of bound operands.
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlCaseOperator
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlCastFunction
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlConvertFunction
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlDatePartFunction
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlDotOperator
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlItemOperator
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlJsonArrayFunction
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlJsonDepthFunction
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlJsonModifyFunction
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlJsonObjectFunction
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlJsonPrettyFunction
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlJsonRemoveFunction
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlJsonTypeFunction
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlJsonValueFunction
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlLikeOperator
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlMultisetMemberOfOperator
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlOverlapsOperator
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlPosixRegexOperator
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlSubstringFunction
- getOperandCountRange() - Method in class org.apache.calcite.sql.fun.SqlTranslateFunction
- getOperandCountRange() - Method in class org.apache.calcite.sql.SqlDescriptorOperator
- getOperandCountRange() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns a constraint on the number of operands expected by this operator.
- getOperandCountRange() - Method in class org.apache.calcite.sql.SqlWindowTableFunction.AbstractOperandMetadata
- getOperandCountRange() - Method in class org.apache.calcite.sql.type.ArrayElementOperandTypeChecker
- getOperandCountRange() - Method in class org.apache.calcite.sql.type.AssignableOperandTypeChecker
- getOperandCountRange() - Method in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- getOperandCountRange() - Method in class org.apache.calcite.sql.type.ExplicitOperandTypeChecker
- getOperandCountRange() - Method in class org.apache.calcite.sql.type.FamilyOperandTypeChecker
- getOperandCountRange() - Method in class org.apache.calcite.sql.type.MultisetOperandTypeChecker
- getOperandCountRange() - Method in class org.apache.calcite.sql.type.SameOperandTypeChecker
- getOperandCountRange() - Method in class org.apache.calcite.sql.type.SetopOperandTypeChecker
- getOperandCountRange() - Method in interface org.apache.calcite.sql.type.SqlOperandTypeChecker
-
Returns the range of operand counts allowed in a call.
- getOperandCountRange() - Method in interface org.apache.calcite.sql.type.SqlSingleOperandTypeChecker
- getOperandList() - Method in class org.apache.calcite.sql.babel.postgresql.SqlBegin
- getOperandList() - Method in class org.apache.calcite.sql.babel.postgresql.SqlCommit
- getOperandList() - Method in class org.apache.calcite.sql.babel.postgresql.SqlDiscard
- getOperandList() - Method in class org.apache.calcite.sql.babel.postgresql.SqlRollback
- getOperandList() - Method in class org.apache.calcite.sql.babel.postgresql.SqlShow
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlAttributeDefinition
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlCheckConstraint
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlColumnDeclaration
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlCreateForeignSchema
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlCreateFunction
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlCreateMaterializedView
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlCreateSchema
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlCreateTable
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlCreateTableLike
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlCreateType
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlCreateView
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlDropObject
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlDropSchema
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlKeyConstraint
- getOperandList() - Method in class org.apache.calcite.sql.ddl.SqlTruncateTable
- getOperandList() - Method in class org.apache.calcite.sql.fun.SqlCase
- getOperandList() - Method in class org.apache.calcite.sql.SqlAsofJoin
- getOperandList() - Method in class org.apache.calcite.sql.SqlBasicCall
- getOperandList() - Method in class org.apache.calcite.sql.SqlCall
-
Returns the list of operands.
- getOperandList() - Method in class org.apache.calcite.sql.SqlDelete
- getOperandList() - Method in class org.apache.calcite.sql.SqlDescribeSchema
- getOperandList() - Method in class org.apache.calcite.sql.SqlDescribeTable
- getOperandList() - Method in class org.apache.calcite.sql.SqlExplain
- getOperandList() - Method in class org.apache.calcite.sql.SqlHint
- getOperandList() - Method in class org.apache.calcite.sql.SqlInsert
- getOperandList() - Method in class org.apache.calcite.sql.SqlJoin
- getOperandList() - Method in class org.apache.calcite.sql.SqlLambda
- getOperandList() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getOperandList() - Method in class org.apache.calcite.sql.SqlMerge
- getOperandList() - Method in class org.apache.calcite.sql.SqlOrderBy
- getOperandList() - Method in class org.apache.calcite.sql.SqlPivot
- getOperandList() - Method in class org.apache.calcite.sql.SqlSelect
- getOperandList() - Method in class org.apache.calcite.sql.SqlSetOption
- getOperandList() - Method in class org.apache.calcite.sql.SqlSnapshot
- getOperandList() - Method in class org.apache.calcite.sql.SqlTableRef
- getOperandList() - Method in class org.apache.calcite.sql.SqlUnpivot
- getOperandList() - Method in class org.apache.calcite.sql.SqlUpdate
- getOperandList() - Method in class org.apache.calcite.sql.SqlWindow
- getOperandList() - Method in class org.apache.calcite.sql.SqlWith
- getOperandList() - Method in class org.apache.calcite.sql.SqlWithItem
- getOperandList(int) - Method in class org.apache.calcite.sql.type.SameOperandTypeChecker
- getOperandLiteralValue(int) - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Deprecated.
- getOperandLiteralValue(int, Class<T>) - Method in class org.apache.calcite.rex.RexCallBinding
- getOperandLiteralValue(int, Class<T>) - Method in class org.apache.calcite.sql.SqlCallBinding
- getOperandLiteralValue(int, Class<T>) - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Gets the value of a literal operand.
- getOperandLiteralValue(int, RelDataType) - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Gets the value of a literal operand as a Calcite type.
- getOperandLiteralValueOrThrow(SqlOperatorBinding, int, Class<T>) - Static method in class org.apache.calcite.sql.validate.SqlNonNullableAccessors
- getOperandMonotonicity(int) - Method in class org.apache.calcite.rex.RexCallBinding
- getOperandMonotonicity(int) - Method in class org.apache.calcite.sql.SqlCallBinding
- getOperandMonotonicity(int) - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Gets the monotonicity of a bound operand.
- getOperands() - Method in class org.apache.calcite.plan.RelOptRule
-
Returns a flattened list of operands of this rule.
- getOperands() - Method in class org.apache.calcite.rex.RexCall
- getOperandScope(SqlCall) - Method in class org.apache.calcite.sql.validate.AggregatingSelectScope
- getOperandScope(SqlCall) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- getOperandScope(SqlCall) - Method in class org.apache.calcite.sql.validate.ParameterScope
- getOperandScope(SqlCall) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Returns the scope within which operands to a call are to be validated.
- getOperandSqlTypeFamily(int) - Method in class org.apache.calcite.sql.type.FamilyOperandTypeChecker
- getOperandSqlTypeFamily(int) - Method in interface org.apache.calcite.sql.type.ImplicitCastOperandTypeChecker
-
Get the operand SqlTypeFamily of formal index
iFormalOperand
. - getOperandType(int) - Method in class org.apache.calcite.rel.core.Aggregate.AggCallBinding
- getOperandType(int) - Method in class org.apache.calcite.rex.RexCallBinding
- getOperandType(int) - Method in class org.apache.calcite.sql.ExplicitOperatorBinding
- getOperandType(int) - Method in class org.apache.calcite.sql.SqlCallBinding
- getOperandType(int) - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Gets the type of a bound operand.
- getOperandTypeChecker() - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- getOperandTypeChecker() - Method in class org.apache.calcite.sql.fun.SqlItemOperator
- getOperandTypeChecker() - Method in class org.apache.calcite.sql.SqlBasicFunction
- getOperandTypeChecker() - Method in class org.apache.calcite.sql.SqlOperator
- getOperandTypeChecker() - Method in class org.apache.calcite.sql.SqlWindowTableFunction
- getOperandTypeChecker() - Method in class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
- getOperandTypeChecker() - Method in class org.apache.calcite.sql.validate.SqlUserDefinedFunction
- getOperandTypeChecker() - Method in class org.apache.calcite.sql.validate.SqlUserDefinedTableMacro
- getOperandTypeInference() - Method in class org.apache.calcite.sql.SqlOperator
- getOperation() - Method in class org.apache.calcite.rel.core.TableModify
- getOperator() - Method in class org.apache.calcite.rex.RexCall
- getOperator() - Method in class org.apache.calcite.sql.babel.postgresql.SqlBegin
- getOperator() - Method in class org.apache.calcite.sql.babel.postgresql.SqlCommit
- getOperator() - Method in class org.apache.calcite.sql.babel.postgresql.SqlDiscard
- getOperator() - Method in class org.apache.calcite.sql.babel.postgresql.SqlRollback
- getOperator() - Method in class org.apache.calcite.sql.babel.postgresql.SqlShow
- getOperator() - Method in class org.apache.calcite.sql.ddl.SqlAttributeDefinition
- getOperator() - Method in class org.apache.calcite.sql.ddl.SqlCheckConstraint
- getOperator() - Method in class org.apache.calcite.sql.ddl.SqlColumnDeclaration
- getOperator() - Method in class org.apache.calcite.sql.ddl.SqlCreateFunction
- getOperator() - Method in class org.apache.calcite.sql.ddl.SqlKeyConstraint
- getOperator() - Method in class org.apache.calcite.sql.fun.SqlCase
- getOperator() - Method in class org.apache.calcite.sql.parser.SqlParserUtil.ToTreeListItem
- getOperator() - Method in class org.apache.calcite.sql.SqlAsofJoin
- getOperator() - Method in class org.apache.calcite.sql.SqlBasicCall
- getOperator() - Method in class org.apache.calcite.sql.SqlCall
- getOperator() - Method in class org.apache.calcite.sql.SqlDdl
- getOperator() - Method in class org.apache.calcite.sql.SqlDelete
- getOperator() - Method in class org.apache.calcite.sql.SqlDescribeSchema
- getOperator() - Method in class org.apache.calcite.sql.SqlDescribeTable
- getOperator() - Method in class org.apache.calcite.sql.SqlExplain
- getOperator() - Method in class org.apache.calcite.sql.SqlHint
- getOperator() - Method in class org.apache.calcite.sql.SqlInsert
- getOperator() - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall.SimpleMakeCall
- getOperator() - Method in class org.apache.calcite.sql.SqlJoin
- getOperator() - Method in class org.apache.calcite.sql.SqlLambda
- getOperator() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getOperator() - Method in class org.apache.calcite.sql.SqlMerge
- getOperator() - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Returns the bound operator.
- getOperator() - Method in class org.apache.calcite.sql.SqlOrderBy
- getOperator() - Method in class org.apache.calcite.sql.SqlPivot
- getOperator() - Method in class org.apache.calcite.sql.SqlSelect
- getOperator() - Method in class org.apache.calcite.sql.SqlSetOption
- getOperator() - Method in class org.apache.calcite.sql.SqlSnapshot
- getOperator() - Method in class org.apache.calcite.sql.SqlTableRef
- getOperator() - Method in class org.apache.calcite.sql.SqlUnpivot
- getOperator() - Method in class org.apache.calcite.sql.SqlUpdate
- getOperator() - Method in class org.apache.calcite.sql.SqlWindow
- getOperator() - Method in class org.apache.calcite.sql.SqlWith
- getOperator() - Method in class org.apache.calcite.sql.SqlWithItem
- getOperator() - Method in class org.apache.calcite.sql.validate.SqlWithItemTableRef
- getOperatorConversionMap() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getOperatorList() - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- getOperatorList() - Method in interface org.apache.calcite.sql.SqlOperatorTable
-
Retrieves a list of all functions and operators in this table.
- getOperatorList() - Method in class org.apache.calcite.sql.SqlSpatialTypeOperatorTable
- getOperatorList() - Method in class org.apache.calcite.sql.util.ChainedSqlOperatorTable
- getOperatorList() - Method in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
- getOperatorSignature(SqlOperator, List<?>) - Static method in class org.apache.calcite.sql.SqlUtil
-
Constructs an operator signature from a type list.
- getOperatorTable() - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the operator table used by this validator.
- getOperatorTable() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getOperatorTable() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns operator table that should be used to resolve functions and operators during query validation.
- getOperatorTable(Iterable<SqlLibrary>) - Method in class org.apache.calcite.sql.fun.SqlLibraryOperatorTableFactory
-
Returns a SQL operator table that contains operators in the given set of libraries.
- getOperatorTable(Iterable<SqlLibrary>, boolean) - Method in class org.apache.calcite.sql.fun.SqlLibraryOperatorTableFactory
-
Returns a SQL operator table that contains operators in the given set of libraries, optionally inheriting in operators in
SqlLibrary.ALL
. - getOperatorTable(SqlLibrary...) - Method in class org.apache.calcite.sql.fun.SqlLibraryOperatorTableFactory
-
Returns a SQL operator table that contains operators in the given library or libraries.
- getOpt(String) - Method in class org.apache.calcite.rel.type.TimeFrameSet
-
Returns the time frame with the given name (case-insensitive), or returns null.
- getOpTab() - Method in class org.apache.calcite.rex.RexBuilder
-
Returns this RexBuilder's operator table.
- getOptionFormat() - Method in class org.apache.calcite.sql.SqlHint
-
Returns the hint option format.
- getOptionKVPairs() - Method in class org.apache.calcite.sql.SqlHint
-
Returns a key value string map if the hint option is a list of pair, each pair contains a simple SQL identifier and a string literal; else returns an empty map.
- getOptionList() - Method in class org.apache.calcite.sql.SqlHint
-
Returns a string list if the hint option is a list of simple SQL identifier, or a list of literals, else returns an empty list.
- getOrderKey() - Method in class org.apache.calcite.rex.RexWindowBound
-
Returns relative sort offset when known at compile time.
- getOrderKeys() - Method in class org.apache.calcite.rel.core.Match
- getOrderList() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getOrderList() - Method in class org.apache.calcite.sql.SqlSelect
- getOrderList() - Method in class org.apache.calcite.sql.SqlWindow
- getOrderList() - Method in class org.apache.calcite.sql.validate.DelegatingScope
- getOrderList() - Method in class org.apache.calcite.sql.validate.ParameterScope
- getOrderList() - Method in class org.apache.calcite.sql.validate.SelectScope
- getOrderList() - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Returns the expressions by which the rows in this scope are sorted.
- getOrderScope(SqlSelect) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the scope that expressions in the SELECT and HAVING clause of this query should use.
- getOrderScope(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getOrdinal() - Method in interface org.apache.calcite.schema.FunctionParameter
-
Zero-based ordinal of this parameter within the member's parameter list.
- getOrdinalBitSet(RelDataType, Map<Integer, RelDataTypeField>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Gets the bit-set to the column ordinals in the source for columns that intersect in the target.
- getOrdinalBitSet(RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Gets the bit-set to the column ordinals in the source for columns that intersect in the target.
- getOriginal() - Method in class org.apache.calcite.plan.volcano.RelSubset
- getOriginal(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getOriginalExpression() - Method in class org.apache.calcite.plan.RelOptCluster
-
Deprecated.
- getOriginalStatement() - Method in exception class org.apache.calcite.runtime.CalciteContextException
-
Returns the input string that is associated with the context.
- getOriginColumnOrdinal() - Method in class org.apache.calcite.rel.metadata.RelColumnOrigin
-
Returns the 0-based index of column in origin table; whether this ordinal is flattened or unflattened depends on whether UDT flattening has already been performed on the relational expression which produced this description.
- getOriginTable() - Method in class org.apache.calcite.rel.metadata.RelColumnOrigin
-
Returns table of origin.
- getOsVersionInfo() - Static method in class org.apache.calcite.adapter.utils.OsQueryTableUtil
- getOtherSelfJoinFactor(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns the other factor in a self-join pair if the factor passed in is a factor in a removable self-join; otherwise, returns null.
- getOutConvention() - Method in class org.apache.calcite.plan.RelOptRule
-
Returns the convention of the result of firing this rule, null if not known.
- getOutConvention() - Method in class org.apache.calcite.rel.convert.ConverterRule
- getOutConvention() - Method in class org.apache.calcite.rel.convert.TraitMatchingRule
- getOutConvention() - Method in class org.apache.calcite.rel.rules.CoerceInputsRule
- getOutConvention() - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule
- getOuterJoinCond(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns outer join conditions associated with the specified null-generating factor.
- getOuterJoinConditions() - Method in class org.apache.calcite.rel.rules.MultiJoin
-
Returns outer join conditions for null-generating inputs.
- getOuterJoinFactors(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns a bitmap containing the factors that a null-generating factor is dependent upon, if the factor is null-generating in a left or right outer join; otherwise null is returned.
- getOutputName() - Method in class org.apache.calcite.adapter.druid.DefaultDimensionSpec
- getOutputName() - Method in interface org.apache.calcite.adapter.druid.DimensionSpec
- getOutputName() - Method in class org.apache.calcite.adapter.druid.ExtractionDimensionSpec
- getOutputRowType() - Method in class org.apache.calcite.rex.RexProgram
-
Returns the type of the output row from this program.
- getOutputType() - Method in class org.apache.calcite.adapter.druid.DefaultDimensionSpec
- getOutputType() - Method in interface org.apache.calcite.adapter.druid.DimensionSpec
- getOutputType() - Method in class org.apache.calcite.adapter.druid.ExtractionDimensionSpec
- getOutputType() - Method in class org.apache.calcite.adapter.druid.VirtualColumn
- getOutTrait() - Method in class org.apache.calcite.plan.RelOptRule
-
Returns the trait which will be modified as a result of firing this rule, or null if the rule is not a converter rule.
- getOutTrait() - Method in class org.apache.calcite.rel.convert.ConverterRule
- getOutwardEdges(V) - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- getOutwardEdges(V) - Method in interface org.apache.calcite.util.graph.DirectedGraph
- getOverScope(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the scope of an OVER or VALUES node.
- getOverScope(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getParameterCount() - Method in interface org.apache.calcite.schema.FunctionContext
-
Returns the number of parameters.
- getParameterName(Method, int) - Static method in class org.apache.calcite.util.ReflectUtil
-
Derives the name of the
i
th parameter of a method. - getParameterNames() - Method in class org.apache.calcite.util.Template
-
Returns the names of the parameters, in the order that they appeared in the template string.
- getParameterRowType() - Method in class org.apache.calcite.prepare.PlannerImpl
- getParameterRowType() - Method in class org.apache.calcite.prepare.Prepare.PreparedExplain
- getParameterRowType() - Method in interface org.apache.calcite.prepare.Prepare.PreparedResult
-
Returns a record type whose fields are the parameters of this statement.
- getParameterRowType() - Method in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- getParameterRowType() - Method in interface org.apache.calcite.tools.Planner
-
Returns a record type that contains the name and type of each parameter.
- getParameterRowType(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns a record type that contains the name and type of each parameter.
- getParameterRowType(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getParameters() - Method in class org.apache.calcite.rex.RexLambda
- getParameters() - Method in interface org.apache.calcite.schema.Function
-
Returns the parameters of this function.
- getParameters() - Method in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- getParameters() - Method in class org.apache.calcite.schema.impl.ReflectiveFunctionBase
-
Returns the parameters of this function.
- getParameters() - Method in class org.apache.calcite.schema.impl.ViewTableMacro
- getParameters() - Method in interface org.apache.calcite.schema.Member
-
Returns the parameters of this member.
- getParameters() - Method in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction
- getParameters() - Method in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction2
- getParameters() - Method in class org.apache.calcite.sql.SqlLambda
- getParameters() - Method in class org.apache.calcite.util.Smalls.SimpleTableMacro
- getParameterTypes() - Method in class org.apache.calcite.sql.validate.SqlLambdaScope
- getParameterTypes(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlCountAggFunction
- getParameterTypes(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlFirstLastValueAggFunction
- getParameterTypes(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlHistogramAggFunction
- getParameterTypes(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
- getParameterTypes(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlSingleValueAggFunction
- getParameterTypes(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlSumAggFunction
- getParameterTypes(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlSumEmptyIsZeroAggFunction
- getParameterTypes(RelDataTypeFactory) - Method in class org.apache.calcite.sql.SqlAggFunction
-
Deprecated.
- getParamNames() - Method in class org.apache.calcite.sql.SqlFunction
-
Deprecated.
- getParamNames() - Method in class org.apache.calcite.sql.validate.SqlUserDefinedFunction
- getParamNames() - Method in class org.apache.calcite.sql.validate.SqlUserDefinedTableMacro
- getParamTypes() - Method in class org.apache.calcite.sql.SqlFunction
-
Deprecated.
- getParent() - Method in class org.apache.calcite.plan.RelOptRuleOperand
-
Returns the parent operand.
- getParent() - Method in class org.apache.calcite.rel.mutable.MutableRel
- getParent() - Method in class org.apache.calcite.rel.rules.LoptJoinTree.BinaryTree
- getParent() - Method in class org.apache.calcite.sql.validate.DelegatingScope
-
Returns the parent scope of this
DelegatingScope
. - getParentCursor(String) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Retrieves the name of the parent cursor referenced by a column list parameter.
- getParentCursor(String) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getParentRels() - Method in class org.apache.calcite.plan.volcano.RelSubset
-
Returns a list of relational expressions one of whose children is this subset.
- getParents() - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Returns a list of parents of the first relational expression.
- getParents(E) - Method in class org.apache.calcite.util.PartiallyOrderedSet
-
Returns the values in this partially-ordered set that are greater-than a given value and there are no intervening values.
- getParents(E, boolean) - Method in class org.apache.calcite.util.PartiallyOrderedSet
-
Returns the values in this partially-ordered set that are greater-than a given value and there are no intervening values.
- getParentSchema() - Method in interface org.apache.calcite.schema.SchemaPlus
-
Returns the parent schema, or null if this schema has no parent.
- getParser(Reader) - Method in interface org.apache.calcite.sql.parser.SqlParserImplFactory
-
Get the underlying parser implementation.
- getParserConfig() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
The configuration of SQL parser.
- getParserMetadata() - Method in class org.apache.calcite.sql.advise.SqlAdvisor
-
Returns the underlying Parser metadata.
- getParserPos() - Method in class org.apache.calcite.sql.SqlTypeNameSpec
- getParserPosition() - Method in class org.apache.calcite.rel.core.AggregateCall
- getParserPosition() - Method in class org.apache.calcite.rex.RexCall
- getParserPosition() - Method in class org.apache.calcite.sql.SqlNode
- getParserTracer() - Static method in class org.apache.calcite.util.trace.CalciteTrace
-
The "org.apache.calcite.sql.parser" tracer reports parse events.
- getPartialMapping(int) - Method in class org.apache.calcite.rex.RexProgram
-
Returns a partial mapping of a set of project expressions.
- getPartialMapping(int, List<? extends RexNode>) - Static method in class org.apache.calcite.rel.core.Project
-
Returns a partial mapping of a set of project expressions.
- getPartitionKeys() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable
- getPartitionKeys() - Method in class org.apache.calcite.rel.core.Match
- getPartitionList() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getPartitionList() - Method in class org.apache.calcite.sql.SqlWindow
- getPartitionRowCount() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResetContextImpl
- getPartitionRowCount() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- getPartitionRowCount() - Method in interface org.apache.calcite.adapter.enumerable.WinAggFrameContext
-
Returns the number of rows in the current partition (as determined by PARTITION BY clause).
- getPassword() - Method in class org.apache.calcite.adapter.redis.RedisConfig
- getPath() - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns the default path resolving functions from this schema.
- getPath() - Method in class org.apache.calcite.test.QuidemTest
-
Factory method for
QuidemTest.test(String)
parameters. - getPaths(V, V) - Method in class org.apache.calcite.util.graph.Graphs.FrozenGraph
-
Returns an iterator of all paths between two nodes, in non-decreasing order of path lengths.
- getPattern() - Method in class org.apache.calcite.rel.core.Match
- getPattern() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getPattern() - Method in class org.apache.calcite.util.format.postgresql.format.FormatPattern
- getPatternDefinitions() - Method in class org.apache.calcite.rel.core.Match
- getPatternDefList() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getPatternVars() - Method in class org.apache.calcite.sql.validate.MatchRecognizeScope
- getPercentageOriginalRows() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.PercentageOriginalRows
-
Estimates the percentage of the number of rows actually produced by a relational expression out of the number of rows it would produce if all single-table filter conditions were removed.
- getPercentageOriginalRows(Aggregate, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPercentageOriginalRows
- getPercentageOriginalRows(Join, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPercentageOriginalRows
- getPercentageOriginalRows(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPercentageOriginalRows
- getPercentageOriginalRows(Union, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPercentageOriginalRows
- getPercentageOriginalRows(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.PercentageOriginalRows.getPercentageOriginalRows()
statistic. - getPercentageOriginalRows(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.PercentageOriginalRows.Handler
- getPercentageOriginalRows(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPercentageOriginalRows
- getPeriod() - Method in class org.apache.calcite.rel.core.Snapshot
- getPeriod() - Method in class org.apache.calcite.sql.SqlSnapshot
- getPermutation() - Method in class org.apache.calcite.rel.core.Project
-
Returns a permutation, if this projection is merely a permutation of its input fields; otherwise null.
- getPermutation() - Method in class org.apache.calcite.rex.RexProgram
-
Returns a permutation, if this program is a permutation, otherwise null.
- getPermutation(int, List<? extends RexNode>) - Static method in class org.apache.calcite.rel.core.Project
-
Returns a permutation, if this projection is merely a permutation of its input fields; otherwise null.
- getPhysicalRowType() - Method in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
-
Returns the physical row type of this prepared statement.
- getPigRelationAlias(RelNode) - Method in class org.apache.calcite.adapter.pig.PigRel.Implementor
- getPigScript(InputStream, Map<String, String>) - Method in class org.apache.calcite.piglet.PigConverter
-
Gets a Pig script string from a file after doing param substitution.
- getPigType() - Method in enum org.apache.calcite.adapter.pig.PigDataType
- getPlanner() - Method in class org.apache.calcite.plan.RelOptCluster
- getPlanner() - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Returns the planner.
- getPlanner(FrameworkConfig) - Static method in class org.apache.calcite.tools.Frameworks
-
Creates a planner.
- getPlannerTaskTracer() - Static method in class org.apache.calcite.util.trace.CalciteTrace
-
Reports volcano planner optimization task events.
- getPlannerTracer() - Static method in class org.apache.calcite.util.trace.CalciteTrace
-
The "org.apache.calcite.plan.RelOptPlanner" tracer prints the query optimization process.
- getPointQueryKey() - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- getPopulationSize(Aggregate, RelMetadataQuery, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMdPopulationSize
- getPopulationSize(Exchange, RelMetadataQuery, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMdPopulationSize
- getPopulationSize(Filter, RelMetadataQuery, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMdPopulationSize
- getPopulationSize(Join, RelMetadataQuery, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMdPopulationSize
- getPopulationSize(Project, RelMetadataQuery, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMdPopulationSize
- getPopulationSize(Sort, RelMetadataQuery, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMdPopulationSize
- getPopulationSize(TableModify, RelMetadataQuery, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMdPopulationSize
- getPopulationSize(TableScan, RelMetadataQuery, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMdPopulationSize
- getPopulationSize(Union, RelMetadataQuery, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMdPopulationSize
- getPopulationSize(Values, RelMetadataQuery, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMdPopulationSize
- getPopulationSize(RelNode, RelMetadataQuery, ImmutableBitSet) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.PopulationSize.Handler
- getPopulationSize(RelNode, RelMetadataQuery, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMdPopulationSize
-
Catch-all implementation for
BuiltInMetadata.PopulationSize.getPopulationSize(ImmutableBitSet)
, invoked using reflection. - getPopulationSize(RelNode, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.PopulationSize.getPopulationSize(ImmutableBitSet)
statistic. - getPopulationSize(ImmutableBitSet) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.PopulationSize
-
Estimates the distinct row count in the original source for the given
groupKey
, ignoring any filtering being applied by the expression. - getPort() - Method in class org.apache.calcite.adapter.redis.RedisConfig
- getPos() - Method in exception class org.apache.calcite.sql.parser.SqlParseException
-
Returns the position where this error occurred.
- getPos() - Method in class org.apache.calcite.sql.parser.SqlParserUtil.ToTreeListItem
- getPosColumn() - Method in exception class org.apache.calcite.runtime.CalciteContextException
-
Returns the 1-based column number, or 0 for missing position information.
- getPosition() - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
- getPosLine() - Method in exception class org.apache.calcite.runtime.CalciteContextException
-
Returns the 1-based line number, or 0 for missing position information.
- getPostDecorrelateRules() - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Returns the rules applied on the rel after decorrelation, never null.
- getPostJoinFilter() - Method in class org.apache.calcite.rel.rules.MultiJoin
-
Returns post-join filter associated with this MultiJoin.
- getPrec() - Method in class org.apache.calcite.sql.SqlAbstractDateTimeLiteral
- getPrec() - Method in class org.apache.calcite.sql.SqlNumericLiteral
- getPrecedenceList() - Method in class org.apache.calcite.rel.type.DynamicRecordTypeImpl
- getPrecedenceList() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Returns the precedence list for this type.
- getPrecedenceList() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getPrecedenceList() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getPrecedenceList() - Method in class org.apache.calcite.sql.type.AbstractSqlType
- getPrecedenceList() - Method in class org.apache.calcite.sql.type.ArraySqlType
- getPrecedenceList() - Method in class org.apache.calcite.sql.type.MultisetSqlType
- getPrecision() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets the JDBC-defined precision for values of this type.
- getPrecision() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getPrecision() - Method in class org.apache.calcite.rel.type.RelRecordType
- getPrecision() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getPrecision() - Method in class org.apache.calcite.sql.SqlBasicTypeNameSpec
- getPrecision() - Method in class org.apache.calcite.sql.type.BasicSqlType
- getPrecision() - Method in class org.apache.calcite.sql.type.IntervalSqlType
- getPredicate() - Method in interface org.apache.calcite.rel.rules.FilterJoinRule.Config
-
Predicate that returns whether a filter is valid in the ON clause of a join for this particular kind of join.
- getPredicates() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Predicates
-
Derives the predicates that hold on rows emitted from a relational expression.
- getPredicates(RelSubset, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Returns the
BuiltInMetadata.Predicates.getPredicates()
statistic. - getPredicates(Aggregate, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for an Aggregate.
- getPredicates(Correlate, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for a correlate node.
- getPredicates(Exchange, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for an Exchange.
- getPredicates(Filter, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Add the Filter condition to the pulledPredicates list from the input.
- getPredicates(Intersect, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for a Intersect.
- getPredicates(Join, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for a
Join
(includingSemiJoin
). - getPredicates(Minus, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for a Minus.
- getPredicates(Project, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for a project.
- getPredicates(Sample, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for a Sample.
- getPredicates(Sort, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for a Sort.
- getPredicates(TableModify, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for a TableModify.
- getPredicates(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for a table scan.
- getPredicates(Union, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for a Union.
- getPredicates(Values, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for a Values.
- getPredicates(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Predicates.Handler
- getPredicates(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Catch-all implementation for
BuiltInMetadata.Predicates.getPredicates()
, invoked using reflection. - getPrefix(String) - Method in class org.apache.calcite.util.SimpleNamespaceContext
- getPrefixes(String) - Method in class org.apache.calcite.util.SimpleNamespaceContext
- getPreOperandCount() - Method in class org.apache.calcite.rel.core.Aggregate.AggCallBinding
- getPreOperandCount() - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Returns the number of pre-operands.
- getPreparingStmt(CalcitePrepare.Context, Type, CalciteCatalogReader, RelOptPlanner) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Returns CalcitePreparingStmt
- getPrimitiveClass() - Method in enum org.apache.calcite.linq4j.tree.Primitive
- getPrimitiveName() - Method in enum org.apache.calcite.linq4j.tree.Primitive
- getPrimitiveWrapperJavaClassName(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Deprecated.
- getProduct(String, String) - Static method in class org.apache.calcite.sql.SqlDialect
-
Deprecated.
- getProgram() - Method in class org.apache.calcite.adapter.enumerable.EnumerableCalc
- getProgram() - Method in class org.apache.calcite.prepare.Prepare
- getProgram() - Method in class org.apache.calcite.rel.core.Calc
- getProgram() - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Converts the state of the program builder to an immutable program, normalizing in the process.
- getProgram() - Static method in class org.apache.calcite.tools.Programs
-
Deprecated.
- getProgram(boolean) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Converts the state of the program builder to an immutable program.
- getPrograms() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns a list of one or more programs used during the course of query evaluation.
- getProjectChild(RelOptRuleCall, Project, boolean) - Method in class org.apache.calcite.rel.rules.JoinProjectTransposeRule
-
Returns the child of the project that will be used as input into the new LogicalJoin once the projects are pulled above the LogicalJoin.
- getProjectChild(RelOptRuleCall, Project, boolean) - Method in class org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule
- getProjectList() - Method in class org.apache.calcite.rex.RexProgram
-
Returns an array of references to the expressions which this program is to project.
- getProjectList() - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Returns the list of project expressions.
- getProjectOrdinals(List<RexNode>) - Static method in class org.apache.calcite.rel.core.Window
- getProjects() - Method in class org.apache.calcite.rel.core.Project
-
Returns the project expressions.
- getProjFields() - Method in class org.apache.calcite.rel.rules.MultiJoin
-
Returns bitmaps representing the fields projected from each input; if an entry is null, all fields are projected.
- getProjFields(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns a bitmap containing the fields that are projected from a factor.
- getProperties() - Method in interface org.apache.calcite.jdbc.CalciteConnection
-
Returns an instance of the connection properties.
- getProvider() - Method in class org.apache.calcite.linq4j.BaseQueryable
- getProvider() - Method in class org.apache.calcite.linq4j.QueryableDefaults.NonLeafReplayableQueryable
- getProvider() - Method in interface org.apache.calcite.linq4j.RawQueryable
-
Gets the query provider that is associated with this data source.
- getProvider() - Method in class org.apache.calcite.schema.impl.AbstractTableQueryable
- getPulledUpPredicates(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.Predicates.getPredicates()
statistic. - getPushDownConditions() - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- getQualifiedName() - Method in class org.apache.calcite.plan.RelOptAbstractTable
- getQualifiedName() - Method in interface org.apache.calcite.plan.RelOptTable
-
Obtains an identifier for this table.
- getQualifiedName() - Method in class org.apache.calcite.prepare.RelOptTableImpl
- getQualifiedName() - Method in class org.apache.calcite.rex.RexTableInputRef
- getQualifiedName() - Method in class org.apache.calcite.rex.RexTableInputRef.RelTableRef
- getQualifiedName() - Method in class org.apache.calcite.sql.validate.DelegatingSqlValidatorTable
- getQualifiedName() - Method in interface org.apache.calcite.sql.validate.SqlValidatorTable
- getQualifiedName() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getQualifiedName(String, int) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
-
Gets the fully qualified name for a
SqlIdentifier
at a given position of a sql statement. - getQualifiedName(RelOptTable) - Method in class org.apache.calcite.plan.TableAccessMap
-
Deprecated.Constructs a qualified name for an optimizer table reference.
- getQualify() - Method in class org.apache.calcite.sql.SqlSelect
- getQuery() - Method in class org.apache.calcite.plan.RelOptCluster
-
Deprecated.
- getQuery(RelDataType, Filter, Project, ImmutableBitSet, List<AggregateCall>, List<String>, List<Integer>, List<RelFieldCollation.Direction>, ImmutableBitSet, Integer, Project, Filter) - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getQueryName() - Method in enum org.apache.calcite.adapter.druid.QueryType
- getQueryProvider() - Method in interface org.apache.calcite.DataContext
-
Returns the query provider.
- getQueryProvider() - Method in class org.apache.calcite.plan.VisitorDataContext
- getQuerySpec() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getQueryString() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getQueryString(String, int) - Method in class org.apache.calcite.adapter.druid.DruidQuery.QuerySpec
- getQueryType() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getQueryType() - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- getQuotedCasing() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns how quoted identifiers are stored.
- getQuoting() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns the quoting scheme, or null if the combination of
SqlDialect.identifierQuoteString
andSqlDialect.identifierEndQuoteString
does not correspond to any known quoting scheme. - getRangeQueryLowerKey() - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- getRangeQueryLowerOp() - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- getRangeQueryUpperKey() - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- getRangeQueryUpperOp() - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- getRawSelectScope(SqlSelect) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the scope for resolving the SELECT, GROUP BY and HAVING clauses.
- getRawSelectScope(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getRecordFields() - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl.SyntheticRecordType
- getRecordFields() - Method in interface org.apache.calcite.linq4j.tree.Types.RecordType
- getReferenceCounts() - Method in class org.apache.calcite.rex.RexProgram
-
Gets reference counts for each expression in the program, where the references are detected from later expressions in the same program, as well as the project list and condition.
- getReferenceExpr() - Method in class org.apache.calcite.rex.RexFieldAccess
-
Returns the expression whose field is being accessed.
- getReferentialConstraints() - Method in class org.apache.calcite.plan.RelOptAbstractTable
- getReferentialConstraints() - Method in interface org.apache.calcite.plan.RelOptTable
-
Returns the referential constraints existing for this table.
- getReferentialConstraints() - Method in class org.apache.calcite.prepare.RelOptTableImpl
- getReferentialConstraints() - Method in interface org.apache.calcite.schema.Statistic
-
Returns the collection of referential constraints (foreign-keys) for this table.
- getReferentialConstraints() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getRefName() - Method in class org.apache.calcite.sql.SqlWindow
- getRel() - Method in interface org.apache.calcite.plan.RelDigest
-
Returns the relnode that this digest is associated with.
- getRel() - Method in class org.apache.calcite.plan.RelOptListener.RelEvent
- getRel(String) - Method in class org.apache.calcite.piglet.PigRelBuilder
- getRel(Operator) - Method in class org.apache.calcite.piglet.PigRelBuilder
- getRelBuilder() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Measure.Context
- getRelBuilder() - Method in class org.apache.calcite.rel.metadata.RelMdMeasure.DelegatingContext
- getRelBuilderConfigTransform() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns a function that takes a
RelBuilder.Config
and returns another. - getRelBuilderFactory() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns the factory to create
RelBuilder
, never null. - getRelDigest() - Method in class org.apache.calcite.rel.AbstractRelNode
- getRelDigest() - Method in interface org.apache.calcite.rel.RelNode
-
Returns a digest of this
RelNode
. - getRelFactories() - Method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- getRelFactories() - Method in interface org.apache.calcite.plan.Convention
-
Return RelFactories struct for this convention.
- getRelHint(HintStrategyTable, SqlNodeList) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns an immutable list of
RelHint
from sql hints, with a given inherit path from the root node. - getRelImplementorTracer() - Static method in class org.apache.calcite.util.trace.CalciteTrace
-
The "org.apache.calcite.rel.RelImplementorImpl" tracer reports when expressions are bound to variables (DEBUG, formerly FINE)
- getRelList() - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Returns a list of matched relational expressions.
- getRelList() - Method in class org.apache.calcite.plan.volcano.RelSubset
-
As
RelSubset.getRels()
but returns a list. - getRelMetadataTimestamp(RelNode) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Deprecated.
- getRelMetadataTimestamp(RelNode) - Method in class org.apache.calcite.plan.hep.HepPlanner
-
Deprecated.
- getRelMetadataTimestamp(RelNode) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Deprecated.
- getRelMetadataTimestamp(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Deprecated.
- getRelMetadataTimestamp(RelNode) - Method in class org.apache.calcite.test.MockRelOptPlanner
-
Deprecated.
- getRelNodeLabel(RelNode, List<Pair<String, Object>>) - Method in class org.apache.calcite.rel.externalize.RelDotWriter
- getRelOptSchema() - Method in class org.apache.calcite.plan.RelOptAbstractTable
- getRelOptSchema() - Method in interface org.apache.calcite.plan.RelOptConnection
-
Returns the schema underlying this connection.
- getRelOptSchema() - Method in interface org.apache.calcite.plan.RelOptTable
-
Returns the
RelOptSchema
this table belongs to. - getRelOptSchema() - Method in class org.apache.calcite.prepare.RelOptTableImpl
- getRelOptSchema() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getRelOptSchema() - Method in class org.apache.calcite.tools.RelBuilder
- getRelOptTable(SqlValidatorNamespace, Prepare.CatalogReader, String, boolean[]) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Converts a
SqlValidatorScope
into aRelOptTable
. - getRelRunner() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.Context
-
Gets a runner; it can execute a relational expression.
- getRels() - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Deprecated.
- getRels() - Method in class org.apache.calcite.plan.volcano.RelSubset
-
Returns the rel nodes in this rel subset.
- getRelsForStores() - Method in class org.apache.calcite.piglet.PigRelBuilder
-
Gets all relational plans corresponding to Pig Store operators.
- getRelTraitDefs() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- getRelTraitDefs() - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Returns the list of active trait types.
- getRelTraitDefs() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- getRelTypeName() - Method in class org.apache.calcite.rel.AbstractRelNode
- getRelTypeName() - Method in interface org.apache.calcite.rel.RelNode
-
Returns the name of this relational expression's class, sans package name, for use in explain.
- getRemainderConditions() - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- getRemaining(RexBuilder) - Method in class org.apache.calcite.rel.core.JoinInfo
-
Deprecated.
- getRepeatableSeed() - Method in class org.apache.calcite.plan.RelOptSamplingParameters
-
If
RelOptSamplingParameters.isRepeatable()
returnstrue
, this method returns a user-specified seed value. - getRepeatableSeed() - Method in class org.apache.calcite.sql.SqlSampleSpec.SqlTableSampleSpec
-
Seed to produce repeatable samples.
- getReplace() - Method in class org.apache.calcite.sql.SqlCreate
- getReplacement(SqlMoniker, boolean, Casing) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
- getReplacement(SqlMoniker, String) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
- getRequiredColumns() - Method in class org.apache.calcite.rel.core.Correlate
-
Returns the required columns in left relation required for the correlation in the right.
- getReservedAndKeyWords() - Method in class org.apache.calcite.sql.advise.SqlAdvisor
-
Returns an array of SQL reserved and keywords.
- getReservedKeywords() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- getResource() - Method in class org.apache.calcite.adapter.redis.RedisJedisManager
- getResultCount() - Method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.CountingSearchResultListener
- getResultSet() - Method in interface org.apache.calcite.server.CalciteServerStatement
- getResultType(SqlTestFactory, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- getResultType(SqlTestFactory, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Returns the data type of the row returned by a SQL query.
- getReturnType() - Method in class org.apache.calcite.sql.type.FunctionSqlType
- getReturnType(RelDataTypeFactory) - Method in interface org.apache.calcite.schema.AggregateFunction
-
Returns the return type of this function, constructed using the given type factory.
- getReturnType(RelDataTypeFactory) - Method in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- getReturnType(RelDataTypeFactory) - Method in class org.apache.calcite.schema.impl.ScalarFunctionImpl
- getReturnType(RelDataTypeFactory) - Method in interface org.apache.calcite.schema.ScalarFunction
-
Returns the return type of this function, constructed using the given type factory.
- getReturnType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlCountAggFunction
- getReturnType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlFirstLastValueAggFunction
- getReturnType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlHistogramAggFunction
- getReturnType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
- getReturnType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlSingleValueAggFunction
- getReturnType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlSumAggFunction
- getReturnType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlSumEmptyIsZeroAggFunction
- getReturnType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.SqlAggFunction
-
Deprecated.
- getReturnType(RelDataTypeFactory, SqlOperatorBinding) - Method in class org.apache.calcite.schema.impl.ScalarFunctionImpl
- getReturnTypeInference() - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- getReturnTypeInference() - Method in class org.apache.calcite.sql.SqlBasicFunction
- getReturnTypeInference() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns the return type inference strategy for this operator, or null if return type inference is implemented by a subclass override.
- getRexBuilder() - Method in class org.apache.calcite.adapter.enumerable.JavaRelImplementor
- getRexBuilder() - Method in class org.apache.calcite.plan.RelOptCluster
- getRexBuilder() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Measure.Context
- getRexBuilder() - Method in interface org.apache.calcite.sql2rel.InitializerContext
- getRexBuilder() - Method in interface org.apache.calcite.sql2rel.SqlRexContext
-
Returns the
RexBuilder
to use to createRexNode
objects. - getRexBuilder() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- getRexBuilder() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Returns the row-expression builder.
- getRexBuilder() - Method in class org.apache.calcite.tools.RelBuilder
-
Returns the builder for
RexNode
expressions. - getRexTransformer(RexBuilder, JoinRelType) - Method in class org.apache.calcite.rel.rules.SingleValuesOptimizationRules.PruneSingleValueRule
- getRight() - Method in class org.apache.calcite.rel.BiRel
- getRight() - Method in class org.apache.calcite.rel.mutable.MutableJoin
- getRight() - Method in class org.apache.calcite.rel.rules.LoptJoinTree
- getRight() - Method in class org.apache.calcite.rel.rules.LoptJoinTree.Node
- getRight() - Method in enum org.apache.calcite.sql.fun.SqlTrimFunction.Flag
- getRight() - Method in class org.apache.calcite.sql.SqlJoin
- getRightChild(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinProjectTransposeRule
-
Returns the Project corresponding to the right child.
- getRightChild(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule
- getRightColumnMapping(int, int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Determines whether there is a mapping from a column in the right factor of a self-join to a column from the left factor.
- getRightKeys() - Method in class org.apache.calcite.rel.core.EquiJoin
-
Deprecated.
- getRightPrec() - Method in class org.apache.calcite.sql.SqlOperator
- getRollup() - Method in class org.apache.calcite.sql.fun.SqlAnyValueAggFunction
- getRollup() - Method in class org.apache.calcite.sql.fun.SqlCountAggFunction
- getRollup() - Method in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
- getRollup() - Method in class org.apache.calcite.sql.fun.SqlSingleValueAggFunction
- getRollup() - Method in class org.apache.calcite.sql.fun.SqlSumAggFunction
- getRollup() - Method in class org.apache.calcite.sql.fun.SqlSumEmptyIsZeroAggFunction
- getRollup() - Method in class org.apache.calcite.sql.SqlAggFunction
-
Gets rollup aggregation function.
- getRollup(List<ImmutableBitSet>) - Static method in enum org.apache.calcite.rel.core.Aggregate.Group
-
Returns the ordered list of bits in a rollup.
- getRollup(SqlAggFunction) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
-
Deprecated.
- getRollup(SqlAggFunction) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule
-
Deprecated.
- getRoot() - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- getRoot() - Method in class org.apache.calcite.plan.hep.HepPlanner
- getRoot() - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Returns the root node of this query.
- getRoot() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- getRoot() - Method in class org.apache.calcite.test.MockRelOptPlanner
- getRootExpression() - Method in class org.apache.calcite.adapter.enumerable.JavaRelImplementor
-
Returns the expression used to access
DataContext
. - getRootRel() - Method in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- getRootSchema() - Method in interface org.apache.calcite.DataContext
-
Returns a sub-schema with a given name, or null.
- getRootSchema() - Method in interface org.apache.calcite.jdbc.CalciteConnection
-
Returns the root schema.
- getRootSchema() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.Context
-
Returns the root schema for statements that need a read-consistent snapshot.
- getRootSchema() - Method in class org.apache.calcite.plan.VisitorDataContext
- getRootSchema() - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- getRootSchema() - Method in interface org.apache.calcite.sql.validate.SqlValidatorCatalogReader
-
Returns the root namespace for name resolution.
- getRowConverter() - Method in class org.apache.calcite.adapter.kafka.KafkaTableOptions
- getRowCount() - Method in class org.apache.calcite.plan.RelOptAbstractTable
- getRowCount() - Method in interface org.apache.calcite.plan.RelOptTable
-
Returns an estimate of the number of rows in the table.
- getRowCount() - Method in class org.apache.calcite.prepare.RelOptTableImpl
- getRowCount() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.RowCount
-
Estimates the number of rows which will be returned by a relational expression.
- getRowCount() - Method in interface org.apache.calcite.schema.Statistic
-
Returns the approximate number of rows in the table.
- getRowCount() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getRowCount(double, double...) - Static method in class org.apache.calcite.materialize.Lattice
-
Returns an estimate of the number of rows in the tile with the given dimensions.
- getRowCount(double, List<Double>) - Static method in class org.apache.calcite.materialize.Lattice
-
Returns an estimate of the number of rows in the tile with the given dimensions.
- getRowCount(Object) - Method in class org.apache.calcite.adapter.java.ReflectiveSchema
- getRowCount(Object) - Method in class org.apache.calcite.test.ReflectiveSchemaWithoutRowCount
- getRowCount(List<Lattice.Column>) - Method in class org.apache.calcite.materialize.Lattice
-
Returns an estimate of the number of rows in the tile with the given dimensions.
- getRowCount(EnumerableLimit, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(RelSubset, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(Aggregate, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(Calc, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(Exchange, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(Filter, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(Intersect, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(Join, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(Minus, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(Project, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(Sample, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(Sort, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(TableModify, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(Union, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(Values, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.RowCount.getRowCount()
statistic. - getRowCount(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.RowCount.Handler
- getRowCount(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
-
Catch-all implementation for
BuiltInMetadata.RowCount.getRowCount()
, invoked using reflection. - getRowCount(SingleRel, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowList() - Static method in class org.apache.calcite.test.schemata.orderstream.OrdersStreamTableFactory
- getRows() - Method in interface org.apache.calcite.plan.RelOptCost
-
Returns the number of rows processed; this should not be confused with the row count produced by a relational expression (
RelNode.estimateRowCount(org.apache.calcite.rel.metadata.RelMetadataQuery)
). - getRows() - Method in class org.apache.calcite.plan.RelOptCostImpl
- getRowsPerMatch() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getRowType() - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Returns the SQL row type.
- getRowType() - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- getRowType() - Method in class org.apache.calcite.plan.RelOptAbstractTable
- getRowType() - Method in interface org.apache.calcite.plan.RelOptNode
- getRowType() - Method in interface org.apache.calcite.plan.RelOptTable
-
Describes the type of rows returned by this table.
- getRowType() - Method in class org.apache.calcite.prepare.RelOptTableImpl
- getRowType() - Method in class org.apache.calcite.rel.AbstractRelNode
- getRowType() - Method in interface org.apache.calcite.rel.RelNode
-
Returns the type of the rows returned by this relational expression.
- getRowType() - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- getRowType() - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- getRowType() - Method in class org.apache.calcite.sql.validate.DelegatingSqlValidatorTable
- getRowType() - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns the row type of this namespace, which comprises a list of names and types of the output columns.
- getRowType() - Method in interface org.apache.calcite.sql.validate.SqlValidatorTable
- getRowType() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable
- getRowType() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockRelViewTable
- getRowType() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getRowType(String) - Method in interface org.apache.calcite.rel.RelInput
- getRowType(String, String) - Method in interface org.apache.calcite.rel.RelInput
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.arrow.ArrowTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.csv.CsvTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.druid.DruidTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.file.CsvTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.file.JsonTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.geode.rel.GeodeTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleScannableTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.innodb.InnodbTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.kafka.KafkaStreamTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.mongodb.MongoTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.pig.PigTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.redis.RedisTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.example.maze.MazeTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.piglet.PigTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.schema.impl.ListTransientTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.schema.impl.StarTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.schema.impl.ViewTable
- getRowType(RelDataTypeFactory) - Method in interface org.apache.calcite.schema.Table
-
Returns this table's row type.
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions.ExplodeTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions.GridTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockDynamicTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.schemata.orderstream.BaseOrderStreamTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.schemata.orderstream.ProductsTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.schemata.orderstream.ProductsTemporalTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.util.Smalls.MazeTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.util.Smalls.SimpleTable
- getRowType(RelDataTypeFactory, List<? extends Object>) - Method in class org.apache.calcite.schema.impl.TableFunctionImpl
- getRowType(RelDataTypeFactory, List<? extends Object>) - Method in interface org.apache.calcite.schema.TableFunction
-
Returns the record type of the table yielded by this function when applied to given arguments.
- getRowType(RelDataTypeFactory, List<? extends Object>) - Method in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction
- getRowType(RelDataTypeFactory, List<? extends Object>) - Method in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction2
- getRowTypeInference() - Method in interface org.apache.calcite.sql.SqlTableFunction
-
Returns the record type of the table yielded by this function when applied to given arguments.
- getRowTypeInference() - Method in class org.apache.calcite.sql.SqlWindowTableFunction
- getRowTypeInference() - Method in class org.apache.calcite.sql.validate.SqlUserDefinedTableFunction
- getRowTypeInference() - Method in class org.apache.calcite.sql.validate.SqlUserDefinedTableMacro
- getRowTypeInference() - Method in class org.apache.calcite.test.MockSqlOperatorTable.BadTableFunction
- getRowTypeInference() - Method in class org.apache.calcite.test.MockSqlOperatorTable.DedupFunction
- getRowTypeInference() - Method in class org.apache.calcite.test.MockSqlOperatorTable.DynamicTypeFunction
- getRowTypeInference() - Method in class org.apache.calcite.test.MockSqlOperatorTable.InvalidTableFunction
- getRowTypeInference() - Method in class org.apache.calcite.test.MockSqlOperatorTable.RampFunction
- getRowTypeInference() - Method in class org.apache.calcite.test.MockSqlOperatorTable.RowFunction
- getRowTypeInference() - Method in class org.apache.calcite.test.MockSqlOperatorTable.ScoreTableFunction
- getRowTypeInference() - Method in class org.apache.calcite.test.MockSqlOperatorTable.SimilarlityTableFunction
- getRowTypeInference() - Method in class org.apache.calcite.test.MockSqlOperatorTable.TopNTableFunction
- getRowTypeSansSystemColumns() - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- getRowTypeSansSystemColumns() - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- getRowTypeSansSystemColumns() - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns the row type of this namespace, sans any system columns.
- getRule() - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Returns the invoked planner rule.
- getRule() - Method in class org.apache.calcite.plan.RelOptRuleOperand
-
Returns the rule this operand belongs to.
- getRuleAttemptsTracer() - Static method in class org.apache.calcite.util.trace.CalciteTrace
- getRuleByDescription(String) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Returns the rule with a given description.
- getRuleCall() - Method in class org.apache.calcite.plan.RelOptListener.RuleEvent
- getRules() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- getRules() - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Returns the list of all registered rules.
- getRules() - Method in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- getRules() - Method in class org.apache.calcite.sql.type.CompositeSingleOperandTypeChecker
- getRules() - Method in class org.apache.calcite.test.MockRelOptPlanner
- getSamplePercentage() - Method in class org.apache.calcite.sql.SqlSampleSpec.SqlTableSampleSpec
-
Deprecated.
- getSamplingParameters() - Method in class org.apache.calcite.rel.core.Sample
-
Retrieve the sampling parameters for this Sample.
- getSamplingPercentage() - Method in class org.apache.calcite.plan.RelOptSamplingParameters
-
Deprecated.
- getSatisfyingSubsets() - Method in class org.apache.calcite.plan.volcano.RelSubset
-
Returns stream of subsets whose traitset is satisfied by current subset's traitset.
- getScale() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets the scale of this type.
- getScale() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getScale() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getScale() - Method in class org.apache.calcite.sql.SqlBasicTypeNameSpec
- getScale() - Method in class org.apache.calcite.sql.SqlNumericLiteral
- getScale() - Method in class org.apache.calcite.sql.type.BasicSqlType
- getScale() - Method in class org.apache.calcite.sql.type.IntervalSqlType
- getScanFactory() - Method in class org.apache.calcite.tools.RelBuilder
- getSchema() - Method in interface org.apache.calcite.jdbc.CalciteConnection
- getSchema() - Method in class org.apache.calcite.sql.SqlDescribeSchema
- getSchema(CalciteSchema, Iterable<String>, SqlNameMatcher) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Finds and returns
CalciteSchema
nested to the given rootSchema with specified schemaPath. - getSchemaObjectMonikers(SqlValidatorCatalogReader, List<String>, List<SqlMoniker>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
- getSchemaPath() - Method in class org.apache.calcite.schema.impl.ViewTable
-
Returns the schema path of the view.
- getSchemaPaths() - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- getSchemaPaths() - Method in class org.apache.calcite.sql.validate.DelegatingSqlValidatorCatalogReader
- getSchemaPaths() - Method in interface org.apache.calcite.sql.validate.SqlValidatorCatalogReader
-
Returns the paths of all schemas to look in for tables.
- getSchemas(Meta.ConnectionHandle, String, Meta.Pat) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- getScope() - Method in class org.apache.calcite.sql.SqlAlter
- getScope() - Method in class org.apache.calcite.sql.SqlCallBinding
-
Returns the scope of the call.
- getScope() - Method in class org.apache.calcite.sql.validate.CollectNamespace
- getScope() - Method in class org.apache.calcite.sql.validate.SqlScopedShuttle
-
Returns the current scope.
- getScope() - Method in class org.apache.calcite.sql.validate.TableConstructorNamespace
-
Returns the scope.
- getScope(SqlCallBinding) - Static method in class org.apache.calcite.sql.validate.SqlNonNullableAccessors
- getScript() - Method in class org.apache.calcite.adapter.pig.PigRel.Implementor
- getSearchResultEnumerator(String, Map<String, String>, List<String>) - Method in interface org.apache.calcite.adapter.splunk.search.SplunkConnection
- getSearchResultEnumerator(String, Map<String, String>, List<String>) - Method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- getSearchResults(String, Map<String, String>, List<String>, SearchResultListener) - Method in interface org.apache.calcite.adapter.splunk.search.SplunkConnection
- getSearchResults(String, Map<String, String>, List<String>, SearchResultListener) - Method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- getSeedRel() - Method in class org.apache.calcite.rel.core.RepeatUnion
- getSelectivity(Aggregate, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdSelectivity
- getSelectivity(Calc, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdSelectivity
- getSelectivity(Filter, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdSelectivity
- getSelectivity(Join, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdSelectivity
- getSelectivity(Project, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdSelectivity
- getSelectivity(Sort, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdSelectivity
- getSelectivity(TableModify, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdSelectivity
- getSelectivity(TableScan, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdSelectivity
- getSelectivity(Union, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdSelectivity
- getSelectivity(RelNode, RelMetadataQuery, RexNode) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Selectivity.Handler
- getSelectivity(RelNode, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdSelectivity
- getSelectivity(RelNode, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.Selectivity.getSelectivity(RexNode)
statistic. - getSelectivity(RexNode) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Selectivity
-
Estimates the percentage of an expression's output rows which satisfy a given predicate.
- getSelectivity(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns a guess for the selectivity of an expression.
- getSelectivityValue(RexNode) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Returns the selectivity value stored in a call.
- getSelectList() - Method in class org.apache.calcite.sql.SqlSelect
- getSelectList(SqlSelect) - Static method in class org.apache.calcite.sql.validate.SqlNonNullableAccessors
- getSelectListItem(SqlNode, int) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns the
i
th select-list item of a query. - getSelectScope(SqlSelect) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the appropriate scope for validating a particular clause of a SELECT statement.
- getSelectScope(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getSelfJoinExprForUpdate(SqlNode, String) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Allows a subclass to provide information about how to convert an UPDATE into a MERGE via self-join.
- getSemiJoinDistinctRowCount(Join, RelMetadataQuery, ImmutableBitSet, RexNode) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Computes the number of distinct rows for a set of keys returned from a semi-join.
- getSet(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Finds an expression's equivalence set.
- getShort() - Method in interface org.apache.calcite.linq4j.tree.Primitive.Source
- getShortestDistance(V, V) - Method in class org.apache.calcite.util.graph.Graphs.FrozenGraph
-
Returns the shortest distance between two points, -1, if there is no path.
- getSign() - Method in class org.apache.calcite.sql.SqlIntervalLiteral.IntervalValue
- getSignature() - Method in interface org.apache.calcite.server.CalciteServerStatement
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlBetweenOperator
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlCastFunction
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlConvertFunction
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlDatePartFunction
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlExtractFunction
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlIntervalOperator
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlJsonArrayFunction
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlJsonModifyFunction
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlJsonObjectFunction
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlJsonQueryFunction
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlOverlayFunction
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlPositionFunction
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlSubstringFunction
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlTranslate3Function
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlTranslateFunction
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlTrimFunction
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.SqlBinaryOperator
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.SqlOperator
-
Returns a template describing how the operator signature is to be built.
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.SqlPostfixOperator
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.SqlPrefixOperator
- getSimple() - Method in class org.apache.calcite.sql.SqlIdentifier
- getSimpleName() - Method in class org.apache.calcite.plan.ConventionTraitDef
- getSimpleName() - Method in class org.apache.calcite.plan.RelTraitDef
-
Returns a simple name for this RelTraitDef (for use in
RelNode.explain(org.apache.calcite.rel.RelWriter)
). - getSimpleName() - Method in class org.apache.calcite.rel.RelCollationTraitDef
- getSimpleName() - Method in class org.apache.calcite.rel.RelDistributionTraitDef
- getSimplify() - Method in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRuleCall
- getSingleRowTableName() - Method in class org.apache.calcite.sql.dialect.OracleSqlDialect
- getSingleRowTableName() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns the name of the system table that has precisely one row.
- getSortExps() - Method in class org.apache.calcite.rel.core.Sort
-
Returns the sort expressions.
- getSource() - Method in class org.apache.calcite.rex.RexExecutable
- getSource() - Method in class org.apache.calcite.sql.SqlInsert
-
Returns the source expression for the data to be inserted.
- getSource(int) - Method in class org.apache.calcite.util.mapping.Mappings.AbstractMapping
- getSource(int) - Method in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
-
Returns the source that a target maps to.
- getSource(int) - Method in class org.apache.calcite.util.mapping.Mappings.OverridingSourceMapping
- getSource(int) - Method in interface org.apache.calcite.util.mapping.Mappings.SourceMapping
-
Returns the source that a target maps to.
- getSource(int) - Method in class org.apache.calcite.util.Permutation
-
Returns the position which maps to
target
. - getSourceCount() - Method in class org.apache.calcite.util.mapping.AbstractSourceMapping
- getSourceCount() - Method in class org.apache.calcite.util.mapping.AbstractTargetMapping
- getSourceCount() - Method in interface org.apache.calcite.util.mapping.Mapping
-
Returns the number of sources.
- getSourceCount() - Method in class org.apache.calcite.util.mapping.Mappings.AbstractMapping
- getSourceCount() - Method in interface org.apache.calcite.util.mapping.Mappings.FunctionMapping
- getSourceCount() - Method in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
- getSourceCount() - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- getSourceCount() - Method in interface org.apache.calcite.util.mapping.Mappings.SourceMapping
- getSourceCount() - Method in interface org.apache.calcite.util.mapping.Mappings.TargetMapping
- getSourceCount() - Method in class org.apache.calcite.util.Permutation
- getSourceExpressionList() - Method in class org.apache.calcite.rel.core.TableModify
- getSourceExpressionList() - Method in class org.apache.calcite.sql.SqlUpdate
-
Returns the list of source expressions.
- getSourceField(int) - Method in class org.apache.calcite.rex.RexProgram
-
Returns the input field that an output field is populated from, or -1 if it is populated from an expression.
- getSourceOpt(int) - Method in class org.apache.calcite.util.mapping.AbstractSourceMapping
- getSourceOpt(int) - Method in class org.apache.calcite.util.mapping.Mappings.AbstractMapping
- getSourceOpt(int) - Method in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
-
Returns the source that a target maps to, or -1 if it is not mapped.
- getSourceOpt(int) - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
-
Returns the source that a target maps to, or -1 if it is not mapped.
- getSourceOpt(int) - Method in interface org.apache.calcite.util.mapping.Mappings.SourceMapping
-
Returns the source that a target maps to, or -1 if it is not mapped.
- getSourceOpt(int) - Method in interface org.apache.calcite.util.mapping.Mappings.TargetMapping
-
Returns the source that a target maps to, or -1 if it is not mapped.
- getSourceOpt(int) - Method in class org.apache.calcite.util.Permutation
- getSourceQualifiedName() - Method in interface org.apache.calcite.rel.RelReferentialConstraint
-
The qualified name of the referencing table, e.g.
- getSourceQualifiedName() - Method in class org.apache.calcite.rel.RelReferentialConstraintImpl
- getSourceSelect() - Method in class org.apache.calcite.sql.SqlDelete
-
Gets the source SELECT expression for the data to be deleted.
- getSourceSelect() - Method in class org.apache.calcite.sql.SqlMerge
-
Gets the source SELECT expression for the data to be updated/inserted.
- getSourceSelect() - Method in class org.apache.calcite.sql.SqlUpdate
-
Gets the source SELECT expression for the data to be updated.
- getSourceSelect(SqlDelete) - Static method in class org.apache.calcite.sql.validate.SqlNonNullableAccessors
- getSourceSelect(SqlMerge) - Static method in class org.apache.calcite.sql.validate.SqlNonNullableAccessors
- getSourceSelect(SqlUpdate) - Static method in class org.apache.calcite.sql.validate.SqlNonNullableAccessors
- getSourceString() - Method in class org.apache.calcite.util.SourceStringReader
-
Returns the source string.
- getSourceTableRef() - Method in class org.apache.calcite.sql.SqlMerge
-
Returns the source query of this MERGE.
- getSpaceName() - Method in enum org.apache.calcite.sql.type.SqlTypeName
-
Returns the name of this type, with underscores converted to spaces, for example "TIMESTAMP WITH LOCAL TIME ZONE", "DATE".
- getSparkContext(DataContext) - Static method in class org.apache.calcite.adapter.spark.SparkRuntime
-
Returns the Spark context for the current execution.
- getSparkHandler(boolean) - Static method in class org.apache.calcite.jdbc.CalcitePrepare.Dummy
-
Returns a spark handler.
- getSql() - Method in class org.apache.calcite.model.JsonLattice
-
Returns the SQL query as a string, concatenating a list of lines if necessary.
- getSql() - Method in class org.apache.calcite.model.JsonMaterialization
-
Returns the SQL query as a string, concatenating a list of lines if necessary.
- getSql() - Method in class org.apache.calcite.model.JsonView
-
Returns the SQL query as a string, concatenating a list of lines if necessary.
- getSql() - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Returns the SQL.
- getSql() - Method in class org.apache.calcite.sql.util.SqlString
-
Returns the SQL string.
- getSqlAndClear() - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Returns the SQL and clears the buffer.
- getSqlIdentifier() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets the
SqlIdentifier
associated with this type. - getSqlIdentifier() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getSqlIdentifier() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getSqlIdentifier() - Method in class org.apache.calcite.sql.SqlFunction
-
Returns the fully-qualified name of function, or null for a built-in function.
- getSqlIdentifier() - Method in class org.apache.calcite.sql.type.ObjectSqlType
- getSqlTimingTracer() - Static method in class org.apache.calcite.util.trace.CalciteTrace
-
The tracer "org.apache.calcite.sql.timing" traces timing for various stages of query processing.
- getSqlToRelConverter(SqlValidator, Prepare.CatalogReader, SqlToRelConverter.Config) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- getSqlToRelConverter(SqlValidator, Prepare.CatalogReader, SqlToRelConverter.Config) - Method in class org.apache.calcite.prepare.Prepare
-
Protected method to allow subclasses to override construction of SqlToRelConverter.
- getSqlToRelConverterConfig() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
The configuration of
SqlToRelConverter
. - getSqlToRelTracer() - Static method in class org.apache.calcite.util.trace.CalciteTrace
-
The "org.apache.calcite.sql2rel" tracer reports parse events.
- getSqlType() - Method in enum org.apache.calcite.adapter.pig.PigDataType
- getSqlTypeName() - Method in class org.apache.calcite.rel.type.DynamicRecordTypeImpl
- getSqlTypeName() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets the
SqlTypeName
of this type. - getSqlTypeName() - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- getSqlTypeName() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
-
Gets the
SqlTypeName
of this type. - getSqlTypeName() - Method in class org.apache.calcite.rel.type.RelRecordType
- getSqlTypeName() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getSqlTypeName() - Method in class org.apache.calcite.sql.type.AbstractSqlType
- getSqlValidator() - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- getSqlValidator() - Method in class org.apache.calcite.prepare.Prepare
- getSqlValidatorConfig() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
The configuration of
SqlValidator
. - getStackTrace(Throwable) - Static method in class org.apache.calcite.util.Util
-
Deprecated.Use
Throwables.getStackTraceAsString(Throwable)
- getStandardName() - Method in enum org.apache.calcite.sql.SqlJsonEncoding
- getStarTable() - Method in class org.apache.calcite.jdbc.CalciteSchema.LatticeEntry
- getStarTable() - Method in class org.apache.calcite.jdbc.CalciteSchema.LatticeEntryImpl
- getStarTables(CalciteSchema) - Static method in class org.apache.calcite.schema.Schemas
-
Returns the star tables defined in a schema.
- getStartColumnNum() - Method in class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
-
Returns 1-based starting column number.
- getStartLineNum() - Method in class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
-
Returns 1-based starting line number.
- getStartPrecision(RelDataTypeSystem) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- getStartPrecisionPreservingDefault() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- getStartUnit() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- getStartUnit() - Method in enum org.apache.calcite.sql.type.SqlTypeName
-
Returns
HOUR
forHOUR TO SECOND
andHOUR
,SECOND
forSECOND
. - getState() - Method in enum org.apache.calcite.sql.SqlStateCodes
-
Deprecated.
- getStateClass() - Method in enum org.apache.calcite.sql.SqlStateCodes
-
Deprecated.
- getStatement(Meta.StatementHandle) - Method in interface org.apache.calcite.server.CalciteServer
-
Returns the statement with a given handle.
- getStatements() - Method in class org.apache.calcite.adapter.pig.PigRel.Implementor
- getStatementTracer() - Static method in class org.apache.calcite.util.trace.CalciteTrace
-
The "org.apache.calcite.prepare.Prepare" tracer prints the generated program at DEBUG (formerly, FINE) or higher.
- getStateSize() - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- getStateSubClass() - Method in enum org.apache.calcite.sql.SqlStateCodes
-
Deprecated.
- getStateType(AggContext) - Method in interface org.apache.calcite.adapter.enumerable.AggImplementor
-
Returns the types of the intermediate variables used by the aggregate implementation.
- getStateType(AggContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.LagImplementor
- getStateType(AggContext) - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- getStatistic() - Method in class org.apache.calcite.adapter.file.JsonTable
- getStatistic() - Method in class org.apache.calcite.adapter.kafka.KafkaStreamTable
- getStatistic() - Method in class org.apache.calcite.piglet.PigTable
- getStatistic() - Method in class org.apache.calcite.schema.impl.AbstractTable
- getStatistic() - Method in interface org.apache.calcite.schema.Table
-
Returns a provider of statistics about this table.
- getStatistic() - Method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions.ExplodeTable
- getStatistic() - Method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions.GridTable
- getStatistic() - Method in class org.apache.calcite.test.schemata.orderstream.BaseOrderStreamTable
- getStatistic() - Method in class org.apache.calcite.test.schemata.orderstream.ProductsTable
- getStatistic() - Method in class org.apache.calcite.test.schemata.orderstream.ProductsTemporalTable
- getStatisticProvider() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns the source of statistics about tables and columns to be used by the lattice suggester to deduce primary keys, foreign keys, and the direction of relationships.
- getStrength() - Method in class org.apache.calcite.sql.parser.SqlParserUtil.ParsedCollation
- getStrictEnd() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getStrictStart() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getString(String) - Method in interface org.apache.calcite.rel.RelInput
-
Returns a
string
value. - getString(List<String>) - Static method in class org.apache.calcite.sql.SqlIdentifier
-
Converts a list of strings to a qualified identifier.
- getStringArray() - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- getStringFunctions() - Static method in class org.apache.calcite.sql.SqlJdbcFunctionCall
- getStringList(String) - Method in interface org.apache.calcite.rel.RelInput
- getStringLiteralOperand(int) - Method in class org.apache.calcite.rex.RexCallBinding
- getStringLiteralOperand(int) - Method in class org.apache.calcite.sql.SqlCallBinding
- getStringLiteralOperand(int) - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Deprecated.
- getStringValue() - Method in class org.apache.calcite.sql.SqlLiteral
-
Deprecated.
- getStrongPolicyInference() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns the
Strong.Policy
strategy for this operator, or null if there is no particular strategy, in which case this policy will be deducted from the operator'sSqlKind
. - getStructKind() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Returns the rule for resolving the fields of a structured type, or
StructKind.NONE
if this is not a structured type. - getStructKind() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getStructKind() - Method in class org.apache.calcite.rel.type.RelRecordType
- getStructKind() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getSubQueryExpr(SqlCall) - Method in interface org.apache.calcite.sql2rel.SqlRexContext
-
Returns the expression used to access a given IN or EXISTS
sub-query
. - getSubQueryExpr(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- getSubSchema(String) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getSubSchema(String) - Method in class org.apache.calcite.schema.impl.AbstractSchema
- getSubSchema(String) - Method in class org.apache.calcite.schema.impl.DelegatingSchema
- getSubSchema(String) - Method in interface org.apache.calcite.schema.Schema
-
Returns a sub-schema with a given name, or null.
- getSubSchema(String) - Method in interface org.apache.calcite.schema.SchemaPlus
- getSubSchema(String, boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema
- getSubSchemaMap() - Method in class org.apache.calcite.adapter.jdbc.JdbcCatalogSchema
- getSubSchemaMap() - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns a collection of sub-schemas, both explicit (defined using
CalciteSchema.add(String, org.apache.calcite.schema.Schema)
) and implicit (defined usingSchema.getSubSchemaNames()
andSchema.getSubSchema(String)
). - getSubSchemaMap() - Method in class org.apache.calcite.schema.impl.AbstractSchema
-
Returns a map of sub-schemas in this schema by name.
- getSubSchemaNames() - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getSubSchemaNames() - Method in class org.apache.calcite.schema.impl.AbstractSchema
- getSubSchemaNames() - Method in class org.apache.calcite.schema.impl.DelegatingSchema
- getSubSchemaNames() - Method in interface org.apache.calcite.schema.Schema
-
Returns the names of this schema's child schemas.
- getSubset(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Returns the subset that a relational expression belongs to.
- getSubset(RelNode, RelTraitSet) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- getSubsetList() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getSubsetNonNull(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Returns the subset that a relational expression belongs to.
- getSubsets() - Method in class org.apache.calcite.rel.core.Match
- getSubsetsSatisfyingThis() - Method in class org.apache.calcite.plan.volcano.RelSubset
-
Returns stream of subsets whose traitset satisfies current subset's traitset.
- getSubtype() - Method in class org.apache.calcite.sql.fun.SqlAvgAggFunction
-
Deprecated.
- getSubtype() - Method in class org.apache.calcite.sql.fun.SqlCovarAggFunction
-
Deprecated.
- getSyntax() - Method in class org.apache.calcite.sql.fun.SqlAbstractTimeFunction
- getSyntax() - Method in class org.apache.calcite.sql.fun.SqlBaseContextVariable
- getSyntax() - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- getSyntax() - Method in class org.apache.calcite.sql.fun.SqlCaseOperator
- getSyntax() - Method in class org.apache.calcite.sql.fun.SqlCastFunction
- getSyntax() - Method in class org.apache.calcite.sql.fun.SqlCountAggFunction
- getSyntax() - Method in class org.apache.calcite.sql.fun.SqlCurrentDateFunction
- getSyntax() - Method in class org.apache.calcite.sql.SqlAsofJoin.SqlAsofJoinOperator
- getSyntax() - Method in class org.apache.calcite.sql.SqlBasicFunction
- getSyntax() - Method in class org.apache.calcite.sql.SqlBinaryOperator
- getSyntax() - Method in class org.apache.calcite.sql.SqlDescriptorOperator
- getSyntax() - Method in class org.apache.calcite.sql.SqlFunction
- getSyntax() - Method in class org.apache.calcite.sql.SqlInternalOperator
- getSyntax() - Method in class org.apache.calcite.sql.SqlJoin.SqlJoinOperator
- getSyntax() - Method in class org.apache.calcite.sql.SqlMatchRecognize.SqlMatchRecognizeOperator
- getSyntax() - Method in class org.apache.calcite.sql.SqlMeasureOperator
- getSyntax() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns the syntactic type of this operator, never null.
- getSyntax() - Method in class org.apache.calcite.sql.SqlPostfixOperator
- getSyntax() - Method in class org.apache.calcite.sql.SqlPrefixOperator
- getSyntax() - Method in class org.apache.calcite.sql.SqlSelectOperator
- getSyntax() - Method in class org.apache.calcite.sql.SqlSnapshot.SqlSnapshotOperator
- getSyntax() - Method in class org.apache.calcite.sql.SqlSpecialOperator
- getSysEndFieldName() - Method in interface org.apache.calcite.schema.TemporalTable
-
Returns the name of the system column that contains the end effective time of each row.
- getSysEndFieldName() - Method in class org.apache.calcite.test.schemata.orderstream.ProductsTemporalTable
- getSysStartFieldName() - Method in interface org.apache.calcite.schema.TemporalTable
-
Returns the name of the system column that contains the start effective time of each row.
- getSysStartFieldName() - Method in class org.apache.calcite.test.schemata.orderstream.ProductsTemporalTable
- getSystemFieldList() - Method in class org.apache.calcite.rel.core.Join
-
Returns a list of system fields that will be prefixed to output row type.
- getSystemFieldList() - Method in class org.apache.calcite.rel.logical.LogicalAsofJoin
- getSystemFieldList() - Method in class org.apache.calcite.rel.logical.LogicalJoin
- getSystemFields() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Returns a list of fields to be prefixed to each relational expression.
- getSystemFunctions() - Static method in class org.apache.calcite.sql.SqlJdbcFunctionCall
- getSystemInfo() - Static method in class org.apache.calcite.adapter.utils.OsQueryTableUtil
- getTable() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getTable() - Method in class org.apache.calcite.adapter.pig.PigAggregate
-
Override this method so it looks down the tree to find the table this node is acting on.
- getTable() - Method in class org.apache.calcite.adapter.pig.PigFilter
-
Override this method so it looks down the tree to find the table this node is acting on.
- getTable() - Method in class org.apache.calcite.adapter.pig.PigJoin
-
The Pig alias of the joined relation will have the same name as one from the left side of the join.
- getTable() - Method in class org.apache.calcite.adapter.pig.PigProject
-
Override this method so it looks down the tree to find the table this node is acting on.
- getTable() - Method in class org.apache.calcite.jdbc.CalciteSchema.TableEntry
- getTable() - Method in class org.apache.calcite.jdbc.CalciteSchema.TableEntryImpl
- getTable() - Method in class org.apache.calcite.rel.AbstractRelNode
- getTable() - Method in class org.apache.calcite.rel.core.TableModify
- getTable() - Method in class org.apache.calcite.rel.core.TableScan
- getTable() - Method in class org.apache.calcite.rel.core.TableSpool
- getTable() - Method in interface org.apache.calcite.rel.RelNode
-
If this relational expression represents an access to a table, returns that table, otherwise returns null.
- getTable() - Method in class org.apache.calcite.rex.RexTableInputRef.RelTableRef
- getTable() - Method in class org.apache.calcite.schema.impl.ModifiableViewTable
- getTable() - Method in interface org.apache.calcite.schema.ModifiableView
-
Returns the underlying table.
- getTable() - Method in class org.apache.calcite.sql.SqlDescribeTable
- getTable() - Method in class org.apache.calcite.sql.validate.MatchRecognizeNamespace
- getTable() - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- getTable() - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- getTable() - Method in class org.apache.calcite.sql.validate.SelectScope
- getTable() - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns the underlying table, or null if there is none.
- getTable(String) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getTable(String) - Static method in class org.apache.calcite.chinook.CodesFunction
- getTable(String) - Method in interface org.apache.calcite.rel.RelInput
- getTable(String) - Method in class org.apache.calcite.schema.impl.AbstractSchema
- getTable(String) - Method in class org.apache.calcite.schema.impl.DelegatingSchema
- getTable(String) - Method in interface org.apache.calcite.schema.Schema
-
Returns a table with a given name, or null if not found.
- getTable(String, boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns a table with the given name.
- getTable(List<String>) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- getTable(List<String>) - Method in interface org.apache.calcite.prepare.Prepare.CatalogReader
- getTable(List<String>) - Method in class org.apache.calcite.sql.validate.DelegatingSqlValidatorCatalogReader
- getTable(List<String>) - Method in interface org.apache.calcite.sql.validate.SqlValidatorCatalogReader
-
Finds a table or schema with the given name, possibly qualified.
- getTable(SqlOperatorBinding) - Method in class org.apache.calcite.sql.validate.SqlUserDefinedTableMacro
-
Returns the table in this UDF, or null if there is no table.
- getTable(SqlValidatorNamespace) - Static method in class org.apache.calcite.sql.validate.SqlNonNullableAccessors
- getTableAccessMode(List<String>) - Method in class org.apache.calcite.plan.TableAccessMap
-
Deprecated.Determines the access mode of a table.
- getTableBasedOnNullaryFunction(String, boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns a tables derived from explicit and implicit functions that take zero parameters.
- getTableBySql(String) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns a table that materializes the given SQL statement.
- getTableDef() - Method in class org.apache.calcite.adapter.innodb.InnodbTable
- getTableDef(String) - Method in class org.apache.calcite.adapter.innodb.InnodbSchema
-
Return table definition.
- getTableEntry(SqlValidatorCatalogReader, List<String>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Finds a
CalciteSchema.TableEntry
in a given catalog reader whose table has the given name, possibly qualified. - getTableExpression(SchemaPlus, String, Table, Class<?>) - Static method in class org.apache.calcite.schema.Schemas
-
Generates an expression with which table can be referenced in generated code.
- getTableForMember(List<String>) - Method in interface org.apache.calcite.plan.RelOptSchema
-
Retrieves a
RelOptTable
based upon a member access. - getTableForMember(List<String>) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- getTableForMember(List<String>) - Method in interface org.apache.calcite.prepare.Prepare.CatalogReader
- getTableForMember(List<String>, String, boolean[]) - Method in interface org.apache.calcite.plan.RelOptSchemaWithSampling
-
Retrieves a
RelOptTable
based upon a member access, using a sample dataset if it exists. - getTableHints() - Method in interface org.apache.calcite.plan.RelOptTable.ToRelContext
-
Returns the table hints of the table to convert, usually you can use the hints to pass along some dynamic params.
- getTableMap() - Method in class org.apache.calcite.adapter.cassandra.CassandraSchema
- getTableMap() - Method in class org.apache.calcite.adapter.clone.CloneSchema
- getTableMap() - Method in class org.apache.calcite.adapter.csv.CsvSchema
- getTableMap() - Method in class org.apache.calcite.adapter.druid.DruidSchema
- getTableMap() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchema
- getTableMap() - Method in class org.apache.calcite.adapter.geode.rel.GeodeSchema
- getTableMap() - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchema
- getTableMap() - Method in class org.apache.calcite.adapter.innodb.InnodbSchema
- getTableMap() - Method in class org.apache.calcite.adapter.java.ReflectiveSchema
- getTableMap() - Method in class org.apache.calcite.adapter.mongodb.MongoSchema
- getTableMap() - Method in class org.apache.calcite.adapter.pig.PigSchema
- getTableMap() - Method in class org.apache.calcite.adapter.splunk.SplunkSchema
- getTableMap() - Method in class org.apache.calcite.adapter.tpcds.TpcdsSchema
- getTableMap() - Method in class org.apache.calcite.adapter.tpch.TpchSchema
- getTableMap() - Method in class org.apache.calcite.schema.impl.AbstractSchema
-
Returns a map of tables in this schema by name.
- getTableModOp() - Method in class org.apache.calcite.prepare.Prepare.PreparedExplain
- getTableModOp() - Method in interface org.apache.calcite.prepare.Prepare.PreparedResult
-
Returns the table modification operation corresponding to this statement if it is a table modification statement; otherwise null.
- getTableModOp() - Method in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- getTableName() - Method in class org.apache.calcite.adapter.redis.RedisTableFieldInfo
- getTableName(RelNode) - Method in class org.apache.calcite.adapter.pig.PigRel.Implementor
- getTableNames() - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getTableNames() - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns the set of all table names.
- getTableNames() - Method in class org.apache.calcite.schema.impl.AbstractSchema
- getTableNames() - Method in class org.apache.calcite.schema.impl.DelegatingSchema
- getTableNames() - Method in interface org.apache.calcite.schema.Schema
-
Returns the names of the tables in this schema.
- getTableNamespace(List<String>) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- getTableNamespace(List<String>) - Method in class org.apache.calcite.sql.validate.ParameterScope
- getTableNamespace(List<String>) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Deprecated.
- getTableOrigin(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Determines the origin of a
RelNode
, provided it maps to a single table, optionally with filtering and projection. - getTablePath() - Method in class org.apache.calcite.schema.impl.ModifiableViewTable
- getTablePath() - Method in interface org.apache.calcite.schema.ModifiableView
-
Returns the full path of the underlying table.
- getTableRef() - Method in class org.apache.calcite.rex.RexTableInputRef
- getTableRef() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getTableRef() - Method in class org.apache.calcite.sql.SqlSnapshot
- getTableReferences() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.TableReferences
-
This provider returns the tables used by a given plan.
- getTableReferences(RelSubset, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
- getTableReferences(Aggregate, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
Table references from Aggregate.
- getTableReferences(Calc, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
Table references from Calc.
- getTableReferences(Exchange, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
Table references from Exchange.
- getTableReferences(Filter, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
Table references from Filter.
- getTableReferences(Join, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
Table references from Join.
- getTableReferences(Project, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
Table references from Project.
- getTableReferences(Sample, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
Table references from Sample.
- getTableReferences(SetOp, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
Table references from Union, Intersect, Minus.
- getTableReferences(Sort, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
Table references from Sort.
- getTableReferences(TableModify, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
Table references from TableModify.
- getTableReferences(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
TableScan table reference.
- getTableReferences(Window, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
Table references from Window.
- getTableReferences(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Determines the tables used by a plan.
- getTableReferences(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.TableReferences.Handler
- getTableReferences(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
- getTables(Meta.ConnectionHandle, String, Meta.Pat, Meta.Pat, List<String>) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- getTablesAccessed() - Method in class org.apache.calcite.plan.TableAccessMap
-
Deprecated.Returns a set of qualified names for all tables accessed.
- getTablesBasedOnNullaryFunctions() - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns tables derived from explicit and implicit functions that take zero parameters.
- getTableScan() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getTableTypes(Meta.ConnectionHandle) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- getTarget() - Method in class org.apache.calcite.adapter.java.ReflectiveSchema
-
Returns the wrapped object.
- getTarget() - Method in class org.apache.calcite.util.DelegatingInvocationHandler
-
Returns the object to forward method calls to, should the derived class not implement the method.
- getTarget(int) - Method in class org.apache.calcite.util.mapping.Mappings.AbstractMapping
- getTarget(int) - Method in interface org.apache.calcite.util.mapping.Mappings.FunctionMapping
-
Returns the target that a source maps to.
- getTarget(int) - Method in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
-
Returns the target that a source maps to.
- getTarget(int) - Method in class org.apache.calcite.util.mapping.Mappings.OverridingTargetMapping
- getTarget(int) - Method in interface org.apache.calcite.util.mapping.Mappings.TargetMapping
-
Returns the target that a source maps to.
- getTarget(int) - Method in class org.apache.calcite.util.Permutation
-
Returns the position that
source
is mapped to. - getTargetColumnList() - Method in class org.apache.calcite.sql.SqlInsert
-
Returns the list of target column names, or null for all columns in the target table.
- getTargetColumnList() - Method in class org.apache.calcite.sql.SqlUpdate
-
Returns the list of target column names.
- getTargetCount() - Method in class org.apache.calcite.util.mapping.AbstractSourceMapping
- getTargetCount() - Method in class org.apache.calcite.util.mapping.AbstractTargetMapping
- getTargetCount() - Method in interface org.apache.calcite.util.mapping.Mapping
-
Returns the number of targets.
- getTargetCount() - Method in class org.apache.calcite.util.mapping.Mappings.AbstractMapping
- getTargetCount() - Method in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
- getTargetCount() - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- getTargetCount() - Method in interface org.apache.calcite.util.mapping.Mappings.SourceMapping
- getTargetCount() - Method in interface org.apache.calcite.util.mapping.Mappings.TargetMapping
- getTargetCount() - Method in class org.apache.calcite.util.Permutation
- getTargetField(RelDataType, RelDataTypeFactory, SqlIdentifier, SqlValidatorCatalogReader, RelOptTable) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Resolve a target column name in the target table.
- getTargetOpt(int) - Method in class org.apache.calcite.util.mapping.AbstractTargetMapping
- getTargetOpt(int) - Method in class org.apache.calcite.util.mapping.Mappings.AbstractMapping
- getTargetOpt(int) - Method in interface org.apache.calcite.util.mapping.Mappings.FunctionMapping
-
Returns the target that a source maps to, or -1 if it is not mapped.
- getTargetOpt(int) - Method in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
-
Returns the target that a source maps to, or -1 if it is not mapped.
- getTargetOpt(int) - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
-
Returns the target that a source maps to, or -1 if it is not mapped.
- getTargetOpt(int) - Method in interface org.apache.calcite.util.mapping.Mappings.SourceMapping
-
Returns the target that a source maps to, or -1 if it is not mapped.
- getTargetOpt(int) - Method in interface org.apache.calcite.util.mapping.Mappings.TargetMapping
-
Returns the target that a source maps to, or -1 if it is not mapped.
- getTargetOpt(int) - Method in class org.apache.calcite.util.Permutation
- getTargetQualifiedName() - Method in interface org.apache.calcite.rel.RelReferentialConstraint
-
The qualified name of the referenced table, e.g.
- getTargetQualifiedName() - Method in class org.apache.calcite.rel.RelReferentialConstraintImpl
- getTargetTable() - Method in class org.apache.calcite.sql.SqlDelete
-
Returns the identifier for the target table of the deletion.
- getTargetTable() - Method in class org.apache.calcite.sql.SqlInsert
-
Return the identifier for the target table of the insertion.
- getTargetTable() - Method in class org.apache.calcite.sql.SqlMerge
-
Return the identifier for the target table of this MERGE.
- getTargetTable() - Method in class org.apache.calcite.sql.SqlUpdate
-
Returns the identifier for the target table of this UPDATE.
- getTargetTable(SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- getTargetType(String, SqlOperatorFixture.CastType) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- getTester() - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns the tester.
- getTestlogRoot() - Method in class org.apache.calcite.test.DiffTestCase
-
Returns the root directory under which test logs should be written.
- getTestTracer(Class<?>) - Static method in class org.apache.calcite.util.trace.CalciteTrace
-
The tracers report important/useful information related with the execution of unit tests.
- getThenOperands() - Method in class org.apache.calcite.sql.fun.SqlCase
- getThis() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
-
Derived classes might wish to override this method to return the "outer" enumerable.
- getThis() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- getThisOrdered() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
-
Derived classes might wish to override this method to return the "outer" ordered-enumerable.
- getThisOrderedQueryable() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- getTightestCommonType(RelDataType, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
-
Case1: type widening with no precision loss.
- getTightestCommonType(RelDataType, RelDataType) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Case1: type widening with no precision loss.
- getTime() - Method in class org.apache.calcite.sql.SqlTimeLiteral
-
Converts this literal to a
TimeString
. - getTime() - Method in class org.apache.calcite.sql.SqlTimeTzLiteral
-
Converts this literal to a
TimeWithTimeZoneString
. - getTimeDateFunctions() - Static method in class org.apache.calcite.sql.SqlJdbcFunctionCall
- getTimeFrameSet() - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the set of allowed time frames.
- getTimeFrameSet() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getTimestamp() - Method in class org.apache.calcite.sql.SqlAbstractDateTimeLiteral
-
Converts this literal to a
TimestampString
. - getTimestampFieldIndex() - Method in class org.apache.calcite.adapter.druid.DruidQuery
-
Returns the index of the timestamp ref, or -1 if not present.
- getTimeZone() - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- getTimeZone() - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
- getTokenImages() - Method in exception class org.apache.calcite.sql.parser.SqlParseException
-
Returns the token images.
- getTokenVal(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- getTopicName() - Method in class org.apache.calcite.adapter.kafka.KafkaTableOptions
- getTopNode() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getTotalByteCodeSize() - Method in class org.apache.calcite.util.javac.JaninoCompiler
- getTotalByteCodeSize() - Method in interface org.apache.calcite.util.javac.JavaCompiler
- getTrait(int) - Method in class org.apache.calcite.plan.RelTraitSet
-
Retrieves a RelTrait from the set.
- getTrait(RelTraitDef<T>) - Method in class org.apache.calcite.plan.RelTraitSet
-
Retrieves a RelTrait of the given type from the set.
- getTraitClass() - Method in class org.apache.calcite.plan.ConventionTraitDef
- getTraitClass() - Method in class org.apache.calcite.plan.RelTraitDef
-
Returns the specific RelTrait type associated with this RelTraitDef.
- getTraitClass() - Method in class org.apache.calcite.rel.RelCollationTraitDef
- getTraitClass() - Method in class org.apache.calcite.rel.RelDistributionTraitDef
- getTraitDef() - Method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- getTraitDef() - Method in enum org.apache.calcite.interpreter.BindableConvention
- getTraitDef() - Method in enum org.apache.calcite.interpreter.InterpretableConvention
- getTraitDef() - Method in class org.apache.calcite.plan.Convention.Impl
- getTraitDef() - Method in interface org.apache.calcite.plan.RelTrait
-
Returns the RelTraitDef that defines this RelTrait.
- getTraitDef() - Method in interface org.apache.calcite.rel.convert.Converter
-
Returns the definition of trait which this converter works on.
- getTraitDef() - Method in class org.apache.calcite.rel.convert.ConverterImpl
- getTraitDef() - Method in class org.apache.calcite.rel.convert.ConverterRule
- getTraitDef() - Method in class org.apache.calcite.rel.RelCollationImpl
- getTraitDefs() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns a list of trait definitions.
- getTraits(int) - Method in class org.apache.calcite.plan.RelTraitSet
-
Retrieves a list of traits from the set.
- getTraits(RelTraitDef<T>) - Method in class org.apache.calcite.plan.RelTraitSet
-
Retrieves a list of traits of the given type from the set.
- getTraitSet() - Method in interface org.apache.calcite.plan.RelOptNode
-
Retrieves this RelNode's traits.
- getTraitSet() - Method in class org.apache.calcite.rel.AbstractRelNode
- getTraitSet() - Method in interface org.apache.calcite.rel.RelInput
- getTransientTable() - Method in class org.apache.calcite.rel.core.RepeatUnion
- getTransitions() - Method in class org.apache.calcite.runtime.Automaton
- getTransitions() - Method in class org.apache.calcite.runtime.DeterministicAutomaton
- getTreeOrder() - Method in class org.apache.calcite.rel.rules.LoptJoinTree
- getTreeOrder(List<Integer>) - Method in class org.apache.calcite.rel.rules.LoptJoinTree.BinaryTree
- getTreeOrder(List<Integer>) - Method in class org.apache.calcite.rel.rules.LoptJoinTree
- getTreeOrder(List<Integer>) - Method in class org.apache.calcite.rel.rules.LoptJoinTree.Leaf
- getTreeOrder(List<Integer>) - Method in class org.apache.calcite.rel.rules.LoptJoinTree.Node
- getTuples() - Method in class org.apache.calcite.rel.core.Values
-
Returns the rows of literals represented by this Values relational expression.
- getTuples(String) - Method in interface org.apache.calcite.rel.RelInput
- getTuples(RelInput) - Method in class org.apache.calcite.rel.core.Values
- getType() - Method in interface org.apache.calcite.adapter.druid.Granularity
- getType() - Method in class org.apache.calcite.jdbc.CalciteSchema.TypeEntry
- getType() - Method in class org.apache.calcite.jdbc.CalciteSchema.TypeEntryImpl
- getType() - Method in class org.apache.calcite.linq4j.tree.AbstractNode
-
Gets the static type of the expression that this Expression represents.
- getType() - Method in class org.apache.calcite.linq4j.tree.ArrayLengthRecordField
- getType() - Method in interface org.apache.calcite.linq4j.tree.PseudoField
- getType() - Method in class org.apache.calcite.linq4j.tree.ReflectedPseudoField
- getType() - Method in class org.apache.calcite.rel.core.AggregateCall
-
Returns the result type.
- getType() - Method in interface org.apache.calcite.rel.RelDistribution
-
Returns the type of distribution.
- getType() - Method in interface org.apache.calcite.rel.type.RelDataTypeField
-
Gets the type of this field.
- getType() - Method in class org.apache.calcite.rel.type.RelDataTypeFieldImpl
- getType() - Method in class org.apache.calcite.rex.RexCall
- getType() - Method in class org.apache.calcite.rex.RexFieldAccess
- getType() - Method in class org.apache.calcite.rex.RexLambda
- getType() - Method in class org.apache.calcite.rex.RexLiteral
- getType() - Method in class org.apache.calcite.rex.RexNode
- getType() - Method in class org.apache.calcite.rex.RexRangeRef
- getType() - Method in class org.apache.calcite.rex.RexVariable
- getType() - Method in interface org.apache.calcite.schema.Member
-
Returns the type of this function's result.
- getType() - Method in class org.apache.calcite.sql.fun.SqlHistogramAggFunction
-
Deprecated.
- getType() - Method in class org.apache.calcite.sql.fun.SqlSingleValueAggFunction
-
Deprecated.
- getType() - Method in class org.apache.calcite.sql.fun.SqlSumAggFunction
-
Deprecated.
- getType() - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- getType() - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- getType() - Method in class org.apache.calcite.sql.validate.SqlIdentifierMoniker
- getType() - Method in interface org.apache.calcite.sql.validate.SqlMoniker
-
Returns the type of object referred to by this moniker.
- getType() - Method in class org.apache.calcite.sql.validate.SqlMonikerImpl
- getType() - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns the type of this namespace.
- getType(String) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getType(String) - Method in class org.apache.calcite.schema.impl.AbstractSchema
- getType(String) - Method in class org.apache.calcite.schema.impl.DelegatingSchema
- getType(String) - Method in interface org.apache.calcite.schema.Schema
-
Returns a type with a given name, or null if not found.
- getType(String, boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns a type, explicit and implicit, with a given name.
- getType(RelDataTypeFactory) - Method in interface org.apache.calcite.schema.FunctionParameter
-
Returns the type of this parameter.
- getTypeCoercion() - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Get the type coercion instance.
- getTypeCoercion() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getTypeEntry(CalciteSchema, SqlIdentifier) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Finds a
CalciteSchema.TypeEntry
in a given schema whose type has the given name, possibly qualified. - getTypeFactory() - Method in class org.apache.calcite.adapter.enumerable.JavaRelImplementor
- getTypeFactory() - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Returns the type factory.
- getTypeFactory() - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- getTypeFactory() - Method in interface org.apache.calcite.DataContext
-
Returns the type factory.
- getTypeFactory() - Method in interface org.apache.calcite.jdbc.CalciteConnection
-
Returns the type factory.
- getTypeFactory() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.Context
- getTypeFactory() - Method in class org.apache.calcite.plan.RelOptCluster
- getTypeFactory() - Method in interface org.apache.calcite.plan.RelOptSchema
-
Returns the
type factory
used to generate types for this schema. - getTypeFactory() - Method in class org.apache.calcite.plan.VisitorDataContext
- getTypeFactory() - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- getTypeFactory() - Method in class org.apache.calcite.prepare.PlannerImpl
- getTypeFactory() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Measure.Context
- getTypeFactory() - Method in class org.apache.calcite.rex.RexBuilder
-
Returns this RexBuilder's type factory.
- getTypeFactory() - Method in interface org.apache.calcite.schema.FunctionContext
-
Returns the type factory.
- getTypeFactory() - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Returns the factory for type creation.
- getTypeFactory() - Method in class org.apache.calcite.sql.test.SqlTestFactory
- getTypeFactory() - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the type factory used by this validator.
- getTypeFactory() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getTypeFactory() - Method in interface org.apache.calcite.sql2rel.SqlRexContext
-
Returns the type factory.
- getTypeFactory() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- getTypeFactory() - Method in interface org.apache.calcite.tools.Planner
-
Returns the type factory.
- getTypeFactory() - Method in class org.apache.calcite.tools.RelBuilder
-
Returns the type factory.
- getTypeInfo(Meta.ConnectionHandle) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- getTypeMap() - Method in class org.apache.calcite.schema.impl.AbstractSchema
-
Returns a map of types in this schema by name.
- getTypeMapping() - Method in class org.apache.calcite.sql.type.SqlTypeAssignmentRule
- getTypeMapping() - Method in class org.apache.calcite.sql.type.SqlTypeCoercionRule
- getTypeMapping() - Method in interface org.apache.calcite.sql.type.SqlTypeMappingRule
-
Returns the type mappings of this rule instance.
- getTypeMappingRule() - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the type mapping rule.
- getTypeName() - Method in enum org.apache.calcite.adapter.redis.RedisDataFormat
- getTypeName() - Method in enum org.apache.calcite.adapter.redis.RedisDataType
- getTypeName() - Method in class org.apache.calcite.rex.RexLiteral
- getTypeName() - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- getTypeName() - Method in class org.apache.calcite.sql.SqlLiteral
-
Returns the value of
SqlLiteral.typeName
. - getTypeName() - Method in class org.apache.calcite.sql.SqlTypeNameSpec
- getTypeName() - Method in class org.apache.calcite.sql.type.ComparableOperandTypeChecker
- getTypeName() - Method in class org.apache.calcite.sql.type.SameOperandTypeChecker
-
Override to change the behavior of
SameOperandTypeChecker.getAllowedSignatures(SqlOperator, String)
. - getTypeNames() - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getTypeNames() - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns the set of all types names.
- getTypeNames() - Method in class org.apache.calcite.schema.impl.AbstractSchema
- getTypeNames() - Method in class org.apache.calcite.schema.impl.DelegatingSchema
- getTypeNames() - Method in interface org.apache.calcite.schema.Schema
-
Returns the names of the types in this schema.
- getTypeNames() - Method in enum org.apache.calcite.sql.type.SqlTypeFamily
-
Returns the collection of
SqlTypeName
s included in this family. - getTypeNameSpec() - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- getTypes() - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getTypes() - Method in class org.apache.calcite.rel.type.RelCrossType
-
Returns the contained types.
- getTypes(RelDataTypeFactory) - Static method in class org.apache.calcite.sql.test.SqlTests
-
Returns a list of typical types.
- getTypeString(RelDataType) - Static method in class org.apache.calcite.sql.test.SqlTests
-
Helper function to get the string representation of a RelDataType (include precision/scale but no charset or collation).
- getTypeSystem() - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Returns the type system.
- getTypeSystem() - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- getTypeSystem() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns the type system implementation for this dialect.
- getTypeSystem() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns the type system.
- getUnionAllRowCount(RelMetadataQuery, Union) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Returns an estimate of the number of rows returned by a
Union
(before duplicates are eliminated). - getUniqueKeys(boolean) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.UniqueKeys
-
Determines the set of unique minimal keys for this expression.
- getUniqueKeys(Aggregate, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUniqueKeys(Calc, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUniqueKeys(Correlate, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUniqueKeys(Filter, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUniqueKeys(Intersect, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
-
Any unique key of any input of Intersect is an unique key of the Intersect.
- getUniqueKeys(Join, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUniqueKeys(Minus, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
-
The unique keys of Minus are precisely the unique keys of its first input.
- getUniqueKeys(Project, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUniqueKeys(Sort, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUniqueKeys(TableModify, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUniqueKeys(TableScan, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUniqueKeys(Union, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUniqueKeys(Values, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUniqueKeys(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.UniqueKeys.getUniqueKeys(boolean)
statistic. - getUniqueKeys(RelNode, boolean) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.UniqueKeys.getUniqueKeys(boolean)
statistic. - getUniqueKeys(RelNode, RelMetadataQuery, boolean) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.UniqueKeys.Handler
- getUniqueKeys(RelNode, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUnit() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Returns
SECOND
for bothHOUR TO SECOND
andSECOND
. - getUnit(TimeFrame) - Method in class org.apache.calcite.rel.type.TimeFrameSet
-
Returns the time unit that this time frame is based upon, or null.
- getUnknownType() - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns an object representing the "unknown" type.
- getUnknownType() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getUnmangledMethodName(Class, String, Class[]) - Static method in class org.apache.calcite.util.ReflectUtil
-
Composes a string representing a human-readable method name (with neither exception nor return type information).
- getUnmangledMethodName(Method) - Static method in class org.apache.calcite.util.ReflectUtil
-
Composes a string representing a human-readable method name (with neither exception nor return type information).
- getUnqualifiedClassName(Class) - Static method in class org.apache.calcite.util.ReflectUtil
-
Gets the name of a class with no package qualifiers; if it's an inner class, it will still be qualified by the containing class (X$Y).
- getUnquotedCasing() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns how unquoted identifiers are stored.
- getUpdateCall() - Method in class org.apache.calcite.sql.SqlMerge
-
Returns the UPDATE statement for this MERGE.
- getUpdateColumnList() - Method in class org.apache.calcite.rel.core.TableModify
- getUpperBound() - Method in class org.apache.calcite.rex.RexWindow
- getUpperBound() - Method in class org.apache.calcite.sql.SqlWindow
- getURL() - Method in class org.apache.calcite.chinook.ChinookAvaticaServer
- getURLConnection(String) - Static method in class org.apache.calcite.runtime.HttpUtils
- getUser() - Static method in class org.apache.calcite.chinook.EnvironmentFairy
- getUsingScope() - Method in class org.apache.calcite.sql.validate.JoinScope
-
Returns the scope which is used for resolving USING clause.
- getValidatedNodeType(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the type assigned to a node by validation.
- getValidatedNodeType(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getValidatedNodeTypeIfKnown(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the type assigned to a node by validation, or null if unknown.
- getValidatedNodeTypeIfKnown(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getValidatedOperandTypes(SqlCall) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the types of a call's operands.
- getValidatedOperandTypes(SqlCall) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getValidationErrorFunction() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getValidator() - Method in class org.apache.calcite.sql.SqlCallBinding
-
Returns the validator.
- getValidator() - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- getValidator() - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- getValidator() - Method in class org.apache.calcite.sql.validate.DelegatingScope
- getValidator() - Method in class org.apache.calcite.sql.validate.ParameterScope
- getValidator() - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns the validator.
- getValidator() - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Returns the validator which created this scope.
- getValidator() - Method in interface org.apache.calcite.sql2rel.SqlRexContext
-
Returns the validator.
- getValidator() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- getValType() - Method in class org.apache.calcite.sql.SqlMapTypeNameSpec
- getValue() - Method in class org.apache.calcite.linq4j.Ord
- getValue() - Method in class org.apache.calcite.rel.type.RelDataTypeFieldImpl
- getValue() - Method in class org.apache.calcite.rex.RexLiteral
-
Returns the value of this literal.
- getValue() - Method in class org.apache.calcite.runtime.MapEntry
- getValue() - Method in class org.apache.calcite.sql.SqlLiteral
-
Returns the value of this literal.
- getValue() - Method in class org.apache.calcite.sql.SqlSetOption
- getValue() - Method in class org.apache.calcite.sql.SqlUnknownLiteral
- getValue() - Method in class org.apache.calcite.util.NlsString
- getValue() - Method in class org.apache.calcite.util.Pair
- getValue(RexNode, RexNode) - Static method in class org.apache.calcite.plan.VisitorDataContext
- getValue2() - Method in class org.apache.calcite.rex.RexLiteral
-
Returns the value of this literal, in the form that the calculator program builder wants it.
- getValue3() - Method in class org.apache.calcite.rex.RexLiteral
-
Returns the value of this literal, in the form that the rex-to-lix translator wants it.
- getValue4() - Method in class org.apache.calcite.rex.RexLiteral
-
Returns the value of this literal, in the form that
RexInterpreter
wants it. - getValueAs(Class<T>) - Method in class org.apache.calcite.rex.RexLiteral
-
Returns the value of this literal as an instance of the specified class.
- getValueAs(Class<T>) - Method in class org.apache.calcite.sql.SqlLiteral
-
Returns the value of this literal as a given Java type.
- getValueBytes() - Method in class org.apache.calcite.util.NlsString
-
Returns the value as a
ByteString
. - getValueOperand() - Method in class org.apache.calcite.sql.fun.SqlCase
- getValueType() - Method in class org.apache.calcite.linq4j.tree.Types.MapType
-
Returns the type of values.
- getValueType() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets the value type if this type is a map, otherwise null.
- getValueType() - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
-
For
RelDataTypeFactoryImpl.JavaType
created withMap
class, we cannot get the value type. - getValueType() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getValueType() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- getValueType() - Method in class org.apache.calcite.sql.type.MapSqlType
- getVariablesSet() - Method in class org.apache.calcite.rel.AbstractRelNode
- getVariablesSet() - Method in class org.apache.calcite.rel.core.Correlate
- getVariablesSet() - Method in class org.apache.calcite.rel.core.Join
- getVariablesSet() - Method in class org.apache.calcite.rel.core.Project
- getVariablesSet() - Method in class org.apache.calcite.rel.logical.LogicalFilter
- getVariablesSet() - Method in interface org.apache.calcite.rel.RelNode
-
Returns the variables that are set in this relational expression but also used and therefore not available to parents of this relational expression.
- getVariablesSet(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a list of variables set by a relational expression or its descendants.
- getVariablesSetAndUsed(RelNode, RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- getVariablesUsed(List<RexSubQuery>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns the set of variables used by the given list of sub-queries and its descendants.
- getVariablesUsed(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns the set of variables used by a relational expression or its descendants.
- getVertex(V) - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- getViewExpander() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns a view expander.
- getViewPath() - Method in class org.apache.calcite.schema.impl.ViewTable
-
Returns the path of the view.
- getViewSql() - Method in class org.apache.calcite.schema.impl.ViewTable
-
Returns the view's SQL definition.
- getVisitor() - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Returns the
visitor
on which theMethodDispatcher
dispatches eachdecorrelateRel
method, the default implementation returns this instance, if you got a sub-class, override this method to replace thevisitor
as the sub-class instance. - getWarnings() - Method in class org.apache.calcite.sql.parser.SqlParser
-
Returns the warnings that were generated by the previous invocation of the parser.
- getWhenOperands() - Method in class org.apache.calcite.sql.fun.SqlCase
- getWhere() - Method in class org.apache.calcite.sql.SqlSelect
- getWhereScope(SqlSelect) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the scope that expressions in the WHERE and GROUP BY clause of this query should use.
- getWhereScope(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getWiderTypeFor(List<RelDataType>, boolean) - Method in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
-
Similar to
AbstractTypeCoercion.getWiderTypeForTwo(org.apache.calcite.rel.type.RelDataType, org.apache.calcite.rel.type.RelDataType, boolean)
, but can handle sequence types. - getWiderTypeFor(List<RelDataType>, boolean) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Similar to
TypeCoercion.getWiderTypeForTwo(org.apache.calcite.rel.type.RelDataType, org.apache.calcite.rel.type.RelDataType, boolean)
, but can handle sequence types. - getWiderTypeForDecimal(RelDataType, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
-
Finds a wider type when one or both types are decimal type.
- getWiderTypeForDecimal(RelDataType, RelDataType) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Finds a wider type when one or both types are DECIMAL type.
- getWiderTypeForTwo(RelDataType, RelDataType, boolean) - Method in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
-
Case2: type widening.
- getWiderTypeForTwo(RelDataType, RelDataType, boolean) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Case2: type widening.
- getWindow() - Method in class org.apache.calcite.rex.RexOver
- getWindowByName(SqlIdentifier, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getWindowCall() - Method in class org.apache.calcite.sql.SqlWindow
- getWindowList() - Method in class org.apache.calcite.sql.SqlSelect
- getWinnerCost() - Method in class org.apache.calcite.plan.volcano.RelSubset
-
Returns the best cost if this subset is fully optimized or null if the subset is not fully optimized.
- getWithItem() - Method in class org.apache.calcite.sql.validate.SqlWithItemTableRef
- getWithScope(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
- getWithScope(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- GitCommitsTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "git log" command to discover git commits.
- GLOBAL_TEMPORARY - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
A global temporary table.
- GLOBAL_TEMPORARY_TABLE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
A global temporary table.
- globalState() - Method in class org.apache.calcite.util.Puffin.Context
- globalState() - Method in interface org.apache.calcite.util.Puffin.Line
-
Returns the global state.
- Glossary - Interface in org.apache.calcite.util
-
A collection of terms.
- go(MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableRelVisitor
- go(RelNode) - Method in class org.apache.calcite.plan.SubstitutionVisitor
-
Returns a list of all possible rels that result from substituting the matched RelNode with the replacement RelNode within the query.
- go(RelNode) - Method in class org.apache.calcite.rel.RelVisitor
-
Starts an iteration.
- go(RelVisitor, RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Sets a
RelVisitor
going on a given relational expression, and returns the result. - go(RexBuilder, CorrelationId, Iterable<? extends CorrelationId>, RelNode) - Static method in class org.apache.calcite.sql2rel.DeduplicateCorrelateVariables
-
Rewrites a relational expression, replacing alternate correlation variables with a canonical correlation variable.
- go0(RelNode) - Method in class org.apache.calcite.plan.SubstitutionVisitor
- goDeeper() - Method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Creates child visitor.
- goDeeper() - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Creates child visitor.
- Goto - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A "go to" expression, such as goto Label in C# or GoTo Label in Visual Basic.
- Goto - Enum constant in enum org.apache.calcite.linq4j.tree.GotoExpressionKind
-
A GotoExpression that represents a jump to some location.
- goto_(LabelTarget) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a "go to" statement.
- goto_(LabelTarget, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a "go to" statement with the specified type.
- goto_(LabelTarget, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a "go to" statement.
- goto_(LabelTarget, Expression, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a "go to" statement with the specified type.
- GotoExpressionKind - Enum in org.apache.calcite.linq4j.tree
-
Specifies what kind of jump a
GotoStatement
represents. - GotoStatement - Class in org.apache.calcite.linq4j.tree
-
Represents an unconditional jump.
- Granularities - Class in org.apache.calcite.adapter.druid
-
Factory methods and helpers for
Granularity
. - Granularity - Interface in org.apache.calcite.adapter.druid
-
A strategy by which Druid rolls up rows into sub-totals based on their timestamp values.
- Granularity.Type - Enum in org.apache.calcite.adapter.druid
-
Type of supported periods for granularity.
- Graphs - Class in org.apache.calcite.util.graph
-
Miscellaneous graph utilities.
- Graphs.FrozenGraph<V,
E extends DefaultEdge> - Class in org.apache.calcite.util.graph -
Immutable grap.
- greater(boolean, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
- greater(byte, byte) - Static method in class org.apache.calcite.runtime.SqlFunctions
- greater(char, char) - Static method in class org.apache.calcite.runtime.SqlFunctions
- greater(double, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
- greater(float, float) - Static method in class org.apache.calcite.runtime.SqlFunctions
- greater(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- greater(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- greater(short, short) - Static method in class org.apache.calcite.runtime.SqlFunctions
- greater(T, T) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper for implementing MAX.
- GREATER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- GREATER_THAN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Greater-than operator, ">".
- GREATER_THAN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Logical greater-than operator, '
>
'. - GREATER_THAN_OR_EQUAL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Greater-than-or-equal operator, ">=".
- GREATER_THAN_OR_EQUAL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Logical greater-than-or-equal operator, '
>=
'. - greaterThan(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a "greater than" numeric comparison.
- greaterThan(Expression, Expression, boolean, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a "greater than" numeric comparison.
- greaterThan(RexNode, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
>
. - greaterThan(V) - Method in interface org.apache.calcite.util.RangeSets.Consumer
- greaterThan(V) - Method in interface org.apache.calcite.util.RangeSets.Handler
- GreaterThan - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A "greater than" comparison, such as (a > b).
- greaterThanOrEqual(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a "greater than or equal" numeric comparison.
- greaterThanOrEqual(Expression, Expression, boolean, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a "greater than or equal" numeric comparison.
- greaterThanOrEqual(RexNode, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
>=
. - GreaterThanOrEqual - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A "greater than or equal to" comparison, such as (a >= b).
- greatest(T, T) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
GREATEST operator.
- GREATEST - Enum constant in enum org.apache.calcite.sql.SqlKind
-
GREATEST
function (Oracle, Spark). - GREATEST - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
Deprecated.
- GREATEST - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "GREATEST(value, value)" function.
- GREATEST_PG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
GREATEST
function (PostgreSQL). - GREATEST_PG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "GREATEST(value, value)" function.
- GREGORIAN - Enum constant in enum org.apache.calcite.util.format.postgresql.DateCalendarEnum
- GridEnumerable(Envelope, BigDecimal, BigDecimal, boolean) - Constructor for class org.apache.calcite.runtime.SpatialTypeFunctions.GridEnumerable
- group(PigRelBuilder.GroupOption, PigRelBuilder.Partitioner, int, Iterable<? extends RelBuilder.GroupKey>) - Method in class org.apache.calcite.tools.PigRelBuilder
- group(PigRelBuilder.GroupOption, PigRelBuilder.Partitioner, int, RelBuilder.GroupKey...) - Method in class org.apache.calcite.tools.PigRelBuilder
-
Groups the data in one or more relations.
- Group(ImmutableBitSet, boolean, RexWindowBound, RexWindowBound, RexWindowExclusion, RelCollation, List<Window.RexWinAggCall>) - Constructor for class org.apache.calcite.rel.core.Window.Group
- GROUP - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- GROUP_BY - Enum constant in enum org.apache.calcite.adapter.druid.QueryType
- GROUP_BY - Enum constant in enum org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- GROUP_BY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- GROUP_BY_DISTINCT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The DISTINCT keyword of the GROUP BY clause.
- GROUP_BY_DISTINCT - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
DISTINCT
operator, occurs withinGROUP BY
clause. - GROUP_BY_LIST - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
GROUP BY list.
- GROUP_BY_MULTIPLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- GROUP_BY2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- GROUP_CONCAT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
GROUP_CONCAT
aggregate function. - GROUP_CONCAT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "GROUP_CONCAT([DISTINCT] expr [, ...] [ORDER BY ...] [SEPARATOR sep])" aggregate function, MySQL's equivalent of
SqlStdOperatorTable.LISTAGG
. - GROUP_ID - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
GROUP_ID()
function. - GROUP_ID - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
GROUP_ID()
function. - groupBy(Enumerable<TSource>, Function1<TSource, TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Groups the elements of a sequence according to a specified key selector function.
- groupBy(Enumerable<TSource>, Function1<TSource, TKey>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Groups the elements of a sequence according to a specified key selector function and compares the keys by using a specified comparer.
- groupBy(Enumerable<TSource>, Function1<TSource, TKey>, Function0<TAccumulate>, Function2<TAccumulate, TSource, TAccumulate>, Function2<TKey, TAccumulate, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Groups the elements of a sequence according to a specified key selector function, initializing an accumulator for each group and adding to it each time an element with the same key is seen.
- groupBy(Enumerable<TSource>, Function1<TSource, TKey>, Function0<TAccumulate>, Function2<TAccumulate, TSource, TAccumulate>, Function2<TKey, TAccumulate, TResult>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Groups the elements of a sequence according to a specified key selector function, initializing an accumulator for each group and adding to it each time an element with the same key is seen.
- groupBy(Enumerable<TSource>, Function1<TSource, TKey>, Function1<TSource, TElement>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Groups the elements of a sequence according to a specified key selector function and projects the elements for each group by using a specified function.
- groupBy(Enumerable<TSource>, Function1<TSource, TKey>, Function1<TSource, TElement>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Groups the elements of a sequence according to a key selector function.
- groupBy(Enumerable<TSource>, Function1<TSource, TKey>, Function1<TSource, TElement>, Function2<TKey, Enumerable<TElement>, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupBy(Enumerable<TSource>, Function1<TSource, TKey>, Function1<TSource, TElement>, Function2<TKey, Enumerable<TElement>, TResult>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupBy(Enumerable<TSource>, Function1<TSource, TKey>, Function2<TKey, Enumerable<TSource>, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupBy(Enumerable<TSource>, Function1<TSource, TKey>, Function2<TKey, Enumerable<TSource>, TResult>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupBy(Function1<T, TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- groupBy(Function1<T, TKey>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- groupBy(Function1<T, TKey>, Function0<TAccumulate>, Function2<TAccumulate, T, TAccumulate>, Function2<TKey, TAccumulate, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- groupBy(Function1<T, TKey>, Function0<TAccumulate>, Function2<TAccumulate, T, TAccumulate>, Function2<TKey, TAccumulate, TResult>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- groupBy(Function1<T, TKey>, Function1<T, TElement>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- groupBy(Function1<T, TKey>, Function1<T, TElement>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- groupBy(Function1<T, TKey>, Function1<T, TElement>, Function2<TKey, Enumerable<TElement>, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- groupBy(Function1<T, TKey>, Function1<T, TElement>, Function2<TKey, Enumerable<TElement>, TResult>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- groupBy(Function1<T, TKey>, Function2<TKey, Enumerable<T>, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- groupBy(Function1<T, TKey>, Function2<TKey, Enumerable<T>, TResult>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- groupBy(Function1<TSource, TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Groups the elements of a sequence according to a specified key selector function.
- groupBy(Function1<TSource, TKey>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Groups the elements of a sequence according to a specified key selector function and compares the keys by using a specified comparer.
- groupBy(Function1<TSource, TKey>, Function0<TAccumulate>, Function2<TAccumulate, TSource, TAccumulate>, Function2<TKey, TAccumulate, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Groups the elements of a sequence according to a specified key selector function, initializing an accumulator for each group and adding to it each time an element with the same key is seen.
- groupBy(Function1<TSource, TKey>, Function0<TAccumulate>, Function2<TAccumulate, TSource, TAccumulate>, Function2<TKey, TAccumulate, TResult>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Groups the elements of a sequence according to a specified key selector function, initializing an accumulator for each group and adding to it each time an element with the same key is seen.
- groupBy(Function1<TSource, TKey>, Function1<TSource, TElement>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Groups the elements of a sequence according to a specified key selector function and projects the elements for each group by using a specified function.
- groupBy(Function1<TSource, TKey>, Function1<TSource, TElement>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Groups the elements of a sequence according to a key selector function.
- groupBy(Function1<TSource, TKey>, Function1<TSource, TElement>, Function2<TKey, Enumerable<TElement>, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupBy(Function1<TSource, TKey>, Function1<TSource, TElement>, Function2<TKey, Enumerable<TElement>, TResult>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupBy(Function1<TSource, TKey>, Function2<TKey, Enumerable<TSource>, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupBy(Function1<TSource, TKey>, Function2<TKey, Enumerable<TSource>, TResult>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Groups the elements of a sequence according to a specified key selector function.
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Groups the elements of a sequence according to a specified key selector function.
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, EqualityComparer) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Groups the elements of a sequence according to a specified key selector function and compares the keys by using a specified comparer.
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Groups the elements of a sequence according to a specified key selector function and compares the keys by using a specified comparer.
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Groups the elements of a sequence according to a specified key selector function and projects the elements for each group by using a specified function.
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Groups the elements of a sequence according to a specified key selector function and projects the elements for each group by using a specified function.
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, EqualityComparer) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Groups the elements of a sequence and projects the elements for each group by using a specified function.
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Groups the elements of a sequence and projects the elements for each group by using a specified function.
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- groupBy(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Groups the elements of a sequence according to a specified key selector function.
- groupBy(FunctionExpression<Function1<T, TKey>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Groups the elements of a sequence according to a specified key selector function and compares the keys by using a specified comparer.
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Groups the elements of a sequence according to a specified key selector function and projects the elements for each group by using a specified function.
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Groups the elements of a sequence and projects the elements for each group by using a specified function.
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupByFolding() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the line-folding policy for the GROUP BY clause.
- groupByK(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupByK(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupByK(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- groupByK(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>, EqualityComparer) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupByK(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupByK(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- groupByK(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- groupByK(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- groupByK(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupByK(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupByMultiple(Enumerable<TSource>, List<Function1<TSource, TKey>>, Function0<TAccumulate>, Function2<TAccumulate, TSource, TAccumulate>, Function2<TKey, TAccumulate, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Groups the elements of a sequence according to a list of specified key selector functions, initializing an accumulator for each group and adding to it each time an element with the same key is seen.
- GroupByScope - Class in org.apache.calcite.sql.validate
-
Represents the name-resolution context for expressions in an GROUP BY clause.
- groupExprList - Variable in class org.apache.calcite.sql.validate.AggregatingSelectScope.Resolved
- groupExprProjection - Variable in class org.apache.calcite.sql.validate.AggregatingSelectScope.Resolved
- groupFunction - Variable in class org.apache.calcite.sql.SqlGroupedWindowFunction
-
The grouped function, if this an auxiliary function; null otherwise.
- groupFunctionMustAppearInGroupByClause(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- Grouping<K,
V> - Interface in org.apache.calcite.linq4j -
Represents a collection of objects that have a common key.
- GROUPING - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
GROUPING(e, ...)
function. - GROUPING - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
GROUPING(c1 [, c2, ...])
function. - GROUPING_ID - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Deprecated.Use
SqlKind.GROUPING
. - GROUPING_ID - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
GROUPING_ID
function is a synonym forGROUPING
. - GROUPING_SETS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The internal
GROUPING SETS
operator that occurs within aGROUP BY
clause. - GROUPING_SETS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
GROUPING SETS
operator, occurs withinGROUP BY
clause or nested within aGROUPING SETS
. - groupingArgument(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- groupingInAggregate(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- groupingInWrongClause(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- groupJoin(Enumerable<TInner>, Function1<T, TKey>, Function1<TInner, TKey>, Function2<T, Enumerable<TInner>, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- groupJoin(Enumerable<TInner>, Function1<T, TKey>, Function1<TInner, TKey>, Function2<T, Enumerable<TInner>, TResult>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- groupJoin(Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, Enumerable<TInner>, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Correlates the elements of two sequences based on equality of keys and groups the results.
- groupJoin(Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, Enumerable<TInner>, TResult>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Correlates the elements of two sequences based on key equality and groups the results.
- groupJoin(Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, Enumerable<TInner>, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- groupJoin(Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, Enumerable<TInner>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- groupJoin(Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, Enumerable<TInner>, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Correlates the elements of two sequences based on key equality and groups the results.
- groupJoin(Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, Enumerable<TInner>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Correlates the elements of two sequences based on key equality and groups the results.
- groupJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, Enumerable<TInner>, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Correlates the elements of two sequences based on equality of keys and groups the results.
- groupJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, Enumerable<TInner>, TResult>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Correlates the elements of two sequences based on key equality and groups the results.
- groupJoin(Queryable<T>, Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, Enumerable<TInner>, TResult>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Correlates the elements of two sequences based on key equality and groups the results.
- groupJoin(Queryable<T>, Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, Enumerable<TInner>, TResult>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- groupJoin(Queryable<T>, Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, Enumerable<TInner>, TResult>>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Correlates the elements of two sequences based on key equality and groups the results.
- groupJoin(Queryable<T>, Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, Enumerable<TInner>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- groupJoin(Queryable<TOuter>, Enumerable<TInner>, FunctionExpression<Function1<TOuter, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<TOuter, Enumerable<TInner>, TResult>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Correlates the elements of two sequences based on key equality and groups the results.
- groupJoin(Queryable<TOuter>, Enumerable<TInner>, FunctionExpression<Function1<TOuter, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<TOuter, Enumerable<TInner>, TResult>>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Correlates the elements of two sequences based on key equality and groups the results.
- groupKey() - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an empty group key.
- groupKey(int...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a group key of fields identified by ordinal.
- groupKey(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a group key.
- groupKey(Iterable<? extends RexNode>, boolean, Iterable<? extends Iterable<? extends RexNode>>) - Method in class org.apache.calcite.tools.RelBuilder
-
Deprecated.Now that indicator is deprecated, use
RelBuilder.groupKey(Iterable, Iterable)
, which has the same behavior as calling this method withindicator = false
. - groupKey(Iterable<? extends RexNode>, Iterable<? extends Iterable<? extends RexNode>>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a group key with grouping sets.
- groupKey(String...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a group key of fields identified by name.
- groupKey(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a group key.
- groupKey(ImmutableBitSet) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a group key, identified by field positions in the underlying relational expression.
- groupKey(ImmutableBitSet, boolean, ImmutableList<ImmutableBitSet>) - Method in class org.apache.calcite.tools.RelBuilder
-
Deprecated.
- groupKey(ImmutableBitSet, Iterable<? extends ImmutableBitSet>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a group key with grouping sets, both identified by field positions in the underlying relational expression.
- groupKeyCount() - Method in interface org.apache.calcite.tools.RelBuilder.GroupKey
-
Returns the number of columns in the group key.
- groups - Variable in class org.apache.calcite.rel.core.Window
- groups - Variable in class org.apache.calcite.rel.mutable.MutableWindow
- groupSet - Variable in class org.apache.calcite.rel.core.Aggregate
- groupSet - Variable in class org.apache.calcite.rel.mutable.MutableAggregate
- groupSet - Variable in class org.apache.calcite.sql.validate.AggregatingSelectScope.Resolved
- groupSets - Variable in class org.apache.calcite.rel.core.Aggregate
- groupSets - Variable in class org.apache.calcite.rel.mutable.MutableAggregate
- groupSets - Variable in class org.apache.calcite.sql.validate.AggregatingSelectScope.Resolved
- groupSets() - Method in interface org.apache.calcite.adapter.enumerable.AggContext
-
Returns the grouping sets we are aggregating on.
- groupSets() - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase.AggContextImpl
- GroupStmt(SqlParserPos, Ast.Identifier, Ast.Identifier, List<Ast.Node>) - Constructor for class org.apache.calcite.piglet.Ast.GroupStmt
- gt(boolean, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
>
operator applied to boolean values. - gt(byte, byte) - Static method in class org.apache.calcite.runtime.SqlFunctions
- gt(char, char) - Static method in class org.apache.calcite.runtime.SqlFunctions
- gt(double, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
- gt(float, float) - Static method in class org.apache.calcite.runtime.SqlFunctions
- gt(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- gt(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- gt(short, short) - Static method in class org.apache.calcite.runtime.SqlFunctions
- gt(Object[], Object[]) - Static method in class org.apache.calcite.runtime.SqlFunctions
- gt(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
>
operator applied to String values. - gt(String, String, Comparator<String>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
>
operator applied to String values. - gt(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
>
operator applied to BigDecimal values. - gt(List<?>, List<?>) - Static method in class org.apache.calcite.runtime.SqlFunctions
- gt(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
>
operator applied to ByteString values. - gt(RexNode, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- GT - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- GT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- GT_NULLABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- gtAny(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
>
operator applied to Object values (at least one operand has ANY type; neither may be null). - GTE - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- gtNullable(T, T) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Returns whether
b0
is greater thanb1
(orb1
is null). - guessSelectivity(RexNode) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Returns default estimates for selectivities, in the absence of stats.
- guessSelectivity(RexNode, boolean) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Returns default estimates for selectivities, in the absence of stats.
H
- H2 - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- H2 - Enum constant in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
- H2SqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the H2 database. - H2SqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.H2SqlDialect
-
Creates an H2SqlDialect.
- HALF_DAYS - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- handle(Expression) - Method in enum org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
Adapts an expression with "normal" result to one that adheres to this particular policy.
- handle(Ast.Node) - Method in class org.apache.calcite.piglet.Handler
-
Creates relational expressions for a given AST node.
- handle(RelNode) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter
-
Opportunity to further refine the relational expression created for a given level.
- handle(RexFieldAccess) - Method in class org.apache.calcite.sql2rel.CorrelationReferenceFinder
- handler(Class<MH>) - Method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- handler(Class<MH>) - Method in interface org.apache.calcite.rel.metadata.MetadataHandlerProvider
-
Provide a handler for the requested metadata class.
- handler(Class<MH>) - Method in class org.apache.calcite.rel.metadata.ProxyingMetadataHandlerProvider
- handler(Class<MH>) - Method in class org.apache.calcite.rel.metadata.RelMetadataQueryBase
-
Provide a handler for the requested metadata class.
- Handler - Class in org.apache.calcite.piglet
-
Walks over a Piglet AST and calls the corresponding methods in a
PigRelBuilder
. - Handler(PigRelBuilder) - Constructor for class org.apache.calcite.piglet.Handler
- handlerClass - Variable in class org.apache.calcite.rel.metadata.MetadataDef
- handlerMethods(Class<? extends MetadataHandler<?>>) - Static method in interface org.apache.calcite.rel.metadata.MetadataHandler
-
Finds handler methods defined by a
MetadataHandler
, and returns a map keyed by method name. - handlers(Class<? extends MetadataHandler<?>>) - Method in class org.apache.calcite.plan.volcano.VolcanoRelMetadataProvider
-
Deprecated.
- handlers(Class<? extends MetadataHandler<?>>) - Method in class org.apache.calcite.rel.metadata.CachingRelMetadataProvider
-
Deprecated.
- handlers(Class<? extends MetadataHandler<?>>) - Method in class org.apache.calcite.rel.metadata.ChainedRelMetadataProvider
- handlers(Class<? extends MetadataHandler<?>>) - Method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- handlers(Class<? extends MetadataHandler<?>>) - Method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
- handlers(Class<? extends MetadataHandler<?>>) - Method in interface org.apache.calcite.rel.metadata.RelMetadataProvider
-
Retrieves a list of
MetadataHandler
for implements a particularMetadataHandler
.class. - handlers(MetadataDef<M>) - Method in class org.apache.calcite.plan.volcano.VolcanoRelMetadataProvider
-
Deprecated.
- handlers(MetadataDef<M>) - Method in class org.apache.calcite.rel.metadata.CachingRelMetadataProvider
-
Deprecated.
- handlers(MetadataDef<M>) - Method in class org.apache.calcite.rel.metadata.ChainedRelMetadataProvider
-
Deprecated.
- handlers(MetadataDef<M>) - Method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
-
Deprecated.
- handlers(MetadataDef<M>) - Method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
-
Deprecated.
- handlers(MetadataDef<M>) - Method in interface org.apache.calcite.rel.metadata.RelMetadataProvider
-
Deprecated.
- handleUnresolvedFunction(SqlCall, SqlOperator, List<RelDataType>, List<String>) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Handles a call to a function which cannot be resolved.
- handleUnresolvedFunction(SqlCall, SqlOperator, List<RelDataType>, List<String>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- hasAllFactors(LoptJoinTree, BitSet) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns whether if a join tree contains all factors required.
- hasCharacter(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is a CHARACTER or contains a CHARACTER type.
- hasCharactor(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Deprecated.
- hasCollation() - Method in class org.apache.calcite.rel.core.AggregateCall
-
Returns true if this AggregateCall has a non-empty collation.
- hasCorrelation() - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMap
-
Returns whether there are any correlating variables in this statement.
- hasException() - Method in class org.apache.calcite.runtime.JsonFunctions.JsonPathContext
- hasException() - Method in class org.apache.calcite.runtime.JsonFunctions.JsonValueContext
- hasExplicitTypeSpec(List<SqlNode>) - Static method in class org.apache.calcite.sql.fun.SqlJsonQueryFunction
- hasExplicitTypeSpec(List<SqlNode>) - Static method in class org.apache.calcite.sql.fun.SqlJsonValueFunction
-
Returns whether there is an explicit return type specification.
- hasExplicitTypeSpec(SqlNode[]) - Static method in class org.apache.calcite.sql.fun.SqlJsonValueFunction
-
Deprecated.
- hasField(String) - Method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Verifies if the variable name is already in use.
- hasField(String) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Verifies if the variable name is already in use.
- hasFieldNames(String) - Static method in class org.apache.calcite.test.Matchers
-
Creates a Matcher that matches a
RelNode
if its field names, converting to a list, are equal to the givenvalue
. - hasFilter() - Method in class org.apache.calcite.rel.core.Aggregate.AggCallBinding
- hasFilter() - Method in class org.apache.calcite.rel.core.AggregateCall
-
Returns whether this AggregateCall has a filter argument.
- hasFilter() - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Returns whether the operator is an aggregate function with a filter.
- hash - Variable in class org.apache.calcite.rex.RexCall
-
Cache of hash code.
- hash(int, boolean) - Static method in class org.apache.calcite.runtime.Utilities
- hash(int, byte) - Static method in class org.apache.calcite.runtime.Utilities
- hash(int, char) - Static method in class org.apache.calcite.runtime.Utilities
- hash(int, double) - Static method in class org.apache.calcite.runtime.Utilities
- hash(int, float) - Static method in class org.apache.calcite.runtime.Utilities
- hash(int, int) - Static method in class org.apache.calcite.runtime.Utilities
- hash(int, int) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- hash(int, long) - Static method in class org.apache.calcite.runtime.Utilities
- hash(int, short) - Static method in class org.apache.calcite.runtime.Utilities
- hash(int, Object) - Static method in class org.apache.calcite.runtime.Utilities
- hash(int, Object) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- hash(Object) - Static method in class org.apache.calcite.runtime.Utilities
- hash(Collection<? extends Number>) - Static method in class org.apache.calcite.rel.RelDistributions
-
Creates a hash distribution.
- HASH - Enum constant in enum org.apache.calcite.adapter.redis.RedisDataType
-
Redis Hashes are maps between string fields and string values.
- HASH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- HASH_DISTRIBUTED - Enum constant in enum org.apache.calcite.rel.RelDistribution.Type
-
There are multiple instances of the stream, and each instance contains records whose keys hash to a particular hash value.
- HASH_JOIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- hashArray(int, Object[]) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- hashCode() - Method in class org.apache.calcite.adapter.druid.DruidQuery.QuerySpec
- hashCode() - Method in class org.apache.calcite.interpreter.Row
- hashCode() - Method in class org.apache.calcite.jdbc.JavaRecordType
- hashCode() - Method in class org.apache.calcite.linq4j.Ord
- hashCode() - Method in class org.apache.calcite.linq4j.tree.AbstractNode
- hashCode() - Method in class org.apache.calcite.linq4j.tree.ArrayLengthRecordField
- hashCode() - Method in class org.apache.calcite.linq4j.tree.BinaryExpression
- hashCode() - Method in class org.apache.calcite.linq4j.tree.BlockStatement
- hashCode() - Method in class org.apache.calcite.linq4j.tree.CatchBlock
- hashCode() - Method in class org.apache.calcite.linq4j.tree.ClassDeclaration
- hashCode() - Method in class org.apache.calcite.linq4j.tree.ConditionalExpression
- hashCode() - Method in class org.apache.calcite.linq4j.tree.ConditionalStatement
- hashCode() - Method in class org.apache.calcite.linq4j.tree.ConstantExpression
- hashCode() - Method in class org.apache.calcite.linq4j.tree.ConstantUntypedNull
- hashCode() - Method in class org.apache.calcite.linq4j.tree.ConstructorDeclaration
- hashCode() - Method in class org.apache.calcite.linq4j.tree.DeclarationStatement
- hashCode() - Method in class org.apache.calcite.linq4j.tree.FieldDeclaration
- hashCode() - Method in class org.apache.calcite.linq4j.tree.ForEachStatement
- hashCode() - Method in class org.apache.calcite.linq4j.tree.ForStatement
- hashCode() - Method in class org.apache.calcite.linq4j.tree.FunctionExpression
- hashCode() - Method in class org.apache.calcite.linq4j.tree.GotoStatement
- hashCode() - Method in class org.apache.calcite.linq4j.tree.IndexExpression
- hashCode() - Method in class org.apache.calcite.linq4j.tree.LabelStatement
- hashCode() - Method in class org.apache.calcite.linq4j.tree.LabelTarget
- hashCode() - Method in class org.apache.calcite.linq4j.tree.MemberExpression
- hashCode() - Method in class org.apache.calcite.linq4j.tree.MethodCallExpression
- hashCode() - Method in class org.apache.calcite.linq4j.tree.MethodDeclaration
- hashCode() - Method in class org.apache.calcite.linq4j.tree.NewArrayExpression
- hashCode() - Method in class org.apache.calcite.linq4j.tree.NewExpression
- hashCode() - Method in class org.apache.calcite.linq4j.tree.ParameterExpression
- hashCode() - Method in class org.apache.calcite.linq4j.tree.ReflectedPseudoField
- hashCode() - Method in class org.apache.calcite.linq4j.tree.TernaryExpression
- hashCode() - Method in class org.apache.calcite.linq4j.tree.ThrowStatement
- hashCode() - Method in class org.apache.calcite.linq4j.tree.TryStatement
- hashCode() - Method in class org.apache.calcite.linq4j.tree.TypeBinaryExpression
- hashCode() - Method in class org.apache.calcite.linq4j.tree.UnaryExpression
- hashCode() - Method in class org.apache.calcite.linq4j.tree.WhileStatement
- hashCode() - Method in class org.apache.calcite.materialize.Lattice.Column
- hashCode() - Method in class org.apache.calcite.materialize.Lattice.Measure
- hashCode() - Method in class org.apache.calcite.materialize.LatticeTable
- hashCode() - Method in class org.apache.calcite.materialize.MaterializationKey
- hashCode() - Method in class org.apache.calcite.materialize.TileKey
- hashCode() - Method in class org.apache.calcite.plan.RelOptCostImpl
- hashCode() - Method in class org.apache.calcite.plan.RelOptRule
- hashCode() - Method in class org.apache.calcite.plan.RelOptRuleOperand
- hashCode() - Method in interface org.apache.calcite.plan.RelTrait
- hashCode() - Method in class org.apache.calcite.plan.RelTraitSet
- hashCode() - Method in class org.apache.calcite.plan.volcano.VolcanoRelMetadataProvider
-
Deprecated.
- hashCode() - Method in class org.apache.calcite.prepare.RelOptTableImpl
- hashCode() - Method in class org.apache.calcite.profile.Profiler.Column
- hashCode() - Method in class org.apache.calcite.rel.AbstractRelNode
- hashCode() - Method in class org.apache.calcite.rel.core.AggregateCall
- hashCode() - Method in class org.apache.calcite.rel.core.CorrelationId
- hashCode() - Method in class org.apache.calcite.rel.core.Match.RexMRAggCall
- hashCode() - Method in class org.apache.calcite.rel.core.Window.Group
- hashCode() - Method in class org.apache.calcite.rel.core.Window.RexWinAggCall
- hashCode() - Method in class org.apache.calcite.rel.hint.RelHint
- hashCode() - Method in class org.apache.calcite.rel.metadata.ChainedRelMetadataProvider
- hashCode() - Method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- hashCode() - Method in class org.apache.calcite.rel.metadata.RelColumnOrigin
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableAggregate
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableCalc
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableCollect
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableCorrelate
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableExchange
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableFilter
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableJoin
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableMatch
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableProject
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableSample
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableScan
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableSetOp
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableSort
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableTableFunctionScan
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableTableModify
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableUncollect
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableValues
- hashCode() - Method in class org.apache.calcite.rel.mutable.MutableWindow
- hashCode() - Method in class org.apache.calcite.rel.RelCollationImpl
- hashCode() - Method in class org.apache.calcite.rel.RelFieldCollation
- hashCode() - Method in class org.apache.calcite.rel.type.RelDataTypeFieldImpl
- hashCode() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- hashCode() - Method in class org.apache.calcite.rex.RexCall
- hashCode() - Method in class org.apache.calcite.rex.RexCorrelVariable
- hashCode() - Method in class org.apache.calcite.rex.RexDynamicParam
- hashCode() - Method in class org.apache.calcite.rex.RexFieldAccess
- hashCode() - Method in class org.apache.calcite.rex.RexInputRef
- hashCode() - Method in class org.apache.calcite.rex.RexLambda
- hashCode() - Method in class org.apache.calcite.rex.RexLambdaRef
- hashCode() - Method in class org.apache.calcite.rex.RexLiteral
- hashCode() - Method in class org.apache.calcite.rex.RexLocalRef
- hashCode() - Method in class org.apache.calcite.rex.RexNode
- hashCode() - Method in class org.apache.calcite.rex.RexOver
- hashCode() - Method in class org.apache.calcite.rex.RexRangeRef
- hashCode() - Method in class org.apache.calcite.rex.RexSubQuery
- hashCode() - Method in class org.apache.calcite.rex.RexTableInputRef
- hashCode() - Method in class org.apache.calcite.rex.RexTableInputRef.RelTableRef
- hashCode() - Method in class org.apache.calcite.rex.RexWindow
- hashCode() - Method in class org.apache.calcite.runtime.ConsList
- hashCode() - Method in class org.apache.calcite.runtime.FlatLists.Flat1List
- hashCode() - Method in class org.apache.calcite.runtime.FlatLists.Flat2List
- hashCode() - Method in class org.apache.calcite.runtime.FlatLists.Flat3List
- hashCode() - Method in class org.apache.calcite.runtime.FlatLists.Flat4List
- hashCode() - Method in class org.apache.calcite.runtime.FlatLists.Flat5List
- hashCode() - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- hashCode() - Method in class org.apache.calcite.runtime.JsonFunctions.JsonValueContext
- hashCode() - Method in class org.apache.calcite.runtime.MapEntry
- hashCode() - Method in class org.apache.calcite.schema.impl.LongSchemaVersion
- hashCode() - Method in class org.apache.calcite.sql.parser.SqlParserPos
- hashCode() - Method in class org.apache.calcite.sql.parser.StringAndPos
- hashCode() - Method in class org.apache.calcite.sql.SqlCollation
- hashCode() - Method in class org.apache.calcite.sql.SqlIntervalLiteral.IntervalValue
- hashCode() - Method in class org.apache.calcite.sql.SqlLiteral
- hashCode() - Method in class org.apache.calcite.sql.SqlNodeList
- hashCode() - Method in class org.apache.calcite.sql.SqlOperator
- hashCode() - Method in class org.apache.calcite.sql.TableCharacteristic
- hashCode() - Method in class org.apache.calcite.sql.util.IdPair
- hashCode() - Method in class org.apache.calcite.sql.util.SqlString
- hashCode() - Method in class org.apache.calcite.sql.validate.SqlMonikerImpl
- hashCode() - Method in class org.apache.calcite.sql.validate.SqlQualified
- hashCode() - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMap
- hashCode() - Method in class org.apache.calcite.test.schemata.foodmart.FoodmartSchema.SalesFact
- hashCode() - Method in class org.apache.calcite.test.schemata.hr.Department
- hashCode() - Method in class org.apache.calcite.test.schemata.hr.Dependent
- hashCode() - Method in class org.apache.calcite.test.schemata.hr.Employee
- hashCode() - Method in class org.apache.calcite.test.schemata.hr.Event
- hashCode() - Method in class org.apache.calcite.test.schemata.hr.HierarchySchema.Hierarchy
- hashCode() - Method in class org.apache.calcite.test.schemata.hr.Location
- hashCode() - Method in class org.apache.calcite.test.schemata.hr.NullableTest
- hashCode() - Method in class org.apache.calcite.test.schemata.lingual.LingualEmp
- hashCode() - Method in class org.apache.calcite.util.BitString
- hashCode() - Method in class org.apache.calcite.util.DateString
- hashCode() - Method in class org.apache.calcite.util.graph.DefaultEdge
- hashCode() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns the hash code value for this bit set.
- hashCode() - Method in class org.apache.calcite.util.ImmutableIntList
- hashCode() - Method in class org.apache.calcite.util.mapping.IntPair
- hashCode() - Method in class org.apache.calcite.util.mapping.Mappings.FiniteAbstractMapping
- hashCode() - Method in class org.apache.calcite.util.NameMap
- hashCode() - Method in class org.apache.calcite.util.NameMultimap
- hashCode() - Method in class org.apache.calcite.util.NameSet
- hashCode() - Method in class org.apache.calcite.util.NlsString
- hashCode() - Method in class org.apache.calcite.util.Pair
- hashCode() - Method in class org.apache.calcite.util.Permutation
- hashCode() - Method in class org.apache.calcite.util.Sarg
- hashCode() - Method in class org.apache.calcite.util.TimestampString
- hashCode() - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
- hashCode() - Method in class org.apache.calcite.util.TimeString
- hashCode() - Method in class org.apache.calcite.util.TimeWithTimeZoneString
- hashCode(boolean) - Static method in class org.apache.calcite.runtime.Utilities
-
Deprecated.
- hashCode(double) - Static method in class org.apache.calcite.runtime.Utilities
-
Deprecated.
- hashCode(double) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- hashCode(float) - Static method in class org.apache.calcite.runtime.Utilities
-
Deprecated.
- hashCode(long) - Static method in class org.apache.calcite.runtime.Utilities
-
Deprecated.
- hashCode(RangeSet<C>) - Static method in class org.apache.calcite.util.RangeSets
-
Computes a hash code for a range set.
- hashCode(SqlOperator, List<RexNode>) - Static method in class org.apache.calcite.rex.RexNormalize
-
Computes the hashCode of a rex call.
- hashCode(T) - Method in interface org.apache.calcite.linq4j.function.EqualityComparer
- hasHints() - Method in class org.apache.calcite.sql.SqlSelect
- hasHints(String) - Static method in class org.apache.calcite.test.Matchers
-
Creates a Matcher that matches a
RelNode
if its hints string representation is equal to the givenvalue
. - hashJoin(Enumerable<TInner>, Function1<T, TKey>, Function1<TInner, TKey>, Function2<T, TInner, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- hashJoin(Enumerable<TInner>, Function1<T, TKey>, Function1<TInner, TKey>, Function2<T, TInner, TResult>, EqualityComparer<TKey>, boolean, boolean) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- hashJoin(Enumerable<TInner>, Function1<T, TKey>, Function1<TInner, TKey>, Function2<T, TInner, TResult>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- hashJoin(Enumerable<TInner>, Function1<T, TKey>, Function1<TInner, TKey>, Function2<T, TInner, TResult>, EqualityComparer<TKey>, boolean, boolean, Predicate2<T, TInner>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- hashJoin(Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, TInner, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Correlates the elements of two sequences based on matching keys.
- hashJoin(Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, TInner, TResult>, EqualityComparer<TKey>, boolean, boolean) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Correlates the elements of two sequences based on matching keys, with optional outer join semantics.
- hashJoin(Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, TInner, TResult>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Correlates the elements of two sequences based on matching keys.
- hashJoin(Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, TInner, TResult>, EqualityComparer<TKey>, boolean, boolean, Predicate2<TSource, TInner>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Correlates the elements of two sequences based on matching keys, with optional outer join semantics.
- hashJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, TInner, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Correlates the elements of two sequences based on matching keys.
- hashJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, TInner, TResult>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Correlates the elements of two sequences based on matching keys.
- hashJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, TInner, TResult>, EqualityComparer<TKey>, boolean, boolean) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Correlates the elements of two sequences based on matching keys.
- hashJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, TInner, TResult>, EqualityComparer<TKey>, boolean, boolean, Predicate2<TSource, TInner>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Correlates the elements of two sequences based on matching keys.
- hasImplicitTableAlias() - Method in class org.apache.calcite.sql.dialect.Db2SqlDialect
- hasImplicitTableAlias() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether a qualified table in the FROM clause has an implicit alias which consists of just the table name.
- hasLeftChild(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinProjectTransposeRule
-
Returns whether the rule was invoked with a left project child.
- hasLeftChild(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule
- hasMessage(Throwable, String) - Static method in class org.apache.calcite.util.TestUtil
-
Checks if exceptions have give substring.
- hasNext() - Method in class org.apache.calcite.util.Filterator
- hasNext() - Method in class org.apache.calcite.util.graph.BreadthFirstIterator
- hasNext() - Method in class org.apache.calcite.util.graph.DepthFirstIterator
- hasNext() - Method in class org.apache.calcite.util.graph.TopologicalOrderIterator
- hasOrderBy() - Method in class org.apache.calcite.sql.SqlSelect
- hasOrderedCall(List<AggImpState>) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase
- hasRex(String) - Static method in class org.apache.calcite.test.Matchers
-
Creates a Matcher that matches a
RexNode
if its string representation, after converting Windows-style line endings ("\r\n") to Unix-style line endings ("\n"), is equal to the givenvalue
. - hasRightChild(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinProjectTransposeRule
-
Returns whether the rule was invoked with 2 children.
- hasRightChild(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule
- hasRows() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResetContextImpl
- hasRows() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- hasRows() - Method in interface org.apache.calcite.adapter.enumerable.WinAggFrameContext
-
Returns the boolean expression that tells if the partition has rows.
- hasScale(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type's scale is set.
- hasTimeZone - Variable in class org.apache.calcite.sql.SqlAbstractDateTimeLiteral
- hasTree(String) - Static method in class org.apache.calcite.test.Matchers
-
Creates a Matcher that matches a
RelNode
if its string representation, after converting Windows-style line endings ("\r\n") to Unix-style line endings ("\n"), is equal to the givenvalue
. - hasTrickyRollup(Sort, Aggregate) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- hasVariable(String) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- hasWarning(Consumer<List<? extends Throwable>>) - Method in class org.apache.calcite.sql.parser.SqlParserFixture
- hasWhere() - Method in class org.apache.calcite.sql.SqlSelect
- HAVING - Enum constant in enum org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- HAVING_OPERAND - Static variable in class org.apache.calcite.sql.SqlSelect
- havingFolding() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the line-folding policy for the HAVING clause.
- havingMustBeBoolean() - Method in interface org.apache.calcite.runtime.CalciteResource
- header() - Method in class org.apache.calcite.util.XmlOutput
-
Write header.
- header(String) - Method in class org.apache.calcite.util.XmlOutput
-
Write header, take version as input.
- hep(Iterable<? extends RelOptRule>, boolean, RelMetadataProvider) - Static method in class org.apache.calcite.tools.Programs
-
Creates a program that executes a list of rules in a HEP planner.
- HepMatchOrder - Enum in org.apache.calcite.plan.hep
-
HepMatchOrder specifies the order of graph traversal when looking for rule matches.
- HepPlanner - Class in org.apache.calcite.plan.hep
-
HepPlanner is a heuristic implementation of the
RelOptPlanner
interface. - HepPlanner(HepProgram) - Constructor for class org.apache.calcite.plan.hep.HepPlanner
-
Creates a new HepPlanner that allows DAG.
- HepPlanner(HepProgram, Context) - Constructor for class org.apache.calcite.plan.hep.HepPlanner
-
Creates a new HepPlanner that allows DAG.
- HepPlanner(HepProgram, Context, boolean, Function2<RelNode, RelNode, Void>, RelOptCostFactory) - Constructor for class org.apache.calcite.plan.hep.HepPlanner
-
Creates a new HepPlanner with the option to keep the graph a tree (noDag = true) or allow DAG (noDag = false).
- HepProgram - Class in org.apache.calcite.plan.hep
-
HepProgram specifies the order in which rules should be attempted by
HepPlanner
. - HepProgramBuilder - Class in org.apache.calcite.plan.hep
-
HepProgramBuilder creates instances of
HepProgram
. - HepProgramBuilder() - Constructor for class org.apache.calcite.plan.hep.HepProgramBuilder
-
Creates a new HepProgramBuilder with an initially empty program.
- HepRelVertex - Class in org.apache.calcite.plan.hep
-
HepRelVertex wraps a real
RelNode
as a vertex in a DAG representing the entire query expression. - HepRuleCall - Class in org.apache.calcite.plan.hep
-
HepRuleCall implements
RelOptRuleCall
for aHepPlanner
. - heuristicJoinOrder(Iterable<? extends RelOptRule>, boolean, int) - Static method in class org.apache.calcite.tools.Programs
-
Creates a program that invokes heuristic join-order optimization (via
JoinToMultiJoinRule
,MultiJoin
andLoptOptimizeJoinRule
) if there are 6 or more joins (7 or more relations). - HH12 - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- HH24 - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- hierarchies - Variable in class org.apache.calcite.test.schemata.hr.HierarchySchema
- Hierarchy(int, int) - Constructor for class org.apache.calcite.test.schemata.hr.HierarchySchema.Hierarchy
- HIERARCHY_TABLE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
A hierarchy table.
- HierarchySchema - Class in org.apache.calcite.test.schemata.hr
-
A Schema representing a hierarchy of employees.
- HierarchySchema() - Constructor for class org.apache.calcite.test.schemata.hr.HierarchySchema
- HierarchySchema.Hierarchy - Class in org.apache.calcite.test.schemata.hr
-
Hierarchy representing manager - subordinate.
- HIGH - Enum constant in enum org.apache.calcite.config.NullCollation
-
Nulls first for DESC, nulls last for ASC.
- hilbert(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the position of a point on the Hilbert curve.
- hilbert(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the position of a point on the Hilbert curve, or null if it is not a 2-dimensional point.
- HILBERT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
Hilbert
function that converts (x, y) to a position on a Hilbert space-filling curve. - HilbertCurve2D - Class in org.apache.calcite.runtime
-
2-dimensional Hilbert space-filling curve.
- HilbertCurve2D(int) - Constructor for class org.apache.calcite.runtime.HilbertCurve2D
- HINT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Sql Hint statement.
- Hintable - Interface in org.apache.calcite.rel.hint
- HintErrorLogger() - Constructor for class org.apache.calcite.rel.hint.HintStrategyTable.HintErrorLogger
- hintName - Variable in class org.apache.calcite.rel.hint.RelHint
- hintOption(String) - Method in class org.apache.calcite.rel.hint.RelHint.Builder
-
Add a hint option as string.
- hintOption(String, String) - Method in class org.apache.calcite.rel.hint.RelHint.Builder
-
Add a hint option as string key-value pair.
- hintOptionChecker - Variable in class org.apache.calcite.rel.hint.HintStrategy
- HintOptionChecker - Interface in org.apache.calcite.rel.hint
-
A
HintOptionChecker
validates the options of aRelHint
. - hintOptions(Iterable<String>) - Method in class org.apache.calcite.rel.hint.RelHint.Builder
-
Add multiple string hint options.
- hintOptions(Map<String, String>) - Method in class org.apache.calcite.rel.hint.RelHint.Builder
-
Add multiple string key-value pair hint options.
- HintPredicate - Interface in org.apache.calcite.rel.hint
-
A
HintPredicate
indicates whether aRelNode
can apply the specified hint. - HintPredicates - Class in org.apache.calcite.rel.hint
-
A collection of hint predicates.
- HintPredicates() - Constructor for class org.apache.calcite.rel.hint.HintPredicates
- hints - Variable in class org.apache.calcite.rel.core.Aggregate
- hints - Variable in class org.apache.calcite.rel.core.Calc
- hints - Variable in class org.apache.calcite.rel.core.Correlate
- hints - Variable in class org.apache.calcite.rel.core.Filter
- hints - Variable in class org.apache.calcite.rel.core.Join
- hints - Variable in class org.apache.calcite.rel.core.Project
- hints - Variable in class org.apache.calcite.rel.core.SetOp
- hints - Variable in class org.apache.calcite.rel.core.Snapshot
- hints - Variable in class org.apache.calcite.rel.core.Sort
- hints - Variable in class org.apache.calcite.rel.core.TableFunctionScan
- hints - Variable in class org.apache.calcite.rel.core.TableScan
-
The table hints.
- hints - Variable in class org.apache.calcite.rel.core.Values
- hints - Variable in class org.apache.calcite.rel.core.Window
- hints - Variable in class org.apache.calcite.rel.RelRoot
- hints(Iterable<RelHint>) - Method in class org.apache.calcite.tools.RelBuilder
-
Attaches multiple hints to the stack top relational expression.
- hints(RelHint...) - Method in class org.apache.calcite.tools.RelBuilder
-
Attaches an array of hints to the stack top relational expression.
- Hints - Annotation Type in org.apache.calcite.linq4j.function
-
Annotation applied to a user-defined function that gives extra metadata about that function.
- hintStrategy(String, HintPredicate) - Method in class org.apache.calcite.rel.hint.HintStrategyTable.Builder
- hintStrategy(String, HintStrategy) - Method in class org.apache.calcite.rel.hint.HintStrategyTable.Builder
- HintStrategy - Class in org.apache.calcite.rel.hint
-
Represents a hint strategy entry of
HintStrategyTable
. - HintStrategy.Builder - Class in org.apache.calcite.rel.hint
-
Builder for
HintStrategy
. - HintStrategyTable - Class in org.apache.calcite.rel.hint
-
A collection of
HintStrategy
s. - HintStrategyTable.Builder - Class in org.apache.calcite.rel.hint
-
Builder for
HintStrategyTable
. - HintStrategyTable.HintErrorLogger - Class in org.apache.calcite.rel.hint
-
Implementation of
Litmus
that returns a status code, it logs warnings for fail check and does not throw. - HISTOGRAM - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy for Histogram agg support.
- HISTOGRAM_AGG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
HISTOGRAM
aggregate function support. - HISTOGRAM_FIRST_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
HISTOGRAM_FIRST_VALUE
window aggregate function. - HISTOGRAM_LAST_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
HISTOGRAM_LAST_VALUE
window aggregate function. - HISTOGRAM_MAX - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
HISTOGRAM_MAX
window aggregate function. - HISTOGRAM_MIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
HISTOGRAM_MIN
window aggregate function. - history - Variable in class org.apache.calcite.model.JsonStream
-
Whether the history of the table is available.
- hits() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHits
- HIVE - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
A collection of operators that are in Apache Hive but not in standard SQL.
- HIVE - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- HiveSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Apache Hive database. - HiveSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.HiveSqlDialect
-
Creates a HiveSqlDialect.
- hoist(String) - Method in class org.apache.calcite.tools.Hoist
-
Hoists literals in a given SQL string, returning a
Hoist.Hoisted
. - Hoist - Class in org.apache.calcite.tools
-
Utility that extracts constants from a SQL query.
- Hoist.Config - Interface in org.apache.calcite.tools
-
Configuration.
- Hoist.Hoisted - Class in org.apache.calcite.tools
-
Result of hoisting.
- Hoist.Variable - Class in org.apache.calcite.tools
-
Variable.
- Holder - Class in org.apache.calcite.rel.mutable
-
Implementation of
MutableRel
whose only purpose is to have a child. - Holder<E> - Class in org.apache.calcite.util
-
A mutable slot that can contain one object.
- Holder(E) - Constructor for class org.apache.calcite.util.Holder
-
Creates a Holder containing a given value.
- Hook - Enum in org.apache.calcite.runtime
-
Collection of hooks that can be set by observers and are executed at various parts of the query preparation process.
- Hook.Closeable - Interface in org.apache.calcite.runtime
-
Removes a Hook after use.
- HOP - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
HOP
group function. - HOP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
HOP as a table function.
- HOP_END - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
HOP_END
auxiliary function of theSqlKind.HOP
group function. - HOP_END - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
HOP_END
auxiliary function of theHOP
group function. - HOP_OLD - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
HOP
group function. - HOP_START - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
HOP_START
auxiliary function of theSqlKind.HOP
group function. - HOP_START - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
HOP_START
auxiliary function of theHOP
group function. - hopping(Enumerator<Object[]>, int, long, long, long) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
-
Create enumerable implementation that applies hopping on each element from the input enumerator and produces at least one element for each input element.
- HOPPING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- HOUR - Enum constant in enum org.apache.calcite.adapter.druid.Granularity.Type
- HOUR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
HOUR
operator. - HOUR_VARIANTS - Static variable in class org.apache.calcite.test.SqlOperatorTest
- HOURS_IN_DAY - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- HOURS_IN_HALF_DAY - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- hr() - Static method in class org.apache.calcite.test.CalciteAssert
-
Short-hand for
CalciteAssert.that().with(Config.REGULAR)
. - HR - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- HrSchema - Class in org.apache.calcite.test.schemata.hr
-
A schema that contains two tables by reflection.
- HrSchema() - Constructor for class org.apache.calcite.test.schemata.hr.HrSchema
- HrSchemaBig - Class in org.apache.calcite.test.schemata.hr
-
HR schema with more data than in
HrSchema
. - HrSchemaBig() - Constructor for class org.apache.calcite.test.schemata.hr.HrSchemaBig
- HSQLDB - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- HSQLDB - Enum constant in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
- HsqldbSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Hsqldb database. - HsqldbSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.HsqldbSqlDialect
-
Creates an HsqldbSqlDialect.
- HttpUtils - Class in org.apache.calcite.runtime
-
Utilities for connecting to REST services such as Splunk via HTTP.
- human(double) - Static method in class org.apache.calcite.util.Util
-
Converts a number into human-readable form, with 3 digits and a "K", "M" or "G" multiplier for thousands, millions or billions.
- HUNDREDTHS_OF_MS - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- HUNDREDTHS_OF_SECOND - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- HYDE - Enum constant in enum org.apache.calcite.sql.SqlWriter.SubQueryStyle
-
Julian's style of sub-query nesting.
- HYPER_LOG_LOG - Enum constant in enum org.apache.calcite.adapter.redis.RedisDataType
-
HyperLogLog is a probabilistic data structure used in order to count unique things.
- HYPER_UNIQUE - Enum constant in enum org.apache.calcite.adapter.druid.DruidType
I
- i - Variable in class org.apache.calcite.linq4j.Ord
- i - Variable in exception class org.apache.calcite.sql.parser.SqlParserUtil.MalformedUnicodeEscape
- i - Variable in class org.apache.calcite.sql.validate.SqlValidatorScope.Step
- i - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- id - Variable in class org.apache.calcite.plan.RelOptRuleCall
- id - Variable in class org.apache.calcite.rel.AbstractRelNode
-
Unique id of this object, for debugging.
- id - Variable in class org.apache.calcite.rex.RexCorrelVariable
- id - Variable in class org.apache.calcite.sql.advise.SqlAdvisorHint
-
Fully qualified object name as string.
- id - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.IdInfo
- id - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.IntAndString
- id() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHit
-
Returns the id of this hit (usually document id).
- id() - Method in class org.apache.calcite.sql.validate.SqlIdentifierMoniker
- id() - Method in interface org.apache.calcite.sql.validate.SqlMoniker
- id() - Method in class org.apache.calcite.sql.validate.SqlMonikerImpl
- ID - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- ID_LIST - Enum constant in enum org.apache.calcite.sql.SqlHint.HintOptionFormat
-
The hint options are as simple identifier list.
- identifier - Variable in class org.apache.calcite.sql.validate.SqlQualified
- identifier(String) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Appends an identifier to this buffer, quoting accordingly.
- identifier(String...) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Appends one or more identifiers to this buffer, quoting accordingly.
- identifier(String, boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- identifier(String, boolean) - Method in interface org.apache.calcite.sql.SqlWriter
-
Prints an identifier, quoting as necessary.
- identifier(List<String>) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Appends a compound identifier to this buffer, quoting accordingly.
- Identifier(SqlParserPos, String) - Constructor for class org.apache.calcite.piglet.Ast.Identifier
- IDENTIFIER - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- IDENTIFIER - Enum constant in enum org.apache.calcite.sql.SqlKind
-
An identifier.
- IDENTIFIER - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Compound identifier.
- identifierEndQuoteString - Variable in class org.apache.calcite.sql.SqlDialect
- identifierEscapedQuote - Variable in class org.apache.calcite.sql.SqlDialect
- identifierEscapedQuoteString() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- identifierExpansion() - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Returns whether to expand identifiers other than column references.
- identifierMaxLength() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- IdentifierNamespace - Class in org.apache.calcite.sql.validate
-
Namespace whose contents are defined by the type of an
identifier
. - identifierNeedsQuote(String) - Method in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
- identifierNeedsQuote(String) - Method in class org.apache.calcite.sql.dialect.ExasolSqlDialect
- identifierNeedsQuote(String) - Method in class org.apache.calcite.sql.dialect.FireboltSqlDialect
- identifierNeedsQuote(String) - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether to quote an identifier.
- identifierQuoteString - Variable in class org.apache.calcite.sql.SqlDialect
- identifierQuoteString() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- identifiers() - Method in class org.apache.calcite.materialize.Lattice.BaseColumn
- identifierTooLong(String, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- identity() - Method in class org.apache.calcite.rel.core.TableScan
-
Returns an identity projection.
- identity() - Method in class org.apache.calcite.util.Permutation
-
Initializes this permutation to the identity permutation.
- identity(int) - Static method in class org.apache.calcite.util.ImmutableIntList
-
Returns the identity list [0, ..., count - 1].
- identity(RelOptTable) - Static method in class org.apache.calcite.rel.core.TableScan
-
Returns an identity projection for the given table.
- IDENTITY - Static variable in interface org.apache.calcite.linq4j.function.Function1
-
The identity function.
- IDENTITY_COMPARER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IDENTITY_SELECTOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IDENTITY_TO_MAP - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns a MAP type.
- IDENTITY_TO_MAP - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy that converts a type to a MAP type, which key and value type is same.
- IDENTITY_TO_MAP_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.IDENTITY_TO_MAP
but returns with nullability if any of the operands is nullable. - identityComparer() - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns an
EqualityComparer
that uses object identity and hash code. - identityList(int) - Static method in class org.apache.calcite.adapter.file.CsvEnumerator
-
Returns an array of integers {0, ..., n - 1}.
- IdentityMapping(int) - Constructor for class org.apache.calcite.util.mapping.Mappings.IdentityMapping
-
Creates an identity mapping.
- identityProjects(RelDataType) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a list of
RexInputRef
expressions, projecting the fields of a given record type. - identitySelector() - Static method in class org.apache.calcite.linq4j.function.Functions
- IdentityTableFunction() - Constructor for class org.apache.calcite.util.Smalls.IdentityTableFunction
- IdInfo(SqlValidatorScope, SqlIdentifier) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.IdInfo
- IdPair<L,
R> - Class in org.apache.calcite.sql.util -
Similar to
Pair
but identity is based on identity of values. - IdPair(L, R) - Constructor for class org.apache.calcite.sql.util.IdPair
- idPositions - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Maps
SqlParserPos
strings to theSqlIdentifier
identifier objects at these positions. - IdToken(SqlSimpleParser.TokenType, String) - Constructor for class org.apache.calcite.sql.advise.SqlSimpleParser.IdToken
- IF - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The "IF" function (BigQuery, Hive, Spark).
- IF - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "IF(condition, thenValue, elseValue)" function.
- ifExists - Variable in class org.apache.calcite.sql.SqlDrop
-
Whether "IF EXISTS" was specified.
- ifNotExists - Variable in class org.apache.calcite.sql.SqlCreate
-
Whether "IF NOT EXISTS" was specified.
- IFNULL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "IFNULL(value, value)" function.
- ifThen(Expression, Node) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ConditionalExpression that represents a conditional block with an if statement.
- ifThenElse(Iterable<? extends Node>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ConditionalExpression that represents a conditional block with if and else statements:
if (test) stmt1 [ else if (test2) stmt2 ]...
- ifThenElse(Expression, Node...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ConditionalExpression that represents a conditional block with if and else statements:
if (test) stmt1 [ else if (test2) stmt2 ]...
- ifThenElse(Expression, Node, Node) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ConditionalExpression that represents a conditional block with if and else statements.
- IGNORE - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
-
Like ANY, but do not even validate the operand.
- IGNORE - Static variable in interface org.apache.calcite.util.Litmus
-
Implementation of
Litmus
that returns a status code but does not throw. - IGNORE_ANY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- IGNORE_NULLS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
IGNORE NULLS
operator. - IGNORE_NULLS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
IGNORE NULLS
operator. - ignore0() - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns a function of arity 0 that does nothing.
- ignore1() - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns a function of arity 1 that does nothing.
- ignore2() - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns a function of arity 2 that does nothing.
- IGNORED - Enum constant in enum org.apache.calcite.util.Optionality
-
A property is ignored if an instance may or may not possess it; if it possesses the property, the effect is as if it does not.
- ignoreNulls - Variable in class org.apache.calcite.rel.core.Window.RexWinAggCall
-
Whether to ignore nulls.
- ignoreNulls() - Method in class org.apache.calcite.rel.core.AggregateCall
-
Returns whether this AggregateCall ignores nulls.
- ignoreNulls() - Method in class org.apache.calcite.rex.RexOver
- ignoreNulls(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
-
Returns a copy of this AggCall that ignores nulls.
- iInputColumn - Variable in class org.apache.calcite.rel.metadata.RelColumnMapping
-
0-based ordinal of mapped column within input rel.
- iInputRel - Variable in class org.apache.calcite.rel.metadata.RelColumnMapping
-
0-based ordinal of mapped input rel.
- ilike(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.LikeFunction
-
SQL
ILIKE
function. - ilike(String, String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.LikeFunction
-
SQL
ILIKE
function with escape. - ILIKE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ILIKE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The case-insensitive variant of the LIKE operator.
- ILIKE_ESCAPE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- illegalArgumentForTableFunctionCall(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalArgumentsInMapFromArraysFunc(int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalArrayExpression(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalBinaryString(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalBitGetPositionExceedsLimit(int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalColon() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalComma() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalCursorExpression() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalEmptyBehaviorInJsonQueryFunc(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalEmptyBehaviorInJsonValueFunc(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalEmptyObjectInJsonQueryFunc() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalEmptyPadPattern() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalErrorBehaviorInJsonExistsFunc(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalErrorBehaviorInJsonQueryFunc(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalErrorBehaviorInJsonValueFunc(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalExpressionForTemporal(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalFromEmpty() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalIntervalLiteral(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalJoinExpression() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalJsonPathMode(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalJsonPathModeInPathSpec(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalJsonPathSpec(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalLiteral(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalLocaleFormat(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalMapEntriesWithNullKey() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalMapKeysWithNullKey() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalMapValuesWithNullKey() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalMinusDate() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalMixingOfTypes() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalNegativeBitGetPosition(int) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalNegativeDecimalValue() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalNegativePadLength() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalNegativeSubstringLength() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalNonQueryExpression() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalOrderBy() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalOverlaps() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalQueryExpression() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalRowExpression() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalWrapperBehaviorInJsonQueryFunc(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalXslt(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- IMMEDIATELY_PRECEDES - Enum constant in enum org.apache.calcite.sql.SqlKind
-
IMMEDIATELY PRECEDES
operator for periods. - IMMEDIATELY_PRECEDES - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IMMEDIATELY_SUCCEEDS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
IMMEDIATELY SUCCEEDS
operator for periods. - IMMEDIATELY_SUCCEEDS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- immutable() - Method in interface org.apache.calcite.runtime.ImmutablePairList
- immutable() - Method in interface org.apache.calcite.runtime.PairList
-
Returns an ImmutablePairList whose contents are the same as this PairList.
- IMMUTABLE_INT_LIST_COPY_OF - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IMMUTABLE_INT_LIST_IDENTITY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ImmutableBitSet - Class in org.apache.calcite.util
-
An immutable list of bits.
- ImmutableBitSet.Builder - Class in org.apache.calcite.util
-
Builder.
- immutableCopy(Iterable<? extends Iterable<E>>) - Static method in class org.apache.calcite.util.Util
-
Returns a copy of a list of lists, making the component lists immutable if they are not already.
- immutableCopyOf(Map<String, V>) - Static method in class org.apache.calcite.util.NameMap
-
Creates a NameMap that is an immutable copy of a given map.
- immutableCopyOf(Set<String>) - Static method in class org.apache.calcite.util.NameSet
-
Creates a NameSet that is an immutable copy of a given collection.
- ImmutableIntList - Class in org.apache.calcite.util
-
An immutable list of
Integer
values backed by an array ofint
s. - ImmutableNullableList<E> - Class in org.apache.calcite.util
-
An immutable list that may contain null values.
- ImmutableNullableList.Builder<E> - Class in org.apache.calcite.util
-
A builder for creating immutable nullable list instances.
- ImmutableNullableMap<K,
V> - Class in org.apache.calcite.util -
An immutable map that may contain null values.
- ImmutableNullableSet<E> - Class in org.apache.calcite.util
-
An immutable set that may contain null values.
- ImmutableNullableSet.Builder<E> - Class in org.apache.calcite.util
-
A builder for creating immutable nullable set instances.
- ImmutablePairList<T,
U> - Interface in org.apache.calcite.runtime -
Immutable list of pairs.
- Impl(String, Class<? extends RelNode>) - Constructor for class org.apache.calcite.plan.Convention.Impl
- Impl(SqlFunction) - Constructor for class org.apache.calcite.sql2rel.AuxiliaryConverter.Impl
- implement(ArrowRel.Implementor) - Method in interface org.apache.calcite.adapter.arrow.ArrowRel
- implement(CassandraRel.Implementor) - Method in class org.apache.calcite.adapter.cassandra.CassandraFilter
- implement(CassandraRel.Implementor) - Method in class org.apache.calcite.adapter.cassandra.CassandraLimit
- implement(CassandraRel.Implementor) - Method in class org.apache.calcite.adapter.cassandra.CassandraProject
- implement(CassandraRel.Implementor) - Method in interface org.apache.calcite.adapter.cassandra.CassandraRel
- implement(CassandraRel.Implementor) - Method in class org.apache.calcite.adapter.cassandra.CassandraSort
- implement(CassandraRel.Implementor) - Method in class org.apache.calcite.adapter.cassandra.CassandraTableScan
- implement(ElasticsearchRel.Implementor) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchAggregate
- implement(ElasticsearchRel.Implementor) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter
- implement(ElasticsearchRel.Implementor) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchProject
- implement(ElasticsearchRel.Implementor) - Method in interface org.apache.calcite.adapter.elasticsearch.ElasticsearchRel
- implement(ElasticsearchRel.Implementor) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSort
- implement(ElasticsearchRel.Implementor) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTableScan
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.cassandra.CassandraToEnumerableConverter
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.csv.CsvTableScan
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchToEnumerableConverter
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregate
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableAsofJoin
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoin
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCalc
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCollect
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCorrelate
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableFilter
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableHashJoin
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableInterpreter
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableIntersect
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableLimit
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableLimitSort
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMatch
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMergeJoin
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMergeUnion
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMinus
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableNestedLoopJoin
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableProject
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in interface org.apache.calcite.adapter.enumerable.EnumerableRel
-
Creates a plan for this expression according to a calling convention.
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRepeatUnion
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableSort
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableSortedAggregate
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableFunctionScan
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableModify
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableSpool
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableUncollect
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableUnion
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableValues
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindow
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.file.CsvTableScan
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.geode.rel.GeodeToEnumerableConverter
-
Creates a plan for this expression according to a calling convention.
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.innodb.InnodbToEnumerableConverter
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverter
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.mongodb.MongoToEnumerableConverter
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.pig.PigToEnumerableConverter
-
Creates a plan for this expression according to a calling convention.
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.spark.SparkToEnumerableConverter
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.splunk.SplunkTableScan
- implement(RexToLixTranslator, Expression, RexCall, PhysType, PhysType) - Method in interface org.apache.calcite.adapter.enumerable.TableFunctionCallImplementor
-
Implements a table-valued function call.
- implement(RexToLixTranslator, RexCall, List<RexToLixTranslator.Result>) - Method in interface org.apache.calcite.adapter.enumerable.RexImpTable.RexCallImplementor
- implement(RexToLixTranslator, RexCall, List<Expression>) - Method in interface org.apache.calcite.adapter.enumerable.NotNullImplementor
-
Implements a call with assumption that all the null-checking is implemented by caller.
- implement(RexToLixTranslator, RexCall, List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.ReflectiveCallNotNullImplementor
- implement(RexToLixTranslator, RexCall, RexImpTable.NullAs) - Method in interface org.apache.calcite.adapter.enumerable.CallImplementor
-
Implements a call.
- implement(RexToLixTranslator, RexCall, ParameterExpression, ParameterExpression, ParameterExpression, ParameterExpression) - Method in interface org.apache.calcite.adapter.enumerable.MatchImplementor
-
Implements a call.
- implement(GeodeRel.GeodeImplementContext) - Method in class org.apache.calcite.adapter.geode.rel.GeodeAggregate
- implement(GeodeRel.GeodeImplementContext) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter
- implement(GeodeRel.GeodeImplementContext) - Method in class org.apache.calcite.adapter.geode.rel.GeodeProject
- implement(GeodeRel.GeodeImplementContext) - Method in interface org.apache.calcite.adapter.geode.rel.GeodeRel
-
Callback for the implementation process that collects the context from the
GeodeRel
required to convert the relational tree into physical such. - implement(GeodeRel.GeodeImplementContext) - Method in class org.apache.calcite.adapter.geode.rel.GeodeSort
- implement(GeodeRel.GeodeImplementContext) - Method in class org.apache.calcite.adapter.geode.rel.GeodeTableScan
- implement(InnodbRel.Implementor) - Method in class org.apache.calcite.adapter.innodb.InnodbFilter
- implement(InnodbRel.Implementor) - Method in class org.apache.calcite.adapter.innodb.InnodbProject
- implement(InnodbRel.Implementor) - Method in interface org.apache.calcite.adapter.innodb.InnodbRel
- implement(InnodbRel.Implementor) - Method in class org.apache.calcite.adapter.innodb.InnodbSort
- implement(InnodbRel.Implementor) - Method in class org.apache.calcite.adapter.innodb.InnodbTableScan
- implement(JdbcImplementor) - Method in interface org.apache.calcite.adapter.jdbc.JdbcRel
- implement(JdbcImplementor) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcAggregate
- implement(JdbcImplementor) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcCalc
-
Deprecated.
- implement(JdbcImplementor) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcFilter
- implement(JdbcImplementor) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcIntersect
- implement(JdbcImplementor) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcJoin
- implement(JdbcImplementor) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcMinus
- implement(JdbcImplementor) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcProject
- implement(JdbcImplementor) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcSort
- implement(JdbcImplementor) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcTableModify
- implement(JdbcImplementor) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcUnion
- implement(JdbcImplementor) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcValues
- implement(JdbcImplementor) - Method in class org.apache.calcite.adapter.jdbc.JdbcTableScan
- implement(MongoRel.Implementor) - Method in class org.apache.calcite.adapter.mongodb.MongoAggregate
- implement(MongoRel.Implementor) - Method in class org.apache.calcite.adapter.mongodb.MongoFilter
- implement(MongoRel.Implementor) - Method in class org.apache.calcite.adapter.mongodb.MongoProject
- implement(MongoRel.Implementor) - Method in interface org.apache.calcite.adapter.mongodb.MongoRel
- implement(MongoRel.Implementor) - Method in class org.apache.calcite.adapter.mongodb.MongoSort
- implement(MongoRel.Implementor) - Method in class org.apache.calcite.adapter.mongodb.MongoTableScan
- implement(PigRel.Implementor) - Method in class org.apache.calcite.adapter.pig.PigAggregate
- implement(PigRel.Implementor) - Method in class org.apache.calcite.adapter.pig.PigFilter
- implement(PigRel.Implementor) - Method in class org.apache.calcite.adapter.pig.PigJoin
- implement(PigRel.Implementor) - Method in class org.apache.calcite.adapter.pig.PigProject
- implement(PigRel.Implementor) - Method in interface org.apache.calcite.adapter.pig.PigRel
-
Converts this node to a Pig Latin statement.
- implement(PigRel.Implementor) - Method in class org.apache.calcite.adapter.pig.PigTableScan
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.adapter.druid.DruidQuery
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.adapter.enumerable.EnumerableBindable
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.adapter.enumerable.EnumerableInterpretable
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.interpreter.Bindables.BindableAggregate
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.interpreter.Bindables.BindableFilter
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.interpreter.Bindables.BindableIntersect
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.interpreter.Bindables.BindableJoin
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.interpreter.Bindables.BindableMatch
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.interpreter.Bindables.BindableMinus
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.interpreter.Bindables.BindableProject
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.interpreter.Bindables.BindableSort
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.interpreter.Bindables.BindableTableScan
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.interpreter.Bindables.BindableUnion
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.interpreter.Bindables.BindableValues
- implement(InterpretableRel.InterpreterImplementor) - Method in class org.apache.calcite.interpreter.Bindables.BindableWindow
- implement(InterpretableRel.InterpreterImplementor) - Method in interface org.apache.calcite.interpreter.InterpretableRel
-
Creates an interpreter node to implement this relational expression.
- implement(RelNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcImplementor
- implement(RelRoot) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- implement(RelRoot) - Method in class org.apache.calcite.prepare.Prepare
-
Implements a physical query plan.
- ImplementableAggFunction - Interface in org.apache.calcite.schema
-
Function that can be translated to java code.
- ImplementableFunction - Interface in org.apache.calcite.schema
-
Function that can be translated to java code.
- implementAdd(AggContext, AggAddContext) - Method in interface org.apache.calcite.adapter.enumerable.AggImplementor
-
Updates intermediate values to account for the newly added value.
- implementAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.LagImplementor
- implementAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- implemented - Variable in class org.apache.calcite.linq4j.tree.ClassDeclaration
- implementLambdaFactory(BlockBuilder, PhysType, List<AggImpState>, Expression, boolean, ParameterExpression) - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase
-
Implements the
AggregateLambdaFactory
. - implementNotNullAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.UserDefinedAggReflectiveImplementor
- implementNotNullAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- implementNotNullAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- implementNotNullAdd(WinAggContext, WinAggAddContext) - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- implementNotNullReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.UserDefinedAggReflectiveImplementor
- implementNotNullReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- implementNotNullReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- implementNotNullReset(WinAggContext, WinAggResetContext) - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- implementNotNullResult(AggContext, AggResultContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.UserDefinedAggReflectiveImplementor
- implementNotNullResult(AggContext, AggResultContext) - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- implementNotNullResult(AggContext, AggResultContext) - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- implementNotNullResult(WinAggContext, WinAggResultContext) - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- implementor - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- implementor() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.BaseContext
- implementor() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- implementor() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.SimpleContext
- Implementor() - Constructor for class org.apache.calcite.adapter.arrow.ArrowRel.Implementor
- Implementor() - Constructor for class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
- Implementor() - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
- Implementor() - Constructor for class org.apache.calcite.adapter.innodb.InnodbRel.Implementor
- Implementor() - Constructor for class org.apache.calcite.adapter.pig.PigRel.Implementor
- Implementor(RexBuilder) - Constructor for class org.apache.calcite.adapter.mongodb.MongoRel.Implementor
- Implementor(RexBuilder) - Constructor for class org.apache.calcite.adapter.spark.SparkRel.Implementor
- implementReset(AggContext, AggResetContext) - Method in interface org.apache.calcite.adapter.enumerable.AggImplementor
-
Implements reset of the intermediate variables to the initial state.
- implementReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.LagImplementor
- implementReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- implementResult(AggContext, AggResultContext) - Method in interface org.apache.calcite.adapter.enumerable.AggImplementor
-
Calculates the resulting value based on the intermediate variables.
- implementResult(AggContext, AggResultContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.LagImplementor
- implementResult(AggContext, AggResultContext) - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- implementRoot(EnumerableRel, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- implementSpark(SparkRel.Implementor) - Method in class org.apache.calcite.adapter.spark.EnumerableToSparkConverter
- implementSpark(SparkRel.Implementor) - Method in class org.apache.calcite.adapter.spark.JdbcToSparkConverter
- implementSpark(SparkRel.Implementor) - Method in interface org.apache.calcite.adapter.spark.SparkRel
- implementSpark(SparkRel.Implementor) - Method in class org.apache.calcite.adapter.spark.SparkRules.SparkCalc
- implementSpark(SparkRel.Implementor) - Method in class org.apache.calcite.adapter.spark.SparkRules.SparkValues
- IMPLICIT - Enum constant in enum org.apache.calcite.sql.SqlCollation.Coercibility
- IMPLICIT - Static variable in class org.apache.calcite.sql.SqlCollation
- implicitCast(RelDataType, SqlTypeFamily) - Method in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
-
Type coercion based on the inferred type from passed in operand and the
SqlTypeFamily
defined in the checkers, e.g. - ImplicitCastOperandTypeChecker - Interface in org.apache.calcite.sql.type
-
An operand type checker that supports implicit type cast, see
TypeCoercion.builtinFunctionCoercion(SqlCallBinding, List, List)
for details. - implies(RexNode, RexNode) - Method in class org.apache.calcite.plan.RexImplicationChecker
-
Checks if condition first implies (⇒) condition second.
- in(RelNode, ImmutableList<RexNode>) - Static method in class org.apache.calcite.rex.RexSubQuery
-
Creates an IN sub-query.
- in(RelNode, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an IN predicate with a sub-query.
- in(RexNode, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an IN predicate with a list of values.
- in(RexNode, Function<RelBuilder, RelNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an IN predicate with a sub-query.
- in(RexNode, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an IN predicate with a list of values.
- IN - Enum constant in enum org.apache.calcite.plan.RelOptUtil.SubQueryType
- IN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
IN
operator. - IN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
IN
operator tests for a value's membership in a sub-query or a list of values. - IN_FENNEL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Use of the
IN_FENNEL
operator forces the argument to be evaluated in Fennel. - IN_PROGRESS - Enum constant in enum org.apache.calcite.sql.validate.SqlValidatorImpl.Status
-
Validation is in progress for this scope.
- inBooleanFamily(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is in SqlTypeFamily.Boolean.
- inCalc(Calc) - Method in class org.apache.calcite.rex.RexUtil.RexFinder
-
Returns whether a
Calc
contains the kind of expression we seek. - inceptionDate - Variable in class org.apache.calcite.test.schemata.hr.DepartmentPlus
- inCharFamily(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is in SqlTypeFamily.Character.
- inCharFamily(SqlTypeName) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type name is in SqlTypeFamily.Character.
- inCharOrBinaryFamilies(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type family is either character or binary.
- includeNulls - Variable in class org.apache.calcite.sql.SqlUnpivot
- includingOptions - Variable in class org.apache.calcite.sql.ddl.SqlCreateTableLike
- incompatibleCharset(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- incompatibleTypes() - Method in interface org.apache.calcite.runtime.CalciteResource
- incompatibleTypesInList() - Method in interface org.apache.calcite.runtime.CalciteResource
- incompatibleValueType(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- incr(int) - Method in class org.apache.calcite.util.ImmutableIntList
-
Increments
offset
to each element of the list and returns a new int list. - INCREASING - Enum constant in enum org.apache.calcite.sql.validate.SqlMonotonicity
- increment(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents the incrementing of the expression value by 1.
- increment(Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents the incrementing of the expression by 1.
- Increment - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A unary increment operation, such as (a + 1) in C# and Visual Basic.
- INDENT - Static variable in class org.apache.calcite.util.StackWriter
-
Directive for increasing the indentation level.
- INDENT_SPACE4 - Static variable in class org.apache.calcite.util.StackWriter
-
Four-space indentation.
- INDENT_TAB - Static variable in class org.apache.calcite.util.StackWriter
-
Tab indentation.
- indentation() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the number of spaces indentation.
- index - Variable in class org.apache.calcite.rex.RexSlot
- index() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResetContextImpl
- index() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- index() - Method in interface org.apache.calcite.adapter.enumerable.WinAggFrameContext
-
Returns the index of the current row in the partition.
- Index - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An index operation or an operation that accesses a property that takes arguments.
- INDEX - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
Index table.
- indexCondition - Variable in class org.apache.calcite.adapter.innodb.InnodbFilter
- IndexCondition - Class in org.apache.calcite.adapter.innodb
-
Index condition.
- IndexExpression - Class in org.apache.calcite.linq4j.tree
-
Represents indexing a property or array.
- IndexExpression(Expression, List<Expression>) - Constructor for class org.apache.calcite.linq4j.tree.IndexExpression
- indexExpressions - Variable in class org.apache.calcite.linq4j.tree.IndexExpression
- indexOf(int) - Method in class org.apache.calcite.util.ImmutableBitSet
-
The ordinal of a given bit, or -1 if it is not set.
- indexOf(int) - Method in class org.apache.calcite.util.ImmutableIntList
- indexOf(Object) - Method in class org.apache.calcite.runtime.ConsList
- indexOf(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat1List
- indexOf(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat2List
- indexOf(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat3List
- indexOf(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat4List
- indexOf(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat5List
- indexOf(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- indexOf(Object) - Method in class org.apache.calcite.sql.SqlNodeList
- indexOf(Object) - Method in class org.apache.calcite.util.ImmutableIntList
- indexOf(Iterable<String>, String) - Method in interface org.apache.calcite.sql.validate.SqlNameMatcher
-
Returns the index of the first element of a collection that matches.
- indexOf(String) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Returns the index within this string of the first occurrence of the specified substring.
- indexOf(String, int) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Returns the index within this string of the first occurrence of the specified substring, starting at the specified index.
- indexOfDeep(List<? extends SqlNode>, SqlNode, Litmus) - Static method in class org.apache.calcite.sql.SqlUtil
-
Finds the index of an expression in a list, comparing using
SqlNode.equalsDeep(SqlNode, Litmus)
. - IndexRangeOrdering() - Constructor for class org.apache.calcite.runtime.SpaceFillingCurve2D.IndexRangeOrdering
- indexToLineCol(String, int) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Returns the (1-based) line and column corresponding to a particular (0-based) offset in a string.
- indicator - Variable in class org.apache.calcite.plan.RelOptUtil.Exists
- indicator - Variable in class org.apache.calcite.rel.core.Aggregate
-
Deprecated.
- induce(ImmutableBitSet, List<ImmutableBitSet>) - Static method in enum org.apache.calcite.rel.core.Aggregate.Group
- inferJoinEqualConditions(List<RexNode>, Join) - Method in class org.apache.calcite.rel.rules.FilterJoinRule
-
Infers more equal conditions for the join condition.
- inferOperandTypes(SqlCallBinding, RelDataType, RelDataType[]) - Method in class org.apache.calcite.sql.type.ExplicitOperandTypeInference
- inferOperandTypes(SqlCallBinding, RelDataType, RelDataType[]) - Method in interface org.apache.calcite.sql.type.SqlOperandTypeInference
-
Infers any unknown operand types.
- inferReturnType(RelDataTypeFactory, List<RelDataType>) - Method in class org.apache.calcite.sql.SqlOperator
-
Infers the type of a call to this operator with a given set of operand types.
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlAbstractTimeFunction
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlArrayValueConstructor
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlBetweenOperator
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlCaseOperator
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlDotOperator
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlItemOperator
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlLiteralChainOperator
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlMapValueConstructor
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlMultisetValueConstructor
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlRowOperator
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.SqlOperator
-
Infers the return type of an invocation of this operator; only called after the number and types of operands have already been validated.
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.SqlTypeConstructorFunction
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.SqlUnnestOperator
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.SqlUnresolvedFunction
-
Infers the return type of an invocation of this operator; only called after the number and types of operands have already been validated.
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.type.CursorReturnTypeInference
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.type.ExplicitReturnTypeInference
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.type.MatchReturnTypeInference
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.type.OrdinalReturnTypeInference
- inferReturnType(SqlOperatorBinding) - Method in interface org.apache.calcite.sql.type.SqlReturnTypeInference
-
Infers the return type of a call to an
SqlOperator
. - inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.type.SqlReturnTypeInferenceChain
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.type.SqlTypeTransformCascade
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.type.TableFunctionReturnTypeInference
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.test.MockSqlOperatorTable.BadTableFunction
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.test.MockSqlOperatorTable.CompositeFunction
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.test.MockSqlOperatorTable.MapFunction
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.test.MockSqlOperatorTable.MyFunction
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.test.MockSqlOperatorTable.SplitFunction
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.test.MockSqlOperatorTable.StructuredFunction
- InferTypes - Class in org.apache.calcite.sql.type
-
Strategies for inferring operand types.
- inferUnknownTypes(RelDataType, SqlValidatorScope, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- inferViewPredicates(Map<Integer, RexNode>, List<RexNode>, RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Decomposes the WHERE clause of a view into predicates that constraint a column to a particular value.
- inFilter(Filter) - Method in class org.apache.calcite.rex.RexUtil.RexFinder
-
Returns whether a
Filter
contains the kind of expression we seek. - InfiniteOrdersStreamTableFactory - Class in org.apache.calcite.test.schemata.orderstream
-
Mock table that returns a stream of orders from a fixed array.
- InfiniteOrdersStreamTableFactory() - Constructor for class org.apache.calcite.test.schemata.orderstream.InfiniteOrdersStreamTableFactory
- InfiniteOrdersTable - Class in org.apache.calcite.test.schemata.orderstream
-
Table representing an infinitely larger ORDERS stream.
- InfiniteOrdersTable() - Constructor for class org.apache.calcite.test.schemata.orderstream.InfiniteOrdersTable
- infix(Object, int, boolean) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- infix(Object, int, boolean) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- INFIX - Enum constant in enum org.apache.calcite.util.PrecedenceClimbingParser.Type
- INFIX_CAST - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
Infix "::" cast operator used by PostgreSQL, for example
'100'::INTEGER
. - info(String) - Method in class org.apache.calcite.util.trace.CalciteLogger
- info(String, Object, Object) - Method in class org.apache.calcite.util.trace.CalciteLogger
-
Logs an INFO message with two Object parameters.
- info(String, Object, Object, Object) - Method in class org.apache.calcite.util.trace.CalciteLogger
-
Conditionally logs an INFO message with three Object parameters.
- info(String, Object, Object, Object, Object) - Method in class org.apache.calcite.util.trace.CalciteLogger
-
Conditionally logs an INFO message with four Object parameters.
- info(String, Object...) - Method in class org.apache.calcite.util.trace.CalciteLogger
- INFOBRIGHT - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- InfobrightSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Infobright database. - InfobrightSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.InfobrightSqlDialect
-
Creates an InfobrightSqlDialect.
- INFORMIX - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- InformixSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Informix database. - InformixSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.InformixSqlDialect
-
Creates an InformixSqlDialect.
- INGRES - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- IngresSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Ingres database. - IngresSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.IngresSqlDialect
-
Creates an IngresSqlDialect.
- inheritors() - Method in enum org.apache.calcite.sql.fun.SqlLibrary
-
Returns the libraries that inherit this library's functions, because their
SqlLibrary.parent
field points to this. - inheritPath - Variable in class org.apache.calcite.rel.hint.RelHint
- inheritPath(Integer...) - Method in class org.apache.calcite.rel.hint.RelHint.Builder
-
Sets up the inherit path with given integer array.
- inheritPath(Iterable<Integer>) - Method in class org.apache.calcite.rel.hint.RelHint.Builder
-
Sets up the inherit path with given integer list.
- init() - Method in class org.apache.calcite.interpreter.AggregateNode.BigDecimalSum
- init() - Method in class org.apache.calcite.interpreter.AggregateNode.DoubleSum
- init() - Method in class org.apache.calcite.interpreter.AggregateNode.IntSum
- init() - Method in class org.apache.calcite.interpreter.AggregateNode.LongSum
- init() - Method in class org.apache.calcite.interpreter.AggregateNode.MaxBoolean
- init() - Method in class org.apache.calcite.interpreter.AggregateNode.MinBoolean
- init() - Method in class org.apache.calcite.interpreter.AggregateNode.NumericComparison
- init() - Method in class org.apache.calcite.runtime.AccumOperation
- init() - Method in class org.apache.calcite.runtime.CollectOperation
- init() - Method in class org.apache.calcite.runtime.UnionOperation
- init() - Method in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
-
Performs post-constructor initialization of an operator table.
- init() - Method in class org.apache.calcite.test.catalog.MockCatalogReader
-
Initializes this catalog reader.
- init() - Method in class org.apache.calcite.test.catalog.MockCatalogReaderDynamic
- init() - Method in class org.apache.calcite.test.catalog.MockCatalogReaderExtended
- init() - Method in class org.apache.calcite.test.catalog.MockCatalogReaderSimple
- init() - Method in class org.apache.calcite.test.catalog.MustFilterMockCatalogReader
- init() - Static method in class org.apache.calcite.util.Smalls.MyStaticSumFunction
- init() - Method in class org.apache.calcite.util.Smalls.MySum3
- init() - Method in class org.apache.calcite.util.Smalls.MySumFunction
- init() - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter1
- init() - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter2
- init() - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter1
- init() - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter2
- init() - Method in class org.apache.calcite.util.Smalls.SumFunctionBadIAdd
- init(Class) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- init(Class) - Method in class org.apache.calcite.prepare.Prepare
- init(RelOptPlanner) - Static method in class org.apache.calcite.rel.convert.NoneConverter
- initcap(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL INITCAP(string) function.
- INITCAP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- INITCAP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- initialHandler(Class<H>) - Static method in class org.apache.calcite.rel.metadata.RelMetadataQueryBase
-
Deprecated.
- initializer - Variable in class org.apache.calcite.linq4j.tree.DeclarationStatement
- initializer - Variable in class org.apache.calcite.linq4j.tree.FieldDeclaration
- InitializerContext - Interface in org.apache.calcite.sql2rel
-
Provides context for
InitializerExpressionFactory
methods. - InitializerExpressionFactory - Interface in org.apache.calcite.sql2rel
-
InitializerExpressionFactory supplies default values for INSERT, UPDATE, and NEW.
- initializerFactory - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- initMethod - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- INJECTION - Enum constant in enum org.apache.calcite.util.mapping.MappingType
- inJoin(Join) - Method in class org.apache.calcite.rex.RexUtil.RexFinder
-
Returns whether a
Join
contains the kind of expression we seek. - inList - Variable in class org.apache.calcite.sql.SqlPivot
- inList - Variable in class org.apache.calcite.sql.SqlUnpivot
- INNER - Enum constant in enum org.apache.calcite.linq4j.JoinType
-
Inner join.
- INNER - Enum constant in enum org.apache.calcite.rel.core.JoinRelType
-
Inner join.
- INNER - Enum constant in enum org.apache.calcite.sql.JoinType
-
Inner join.
- INNODB_QUERYABLE_QUERY - Enum constant in enum org.apache.calcite.adapter.innodb.InnodbMethod
-
Method signature to call for code generation.
- InnodbFilter - Class in org.apache.calcite.adapter.innodb
-
Implementation of a
Filter
relational expression for an InnoDB data source. - InnodbFilterRule(InnodbRules.InnodbFilterRule.InnodbFilterRuleConfig) - Constructor for class org.apache.calcite.adapter.innodb.InnodbRules.InnodbFilterRule
-
Creates a InnodbFilterRule.
- InnodbMethod - Enum in org.apache.calcite.adapter.innodb
-
Builtin methods in InnoDB data source.
- InnodbProject - Class in org.apache.calcite.adapter.innodb
-
Implementation of
Project
relational expression for an InnoDB data source. - InnodbProjectRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.innodb.InnodbRules.InnodbProjectRule
- InnodbQueryable(QueryProvider, SchemaPlus, InnodbTable, String) - Constructor for class org.apache.calcite.adapter.innodb.InnodbTable.InnodbQueryable
- InnodbRel - Interface in org.apache.calcite.adapter.innodb
-
Relational expression that uses InnoDB calling convention.
- InnodbRel.Implementor - Class in org.apache.calcite.adapter.innodb
-
Callback for the implementation process that converts a tree of
InnodbRel
nodes into an InnoDB direct call query. - InnodbRules - Class in org.apache.calcite.adapter.innodb
-
Rules and relational operators for
InnodbRel.CONVENTION
calling convention. - InnodbRules.InnodbFilterRule - Class in org.apache.calcite.adapter.innodb
-
Rule to convert a
LogicalFilter
to aInnodbFilter
. - InnodbRules.InnodbFilterRule.InnodbFilterRuleConfig - Interface in org.apache.calcite.adapter.innodb
-
Rule configuration.
- InnodbRules.InnodbProjectRule - Class in org.apache.calcite.adapter.innodb
-
Rule to convert a
LogicalProject
to aInnodbProject
. - InnodbRules.InnodbSortFilterRule - Class in org.apache.calcite.adapter.innodb
-
Rule to convert a
Sort
to aInnodbSort
. - InnodbRules.InnodbSortFilterRule.InnodbSortFilterRuleConfig - Interface in org.apache.calcite.adapter.innodb
-
Rule configuration.
- InnodbRules.InnodbSortTableScanRule - Class in org.apache.calcite.adapter.innodb
-
Rule to convert a
Sort
to aInnodbSort
based on InnoDB table clustering index. - InnodbRules.InnodbSortTableScanRule.InnodbSortTableScanRuleConfig - Interface in org.apache.calcite.adapter.innodb
-
Rule configuration.
- InnodbSchema - Class in org.apache.calcite.adapter.innodb
-
Schema for an InnoDB data source.
- InnodbSchema(List<String>, String) - Constructor for class org.apache.calcite.adapter.innodb.InnodbSchema
- InnodbSchemaFactory - Class in org.apache.calcite.adapter.innodb
-
Factory that creates a
InnodbSchema
. - InnodbSchemaFactory() - Constructor for class org.apache.calcite.adapter.innodb.InnodbSchemaFactory
- InnodbSort - Class in org.apache.calcite.adapter.innodb
-
Implementation of
Sort
relational expression for an InnoDB data source. - InnodbSortFilterRule(InnodbRules.InnodbSortFilterRule.InnodbSortFilterRuleConfig) - Constructor for class org.apache.calcite.adapter.innodb.InnodbRules.InnodbSortFilterRule
-
Creates a InnodbSortFilterRule.
- InnodbSortTableScanRule(InnodbRules.InnodbSortTableScanRule.InnodbSortTableScanRuleConfig) - Constructor for class org.apache.calcite.adapter.innodb.InnodbRules.InnodbSortTableScanRule
-
Creates a InnodbSortTableScanRule.
- InnodbTable - Class in org.apache.calcite.adapter.innodb
-
Table based on an InnoDB data file.
- InnodbTable(InnodbSchema, String) - Constructor for class org.apache.calcite.adapter.innodb.InnodbTable
- InnodbTable.InnodbQueryable<T> - Class in org.apache.calcite.adapter.innodb
-
Implementation of
Queryable
based on aInnodbTable
. - InnodbTableScan - Class in org.apache.calcite.adapter.innodb
-
Relational expression representing a scan of an InnoDB data source.
- InnodbTableScan(RelOptCluster, RelTraitSet, RelOptTable, InnodbTable, RelDataType, List<RelHint>) - Constructor for class org.apache.calcite.adapter.innodb.InnodbTableScan
- InnodbToEnumerableConverter - Class in org.apache.calcite.adapter.innodb
-
Relational expression representing a scan of a table in InnoDB data source.
- InnodbToEnumerableConverter(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.adapter.innodb.InnodbToEnumerableConverter
- InnodbToEnumerableConverterRule - Class in org.apache.calcite.adapter.innodb
-
Rule to convert a relational expression from
InnodbRel.CONVENTION
toEnumerableConvention
. - InnodbToEnumerableConverterRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.innodb.InnodbToEnumerableConverterRule
-
Creates a InnodbToEnumerableConverterRule.
- inOperationCoercion(SqlCallBinding) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Handles type coercion for IN operation with or without sub-query.
- inOperationCoercion(SqlCallBinding) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
-
Handles type coercion for IN operation with or without sub-query.
- INOPERATIVE_VIEW - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
An inoperative view.
- inProgram(RexProgram) - Method in class org.apache.calcite.rex.RexUtil.RexFinder
-
Returns whether a
RexProgram
contains the kind of expression we seek. - inProject(Project) - Method in class org.apache.calcite.rex.RexUtil.RexFinder
-
Returns whether a
Project
contains the kind of expression we seek. - input - Variable in class org.apache.calcite.rel.mutable.MutableSort
- input - Variable in class org.apache.calcite.rel.SingleRel
- input(String, RelNode) - Method in interface org.apache.calcite.rel.RelWriter
-
Adds an input to the explanation of the current node.
- INPUT_REF - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Reference to an input field.
- inputArgumentsOfFunctionOutOfRange(String, Number, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- InputFinder() - Constructor for class org.apache.calcite.plan.RelOptUtil.InputFinder
- InputFinder(Set<RelDataTypeField>) - Constructor for class org.apache.calcite.plan.RelOptUtil.InputFinder
- InputFinder(Set<RelDataTypeField>, ImmutableBitSet) - Constructor for class org.apache.calcite.plan.RelOptUtil.InputFinder
- InputGetterImpl(List<Pair<Expression, PhysType>>) - Constructor for class org.apache.calcite.adapter.enumerable.RexToLixTranslator.InputGetterImpl
-
Deprecated.
- InputGetterImpl(Map<Expression, PhysType>) - Constructor for class org.apache.calcite.adapter.enumerable.RexToLixTranslator.InputGetterImpl
- InputGetterImpl(Expression, PhysType) - Constructor for class org.apache.calcite.adapter.enumerable.RexToLixTranslator.InputGetterImpl
- inputPosReferenced - Variable in class org.apache.calcite.plan.RelOptUtil.InputReferencedVisitor
- InputReferencedVisitor() - Constructor for class org.apache.calcite.plan.RelOptUtil.InputReferencedVisitor
- inputs - Variable in class org.apache.calcite.rel.core.SetOp
- inputs - Variable in class org.apache.calcite.rel.mutable.MutableUnion
- inputs(RelRule.OperandTransform...) - Method in interface org.apache.calcite.plan.RelRule.OperandDetailBuilder
-
Indicates that this operand has several inputs.
- inputTypeList - Variable in class org.apache.calcite.rex.RexChecker
- inQuery() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- inQuery() - Method in interface org.apache.calcite.sql.SqlWriter
-
Returns whether we are currently in a query context (SELECT, INSERT, UNION, INTERSECT, EXCEPT, and the ORDER BY operator).
- inSameFamily(RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether two types are in same type family.
- inSameFamilyOrNull(RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether two types are in same type family, or one or the other is of type
SqlTypeName.NULL
. - insert(int, String) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Inserts the string into this character sequence.
- INSERT - Enum constant in enum org.apache.calcite.rel.core.TableModify.Operation
- INSERT - Enum constant in enum org.apache.calcite.runtime.JsonFunctions.JsonModifyMode
- INSERT - Enum constant in enum org.apache.calcite.sql.SqlAccessEnum
- INSERT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
INSERT statement.
- insertIntoAlwaysGenerated(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- insertSource(int) - Method in class org.apache.calcite.util.Permutation
-
Inserts into the sources.
- insertTarget(int) - Method in class org.apache.calcite.util.Permutation
-
Inserts into the targets.
- instance() - Static method in class org.apache.calcite.adapter.cassandra.CqlToSqlTypeConversionRules
-
Returns the
singleton
instance. - instance() - Static method in class org.apache.calcite.adapter.innodb.ColumnTypeToSqlTypeConversionRules
-
Returns the
singleton
instance. - instance() - Static method in class org.apache.calcite.adapter.spark.SparkHandlerImpl
-
Creates a SparkHandlerImpl, initializing on first call.
- instance() - Static method in class org.apache.calcite.linq4j.QueryableRecorder
- instance() - Static method in class org.apache.calcite.materialize.MaterializationService
-
Returns the instance of the materialization service.
- instance() - Static method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns an instance of RelMetadataQuery.
- instance() - Static method in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
Deprecated.Returns the Oracle operator table, creating it if necessary.
- instance() - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Returns the standard operator table, creating it if necessary.
- instance() - Static method in class org.apache.calcite.sql.type.JavaToSqlTypeConversionRules
-
Returns the
singleton
instance. - instance() - Static method in class org.apache.calcite.sql.type.SqlTypeAssignmentRule
-
Returns an instance.
- instance() - Static method in class org.apache.calcite.sql.type.SqlTypeCoercionRule
-
Returns an instance.
- instance() - Static method in class org.apache.calcite.sql.util.SqlBasicVisitor.ArgHandlerImpl
- instance(boolean) - Static method in class org.apache.calcite.sql.type.SqlTypeMappingRules
-
Returns the
SqlTypeMappingRule
instance based on the specifiedcoerce
to indicate whether to return as a type coercion rule. - instance(Map<SqlTypeName, ImmutableSet<SqlTypeName>>) - Static method in class org.apache.calcite.sql.type.SqlTypeCoercionRule
-
Returns an instance with specified type mappings.
- INSTANCE - Enum constant in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- INSTANCE - Enum constant in enum org.apache.calcite.interpreter.BindableConvention
- INSTANCE - Enum constant in enum org.apache.calcite.interpreter.InterpretableConvention
- INSTANCE - Enum constant in enum org.apache.calcite.rel.metadata.NullSentinel
-
Placeholder for a null value.
- INSTANCE - Enum constant in enum org.apache.calcite.statistic.MapSqlStatisticProvider
- INSTANCE - Static variable in class org.apache.calcite.adapter.csv.CsvSchemaFactory
-
Public singleton, per factory contract.
- INSTANCE - Static variable in class org.apache.calcite.adapter.druid.DruidTableFactory
- INSTANCE - Static variable in class org.apache.calcite.adapter.enumerable.RexImpTable
-
The singleton instance.
- INSTANCE - Static variable in class org.apache.calcite.adapter.file.FileSchemaFactory
-
Public singleton, per factory contract.
- INSTANCE - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeToEnumerableConverterRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.jdbc.JdbcQueryProvider
- INSTANCE - Static variable in class org.apache.calcite.adapter.jdbc.JdbcSchema.Factory
- INSTANCE - Static variable in class org.apache.calcite.adapter.mongodb.MongoToEnumerableConverterRule
-
Singleton instance of MongoToEnumerableConverterRule.
- INSTANCE - Static variable in class org.apache.calcite.adapter.pig.PigRelFactories.PigAggregateFactory
- INSTANCE - Static variable in class org.apache.calcite.adapter.pig.PigRelFactories.PigFilterFactory
- INSTANCE - Static variable in class org.apache.calcite.adapter.pig.PigRelFactories.PigJoinFactory
- INSTANCE - Static variable in class org.apache.calcite.adapter.pig.PigRelFactories.PigTableScanFactory
- INSTANCE - Static variable in class org.apache.calcite.adapter.pig.PigSchemaFactory
-
Public singleton, per factory contract.
- INSTANCE - Static variable in class org.apache.calcite.adapter.pig.PigToEnumerableConverterRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.redis.RedisTableFactory
- INSTANCE - Static variable in class org.apache.calcite.jdbc.CalciteMetaColumnFactoryImpl
-
Singleton instance.
- INSTANCE - Static variable in class org.apache.calcite.jdbc.CalciteMetaTableFactoryImpl
-
Singleton instance.
- INSTANCE - Static variable in class org.apache.calcite.linq4j.tree.ConstantUntypedNull
- INSTANCE - Static variable in interface org.apache.calcite.linq4j.util.Compatible
- INSTANCE - Static variable in class org.apache.calcite.piglet.PigToSqlAggregateRule
- INSTANCE - Static variable in class org.apache.calcite.plan.ConventionTraitDef
- INSTANCE - Static variable in exception class org.apache.calcite.plan.SubstitutionVisitor.MatchFailed
- INSTANCE - Static variable in class org.apache.calcite.plan.volcano.AbstractConverter.ExpandConversionRule
- INSTANCE - Static variable in interface org.apache.calcite.rel.convert.ConverterRule.Config
- INSTANCE - Static variable in class org.apache.calcite.rel.hint.HintStrategyTable.HintErrorLogger
- INSTANCE - Static variable in class org.apache.calcite.rel.metadata.DefaultRelMetadataProvider
- INSTANCE - Static variable in class org.apache.calcite.rel.RelCollationTraitDef
- INSTANCE - Static variable in class org.apache.calcite.rel.RelDistributionTraitDef
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.SpatialRules
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.TableScanRule
-
Deprecated.
- INSTANCE - Static variable in class org.apache.calcite.rex.RexUtil.SubQueryFinder
- INSTANCE - Static variable in class org.apache.calcite.runtime.Unit
- INSTANCE - Static variable in class org.apache.calcite.schema.impl.AbstractSchema.Factory
- INSTANCE - Static variable in class org.apache.calcite.server.ServerDdlExecutor
-
Singleton instance.
- INSTANCE - Static variable in class org.apache.calcite.sql.fun.SqlCaseOperator
- INSTANCE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperatorTableFactory
-
The singleton instance.
- INSTANCE - Static variable in class org.apache.calcite.sql.fun.SqlLiteralAggFunction
- INSTANCE - Static variable in class org.apache.calcite.sql.fun.SqlTrimFunction
- INSTANCE - Static variable in class org.apache.calcite.sql.SqlDialectFactoryImpl
- INSTANCE - Static variable in class org.apache.calcite.sql.SqlMatchRecognize.SqlMatchRecognizeOperator
- INSTANCE - Static variable in class org.apache.calcite.sql.SqlSelectOperator
- INSTANCE - Static variable in class org.apache.calcite.sql.SqlSnapshot.SqlSnapshotOperator
- INSTANCE - Static variable in class org.apache.calcite.sql.SqlSplittableAggFunction.CountSplitter
- INSTANCE - Static variable in class org.apache.calcite.sql.SqlSplittableAggFunction.SelfSplitter
- INSTANCE - Static variable in class org.apache.calcite.sql.SqlSplittableAggFunction.Sum0Splitter
- INSTANCE - Static variable in class org.apache.calcite.sql.SqlSplittableAggFunction.SumSplitter
- INSTANCE - Static variable in class org.apache.calcite.sql.test.SqlTestFactory
- INSTANCE - Static variable in class org.apache.calcite.sql2rel.NullInitializerExpressionFactory
- INSTANCE - Static variable in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Singleton instance.
- INSTANCE - Static variable in interface org.apache.calcite.util.Compatible
- INSTANCE - Static variable in interface org.apache.calcite.util.SaffronProperties
-
Deprecated.
- INSTANCE - Static variable in class org.apache.calcite.util.Util.OverFinder
- INSTANCE_COUNT - Static variable in class org.apache.calcite.util.Smalls.MyDeterministicPlusFunction
- INSTANCE_COUNT - Static variable in class org.apache.calcite.util.Smalls.MyPlusFunction
- INSTANCE_COUNT - Static variable in class org.apache.calcite.util.Smalls.MyPlusInitFunction
- INSTR - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "INSTR(string, substring [, position [, occurrence]])" function.
- INT - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive
- INT_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- IntAndString(int, String) - Constructor for class org.apache.calcite.test.schemata.catchall.CatchallSchema.IntAndString
- integer - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.BadType
- INTEGER - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- INTEGER - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- INTEGER - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is an Integer.
- INTEGER - Static variable in interface org.apache.calcite.util.JdbcType
- INTEGER_CAST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- INTEGER_CAST_ROUNDING_MODE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- INTEGER_DECIMAL_CAST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- INTEGER_DECIMAL_CAST_ROUNDING_MODE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- INTEGER_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- INTEGER_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is an Integer with nulls allowed if any of the operands allow nulls.
- INTEGER_NULLABLE - Static variable in interface org.apache.calcite.util.JdbcType
- INTEGER_QUOTIENT_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is
ReturnTypes.ARG0_INTERVAL_NULLABLE
andReturnTypes.LEAST_RESTRICTIVE
. - INTEGER_TYPE_CHECKER - Static variable in class org.apache.calcite.sql.test.SqlTests
- integerCast(Primitive, Object) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Called from BuiltInMethod.INTEGER_CAST
- integerCast(Primitive, Object, RoundingMode) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Called from BuiltInMethod.INTEGER_CAST_ROUNDING_MODE
- integerDecimalCast(Number, int, int) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Called from BuiltInMethod.INTEGER_DECIMAL_CAST
- integerDecimalCast(Number, int, int, RoundingMode) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Called from BuiltInMethod.INTEGER_DECIMAL_CAST_ROUNDING_MODE
- IntegerFunction1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function that takes one parameter and returns a native
int
value. - IntegerIntervalSet - Class in org.apache.calcite.util
-
A set of non-negative integers defined by a sequence of points, intervals, and exclusions.
- integers - Variable in class org.apache.calcite.util.Version
- INTEGRATION_TEST - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to run integration tests.
- INTERBASE - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- InterbaseSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Interbase database. - InterbaseSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.InterbaseSqlDialect
-
Creates an InterbaseSqlDialect.
- INTERFACE_ADDRESSES - Enum constant in enum org.apache.calcite.adapter.os.OsQueryType
- INTERFACE_DETAILS - Enum constant in enum org.apache.calcite.adapter.os.OsQueryType
- InterfaceAddressesTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "interface_addresses".
- InterfaceDetailsTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "interface_details".
- internal(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- INTERNAL - Enum constant in enum org.apache.calcite.sql.SqlSyntax
-
Syntax of an internal operator, which does not appear in the SQL.
- INTERNAL_TO_DATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- INTERNAL_TO_TIME - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- INTERNAL_TO_TIMESTAMP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- internalParameters - Variable in class org.apache.calcite.interpreter.InterpretableRel.InterpreterImplementor
- internalToDate(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a SQL DATE value from the internal representation type (number of days since January 1st, 1970) to the Java type (
Date
). - internalToDate(Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a nullable SQL DATE value from the internal representation type (number of days since January 1st, 1970) to the Java type (
Date
). - internalToTime(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a SQL TIME value from the internal representation type (number of milliseconds since January 1st, 1970) to the Java type (
Time
). - internalToTime(Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a nullable SQL TIME value from the internal representation type (number of milliseconds since January 1st, 1970) to the Java type (
Time
). - internalToTimestamp(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a SQL TIMESTAMP value from the internal representation type (number of milliseconds since January 1st, 1970) to the Java Type (
Timestamp
) in the local time zone. - internalToTimestamp(Long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a nullable SQL TIMESTAMP value from the internal representation type (number of milliseconds since January 1st, 1970) to the Java Type (
Timestamp
) in the local time zone. - InterpretableConvention - Enum in org.apache.calcite.interpreter
-
Calling convention that returns results as an
Enumerable
of object arrays. - InterpretableConverter - Class in org.apache.calcite.interpreter
-
Relational expression that converts any relational expression input to
InterpretableConvention
, by wrapping it in an interpreter. - InterpretableConverter(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.interpreter.InterpretableConverter
- InterpretableRel - Interface in org.apache.calcite.interpreter
-
Relational expression that can implement itself using an interpreter.
- InterpretableRel.InterpreterImplementor - Class in org.apache.calcite.interpreter
- interpreter - Variable in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- Interpreter - Class in org.apache.calcite.interpreter
-
Interpreter.
- Interpreter(DataContext, RelNode) - Constructor for class org.apache.calcite.interpreter.Interpreter
-
Creates an Interpreter.
- INTERPRETER - Static variable in interface org.apache.calcite.rel.rules.FilterTableScanRule.Config
- INTERPRETER - Static variable in interface org.apache.calcite.rel.rules.ProjectTableScanRule.Config
-
Config that matches Project on EnumerableInterpreter on TableScan.
- INTERPRETER_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Given a language, define a representation for its grammar along with an interpreter that uses the representation to interpret sentences in the language.
- InterpreterImplementor(Compiler, CalcitePrepare.SparkHandler, DataContext) - Constructor for class org.apache.calcite.interpreter.InterpretableRel.InterpreterImplementor
- Interpreters - Class in org.apache.calcite.interpreter
-
Utilities relating to
Interpreter
andInterpretableConvention
. - intersect(boolean) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
Intersect
of the two most recent relational expressions on the stack. - intersect(boolean, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
Intersect
of then
most recent relational expressions on the stack. - intersect(Enumerable<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- intersect(Enumerable<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- intersect(Enumerable<T>, boolean) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- intersect(Enumerable<T>, boolean) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- intersect(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- intersect(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- intersect(Enumerable<T>, EqualityComparer<T>, boolean) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- intersect(Enumerable<T>, EqualityComparer<T>, boolean) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- intersect(Enumerable<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Produces the set intersection of two sequences by using the default equality comparer to compare values, eliminate duplicates.
- intersect(Enumerable<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Produces the set intersection of two sequences by using the default equality comparer to compare values, eliminate duplicates.(Defined by Queryable.)
- intersect(Enumerable<TSource>, boolean) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Produces the set intersection of two sequences by using the default equality comparer to compare values, using
all
to indicate whether to eliminate duplicates. - intersect(Enumerable<T>, boolean) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Produces the set intersection of two sequences by using the default equality comparer to compare values, using
all
to indicate whether to eliminate duplicates. - intersect(Enumerable<TSource>, Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Produces the set intersection of two sequences by using the default equality comparer to compare values, eliminate duplicates.(Defined by Enumerable.)
- intersect(Enumerable<TSource>, Enumerable<TSource>, boolean) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Produces the set intersection of two sequences by using the default equality comparer to compare values, using
all
to indicate whether to eliminate duplicates. - intersect(Enumerable<TSource>, Enumerable<TSource>, EqualityComparer<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Produces the set intersection of two sequences by using the specified
EqualityComparer<TSource>
to compare values, eliminate duplicates. - intersect(Enumerable<TSource>, Enumerable<TSource>, EqualityComparer<TSource>, boolean) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Produces the set intersection of two sequences by using the specified
EqualityComparer<TSource>
to compare values, usingall
to indicate whether to eliminate duplicates. - intersect(Enumerable<TSource>, EqualityComparer<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Produces the set intersection of two sequences by using the specified
EqualityComparer<TSource>
to compare values, eliminate duplicates. - intersect(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Produces the set intersection of two sequences by using the specified
EqualityComparer<TSource>
to compare values, eliminate duplicates. - intersect(Enumerable<TSource>, EqualityComparer<TSource>, boolean) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Produces the set intersection of two sequences by using the specified
EqualityComparer<TSource>
to compare values, usingall
to indicate whether to eliminate duplicates. - intersect(Enumerable<T>, EqualityComparer<T>, boolean) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Produces the set intersection of two sequences by using the specified
EqualityComparer<TSource>
to compare values, usingall
to indicate whether to eliminate duplicates. - intersect(Queryable<T>, Enumerable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Produces the set intersection of two sequences by using the default equality comparer to compare values.
- intersect(Queryable<T>, Enumerable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Produces the set intersection of two sequences by using the default equality comparer to compare values, eliminate duplicates.
- intersect(Queryable<T>, Enumerable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- intersect(Queryable<T>, Enumerable<T>, boolean) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Produces the set intersection of two sequences by using the default equality comparer to compare values, using
all
to indicate whether to eliminate duplicates. - intersect(Queryable<T>, Enumerable<T>, boolean) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- intersect(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Produces the set intersection of two sequences by using the specified
EqualityComparer<T>
to compare values. - intersect(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Produces the set intersection of two sequences by using the specified EqualityComparer to compare values, eliminate duplicates.
- intersect(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- intersect(Queryable<T>, Enumerable<T>, EqualityComparer<T>, boolean) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Produces the set intersection of two sequences by using the specified EqualityComparer to compare values, using
all
to indicate whether to eliminate duplicates. - intersect(Queryable<T>, Enumerable<T>, EqualityComparer<T>, boolean) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- intersect(ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
- intersect(ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns a bit set with all the bits set in both this set and in another.
- Intersect - Class in org.apache.calcite.rel.core
-
Relational expression that returns the intersection of the rows of its inputs.
- Intersect(RelOptCluster, RelTraitSet, List<RelHint>, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.core.Intersect
-
Creates an Intersect.
- Intersect(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.core.Intersect
-
Creates an Intersect.
- Intersect(RelInput) - Constructor for class org.apache.calcite.rel.core.Intersect
-
Creates an Intersect by parsing serialized output.
- INTERSECT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
INTERSECT
relational operator. - INTERSECT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- INTERSECT - Static variable in interface org.apache.calcite.rel.rules.UnionMergeRule.Config
- INTERSECT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- INTERSECT_ALL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- INTERSECT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts a
Intersect
to empty if any of its children are empty. - INTERSECT_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- INTERSECT_TO_DISTINCT - Static variable in class org.apache.calcite.rel.rules.CoreRules
- INTERSECTION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
INTERSECTION
aggregate function. - INTERSECTION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The INTERSECTION operator.
- intersects(Collection<E>, Collection<E>) - Static method in class org.apache.calcite.util.Util
-
Returns whether two collections have any elements in common.
- intersects(ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns true if the specified
ImmutableBitSet
has any bits set totrue
that are also set totrue
in thisImmutableBitSet
. - IntersectToDistinctRule - Class in org.apache.calcite.rel.rules
- IntersectToDistinctRule(Class<? extends Intersect>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.IntersectToDistinctRule
-
Deprecated.
- IntersectToDistinctRule(IntersectToDistinctRule.Config) - Constructor for class org.apache.calcite.rel.rules.IntersectToDistinctRule
-
Creates an IntersectToDistinctRule.
- IntersectToDistinctRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- interval - Variable in class org.apache.calcite.rel.core.Match
- interval - Variable in class org.apache.calcite.rel.mutable.MutableMatch
- interval(Iterable<TimeUnitRange>) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a checker that passes if the operand is an interval appropriate for a given date/time type.
- INTERVAL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
INTERVAL
expression. - INTERVAL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Interval expression, '
INTERVAL n timeUnit
'. - INTERVAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
- INTERVAL_DATETIME - Static variable in class org.apache.calcite.sql.type.OperandTypes
- INTERVAL_DAY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_DAY_HOUR - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_DAY_MINUTE - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_DAY_SECOND - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_DAY_TIME - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- INTERVAL_DAY_TIME_TO_STRING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- INTERVAL_HOUR - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_HOUR_MINUTE - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_HOUR_SECOND - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_INTERVAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
- INTERVAL_MINUTE - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_MINUTE_SECOND - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_MONTH - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_NUMERIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
- INTERVAL_QUALIFIER - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Interval qualifier.
- INTERVAL_SAME_SAME - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Parameter type-checking strategy where type must a nullable time interval, nullable time interval.
- INTERVAL_SECOND - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_YEAR - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_YEAR_MONTH - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- INTERVAL_YEAR_MONTH - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_YEAR_MONTH_TO_STRING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- intervalFieldExceedsPrecision(Number, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- intervalFractionalSecondPrecisionOutOfRange(int, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- INTERVALINTERVAL_INTERVALDATETIME - Static variable in class org.apache.calcite.sql.type.OperandTypes
- intervalMustBeNonNegative(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- IntervalOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Parameter type-checking strategy whether the operand must be an interval.
- IntervalSqlType - Class in org.apache.calcite.sql.type
-
IntervalSqlType represents a standard SQL datetime interval type.
- IntervalSqlType(RelDataTypeSystem, SqlIntervalQualifier, boolean) - Constructor for class org.apache.calcite.sql.type.IntervalSqlType
-
Constructs an IntervalSqlType.
- intervalStartPrecisionOutOfRange(int, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- IntervalTest - Class in org.apache.calcite.test
-
Test cases for intervals.
- IntervalTest(IntervalTest.Fixture) - Constructor for class org.apache.calcite.test.IntervalTest
- IntervalTest.Fixture - Interface in org.apache.calcite.test
-
Fluent interface for binding an expression to create a fixture that can be used to validate, check AST, or check type.
- IntervalTest.Fixture2 - Interface in org.apache.calcite.test
-
Fluent interface to validate an expression.
- intervalToMillis(String, SqlIntervalQualifier) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- intervalToMillis(SqlIntervalLiteral.IntervalValue) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Converts the interval value into a millisecond representation.
- intervalToMonths(String, SqlIntervalQualifier) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- intervalToMonths(SqlIntervalLiteral.IntervalValue) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Converts the interval value into a months representation.
- IntHolder(int) - Constructor for class org.apache.calcite.test.schemata.catchall.CatchallSchema.IntHolder
- IntList - Class in org.apache.calcite.util
-
Deprecated.
- IntList() - Constructor for class org.apache.calcite.util.IntList
-
Deprecated.
- into(C) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- into(C) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Copies the contents of this sequence into a collection.
- into(Enumerable<T>, C) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Default implementation of
ExtendedEnumerable.into(Collection)
. - INTO - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IntPair - Class in org.apache.calcite.util.mapping
-
An immutable pair of integers.
- IntPair(int, int) - Constructor for class org.apache.calcite.util.mapping.IntPair
- inTrait() - Method in interface org.apache.calcite.rel.convert.ConverterRule.Config
- inTraits - Variable in class org.apache.calcite.rel.convert.ConverterImpl
- inTree(String) - Static method in class org.apache.calcite.test.Matchers
-
Creates a Matcher that matches a
RelNode
if its string representation, after converting Windows-style line endings ("\r\n") to Unix-style line endings ("\n"), contains the givenvalue
as a substring. - intRelDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- IntString(int, String) - Constructor for class org.apache.calcite.util.Smalls.IntString
- IntSum() - Constructor for class org.apache.calcite.interpreter.AggregateNode.IntSum
- intValue(boolean) - Method in class org.apache.calcite.sql.SqlLiteral
-
Returns the integer value of this literal.
- intValue(RexNode) - Static method in class org.apache.calcite.rex.RexLiteral
-
Returns the value of a literal, cast, or unary minus, as an int; never null.
- INVALID_ARGUMENTS_NUMBER - Static variable in interface org.apache.calcite.sql.test.SqlOperatorFixture
- INVALID_ARGUMENTS_TYPE_VALIDATION_ERROR - Static variable in interface org.apache.calcite.sql.test.SqlOperatorFixture
- INVALID_CHAR_MESSAGE - Static variable in interface org.apache.calcite.sql.test.SqlOperatorFixture
- invalidArgCount(String, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidateMetadataQuery() - Method in class org.apache.calcite.plan.RelOptCluster
-
Should be called whenever the current
RelMetadataQuery
becomes invalid. - invalidBoolean(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidCharacterForCast(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidCompare(String, String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidCount() - Method in class org.apache.calcite.rel.RelValidityChecker
- invalidInputForExistsNode(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidInputForExtractValue(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidInputForExtractXml(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidInputForJsonDepth(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidInputForJsonInsert(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidInputForJsonKeys(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidInputForJsonLength(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidInputForJsonRemove(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidInputForJsonReplace(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidInputForJsonSet(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidInputForJsonStorageSize(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidInputForJsonType(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidInputForRegexpReplace(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidInputForXmlTransform(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidIntegerInputForRegexpFunctions(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidLiteral(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidOrderBy(int, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidOrderByPos() - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidPartitionKeys(int, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidPrecisionForDecimalType(int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidRegexInputForRegexpFunctions(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- InvalidRelException - Exception Class in org.apache.calcite.rel
-
Exception that indicates that a relational expression would be invalid with given parameters.
- InvalidRelException(String) - Constructor for exception class org.apache.calcite.rel.InvalidRelException
-
Creates an InvalidRelException.
- InvalidRelException(String, Throwable) - Constructor for exception class org.apache.calcite.rel.InvalidRelException
-
Creates an InvalidRelException with a cause.
- invalidReplacePatternForRegexpReplace(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidSampleSize() - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidScaleForDecimalType(int, int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- InvalidTableFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.InvalidTableFunction
- invalidTimeFrame(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidTypesForArithmetic(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidTypesForComparison(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- inventFieldName(Expression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Generates field name to store given expression.
- inverse() - Method in class org.apache.calcite.util.mapping.AbstractSourceMapping
- inverse() - Method in class org.apache.calcite.util.mapping.AbstractTargetMapping
- inverse() - Method in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
- inverse() - Method in class org.apache.calcite.util.mapping.Mappings.OverridingSourceMapping
- inverse() - Method in class org.apache.calcite.util.mapping.Mappings.OverridingTargetMapping
- inverse() - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- inverse() - Method in interface org.apache.calcite.util.mapping.Mappings.SourceMapping
- inverse() - Method in interface org.apache.calcite.util.mapping.Mappings.TargetMapping
- inverse() - Method in enum org.apache.calcite.util.mapping.MappingType
- inverse() - Method in class org.apache.calcite.util.Permutation
-
Returns the inverse permutation.
- INVERSE_FUNCTION - Enum constant in enum org.apache.calcite.util.mapping.MappingType
-
An inverse function has a source for every target, but a source might have 0, 1 or more targets.
- INVERSE_INJECTION - Enum constant in enum org.apache.calcite.util.mapping.MappingType
- INVERSE_PARTIAL_FUNCTION - Enum constant in enum org.apache.calcite.util.mapping.MappingType
- INVERSE_PARTIAL_INJECTION - Enum constant in enum org.apache.calcite.util.mapping.MappingType
- INVERSE_SURJECTION - Enum constant in enum org.apache.calcite.util.mapping.MappingType
-
An inverse surjection has a source for every target, and no source has more than one target.
- invert(Iterable<IntPair>) - Static method in class org.apache.calcite.util.mapping.Mappings
- invert(Iterator<IntPair>) - Static method in class org.apache.calcite.util.mapping.Mappings
- invert(RexBuilder, RexCall) - Static method in class org.apache.calcite.rex.RexUtil
- invert(Mapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Converts a mapping to its inverse.
- InvocationExpression - Class in org.apache.calcite.linq4j.tree
-
Represents an expression that applies a delegate or lambda expression to a list of argument expressions.
- InvocationExpression(ExpressionType, Class) - Constructor for class org.apache.calcite.linq4j.tree.InvocationExpression
- invoke(Object...) - Method in interface org.apache.calcite.util.ReflectUtil.MethodDispatcher
-
Invokes method on an object with a given set of arguments.
- invoke(Object, Method, Object[]) - Method in class org.apache.calcite.util.BarfingInvocationHandler
- invoke(Object, Method, Object[]) - Method in class org.apache.calcite.util.DelegatingInvocationHandler
- invoke(Expression, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an InvocationExpression that applies a delegate or lambda expression to a list of argument expressions.
- invoke(Expression, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an InvocationExpression that applies a delegate or lambda expression to a list of argument expressions, using varargs.
- Invoke - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An operation that invokes a delegate or lambda expression, such as sampleDelegate.Invoke().
- invokeVisitor(ReflectiveVisitor, Object, Class, String) - Static method in class org.apache.calcite.util.ReflectUtil
-
Implements the
Glossary.VISITOR_PATTERN
via reflection. - invokeVisitor(R, E, String) - Method in interface org.apache.calcite.util.ReflectiveVisitDispatcher
-
Implements the
Glossary.VISITOR_PATTERN
via reflection. - iOutputColumn - Variable in class org.apache.calcite.rel.metadata.RelColumnMapping
-
0-based ordinal of mapped output column.
- is(Type) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Returns whether a given type is primitive.
- IS_A_SET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IS_A_SET - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_DIFFERENT_FROM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The internal
$IS_DIFFERENT_FROM
operator is the same as the user-levelSqlStdOperatorTable.IS_DISTINCT_FROM
in all respects except that the test for equality on character datatypes treats trailing spaces as significant. - IS_DISTINCT_FROM - Enum constant in enum org.apache.calcite.sql.SqlKind
-
IS DISTINCT FROM
operator. - IS_DISTINCT_FROM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
IS DISTINCT FROM
operator. - IS_EMPTY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IS_EMPTY - Static variable in class org.apache.calcite.rel.core.Values
-
Deprecated.
- IS_EMPTY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_EMPTY_J - Static variable in class org.apache.calcite.rel.core.Values
- IS_FALSE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
IS FALSE
operator. - IS_FALSE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_INF - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IS_INF - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "IS_INF(value)" function.
- IS_JSON_ARRAY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IS_JSON_ARRAY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_JSON_OBJECT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IS_JSON_OBJECT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_JSON_SCALAR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IS_JSON_SCALAR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_JSON_VALUE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IS_JSON_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_MEASURE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IS_NAME - Static variable in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
- IS_NAN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IS_NAN - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "IS_NAN(value)" function.
- IS_NOT_A_SET - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_NOT_DISTINCT_FROM - Enum constant in enum org.apache.calcite.sql.SqlKind
-
IS NOT DISTINCT FROM
operator. - IS_NOT_DISTINCT_FROM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
IS NOT DISTINCT FROM
operator. - IS_NOT_EMPTY - Static variable in class org.apache.calcite.rel.core.Values
-
Deprecated.
- IS_NOT_EMPTY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_NOT_FALSE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
IS NOT FALSE
operator. - IS_NOT_FALSE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IS_NOT_FALSE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_NOT_GRAND_TOTAL - Static variable in class org.apache.calcite.rel.core.Aggregate
-
Deprecated.
- IS_NOT_JSON_ARRAY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_NOT_JSON_OBJECT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_NOT_JSON_SCALAR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_NOT_JSON_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_NOT_NULL - Enum constant in enum org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
Return true if result is not null, false if result is null.
- IS_NOT_NULL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
IS NOT NULL
operator. - IS_NOT_NULL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_NOT_TRUE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
IS NOT TRUE
operator. - IS_NOT_TRUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_NOT_UNKNOWN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_NULL - Enum constant in enum org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
Return false if result is not null, true if result is null.
- IS_NULL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
IS NULL
operator. - IS_NULL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_PHASE_TRANSITION - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IS_SIMPLE - Static variable in class org.apache.calcite.rel.core.Aggregate
-
Deprecated.
- IS_TRUE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
IS TRUE
operator. - IS_TRUE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- IS_TRUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_UNKNOWN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
IS UNKNOWN
operator. - IS_UNKNOWN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- isA(Collection<SqlKind>) - Method in class org.apache.calcite.rex.RexNode
- isA(Set<SqlKind>) - Method in class org.apache.calcite.sql.SqlNode
-
Returns whether this node is a member of an aggregate category.
- isA(SqlKind) - Method in class org.apache.calcite.rex.RexNode
- isA(MappingType) - Method in enum org.apache.calcite.util.mapping.MappingType
-
Returns whether this mapping type is (possibly a weaker form of) a given mapping type.
- isAddJsonTypeOperatorEnabled() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Whether add
SqlStdOperatorTable.JSON_TYPE_OPERATOR
for between json functions. - isAggregate(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Deprecated.
- isAggregate(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Deprecated.
- isAggregate(SqlSelect) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns whether a SELECT statement is an aggregation.
- isAggregate(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- isAggregate(Matcher<Boolean>) - Method in class org.apache.calcite.test.SqlValidatorFixture
- isAggregator() - Method in class org.apache.calcite.sql.SqlAggFunction
- isAggregator() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether this operator is an aggregate function.
- isAll() - Method in class org.apache.calcite.rel.mutable.MutableSetOp
- isAll() - Method in class org.apache.calcite.sql.SqlSetOperator
- isAll() - Method in class org.apache.calcite.util.Sarg
-
Returns whether this Sarg includes all values (including or not including null).
- isAllowAlwaysTrueCondition() - Method in interface org.apache.calcite.rel.rules.JoinAssociateRule.Config
-
Whether to emit the new join tree if the new top or bottom join has a condition which is always
TRUE
. - isAllowAlwaysTrueCondition() - Method in interface org.apache.calcite.rel.rules.JoinCommuteRule.Config
-
Whether to emit the new join tree if the join condition is
TRUE
(that is, cartesian joins); default true. - isAllowFunctions() - Method in interface org.apache.calcite.rel.rules.AggregateJoinTransposeRule.Config
-
Whether to push down aggregate functions, default false.
- isAllowPartial() - Method in class org.apache.calcite.sql.SqlWindow
-
Returns whether partial windows are allowed.
- isAllRows() - Method in class org.apache.calcite.rel.core.Match
- isAlmost(double) - Static method in class org.apache.calcite.test.Matchers
-
Creates a matcher that matches when the examined object is within
Matchers.EPSILON
of the specifiedoperand
. - isAlwaysFalse() - Method in class org.apache.calcite.rex.RexCall
- isAlwaysFalse() - Method in class org.apache.calcite.rex.RexLiteral
- isAlwaysFalse() - Method in class org.apache.calcite.rex.RexNode
-
Returns whether this expression always returns false.
- isAlwaysMeasure(Lattice.Column) - Method in class org.apache.calcite.materialize.Lattice
-
Returns whether every use of a column is as an argument to a measure.
- isAlwaysNonEmpty() - Method in class org.apache.calcite.rel.core.Window.Group
-
Returns if the window is guaranteed to have rows.
- isAlwaysNonEmpty() - Method in class org.apache.calcite.sql.SqlWindow
-
Returns if the window is guaranteed to have rows.
- isAlwaysNonEmpty(RexWindowBound, RexWindowBound) - Static method in class org.apache.calcite.sql.SqlWindow
- isAlwaysTrue() - Method in class org.apache.calcite.rex.RexCall
- isAlwaysTrue() - Method in class org.apache.calcite.rex.RexLiteral
- isAlwaysTrue() - Method in class org.apache.calcite.rex.RexNode
-
Returns whether this expression always returns true.
- isAlwaysUseParentheses() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isAlwaysUseParentheses() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- isAlwaysUseParentheses() - Method in interface org.apache.calcite.sql.SqlWriter
-
Returns whether to enclose all expressions in parentheses, even if the operator has high enough precedence that the parentheses are not required.
- isAnon() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- isAnon() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Returns whether to remove trivial aliases such as "EXPR$0" when converting the current relational expression into a SELECT.
- isApplyAllowed() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isApplyAllowed() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether
CROSS APPLY
andOUTER APPLY
operators are allowed in the parser. - isApplyAllowed() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isApplyAllowed() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isApproximate() - Method in class org.apache.calcite.rel.core.AggregateCall
-
Returns whether this AggregateCall is approximate, as in
APPROX_COUNT_DISTINCT(empno)
. - isApproximateNumeric(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is numeric with approximate precision.
- isArgumentConstant(int) - Method in interface org.apache.calcite.schema.FunctionContext
-
Returns whether the value of an argument is constant.
- isArray(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- isArray(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is ARRAY.
- isASet(Collection) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the IS A SET function.
- isAssignableFrom(Type, Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- isAtomic(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is atomic (datetime, numeric, string or BOOLEAN).
- isAtomic(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
- isAutoincrement(SqlTypeName) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- isAutoincrement(SqlTypeName) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns whether the type can be auto increment.
- isAutoincrement(SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- isBangEqualAllowed() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isBangEqualAllowed() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether the bang-equal token != is allowed as an alternative to <> in the parser.
- isBangEqualAllowed() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isBangEqualAllowed() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isBefore() - Method in class org.apache.calcite.plan.RelOptListener.RuleAttemptedEvent
- isBefore(SchemaVersion) - Method in class org.apache.calcite.schema.impl.LongSchemaVersion
- isBefore(SchemaVersion) - Method in interface org.apache.calcite.schema.SchemaVersion
-
Returns if this Version happens before the other Version.
- isBernoulli() - Method in class org.apache.calcite.plan.RelOptSamplingParameters
-
Indicates whether Bernoulli or system sampling should be performed.
- isBernoulli() - Method in class org.apache.calcite.sql.SqlSampleSpec.SqlTableSampleSpec
-
Indicates Bernoulli vs.
- isBijection() - Method in enum org.apache.calcite.util.mapping.MappingType
-
A mapping is a bijection if it is a surjection and it is an injection.
- isBinary(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is BINARY.
- isBoolean(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is BOOLEAN.
- isBoundedVariableWidth(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is variable width with bounded precision.
- isBox(Type) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Returns whether a given type is a box type (e.g.
- isBoxed() - Method in class org.apache.calcite.rel.core.Project
-
Deprecated.
- isCacheEnabled() - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- isCacheEnabled() - Method in class org.apache.calcite.jdbc.CalciteSchema
- isCacheEnabled() - Method in interface org.apache.calcite.schema.SchemaPlus
- isCaching - Variable in class org.apache.calcite.test.RelMetadataFixture.MetadataConfig
- isCaching() - Method in class org.apache.calcite.test.RelMetadataFixture.MetadataConfig
- isCalendarCompatible(DateCalendarEnum) - Method in enum org.apache.calcite.util.format.postgresql.DateCalendarEnum
-
Tests if the provided calendar is compatible with this calendar.
- isCallTo(RexNode, SqlOperator) - Static method in class org.apache.calcite.rex.RexUtil
- isCallTo(SqlNode, SqlOperator) - Static method in class org.apache.calcite.sql.SqlUtil
- isCancelRequested() - Method in class org.apache.calcite.util.CancelFlag
-
Returns whether a cancellation has been requested.
- isCaseClausesOnNewLines() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isCasePredicate(RexCall, int) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a given operand of a CASE expression is a predicate.
- isCaseSensitive() - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- isCaseSensitive() - Method in class org.apache.calcite.sql.fun.SqlLikeOperator
-
Returns whether this operator matches the case of its operands.
- isCaseSensitive() - Method in class org.apache.calcite.sql.fun.SqlPosixRegexOperator
-
Returns whether this operator matches the case of its operands.
- isCaseSensitive() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether matching of identifiers is case-sensitive.
- isCaseSensitive() - Method in interface org.apache.calcite.sql.validate.SqlNameMatcher
-
Returns whether name matching is case-sensitive.
- isCaseSensitive() - Method in interface org.apache.calcite.sql.validate.SqlValidatorCatalogReader
- isCaseSensitive() - Method in class org.apache.calcite.test.catalog.MockCatalogReader
- isCaseSensitive(SqlTypeName) - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- isCaseSensitive(SqlTypeName) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns whether the type is case sensitive.
- isCaseSensitive(SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- isCharacter(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is CHARACTER.
- isCharset(String) - Static method in class org.apache.calcite.test.Matchers
-
Creates a matcher that matches if the examined value has a given name.
- isCharTypeComparable(List<RelDataType>) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Checks whether two types or more are char comparable.
- isCharTypeComparable(SqlCallBinding, List<SqlNode>, boolean) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether the operands to a call are char type-comparable.
- isChildNullable(int) - Method in class org.apache.calcite.sql.validate.ListScope
-
Whether the ith child namespace produces nullable result.
- isClauseStartsLine() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isClauseStartsLine() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- isClauseStartsLine() - Method in interface org.apache.calcite.sql.SqlWriter
-
Returns whether this writer should start each clause (e.g.
- isCoerceNames() - Method in interface org.apache.calcite.rel.rules.CoerceInputsRule.Config
-
Whether to coerce names.
- isCollationTrivial() - Method in class org.apache.calcite.rel.RelRoot
- isCollection(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is ARRAY or MULTISET.
- isComparable(RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether two types are comparable.
- isCompatible(Set<ChronoUnitEnum>) - Method in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
-
Checks if the current item can be added to
units
without causing any conflicts. - isComplementedPoints() - Method in class org.apache.calcite.util.Sarg
-
Returns whether this Sarg, when negated, is a collection of 1 or more points (and perhaps an
IS NULL
ifnullAs == RexUnknownAs.TRUE
). - isComplex() - Method in enum org.apache.calcite.adapter.druid.DruidType
-
Returns whether this type should be used inside a
ComplexMetric
. - isComplexMetric(String) - Method in class org.apache.calcite.adapter.druid.DruidTable
-
Returns whether the given
alias
is a reference to a registeredComplexMetric
. - isComponentQuoted(int) - Method in class org.apache.calcite.sql.SqlIdentifier
-
Returns whether the
i
th component of a compound identifier is quoted. - isConstant(Iterable<? extends Expression>) - Method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Verifies if all the expressions in given list are effectively constant.
- isConstant(Expression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Verifies if the expression is effectively constant.
- isConstant(Expression) - Method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Verifies if the expression is effectively constant.
- isConstant(RexNode) - Method in class org.apache.calcite.rex.RexProgram
-
Returns whether an expression is constant.
- isConstant(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether node is made up of constants.
- isConstantNull(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Returns whether an expression always evaluates to null.
- isConstructorDeterministic(NewExpression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Checks if new instance creation can be reused.
- isCopyFilter() - Method in interface org.apache.calcite.rel.rules.FilterProjectTransposeRule.Config
-
Whether to create a
Filter
of the same convention as the matched Filter. - isCopyProject() - Method in interface org.apache.calcite.rel.rules.FilterProjectTransposeRule.Config
-
Whether to create a
Project
of the same convention as the matched Project. - isCountStar() - Method in class org.apache.calcite.sql.SqlCall
-
Returns whether it is the function
COUNT(*)
. - isCreateValuesRel() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns the
createValuesRel
option. - isCurrentRow() - Method in class org.apache.calcite.rex.RexWindowBound
-
Returns if the bound is CURRENT ROW.
- isCurrentRow(SqlNode) - Static method in class org.apache.calcite.sql.SqlWindow
-
Returns whether an expression represents the "CURRENT ROW" bound.
- isDate() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Whether this is a DATE interval (including all week intervals).
- isDate(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is DATE.
- isDatetime(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is DATE, TIME, or TIMESTAMP.
- isDdl() - Static method in class org.apache.calcite.sql.parser.SqlParserTest
-
Returns a
Matcher
that succeeds if the givenSqlNode
is a DDL statement. - isDecimal(String) - Static method in class org.apache.calcite.sql.test.ResultCheckers
- isDecimal(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is DECIMAL.
- isDecorrelationEnabled() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns the
decorrelationEnabled
option. - isDecreasing() - Method in enum org.apache.calcite.sql.validate.SqlMonotonicity
-
Whether values of this monotonicity are decreasing.
- isDefault() - Method in interface org.apache.calcite.plan.RelTrait
-
Returns whether this trait is the default trait value.
- isDefault() - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns whether all the traits are default trait value.
- isDefaultOrder(boolean, boolean) - Method in enum org.apache.calcite.config.NullCollation
-
Returns whether a given combination of null direction and sort order is the default order of nulls returned in the ORDER BY clause.
- isDefaultSansConvention() - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns whether all the traits except
Convention
are default trait value. - isDefinitelyDistinctAndNonNull(List<? extends E>) - Static method in class org.apache.calcite.util.Util
-
Returns whether the elements of
list
are definitely distinct and not null, working quickly and sometimes giving false negatives for large lists. - isDelete() - Method in class org.apache.calcite.rel.core.TableModify
- isDelivered() - Method in class org.apache.calcite.plan.volcano.RelSubset
- isDerived() - Method in class org.apache.calcite.rel.metadata.RelColumnOrigin
-
Consider the query
select a+b as c, d as e from t
. - isDescending() - Method in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Returns whether this is
RelFieldCollation.Direction.DESCENDING
orRelFieldCollation.Direction.STRICTLY_DESCENDING
. - isDeterministic() - Method in class org.apache.calcite.sql.fun.SqlRandIntegerFunction
- isDeterministic() - Method in class org.apache.calcite.sql.fun.SqlSequenceValueOperator
- isDeterministic() - Method in class org.apache.calcite.sql.SqlBasicFunction
- isDeterministic() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether a call to this operator is guaranteed to always return the same result given the same operands; true is assumed by default.
- isDeterministic() - Method in class org.apache.calcite.test.MockSqlOperatorTable.MyAvgAggFunction
- isDeterministic(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a given expression is deterministic.
- isDistinct() - Method in class org.apache.calcite.rel.core.AggregateCall
-
Returns whether this AggregateCall is distinct, as in
COUNT(DISTINCT empno)
. - isDistinct() - Method in class org.apache.calcite.rex.RexOver
- isDistinct() - Method in class org.apache.calcite.sql.SqlSelect
- isDistinct() - Method in class org.apache.calcite.sql.SqlSetOperator
- isDistinct(List<E>) - Static method in class org.apache.calcite.util.Util
-
Returns whether the elements of
list
are distinct. - isDistinctFrom(RexBuilder, RexNode, RexNode, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a translation of the
IS DISTINCT FROM
(orIS NOT DISTINCT FROM
) sql operator. - isDistinctFrom(RexNode, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an expression equivalent to
o0 IS DISTINCT FROM o1
. - isDml - Variable in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- isDml() - Method in class org.apache.calcite.prepare.Prepare.PreparedExplain
- isDml() - Method in interface org.apache.calcite.prepare.Prepare.PreparedResult
-
Returns whether this result is for a DML statement, in which case the result set is one row with one column containing the number of rows affected.
- isDml() - Method in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- isDynamicFunction() - Method in class org.apache.calcite.sql.fun.SqlAbstractTimeFunction
- isDynamicFunction() - Method in class org.apache.calcite.sql.fun.SqlBaseContextVariable
- isDynamicFunction() - Method in class org.apache.calcite.sql.fun.SqlCurrentDateFunction
- isDynamicFunction() - Method in class org.apache.calcite.sql.fun.SqlRandIntegerFunction
- isDynamicFunction() - Method in class org.apache.calcite.sql.SqlBasicFunction
- isDynamicFunction() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether it is unsafe to cache query plans referencing this operator; false is assumed by default.
- isDynamicStar() - Method in interface org.apache.calcite.rel.type.RelDataTypeField
-
Returns true if this is a dynamic star field.
- isDynamicStar() - Method in class org.apache.calcite.rel.type.RelDataTypeFieldImpl
- isDynamicStarColName(String) - Static method in class org.apache.calcite.rel.type.DynamicRecordType
-
Returns true if the column name starts with DYNAMIC_STAR_PREFIX.
- isDynamicStruct() - Method in class org.apache.calcite.rel.type.DynamicRecordType
- isDynamicStruct() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Returns whether this type has dynamic structure (for "schema-on-read" table).
- isDynamicStruct() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- isDynamicStruct() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- isEffectivelyNotNull(RexNode) - Method in class org.apache.calcite.plan.RelOptPredicateList
-
Returns whether an expression is effectively NOT NULL due to an
e IS NOT NULL
condition in this predicate list. - isEmpty() - Method in class org.apache.calcite.runtime.ConsList
- isEmpty() - Method in class org.apache.calcite.sql.SqlNodeList
- isEmpty() - Method in class org.apache.calcite.util.CompositeMap
- isEmpty() - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
- isEmpty() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns true if this
ImmutableBitSet
contains no bits that are set totrue
. - isEmpty() - Method in class org.apache.calcite.util.ImmutableIntList
- isEmpty(RelOptPredicateList) - Static method in class org.apache.calcite.plan.RelOptPredicateList
-
Returns true if given predicate list is empty.
- isEmpty(Values) - Static method in class org.apache.calcite.rel.core.Values
-
Predicate, to be used when defining an operand of a
RelOptRule
, that returns true if a Values contains zero tuples. - isEmptyList(SqlNode) - Static method in class org.apache.calcite.sql.SqlNodeList
- isEnabled(RelTraitDef<T>) - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns whether a given kind of trait is enabled.
- isEnforcer() - Method in class org.apache.calcite.plan.volcano.AbstractConverter
- isEnforcer() - Method in class org.apache.calcite.rel.AbstractRelNode
- isEnforcer() - Method in class org.apache.calcite.rel.core.Sort
- isEnforcer() - Method in interface org.apache.calcite.rel.RelNode
-
Indicates whether it is an enforcer operator, e.g.
- isEqui() - Method in class org.apache.calcite.rel.core.JoinInfo
-
Returns whether this is an equi-join.
- isEqui(RelNode, RelNode, RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- isEqWithEpsilon(RelOptCost) - Method in interface org.apache.calcite.plan.RelOptCost
-
Compares this to another cost, allowing for slight roundoff errors.
- isEqWithEpsilon(RelOptCost) - Method in class org.apache.calcite.plan.RelOptCostImpl
- isEvolveLattice() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns whether the lattice suggester should try to widen a lattice when a new query arrives that doesn't quite fit, as opposed to creating a new lattice.
- isExact() - Method in class org.apache.calcite.sql.SqlNumericLiteral
- isExactDateTime(LocalDateTime) - Static method in class org.apache.calcite.sql.test.ResultCheckers
- isExactly(double) - Static method in class org.apache.calcite.sql.test.ResultCheckers
- isExactly(String) - Static method in class org.apache.calcite.sql.test.ResultCheckers
- isExactNumeric(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is numeric with exact precision.
- isExactTime(LocalTime) - Static method in class org.apache.calcite.sql.test.ResultCheckers
- isExcludeCurrentRow(SqlLiteral) - Static method in class org.apache.calcite.sql.SqlWindow
- isExcludeGroup(SqlLiteral) - Static method in class org.apache.calcite.sql.SqlWindow
- isExcludeNoOthers(SqlLiteral) - Static method in class org.apache.calcite.sql.SqlWindow
- isExcludeTies(SqlLiteral) - Static method in class org.apache.calcite.sql.SqlWindow
- isExpand() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns the
expand
option. - isExpanded() - Method in class org.apache.calcite.sql.SqlCall
-
Whether this call was created by expanding a parentheses-free call to what was syntactically an identifier.
- isExplain() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns the
explain
option. - isFalse(Boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
NULL → FALSE, FALSE → TRUE, TRUE → FALSE.
- isFalse(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Returns whether the expression evaluates to false.
- isFalse(Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Returns whether the expression evaluates to false.
- IsFalse - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A false condition value.
- isFixedNumeric() - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Returns whether this Primitive is a fixed-point numeric type.
- isFixedParameters() - Method in class org.apache.calcite.sql.type.OperandMetadataImpl
- isFixedParameters() - Method in interface org.apache.calcite.sql.type.SqlOperandTypeChecker
-
Returns whether the list of parameters is fixed-length.
- isFlat(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is flat.
- isFlat(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns false if the expression can be optimized by flattening calls to an associative operator such as AND and OR.
- isFlattened() - Method in class org.apache.calcite.rel.core.TableModify
- isFollowing() - Method in class org.apache.calcite.rex.RexWindowBound
-
Returns if the bound is FOLLOWING.
- isForeignKey(RelOptTable, List<Integer>, RelOptTable, List<Integer>) - Method in interface org.apache.calcite.materialize.SqlStatisticProvider
-
Returns whether a join is a foreign key; that is, whether every row in the referencing table is matched by at least one row in the referenced table.
- isForeignKey(RelOptTable, List<Integer>, RelOptTable, List<Integer>) - Method in class org.apache.calcite.statistic.CachingSqlStatisticProvider
- isForeignKey(RelOptTable, List<Integer>, RelOptTable, List<Integer>) - Method in enum org.apache.calcite.statistic.MapSqlStatisticProvider
- isForeignKey(RelOptTable, List<Integer>, RelOptTable, List<Integer>) - Method in class org.apache.calcite.statistic.QuerySqlStatisticProvider
- isFromRequired() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isFromRequired() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether
FROM
clause is required in aSELECT
statement. - isFromRequired() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isFromRequired() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isFullOuterJoin() - Method in class org.apache.calcite.rel.rules.MultiJoin
-
Returns true if the MultiJoin corresponds to a full outer join.
- isFunction() - Method in enum org.apache.calcite.sql.SqlFunctionCategory
- isFunction() - Method in enum org.apache.calcite.util.mapping.MappingType
-
A mapping is a total function if every source has precisely one target.
- isGeneratedAlias(String) - Static method in class org.apache.calcite.sql.SqlUtil
-
Whether the alias is generated by calcite.
- isGeneratedAlways(RelOptTable, int) - Method in interface org.apache.calcite.sql2rel.InitializerExpressionFactory
-
Deprecated.Use
c.generationStrategy(t, i) == VIRTUAL || c.generationStrategy(t, i) == STORED
- isGeneratedAlways(RelOptTable, int) - Method in class org.apache.calcite.sql2rel.NullInitializerExpressionFactory
- isGroup() - Method in class org.apache.calcite.sql.SqlGroupedWindowFunction
- isGroup() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether this is a group function.
- isGroupAuxiliary() - Method in class org.apache.calcite.sql.SqlGroupedWindowFunction
- isGroupAuxiliary() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether this is an group auxiliary function.
- isGroupByAlias() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isGroupByAlias() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow aliases from the
SELECT
clause to be used as column names in theGROUP BY
clause. - isGroupByAlias() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isGroupByAlias() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isGroupByOrdinal() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isGroupByOrdinal() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether
GROUP BY 2
is interpreted to mean 'group by the 2nd column in the select list'. - isGroupByOrdinal() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isGroupByOrdinal() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isGroupingExpr(SqlNode) - Method in class org.apache.calcite.sql.validate.AggregatingSelectScope.Resolved
-
Returns whether a given expression is equal to one of the grouping expressions.
- isGuaranteed() - Method in class org.apache.calcite.rel.convert.ConverterRule
-
Returns true if this rule can convert any relational expression of the input convention.
- isHavingAlias() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isHavingAlias() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow aliases from the
SELECT
clause to be used as column names in theHAVING
clause. - isHavingAlias() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isHavingAlias() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isHexDigit(char) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Returns true if the specified character is a base-16 digit.
- isHomogeneous(boolean) - Method in class org.apache.calcite.rel.core.SetOp
-
Returns whether all the inputs of this set operator have the same row type as its output row.
- isIdentity() - Method in interface org.apache.calcite.util.mapping.Mapping
-
Returns whether this mapping is the identity.
- isIdentity() - Method in class org.apache.calcite.util.mapping.Mappings.AbstractMapping
- isIdentity() - Method in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
- isIdentity() - Method in class org.apache.calcite.util.mapping.Mappings.OverridingSourceMapping
- isIdentity() - Method in class org.apache.calcite.util.mapping.Mappings.OverridingTargetMapping
- isIdentity() - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- isIdentity() - Method in interface org.apache.calcite.util.mapping.Mappings.SourceMapping
- isIdentity() - Method in class org.apache.calcite.util.Permutation
-
Returns whether this is the identity permutation.
- isIdentity(List<? extends RexNode>, RelDataType) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a list of expressions projects the incoming fields.
- isIdentity(List<Integer>, int) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Returns whether a list of integers is the identity mapping [0, ..., n - 1].
- isIdentity(Mappings.TargetMapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Returns whether a mapping is the identity.
- isIncludeOuter() - Method in interface org.apache.calcite.rel.rules.JoinProjectTransposeRule.Config
-
Whether to include outer joins, default false.
- isInf(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
IS_INF
operator applied to double values. - isInf(float) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
IS_INF
operator applied to float values. - isInf(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
IS_INF
operator applied to BigDecimal values. - isInfinite() - Method in interface org.apache.calcite.plan.RelOptCost
-
Returns whether this cost represents an expression that hasn't actually been implemented (e.g.
- isInfinite() - Method in class org.apache.calcite.plan.RelOptCostImpl
- isInjection() - Method in enum org.apache.calcite.util.mapping.MappingType
-
A mapping is an injection if it is a function and no target has more than one source.
- isInsert() - Method in class org.apache.calcite.rel.core.TableModify
- isInsertSubsetColumnsAllowed() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isInsertSubsetColumnsAllowed() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow
INSERT
(orUPSERT
) with no column list but fewer values than the target table. - isInsertSubsetColumnsAllowed() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isInsertSubsetColumnsAllowed() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isInteger() - Method in class org.apache.calcite.sql.SqlNumericLiteral
- isInterval(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is some kind of INTERVAL.
- isIntType(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is one of the integer types.
- isJavaPrimitive(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Deprecated.
- isJavaType(RelDataType) - Static method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- isJson() - Method in class org.apache.calcite.sql.SqlExplain
-
Returns whether result is to be in JSON format.
- isJsonArray(String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- isJsonObject(String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- isJsonScalar(String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- isJsonValue(String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- isKey(RelOptTable, List<Integer>) - Method in interface org.apache.calcite.materialize.SqlStatisticProvider
-
Returns whether a collection of columns is a unique (or primary) key.
- isKey(RelOptTable, List<Integer>) - Method in class org.apache.calcite.statistic.CachingSqlStatisticProvider
- isKey(RelOptTable, List<Integer>) - Method in enum org.apache.calcite.statistic.MapSqlStatisticProvider
- isKey(RelOptTable, List<Integer>) - Method in class org.apache.calcite.statistic.QuerySqlStatisticProvider
- isKey(ImmutableBitSet) - Method in class org.apache.calcite.plan.RelOptAbstractTable
- isKey(ImmutableBitSet) - Method in interface org.apache.calcite.plan.RelOptTable
-
Returns whether the given columns are a key or a superset of a unique key of this table.
- isKey(ImmutableBitSet) - Method in class org.apache.calcite.prepare.RelOptTableImpl
- isKey(ImmutableBitSet) - Method in interface org.apache.calcite.schema.Statistic
-
Returns whether the given set of columns is a unique key, or a superset of a unique key, of the table.
- isKey(ImmutableBitSet) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- isKeywordPresent(SqlSelectKeyword) - Method in class org.apache.calcite.sql.SqlSelect
- isKeywordsLowercase() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isKeywordsLowerCase() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- isKeywordsLowerCase() - Method in interface org.apache.calcite.sql.SqlWriter
-
Returns whether to output all keywords (e.g.
- isKnownNotNull(Expression) - Method in class org.apache.calcite.linq4j.tree.OptimizeShuttle
-
Returns whether an expression always returns a non-null result.
- isLast() - Method in interface org.apache.calcite.util.Puffin.Line
-
Returns whether the current line is the last line in its source.
- isLe(RelOptCost) - Method in interface org.apache.calcite.plan.RelOptCost
-
Compares this to another cost.
- isLe(RelOptCost) - Method in class org.apache.calcite.plan.RelOptCostImpl
- isLeftFactorInRemovableSelfJoin(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns whether the factor is the left factor in a self-join.
- isLiberal() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isLiberal() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether this dialect supports features from a wide variety of dialects.
- isLiberal() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isLiberal() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isLimit(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Whether this node contains a limit specification.
- isLimitStartCountAllowed() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isLimitStartCountAllowed() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow the SQL syntax "
LIMIT start, count
". - isLimitStartCountAllowed() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isLimitStartCountAllowed() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isLinux(String) - Static method in class org.apache.calcite.test.Matchers
-
Creates a Matcher that matches when the examined string is equal to the specified
value
when all Windows-style line endings ("\r\n") have been converted to Unix-style line endings ("\n"). - isListOf(E...) - Static method in class org.apache.calcite.test.Matchers
-
Returns a matcher that tests whether an object is a list with the given contents.
- isLiteral(RexNode, boolean) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a node represents a literal.
- isLiteral(SqlNode) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns whether a node is a literal.
- isLiteral(SqlNode, boolean) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns whether a node is a literal.
- isLiteralChain(SqlNode) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns whether a node is a literal chain which is used to represent a continued string literal.
- isLob(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is a LOB of some kind.
- isLogical(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Decide whether a rule is logical or not.
- isLosslessCast(RelDataType, RelDataType) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether the conversion from
source
totarget
type is a 'loss-less' cast, that is, a cast from which the original value of the field can be certainly recovered. - isLosslessCast(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether the input is a 'loss-less' cast, that is, a cast from which the original value of the field can be certainly recovered.
- isLt(RelOptCost) - Method in interface org.apache.calcite.plan.RelOptCost
-
Compares this to another cost.
- isLt(RelOptCost) - Method in class org.apache.calcite.plan.RelOptCostImpl
- isMandatorySource() - Method in enum org.apache.calcite.util.mapping.MappingType
-
Constraint that every target has at least one source.
- isMandatoryTarget() - Method in enum org.apache.calcite.util.mapping.MappingType
-
Constraint that every source has at least one target.
- isMap(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is MAP.
- isMapping() - Method in class org.apache.calcite.rel.core.Project
-
Checks whether this is a functional mapping.
- isMaterialization() - Method in class org.apache.calcite.jdbc.CalciteSchema.FunctionEntry
-
Whether this represents a materialized view.
- isMaterialization() - Method in class org.apache.calcite.jdbc.CalciteSchema.FunctionEntryImpl
- isMeasure() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Returns whether this type is a measure.
- isMeasure(int) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Measure
-
Returns whether a given column is a measure.
- isMeasure(RelNode, int) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.Measure.isMeasure(int)
statistic. - isMeasure(RelNode, RelMetadataQuery, int) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Measure.Handler
- isMeasure(RelNode, RelMetadataQuery, int) - Method in class org.apache.calcite.rel.metadata.RelMdMeasure
-
Catch-all implementation for
BuiltInMetadata.Measure.isMeasure(int)
, invoked using reflection. - isMeasure(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- isMeasure(SqlNode) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Returns whether a select item is a measure.
- isMeasureRef(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Returns whether an expression is a reference to a measure column.
- isMerge() - Method in class org.apache.calcite.rel.core.TableModify
- isMergeJoinSupported(JoinType) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns if certain join type is supported by Enumerable Merge Join implementation.
- isMergeJoinSupported(JoinRelType) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableMergeJoin
- isMethodDeterministic(Method) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Checks if given method is deterministic (i.e.
- isMetric(String) - Method in class org.apache.calcite.adapter.druid.DruidTable
- isMin() - Method in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
-
Deprecated.
- isMinusAllowed() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isMinusAllowed() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether
MINUS
is allowed as an alternative toEXCEPT
in the parser. - isMinusAllowed() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isMinusAllowed() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isMultiset(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is MULTISET.
- isMultisetCast(RexCall) - Static method in class org.apache.calcite.rex.RexMultisetUtil
-
Returns true if
call
is a call toCAST
and the to/from cast types are of multiset types. - isMutable() - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- isMutable() - Method in class org.apache.calcite.schema.impl.AbstractSchema
- isMutable() - Method in class org.apache.calcite.schema.impl.DelegatingSchema
- isMutable() - Method in interface org.apache.calcite.schema.Schema
-
Returns whether the user is allowed to create new tables, functions and sub-schemas in this schema, in addition to those returned automatically by methods such as
Schema.getTable(String)
. - isMutable() - Method in interface org.apache.calcite.schema.SchemaPlus
- isName(String, boolean) - Method in class org.apache.calcite.sql.SqlOperator
- isNameTrivial() - Method in class org.apache.calcite.rel.RelRoot
- isNaN(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
IS_NAN
operator applied to double values. - isNaN(float) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
IS_NAN
operator applied to float values. - isNaN(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
IS_NAN
operator applied to BigDecimal values. - isNatural() - Method in class org.apache.calcite.sql.SqlJoin
- isNaturalNode() - Method in class org.apache.calcite.sql.SqlJoin
- isNegated() - Method in class org.apache.calcite.sql.fun.SqlBetweenOperator
-
Returns whether this is 'NOT' variant of an operator.
- isNegated() - Method in class org.apache.calcite.sql.fun.SqlLikeOperator
-
Returns whether this is the 'NOT LIKE' operator.
- isNegated() - Method in class org.apache.calcite.sql.fun.SqlPosixRegexOperator
-
Returns whether this is 'NOT' variant of an operator.
- isNestedAggregateWindow(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- isNone() - Method in class org.apache.calcite.util.Sarg
-
Returns whether this Sarg includes no values (including or not including null).
- isNormalized(Litmus, RexBuilder) - Method in class org.apache.calcite.rex.RexProgram
-
Returns whether this program is in canonical form.
- isNotDistinctFrom(RexNode, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an expression equivalent to "
o0 IS NOT DISTINCT FROM o1
". - isNotEmpty(Values) - Static method in class org.apache.calcite.rel.core.Values
-
Predicate, to be used when defining an operand of a
RelOptRule
, that returns true if a Values contains one or more tuples. - isNotFalse(Boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
NULL → TRUE, FALSE → FALSE, TRUE → TRUE.
- isNotGrandTotal(Aggregate) - Static method in class org.apache.calcite.rel.core.Aggregate
- isNotIn() - Method in class org.apache.calcite.sql.fun.SqlInOperator
-
Deprecated.
- isNotNull(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
IS NOT NULL
. - isNotTrue(Boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
NULL → TRUE, FALSE → TRUE, TRUE → FALSE.
- isNotTrue(RexNode) - Method in class org.apache.calcite.plan.Strong
-
Returns whether the analyzed expression will definitely not return true (equivalently, will definitely return null or false).
- isNotTrue(RexNode, ImmutableBitSet) - Static method in class org.apache.calcite.plan.Strong
-
Returns whether the analyzed expression will definitely not return true (equivalently, will definitely return null or false) if all of a given set of input columns are null.
- isNull() - Method in class org.apache.calcite.rex.RexLiteral
-
Returns whether this literal's value is null.
- isNull(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is the NULL type.
- isNull(RexFieldAccess) - Method in class org.apache.calcite.plan.Strong
-
Returns whether a given field is definitely null.
- isNull(RexInputRef) - Method in class org.apache.calcite.plan.Strong
-
Returns whether a given input is definitely null.
- isNull(RexNode) - Method in class org.apache.calcite.plan.Strong
-
Returns whether an expression is definitely null.
- isNull(RexNode) - Method in class org.apache.calcite.rex.RexProgram
-
Returns whether an expression always evaluates to null.
- isNull(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a node represents the NULL value or a series of nested
CAST(NULL AS type)
calls. - isNull(RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- isNull(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates ab
IS NULL
. - isNull(RexNode, ImmutableBitSet) - Static method in class org.apache.calcite.plan.Strong
-
Returns whether the analyzed expression will definitely return null if all of a given set of input columns are null.
- isNull(SqlNode) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns whether a node represents the NULL value or a series of nested
CAST(NULL AS type)
calls. - ISNULL_FUNCTION - Static variable in class org.apache.calcite.sql.dialect.MysqlSqlDialect
-
MySQL specific function.
- isNullabilityCast(RelDataTypeFactory, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether an expression is a cast just for the purposes of nullability, not changing any other aspect of the type.
- isNullable - Variable in class org.apache.calcite.sql.type.AbstractSqlType
- isNullable() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Queries whether this type allows null values.
- isNullable() - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- isNullable() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- isNullable() - Method in class org.apache.calcite.rel.type.RelRecordType
- isNullable() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- isNullable() - Method in class org.apache.calcite.sql.type.AbstractSqlType
- isNullable(int) - Method in class org.apache.calcite.sql.validate.AggregatingSelectScope.Resolved
-
Returns whether a field should be nullable due to grouping sets.
- isNullable(RexNode) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Returns whether an expression is nullable.
- isNullGenerating(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns whether the factor corresponds to a null-generating factor in a left or right outer join.
- isNullLiteral(RexNode) - Static method in class org.apache.calcite.rex.RexLiteral
- isNullLiteral(RexNode, boolean) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a node represents the NULL value.
- isNullLiteral(SqlNode, boolean) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns whether a node represents the NULL value.
- isNullOrEmpty(String) - Static method in class org.apache.calcite.util.Util
-
Returns whether s == null or if s.length() == 0.
- isNullValue() - Static method in class org.apache.calcite.sql.test.ResultCheckers
- isNumeric() - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Returns whether this Primitive is a numeric type.
- isNumeric() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.CompiledPattern
-
Does this pattern match a sequence of digits.
- isNumeric() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.NumberCompiledPattern
- isNumeric() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneHoursCompiledPattern
- isNumeric() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneMinutesCompiledPattern
- isNumeric() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneOffsetCompiledPattern
- isNumeric() - Method in class org.apache.calcite.util.format.postgresql.format.compiled.YearWithCommasCompiledPattern
- isNumeric(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is numeric.
- ISO_8601 - Enum constant in enum org.apache.calcite.util.format.postgresql.DateCalendarEnum
- ISO_DATETIME_FORMAT - Static variable in class org.apache.calcite.util.DateTimeStringUtils
-
The SimpleDateFormat string for ISO timestamps, "yyyy-MM-dd'T'HH:mm:ss'Z'".
- ISO_DATETIME_FRACTIONAL_SECOND_FORMAT - Static variable in class org.apache.calcite.util.DateTimeStringUtils
-
The SimpleDateFormat string for ISO timestamps with precisions, "yyyy-MM-dd'T'HH:mm:ss .SSS'Z'"
- isOctalDigit(char) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Returns true if the specific character is a base-8 digit.
- isOffset(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Whether this node contains a offset specification.
- isOffsetLimitAllowed() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isOffsetLimitAllowed() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow the SQL syntax "
OFFSET start LIMIT count
" (that is,OFFSET
beforeLIMIT
, in addition toLIMIT
beforeOFFSET
andOFFSET
beforeFETCH
). - isOffsetLimitAllowed() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isOffsetLimitAllowed() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isOfSameTypeName(Collection<SqlTypeName>, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns true if any element in
typeNames
matches type.getSqlTypeName(). - isOfSameTypeName(SqlTypeName, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns typeName.equals(type.getSqlTypeName()).
- ISOLATION_LEVEL_READ_COMMITTED - Enum constant in enum org.apache.calcite.sql.babel.postgresql.SqlBegin.TransactionMode
- ISOLATION_LEVEL_READ_UNCOMMITTED - Enum constant in enum org.apache.calcite.sql.babel.postgresql.SqlBegin.TransactionMode
- ISOLATION_LEVEL_REPEATABLE_READ - Enum constant in enum org.apache.calcite.sql.babel.postgresql.SqlBegin.TransactionMode
- ISOLATION_LEVEL_SERIALIZABLE - Enum constant in enum org.apache.calcite.sql.babel.postgresql.SqlBegin.TransactionMode
- isOp(int) - Method in interface org.apache.calcite.sql.SqlSpecialOperator.TokenSequence
- isOpenInterval(RangeSet<C>) - Static method in class org.apache.calcite.util.RangeSets
-
Returns whether a range set is a single open interval.
- isOperandLiteral(int, boolean) - Method in class org.apache.calcite.rex.RexCallBinding
- isOperandLiteral(int, boolean) - Method in class org.apache.calcite.sql.SqlCallBinding
- isOperandLiteral(int, boolean) - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Determines whether an operand is a literal.
- isOperandNull(int, boolean) - Method in class org.apache.calcite.rex.RexCallBinding
- isOperandNull(int, boolean) - Method in class org.apache.calcite.sql.ExplicitOperatorBinding
- isOperandNull(int, boolean) - Method in class org.apache.calcite.sql.SqlCallBinding
- isOperandNull(int, boolean) - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Determines whether a bound operand is NULL.
- isOperandTimeFrame(int) - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Returns whether an operand is a time frame.
- isOptional() - Method in interface org.apache.calcite.schema.FunctionParameter
-
Returns whether this parameter is optional.
- isOptional(int) - Method in class org.apache.calcite.sql.SqlWindowTableFunction.AbstractOperandMetadata
- isOptional(int) - Method in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- isOptional(int) - Method in class org.apache.calcite.sql.type.FamilyOperandTypeChecker
- isOptional(int) - Method in interface org.apache.calcite.sql.type.SqlOperandTypeChecker
-
Returns whether the
i
th operand is optional. - isOrder(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Whether this node contains a sort specification.
- isOrdered(SqlNode) - Static method in class org.apache.calcite.sql2rel.SqlToRelConverter
- isOuterJoin() - Method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns whether a join of this type is an outer join, returns true if the join type may generate NULL values, either on the left-hand side or right-hand side.
- isOverAggregateWindow(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- isParameterOptional(Method, int) - Static method in class org.apache.calcite.util.ReflectUtil
-
Derives whether the
i
th parameter of a method is optional. - isPartialFunction() - Method in enum org.apache.calcite.util.mapping.MappingType
-
A mapping is a partial function if every source has at most one target.
- isPercentile() - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- isPercentile() - Method in class org.apache.calcite.sql.SqlAggFunction
-
Returns whether this aggregate function is a PERCENTILE function.
- isPercentRemainderAllowed() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isPercentRemainderAllowed() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether the "%" operator is allowed by the parser as an alternative to the
mod
function. - isPercentRemainderAllowed() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isPercentRemainderAllowed() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isPermutation() - Method in class org.apache.calcite.rex.RexProgram
-
Returns whether this program is a permutation of its inputs.
- isPhaseTransition() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Parallelism
-
Returns whether each physical operator implementing this relational expression belongs to a different process than its inputs.
- isPhaseTransition(Exchange, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdParallelism
- isPhaseTransition(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdParallelism
- isPhaseTransition(Values, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdParallelism
- isPhaseTransition(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.Parallelism.isPhaseTransition()
statistic. - isPhaseTransition(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Parallelism.Handler
- isPhaseTransition(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdParallelism
-
Catch-all implementation for
BuiltInMetadata.Parallelism.isPhaseTransition()
, invoked using reflection. - isPhysical() - Method in class org.apache.calcite.plan.RelOptListener.RelEquivalenceEvent
- isPoint(Range<C>) - Static method in class org.apache.calcite.util.RangeSets
-
Returns whether a range is a point.
- isPoints() - Method in class org.apache.calcite.util.Sarg
-
Returns whether this Sarg is a collection of 1 or more points (and perhaps an
IS NULL
ifnullAs == RexUnknownAs.TRUE
). - isPreceding() - Method in class org.apache.calcite.rex.RexWindowBound
-
Returns if the bound is PRECEDING.
- isPrefix() - Method in enum org.apache.calcite.util.format.postgresql.PatternModifier
-
Is this modifier placed before or after the pattern.
- isPublic(Member) - Static method in class org.apache.calcite.util.ReflectUtil
-
Returns whether a member (constructor, method or field) is public.
- isPureLimit(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Whether this node is a limit without sort specification.
- isPureOrder(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Whether this node is a sort without limit specification.
- isQuantifierAllowed() - Method in class org.apache.calcite.sql.fun.SqlAbstractGroupFunction
- isQuantifierAllowed() - Method in class org.apache.calcite.sql.SqlAggFunction
- isQuantifierAllowed() - Method in class org.apache.calcite.sql.SqlFunction
-
Returns whether this function allows a
DISTINCT
orALL
quantifier. - isQuoteAllIdentifiers() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isQuoteAllIdentifiers() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- isQuoteAllIdentifiers() - Method in interface org.apache.calcite.sql.SqlWriter
-
Returns whether this writer should quote all identifiers, even those that do not contain mixed-case identifiers or punctuation.
- isQuoted() - Method in class org.apache.calcite.sql.parser.SqlParserPos
-
Returns whether this SqlParserPos is quoted.
- isRangeSet(String) - Static method in class org.apache.calcite.test.Matchers
-
Creates a Matcher that matches a
RangeSet
if its string representation, after changing "ߩ" to "..", is equal to the givenvalue
. - isRecord(Class<T>) - Method in interface org.apache.calcite.linq4j.util.Compatible
-
Tells whether the given class is a JDK 16+ record.
- isReferenceOrAccess(RexNode, boolean) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a node represents an input reference or field access.
- isRefTrivial() - Method in class org.apache.calcite.rel.RelRoot
- isRegistered(RelNode) - Method in class org.apache.calcite.plan.hep.HepPlanner
- isRegistered(RelNode) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Determines whether a relational expression has been registered.
- isRegistered(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- isRegistered(RelNode) - Method in class org.apache.calcite.test.MockRelOptPlanner
- isRemovableOuterJoinFactor(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Return whether the factor corresponds to the null-generating factor in an outer join that can be removed.
- isRemovableSelfJoin() - Method in class org.apache.calcite.rel.rules.LoptJoinTree
- isRemovableSelfJoin(Join) - Static method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Determines whether a join is a removable self-join.
- isRemoveSortInSubQuery() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns whether to remove Sort operator for a sub-query if the Sort has no offset and fetch limit attributes.
- isRepeatable() - Method in class org.apache.calcite.plan.RelOptSamplingParameters
-
Indicates whether the sample results should be repeatable.
- isRepeatable() - Method in class org.apache.calcite.sql.SqlSampleSpec.SqlTableSampleSpec
-
Indicates whether repeatable seed should be used.
- isRequired() - Method in class org.apache.calcite.plan.volcano.RelSubset
- isReserved(String) - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Returns whether a word is reserved in this parser.
- isRight() - Method in interface org.apache.calcite.rel.rules.JoinPushThroughJoinRule.Config
-
Whether to push on the right.
- isRightFactorInRemovableSelfJoin(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns whether the factor is the right factor in a self-join.
- isRolledUp(String) - Method in class org.apache.calcite.adapter.druid.DruidTable
- isRolledUp(String) - Method in class org.apache.calcite.adapter.kafka.KafkaStreamTable
- isRolledUp(String) - Method in class org.apache.calcite.schema.impl.AbstractTable
- isRolledUp(String) - Method in interface org.apache.calcite.schema.Table
-
Determines whether the given
column
has been rolled up. - isRolledUp(String) - Method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions.ExplodeTable
- isRolledUp(String) - Method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions.GridTable
- isRolledUp(String) - Method in class org.apache.calcite.test.schemata.orderstream.BaseOrderStreamTable
- isRolledUp(String) - Method in class org.apache.calcite.test.schemata.orderstream.OrdersTable
- isRolledUp(String) - Method in class org.apache.calcite.test.schemata.orderstream.ProductsTable
- isRolledUp(String) - Method in class org.apache.calcite.test.schemata.orderstream.ProductsTemporalTable
- isRollup(ImmutableBitSet, List<ImmutableBitSet>) - Static method in enum org.apache.calcite.rel.core.Aggregate.Group
-
Returns whether a list of sets is a rollup.
- isRoot() - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns whether this is a root schema.
- isRow(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is ROW.
- isRows - Variable in class org.apache.calcite.rel.core.Window.Group
- isRows() - Method in class org.apache.calcite.rex.RexWindow
- isRows() - Method in class org.apache.calcite.sql.SqlWindow
- isRuleExcluded() - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Determines whether the rule is excluded by any root node hint.
- isRuleExcluded(RelOptRule) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Determines whether a given rule is excluded by ruleDescExclusionFilter.
- isRuleExcluded(Hintable, RelOptRule) - Method in class org.apache.calcite.rel.hint.HintStrategyTable
-
Returns whether the
hintable
has hints that imply the givenrule
should be excluded. - isSafeForReuse(DeclarationStatement) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- isSchemaCaseSensitive() - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- isSchemaCaseSensitive() - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Whether two record types are considered distinct if their field names are the same but in different cases.
- isSchemaCaseSensitive() - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- isSelectListExtraIndentFlag() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- isSelectListItemsOnSeparateLines() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isSelectListItemsOnSeparateLines() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- isSelectListItemsOnSeparateLines() - Method in interface org.apache.calcite.sql.SqlWriter
-
Returns whether the items in the SELECT clause should each be on a separate line.
- isSemiJoin() - Method in class org.apache.calcite.rel.core.Join
-
Returns whether this Join is a semijoin.
- isSemiJoinDone() - Method in class org.apache.calcite.rel.core.Join
-
Returns whether this LogicalJoin has already spawned a
SemiJoin
viaJoinAddRedundantSemiJoinRule
. - isSemiJoinDone() - Method in class org.apache.calcite.rel.logical.LogicalJoin
- isSet(String...) - Static method in class org.apache.calcite.sql.test.ResultCheckers
- isSet(CalciteConnectionProperty) - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
-
Returns whether a given property has been assigned a value.
- isSimple() - Method in class org.apache.calcite.sql.SqlIdentifier
-
Returns whether this is a simple identifier.
- isSimple(Aggregate) - Static method in class org.apache.calcite.rel.core.Aggregate
- isSimpleExpression(Expression) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Checks if expression is simple enough to always inline at zero cost.
- isSingle(boolean) - Static method in class org.apache.calcite.sql.test.ResultCheckers
- isSingle(double, String) - Static method in class org.apache.calcite.sql.test.ResultCheckers
- isSingle(int) - Static method in class org.apache.calcite.sql.test.ResultCheckers
- isSingle(String) - Static method in class org.apache.calcite.sql.test.ResultCheckers
- isSingleDatetimeField() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Returns whether this interval has a single datetime field.
- isSinglePartition() - Method in class org.apache.calcite.adapter.cassandra.CassandraFilter
-
Check if the filter restricts to a single partition.
- isSingleSource() - Method in enum org.apache.calcite.util.mapping.MappingType
-
Constraint that every target has at most one source.
- isSingleTarget() - Method in enum org.apache.calcite.util.mapping.MappingType
-
Constraint that every source has at most one target.
- isSingleValue(Values) - Static method in class org.apache.calcite.rel.core.Values
- isSingleValue(SqlCall) - Static method in class org.apache.calcite.util.Util
-
Does nothing with its argument.
- isSmart() - Method in interface org.apache.calcite.rel.rules.FilterJoinRule.Config
-
Whether to try to strengthen join-type, default false.
- isSortByAlias() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isSortByAlias() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether '
ORDER BY x
' is interpreted to mean 'sort by the select list item whose alias is x' even if there is a column called x. - isSortByAlias() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isSortByAlias() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isSortByAliasObscures() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isSortByAliasObscures() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether "empno" is invalid in "select empno as x from emp order by empno" because the alias "x" obscures it.
- isSortByAliasObscures() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isSortByAliasObscures() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isSortByOrdinal() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isSortByOrdinal() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether '
ORDER BY 2
' is interpreted to mean 'sort by the 2nd column in the select list'. - isSortByOrdinal() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isSortByOrdinal() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isSpecial() - Method in enum org.apache.calcite.sql.type.SqlTypeName
- isSpecific() - Method in enum org.apache.calcite.sql.SqlFunctionCategory
- isStar() - Method in class org.apache.calcite.piglet.Ast.Identifier
- isStar() - Method in class org.apache.calcite.piglet.Ast.SpecialIdentifier
- isStar() - Method in class org.apache.calcite.sql.SqlIdentifier
-
Returns whether this identifier is a star, such as "*" or "foo.bar.*".
- isStar(List<RexNode>, RelDataType, RelDataType) - Static method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Returns whether a list of expressions projects all fields, in order, from the input, with the same names.
- isStar(RexProgram) - Static method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- isStatic - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- isStatic(Member) - Static method in class org.apache.calcite.util.ReflectUtil
-
Returns whether a member (constructor, method or field) is static.
- isStream() - Method in class org.apache.calcite.adapter.csv.CsvStreamScannableTable
- isStream() - Method in class org.apache.calcite.adapter.csv.CsvTable
-
Returns whether the table represents a stream.
- isStream() - Method in class org.apache.calcite.adapter.file.CsvTable
-
Returns whether the table represents a stream.
- isStrictEnd() - Method in class org.apache.calcite.rel.core.Match
- isStrictStart() - Method in class org.apache.calcite.rel.core.Match
- isString(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is STRING.
- isStrong(RexNode) - Static method in class org.apache.calcite.plan.Strong
-
Returns whether a given expression is strong.
- isStruct() - Method in class org.apache.calcite.rel.type.DynamicRecordTypeImpl
- isStruct() - Method in class org.apache.calcite.rel.type.RelCrossType
- isStruct() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Queries whether this is a structured type.
- isStruct() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- isStruct() - Method in class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- isSubstituteRule(VolcanoRuleCall) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Checks whether a rule match is a substitution rule match.
- isSurjection() - Method in enum org.apache.calcite.util.mapping.MappingType
-
A mapping is a surjection if it is a function and every target has at least one source.
- isSwapOuter() - Method in interface org.apache.calcite.rel.rules.JoinCommuteRule.Config
-
Whether to swap outer joins; default false.
- isSymbolLiteral(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a node represents a
SqlTypeName.SYMBOL
literal. - isSymmetrical() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether a call to this operator is not sensitive to the operands input order.
- isSystemField(RelDataTypeField) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns whether a field is a system field.
- isSystemField(RelDataTypeField) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- isTableAccessed(List<String>) - Method in class org.apache.calcite.plan.TableAccessMap
-
Deprecated.Determines whether a table is accessed at all.
- isTableAccessedForRead(List<String>) - Method in class org.apache.calcite.plan.TableAccessMap
-
Deprecated.Determines whether a table is accessed for read.
- isTableAccessedForWrite(List<String>) - Method in class org.apache.calcite.plan.TableAccessMap
-
Deprecated.Determines whether a table is accessed for write.
- isTableFunction() - Method in enum org.apache.calcite.sql.SqlFunctionCategory
- isTemporal() - Method in class org.apache.calcite.prepare.RelOptTableImpl
- isTemporal() - Method in interface org.apache.calcite.sql.validate.SqlValidatorTable
-
Returns whether the table is temporal.
- isTemporal() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- isTime() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Whether this is a TIME interval.
- isTimestamp() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Whether this is a TIMESTAMP interval (including all week intervals).
- isTimestamp(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a type is TIMESTAMP.
- isTop() - Method in interface org.apache.calcite.plan.RelMultipleTrait
-
Returns whether this trait is satisfied by every instance of the trait (including itself).
- isTop() - Method in class org.apache.calcite.rel.RelCollationImpl
- isTransformationRule(VolcanoRuleCall) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Checks whether a rule match is a transformation rule match.
- isTrimUnusedFields() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns the
trimUnusedFields
option. - isTrimUnusedFields() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Deprecated.
- isTrivial() - Method in class org.apache.calcite.rex.RexProgram
-
Returns whether this program returns its input exactly.
- isTrivial(Project) - Static method in class org.apache.calcite.rel.rules.ProjectRemoveRule
- isTrivial(MutableProject) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- isTrue(Boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
NULL → FALSE, FALSE → FALSE, TRUE → TRUE.
- isTrue(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Returns whether the expression evaluates to true.
- isTrue(Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Returns whether the expression evaluates to true.
- IsTrue - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A true condition value.
- isTypeCoercionEnabled() - Method in class org.apache.calcite.sql.SqlCallBinding
-
Returns whether to allow implicit type coercion when validation.
- isUnbounded() - Method in class org.apache.calcite.rex.RexWindowBound
-
Returns if the bound is unbounded.
- isUnboundedFollowing() - Method in class org.apache.calcite.rex.RexWindowBound
-
Returns whether the bound is
UNBOUNDED FOLLOWING
. - isUnboundedFollowing(SqlNode) - Static method in class org.apache.calcite.sql.SqlWindow
-
Returns whether an expression represents the "UNBOUNDED FOLLOWING" bound.
- isUnboundedPreceding() - Method in class org.apache.calcite.rex.RexWindowBound
-
Returns whether the bound is
UNBOUNDED PRECEDING
. - isUnboundedPreceding(SqlNode) - Static method in class org.apache.calcite.sql.SqlWindow
-
Returns whether an expression represents the "UNBOUNDED PRECEDING" bound.
- isUnicode(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Checks whether a type represents Unicode character data.
- isUnparserTest() - Method in interface org.apache.calcite.sql.parser.SqlParserTest.Tester
-
Whether this is a sub-class that tests un-parsing as well as parsing.
- isUnparserTest() - Method in class org.apache.calcite.sql.parser.SqlParserTest.UnparsingTesterImpl
- isUpdate() - Method in class org.apache.calcite.rel.core.TableModify
- isUpsert() - Method in class org.apache.calcite.sql.SqlInsert
-
Returns whether this is an UPSERT statement.
- isUserDefined() - Method in enum org.apache.calcite.sql.SqlFunctionCategory
- isUserDefinedNotSpecificFunction() - Method in enum org.apache.calcite.sql.SqlFunctionCategory
- isUsingGroupingSets() - Method in interface org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule.Config
-
Whether to use GROUPING SETS, default true.
- isValid() - Method in class org.apache.calcite.plan.SubstitutionVisitor.AbstractUnifyRule
- isValid() - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- isValid(boolean) - Method in class org.apache.calcite.util.PartiallyOrderedSet
-
Checks internal consistency of this lattice.
- isValid(String) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
-
Attempts to complete and validate a given partially completed sql statement, and returns whether it is valid.
- isValid(RelDataType, List<RelCollation>, boolean) - Static method in class org.apache.calcite.rel.RelCollationImpl
-
Deprecated.
- isValid(RelDataType, List<RelCollation>, boolean) - Static method in class org.apache.calcite.rel.RelCollations
-
Checks that a collection of collations is valid.
- isValid(RexNode) - Method in class org.apache.calcite.rex.RexChecker
-
Returns whether an expression is valid.
- isValid(Litmus) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Checks internal consistency.
- isValid(Litmus, RelNode.Context) - Method in class org.apache.calcite.rel.AbstractRelNode
- isValid(Litmus, RelNode.Context) - Method in class org.apache.calcite.rel.core.Aggregate
- isValid(Litmus, RelNode.Context) - Method in class org.apache.calcite.rel.core.Calc
- isValid(Litmus, RelNode.Context) - Method in class org.apache.calcite.rel.core.Correlate
- isValid(Litmus, RelNode.Context) - Method in class org.apache.calcite.rel.core.Filter
- isValid(Litmus, RelNode.Context) - Method in class org.apache.calcite.rel.core.Join
- isValid(Litmus, RelNode.Context) - Method in class org.apache.calcite.rel.core.Project
- isValid(Litmus, RelNode.Context) - Method in class org.apache.calcite.rel.core.Snapshot
- isValid(Litmus, RelNode.Context) - Method in class org.apache.calcite.rel.core.Window
- isValid(Litmus, RelNode.Context) - Method in interface org.apache.calcite.rel.RelNode
-
Returns whether this relational expression is valid.
- isValid(Litmus, RelNode.Context) - Method in class org.apache.calcite.rex.RexProgram
-
Checks that this program is valid.
- isValid(Litmus, RelNode.Context) - Method in class org.apache.calcite.adapter.druid.DruidQuery
- isValidArgCount(SqlCallBinding) - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall.SimpleMakeCall
- isValidCount(int) - Method in interface org.apache.calcite.sql.SqlOperandCountRange
-
Returns whether
count
is a valid number of operands. - isValidDecimal(BigDecimal) - Static method in class org.apache.calcite.util.NumberUtil
-
Returns whether a
BigDecimal
is a valid Farrago decimal. - isValidDecimalValue(BigDecimal, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether the decimal value is valid for the type.
- isValidJavaIdentifier(String) - Static method in class org.apache.calcite.util.Util
-
Returns true when input string is a valid Java identifier.
- isValidPlan(Project, RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule
- isValidPlan(Project, RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewJoinRule
- isValidPlan(Project, RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
- isValidRelNodePlan(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
Returns whether a RelNode is a valid tree.
- isValidTimeExtract(RexNode) - Static method in class org.apache.calcite.adapter.druid.TimeExtractionFunction
-
Returns whether the RexCall contains a valid extract unit that we can serialize to Druid.
- isValidTimeFloor(RexNode) - Static method in class org.apache.calcite.adapter.druid.TimeExtractionFunction
-
Returns whether the RexCall contains a valid FLOOR unit that we can serialize to Druid.
- isValueAllowed() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- isValueAllowed() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether
VALUE
is allowed as an alternative toVALUES
in the parser. - isValueAllowed() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- isValueAllowed() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- isVisibleInExplain(TableScan, RelMetadataQuery, SqlExplainLevel) - Method in class org.apache.calcite.rel.metadata.RelMdExplainVisibility
- isVisibleInExplain(RelNode, RelMetadataQuery, SqlExplainLevel) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ExplainVisibility.Handler
- isVisibleInExplain(RelNode, RelMetadataQuery, SqlExplainLevel) - Method in class org.apache.calcite.rel.metadata.RelMdExplainVisibility
-
Catch-all implementation for
BuiltInMetadata.ExplainVisibility.isVisibleInExplain(SqlExplainLevel)
, invoked using reflection. - isVisibleInExplain(RelNode, SqlExplainLevel) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.ExplainVisibility.isVisibleInExplain(SqlExplainLevel)
statistic. - isVisibleInExplain(SqlExplainLevel) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ExplainVisibility
-
Determines whether a relational expression should be visible in EXPLAIN PLAN output at a particular level of detail.
- isWeaker(SubstitutionVisitor, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor.Operand
- isWeaker(MutableRel, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor
-
Returns if one rel is weaker than another.
- isWeek() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Whether this qualifier represents
WEEK
,ISOWEEK
, orWEEK(
weekday)
(for weekday inSUNDAY
.. - isWhereListItemsOnSeparateLines() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isWhereListItemsOnSeparateLines() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- isWholeFilter() - Method in interface org.apache.calcite.rel.rules.ProjectFilterTransposeRule.Config
-
Whether to push whole expressions from the filter; if false (the default), only pushes references.
- isWholeProject() - Method in interface org.apache.calcite.rel.rules.ProjectFilterTransposeRule.Config
-
Whether to push whole expressions from the project; if false (the default), only pushes references.
- isWindowDeclarationStartsLine() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isWindowListItemsOnSeparateLines() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isWithin(double, double) - Static method in class org.apache.calcite.sql.test.ResultCheckers
- isWithin(SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.JoinScope
- isWithin(SqlValidatorScope) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Returns whether this scope is enclosed within
scope2
in such a way that it can see the contents ofscope2
. - IsWithin(T, double) - Constructor for class org.apache.calcite.test.Matchers.IsWithin
- isWrapperFor(Class<?>) - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- isWrapperFor(Class<?>) - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- isWrapperFor(Class<?>) - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns whether this namespace implements a given interface, or wraps a class which does.
- isXml() - Method in class org.apache.calcite.sql.SqlExplain
-
Deprecated.
- isYearMonth() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- isYearMonth() - Method in enum org.apache.calcite.sql.type.SqlTypeName
- item(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Implements the
[ ... ]
operator on an object whose type is not known until runtime. - item(String, Object) - Method in class org.apache.calcite.rel.externalize.RelJsonWriter
- item(String, Object) - Method in class org.apache.calcite.rel.externalize.RelWriterImpl
- item(String, Object) - Method in interface org.apache.calcite.rel.RelWriter
-
Adds an attribute to the explanation of the current node.
- ITEM - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Item expression.
- ITEM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The item operator
[ ... ]
, used to access a given element of an array, map or struct. - itemIf(String, Object, boolean) - Method in interface org.apache.calcite.rel.RelWriter
-
Adds an input to the explanation of the current node, if a condition holds.
- itemOptional(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
As
SqlFunctions.item(java.lang.Object, java.lang.Object)
method, but allows object to be nullable. - iterable - Variable in class org.apache.calcite.linq4j.tree.ForEachStatement
- iterable() - Method in class org.apache.calcite.util.NameSet
-
Returns the contents as an iterable.
- ITERABLE_FOR_EACH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- iterableEnumerator(Iterable<? extends T>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Adapter that converts an iterable into an enumerator.
- iterationLimit - Variable in class org.apache.calcite.rel.core.RepeatUnion
-
Maximum number of times to repeat the iterative relational expression; negative value means no limit, 0 means only seed will be evaluated.
- iterator() - Method in class org.apache.calcite.adapter.enumerable.LazyAggregateLambdaFactory.LazySource
- iterator() - Method in class org.apache.calcite.adapter.file.FileReader
- iterator() - Method in class org.apache.calcite.linq4j.AbstractEnumerable
- iterator() - Method in class org.apache.calcite.linq4j.BaseQueryable
- iterator() - Method in class org.apache.calcite.linq4j.QueryableDefaults.ReplayableQueryable
- iterator() - Method in class org.apache.calcite.runtime.FlatLists.AbstractFlatList
- iterator() - Method in class org.apache.calcite.runtime.ConsList
- iterator() - Method in class org.apache.calcite.runtime.FlatLists.Flat1List
- iterator() - Method in class org.apache.calcite.runtime.FlatLists.Flat2List
- iterator() - Method in class org.apache.calcite.runtime.FlatLists.Flat3List
- iterator() - Method in class org.apache.calcite.runtime.FlatLists.Flat4List
- iterator() - Method in class org.apache.calcite.runtime.FlatLists.Flat5List
- iterator() - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- iterator() - Method in class org.apache.calcite.schema.impl.AbstractTableQueryable
- iterator() - Method in class org.apache.calcite.sql.SqlNodeList
- iterator() - Method in class org.apache.calcite.util.ImmutableBitSet
- iterator() - Method in class org.apache.calcite.util.ImmutableIntList
- iterator() - Method in class org.apache.calcite.util.ImmutableNullableSet
- iterator() - Method in class org.apache.calcite.util.IntegerIntervalSet
- iterator() - Method in class org.apache.calcite.util.mapping.AbstractSourceMapping
- iterator() - Method in class org.apache.calcite.util.mapping.AbstractTargetMapping
- iterator() - Method in interface org.apache.calcite.util.mapping.Mapping
-
Returns an iterator over the elements in this mapping.
- iterator() - Method in class org.apache.calcite.util.mapping.Mappings.FiniteAbstractMapping
- iterator() - Method in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
- iterator() - Method in class org.apache.calcite.util.mapping.Mappings.OverridingSourceMapping
- iterator() - Method in class org.apache.calcite.util.mapping.Mappings.OverridingTargetMapping
- iterator() - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- iterator() - Method in class org.apache.calcite.util.PartiallyOrderedSet
- iterator() - Method in class org.apache.calcite.util.Permutation
- iterator() - Method in class org.apache.calcite.util.Smalls.SimpleTable
- ITERATOR_HAS_NEXT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ITERATOR_NEXT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ITERATOR_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Provide a way to access the elements of an aggregate object sequentially without exposing its underlying representation.
- IW - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- IYY - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- IYYYY - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
J
- JaninoCompiler - Class in org.apache.calcite.util.javac
- JaninoCompiler() - Constructor for class org.apache.calcite.util.javac.JaninoCompiler
- JaninoCompiler.JaninoCompilerArgs - Class in org.apache.calcite.util.javac
-
Arguments to an invocation of the Janino compiler.
- JaninoCompilerArgs() - Constructor for class org.apache.calcite.util.javac.JaninoCompiler.JaninoCompilerArgs
- JaninoRelMetadataProvider - Class in org.apache.calcite.rel.metadata
-
Implementation of the
RelMetadataProvider
interface that generates a class that dispatches to the underlying providers. - JaninoRelMetadataProvider.NoHandler - Exception Class in org.apache.calcite.rel.metadata
-
Deprecated.
- JaninoRexCompiler - Class in org.apache.calcite.interpreter
- JaninoRexCompiler(RexBuilder) - Constructor for class org.apache.calcite.interpreter.JaninoRexCompiler
- JAR - Enum constant in enum org.apache.calcite.sql.ddl.SqlDdlNodes.FileType
- JAVA - Enum constant in enum org.apache.calcite.config.Lex
-
Lexical policy similar to Java.
- JAVA - Enum constant in enum org.apache.calcite.sql.test.SqlOperatorFixture.VmName
- JAVA - Enum constant in enum org.apache.calcite.sql.test.SqlTester.VmName
- JAVA_INFO - Enum constant in enum org.apache.calcite.adapter.os.OsQueryType
- JAVA_PLAN - Enum constant in enum org.apache.calcite.runtime.Hook
-
Called with the generated Java plan, just before it is compiled by Janino.
- JAVA_TO_SQL_METHOD_MAP - Static variable in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- JavaCollation - Class in org.apache.calcite.jdbc
-
Collation that uses a specific
Collator
for comparison. - JavaCollation(SqlCollation.Coercibility, Locale, Charset, int) - Constructor for class org.apache.calcite.jdbc.JavaCollation
- JavaCompiler - Interface in org.apache.calcite.util.javac
-
The interface
JavaCompiler
represents an interface to invoke a regular Java compiler. - JavaCompilerArgs - Class in org.apache.calcite.util.javac
-
A
JavaCompilerArgs
holds the arguments for aJavaCompiler
. - JavaCompilerArgs() - Constructor for class org.apache.calcite.util.javac.JavaCompilerArgs
- JavaInfoTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "java_info".
- JavaRecordType - Class in org.apache.calcite.jdbc
-
Record type based on a Java class.
- JavaRecordType(List<RelDataTypeField>, Class) - Constructor for class org.apache.calcite.jdbc.JavaRecordType
- JavaRelImplementor - Class in org.apache.calcite.adapter.enumerable
-
Abstract base class for implementations of
RelImplementor
that generate java code. - JavaRelImplementor(RexBuilder) - Constructor for class org.apache.calcite.adapter.enumerable.JavaRelImplementor
- JavaRowFormat - Enum in org.apache.calcite.adapter.enumerable
-
How a row is represented as a Java value.
- JavaToSqlTypeConversionRules - Class in org.apache.calcite.sql.type
-
JavaToSqlTypeConversionRules defines mappings from common Java types to corresponding SQL types.
- JavaToSqlTypeConversionRules() - Constructor for class org.apache.calcite.sql.type.JavaToSqlTypeConversionRules
- JavaType(Class) - Constructor for class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- JavaType(Class, boolean) - Constructor for class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- JavaType(Class, boolean, Charset, SqlCollation) - Constructor for class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- JavaTypeFactory - Interface in org.apache.calcite.adapter.java
-
Type factory that can register Java classes as record types.
- JavaTypeFactoryExtImpl - Class in org.apache.calcite.adapter.geode.util
-
Implementation of
JavaTypeFactory
. - JavaTypeFactoryExtImpl() - Constructor for class org.apache.calcite.adapter.geode.util.JavaTypeFactoryExtImpl
- JavaTypeFactoryImpl - Class in org.apache.calcite.jdbc
-
Implementation of
JavaTypeFactory
. - JavaTypeFactoryImpl() - Constructor for class org.apache.calcite.jdbc.JavaTypeFactoryImpl
- JavaTypeFactoryImpl(RelDataTypeSystem) - Constructor for class org.apache.calcite.jdbc.JavaTypeFactoryImpl
- JavaTypeFactoryImpl.SyntheticRecordType - Class in org.apache.calcite.jdbc
-
Synthetic record type.
- jdbc(ResultSet, int, Primitive.Sink) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Sends to a sink a value from a given column in a JDBC result set.
- JDBC - Enum constant in enum org.apache.calcite.model.JsonSchema.Type
- JDBC_ARRAY_TO_LIST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JDBC_BUILDER - Static variable in class org.apache.calcite.adapter.jdbc.JdbcRules
-
A
RelBuilderFactory
that creates aRelBuilder
that will create JDBC relational expressions for everything. - JDBC_FN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Call to a function using JDBC function syntax.
- JDBC_FOODMART - Enum constant in enum org.apache.calcite.test.CalciteAssert.Config
-
Configuration that creates a connection to a MySQL server.
- JDBC_FOODMART - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- JDBC_FOODMART_WITH_LATTICE - Enum constant in enum org.apache.calcite.test.CalciteAssert.Config
-
Configuration that contains an in-memory clone of the FoodMart database, plus a lattice to enable on-the-fly materializations.
- JDBC_FOODMART_WITH_LATTICE - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- JDBC_SCHEMA_DATA_SOURCE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JDBC_SCOTT - Enum constant in enum org.apache.calcite.test.CalciteAssert.Config
-
Configuration that creates a connection to hsqldb containing the Scott schema via the JDBC adapter.
- JDBC_SCOTT - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- JDBC_STEELWHEELS - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- JdbcAggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcAggregate
-
Deprecated.
- JdbcAggregate(RelOptCluster, RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcAggregate
- JdbcAggregateRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcAggregateRule
-
Called from the Config.
- JdbcCalc(RelOptCluster, RelTraitSet, RelNode, RexProgram) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcCalc
-
Deprecated.
- JdbcCalc(RelOptCluster, RelTraitSet, RelNode, RexProgram, int) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcCalc
-
Deprecated.
- jdbcCatalog - Variable in class org.apache.calcite.model.JsonJdbcSchema
-
Name of the initial catalog in the JDBC data source.
- jdbcCatalogName - Variable in class org.apache.calcite.adapter.jdbc.JdbcTable
- JdbcCatalogSchema - Class in org.apache.calcite.adapter.jdbc
-
Schema based upon a JDBC catalog (database).
- JdbcCatalogSchema(DataSource, SqlDialect, JdbcConvention, String) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcCatalogSchema
-
Creates a JdbcCatalogSchema.
- JdbcConvention - Class in org.apache.calcite.adapter.jdbc
-
Calling convention for relational operations that occur in a JDBC database.
- JdbcConvention(SqlDialect, Expression, String) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcConvention
- jdbcDriver - Variable in class org.apache.calcite.model.JsonJdbcSchema
-
The name of the JDBC driver class.
- JdbcFilter(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcFilter
- JdbcFilterRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcFilterRule
-
Called from the Config.
- jdbcGet(ResultSet, int) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Gets a value from a given column in a JDBC result set.
- JdbcImplementor - Class in org.apache.calcite.adapter.jdbc
-
State for generating a SQL statement.
- JdbcImplementor(SqlDialect, JavaTypeFactory) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcImplementor
- JdbcIntersect(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcIntersect
- JdbcIntersectRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcIntersectRule
-
Called from the Config.
- JdbcJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcJoin
-
Creates a JdbcJoin.
- JdbcJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, Set<String>) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcJoin
-
Deprecated.
- JdbcJoinRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcJoinRule
-
Called from the Config.
- JdbcMinus(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcMinus
- JdbcMinusRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcMinusRule
-
Called from the Config.
- jdbcName - Variable in enum org.apache.calcite.schema.Schema.TableType
-
The name used in JDBC.
- jdbcPassword - Variable in class org.apache.calcite.model.JsonJdbcSchema
-
JDBC connect string, for example "jdbc:mysql://localhost/foodmart".
- JdbcProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcProject
- JdbcProject(RelOptCluster, RelTraitSet, RelNode, List<RexNode>, RelDataType, int) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcProject
-
Deprecated.
- JdbcProjectRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcProjectRule
-
Called from the Config.
- JdbcQueryProvider - Class in org.apache.calcite.adapter.jdbc
-
Implementation of
QueryProvider
that talks to JDBC databases. - JdbcRel - Interface in org.apache.calcite.adapter.jdbc
-
Relational expression that uses JDBC calling convention.
- JdbcRules - Class in org.apache.calcite.adapter.jdbc
-
Rules and relational operators for
JdbcConvention
calling convention. - JdbcRules.JdbcAggregate - Class in org.apache.calcite.adapter.jdbc
-
Aggregate operator implemented in JDBC convention.
- JdbcRules.JdbcAggregateRule - Class in org.apache.calcite.adapter.jdbc
-
Rule to convert a
Aggregate
to aJdbcRules.JdbcAggregate
. - JdbcRules.JdbcCalc - Class in org.apache.calcite.adapter.jdbc
-
Deprecated.
- JdbcRules.JdbcFilter - Class in org.apache.calcite.adapter.jdbc
-
Implementation of
Filter
injdbc calling convention
. - JdbcRules.JdbcFilterRule - Class in org.apache.calcite.adapter.jdbc
-
Rule to convert a
Filter
to anJdbcRules.JdbcFilter
. - JdbcRules.JdbcIntersect - Class in org.apache.calcite.adapter.jdbc
-
Intersect operator implemented in JDBC convention.
- JdbcRules.JdbcIntersectRule - Class in org.apache.calcite.adapter.jdbc
-
Rule to convert a
Intersect
to aJdbcRules.JdbcIntersect
. - JdbcRules.JdbcJoin - Class in org.apache.calcite.adapter.jdbc
-
Join operator implemented in JDBC convention.
- JdbcRules.JdbcJoinRule - Class in org.apache.calcite.adapter.jdbc
-
Rule that converts a join to JDBC.
- JdbcRules.JdbcMinus - Class in org.apache.calcite.adapter.jdbc
-
Minus operator implemented in JDBC convention.
- JdbcRules.JdbcMinusRule - Class in org.apache.calcite.adapter.jdbc
-
Rule to convert a
Minus
to aJdbcRules.JdbcMinus
. - JdbcRules.JdbcProject - Class in org.apache.calcite.adapter.jdbc
-
Implementation of
Project
injdbc calling convention
. - JdbcRules.JdbcProjectRule - Class in org.apache.calcite.adapter.jdbc
-
Rule to convert a
Project
to anJdbcRules.JdbcProject
. - JdbcRules.JdbcSort - Class in org.apache.calcite.adapter.jdbc
-
Sort operator implemented in JDBC convention.
- JdbcRules.JdbcSortRule - Class in org.apache.calcite.adapter.jdbc
-
Rule to convert a
Sort
to anJdbcRules.JdbcSort
. - JdbcRules.JdbcTableModificationRule - Class in org.apache.calcite.adapter.jdbc
-
Rule that converts a table-modification to JDBC.
- JdbcRules.JdbcTableModify - Class in org.apache.calcite.adapter.jdbc
-
Table-modification operator implemented in JDBC convention.
- JdbcRules.JdbcUnion - Class in org.apache.calcite.adapter.jdbc
-
Union operator implemented in JDBC convention.
- JdbcRules.JdbcUnionRule - Class in org.apache.calcite.adapter.jdbc
-
Rule to convert an
Union
to aJdbcRules.JdbcUnion
. - JdbcRules.JdbcValues - Class in org.apache.calcite.adapter.jdbc
-
Values operator implemented in JDBC convention.
- JdbcRules.JdbcValuesRule - Class in org.apache.calcite.adapter.jdbc
-
Rule that converts a values operator to JDBC.
- jdbcSchema - Variable in class org.apache.calcite.adapter.jdbc.JdbcTable
- jdbcSchema - Variable in class org.apache.calcite.model.JsonJdbcSchema
-
Name of the initial schema in the JDBC data source.
- JdbcSchema - Class in org.apache.calcite.adapter.jdbc
-
Implementation of
Schema
that is backed by a JDBC data source. - JdbcSchema(DataSource, SqlDialect, JdbcConvention, String, String) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcSchema
-
Creates a JDBC schema.
- JdbcSchema.Factory - Class in org.apache.calcite.adapter.jdbc
-
Schema factory that creates a
JdbcSchema
. - JdbcSchema.Foo - Interface in org.apache.calcite.adapter.jdbc
-
Do not use.
- jdbcSchemaName - Variable in class org.apache.calcite.adapter.jdbc.JdbcTable
- JdbcSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcSort
- JdbcSortRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcSortRule
-
Called from the Config.
- jdbcTable - Variable in class org.apache.calcite.adapter.jdbc.JdbcTableScan
- JdbcTable - Class in org.apache.calcite.adapter.jdbc
-
Queryable that gets its data from a table within a JDBC connection.
- JdbcTableModificationRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcTableModificationRule
-
Called from the Config.
- JdbcTableModify(RelOptCluster, RelTraitSet, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcTableModify
- jdbcTableName - Variable in class org.apache.calcite.adapter.jdbc.JdbcTable
- JdbcTableScan - Class in org.apache.calcite.adapter.jdbc
-
Relational expression representing a scan of a table in a JDBC data source.
- JdbcTableScan(RelOptCluster, List<RelHint>, RelOptTable, JdbcTable, JdbcConvention) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcTableScan
- jdbcTableType - Variable in class org.apache.calcite.adapter.jdbc.JdbcTable
- JdbcToEnumerableConverter - Class in org.apache.calcite.adapter.jdbc
-
Relational expression representing a scan of a table in a JDBC data source.
- JdbcToEnumerableConverter(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverter
- JdbcToEnumerableConverterRule - Class in org.apache.calcite.adapter.jdbc
-
Rule to convert a relational expression from
JdbcConvention
toEnumerableConvention
. - JdbcToEnumerableConverterRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverterRule
-
Called from the Config.
- JdbcToSparkConverter - Class in org.apache.calcite.adapter.spark
-
Relational expression representing a scan of a table in a JDBC data source that returns its results as a Spark RDD.
- JdbcToSparkConverter(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.adapter.spark.JdbcToSparkConverter
- JdbcToSparkConverterRule - Class in org.apache.calcite.adapter.spark
-
Rule to convert a relational expression from
JdbcConvention
toSpark convention
. - JdbcToSparkConverterRule(JdbcConvention, RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.spark.JdbcToSparkConverterRule
-
Deprecated.
- JdbcToSparkConverterRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.spark.JdbcToSparkConverterRule
-
Called from the Config.
- JdbcType<T extends @Nullable Object> - Interface in org.apache.calcite.util
-
Maps Java types to their corresponding getters in JDBC.
- JdbcUnion(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcUnion
- JdbcUnionRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcUnionRule
-
Called from the Config.
- jdbcUrl - Variable in class org.apache.calcite.model.JsonJdbcSchema
-
JDBC connect string, for example "jdbc:mysql://localhost/foodmart".
- jdbcUser - Variable in class org.apache.calcite.model.JsonJdbcSchema
-
JDBC user name.
- JdbcValuesRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcValuesRule
-
Called from the Config.
- JETHRO - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- JethroDataSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the JethroData database. - JethroDataSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.JethroDataSqlDialect
-
Creates a JethroDataSqlDialect.
- JethroDataSqlDialect.JethroInfo - Class in org.apache.calcite.sql.dialect
-
Information about the capabilities of a Jethro database.
- JethroDataSqlDialect.JethroInfoCache - Interface in org.apache.calcite.sql.dialect
-
Stores information about capabilities of Jethro databases.
- jethroInfo() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- JethroInfo(Multimap<String, JethroDataSqlDialect.JethroSupportedFunction>) - Constructor for class org.apache.calcite.sql.dialect.JethroDataSqlDialect.JethroInfo
- join(Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, TInner, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- join(Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, TInner, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- join(Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, TInner, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Correlates the elements of two sequences based on matching keys.
- join(Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, TInner, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Correlates the elements of two sequences based on matching keys.
- join(Queryable<T>, Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, TInner, TResult>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Correlates the elements of two sequences based on matching keys.
- join(Queryable<T>, Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, TInner, TResult>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- join(Queryable<T>, Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, TInner, TResult>>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Correlates the elements of two sequences based on matching keys.
- join(Queryable<T>, Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, TInner, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- join(Queryable<TOuter>, Enumerable<TInner>, FunctionExpression<Function1<TOuter, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<TOuter, TInner, TResult>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Correlates the elements of two sequences based on matching keys.
- join(Queryable<TOuter>, Enumerable<TInner>, FunctionExpression<Function1<TOuter, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<TOuter, TInner, TResult>>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Correlates the elements of two sequences based on matching keys.
- join(JoinRelType, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Join
with multiple conditions. - join(JoinRelType, String...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Join
using USING syntax. - join(JoinRelType, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Join
with one condition. - join(JoinRelType, RexNode, Set<CorrelationId>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Join
with correlating variables. - join(JoinRelType, RexNode, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Join
with an array of conditions. - Join - Class in org.apache.calcite.rel.core
-
Relational expression that combines two relational expressions according to some condition.
- Join(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.rel.core.Join
-
Creates a Join.
- Join(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.rel.core.Join
-
Deprecated.
- Join(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, Set<String>) - Constructor for class org.apache.calcite.rel.core.Join
-
Deprecated.
- JOIN - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
Join table.
- JOIN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
JOIN operator or compound FROM clause.
- JOIN - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Pair-wise join.
- JOIN - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
Join
nodes. - JOIN - Static variable in interface org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule.Config
- JOIN - Static variable in class org.apache.calcite.rel.rules.materialize.MaterializedViewRules
-
Rule that matches
Join
. - JOIN - Static variable in interface org.apache.calcite.rel.rules.SubQueryRemoveRule.Config
- JOIN_ADD_REDUNDANT_SEMI_JOIN - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule to add a semi-join into a
Join
. - JOIN_ASSOCIATE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that changes a join based on the associativity rule, ((a JOIN b) JOIN c) → (a JOIN (b JOIN c)).
- JOIN_COMMUTE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that permutes the inputs to an inner
Join
. - JOIN_COMMUTE_OUTER - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.JOIN_COMMUTE
but swaps outer joins as well as inner joins. - JOIN_CONDITION_PUSH - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that pushes predicates in a Join into the inputs to the join.
- JOIN_DERIVE_IS_NOT_NULL_FILTER_RULE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- JOIN_EXTRACT_FILTER - Static variable in class org.apache.calcite.rel.rules.CoreRules
- JOIN_LEFT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts a
Join
to empty if its left child is empty. - JOIN_LEFT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.SingleValuesOptimizationRules
- JOIN_LEFT_PROJECT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.SingleValuesOptimizationRules
- JOIN_LEFT_UNION_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- JOIN_ON_UNIQUE_TO_SEMI_JOIN - Static variable in class org.apache.calcite.rel.rules.CoreRules
- JOIN_PREDICATE - Static variable in class org.apache.calcite.rex.RexUtil.SubQueryFinder
-
Deprecated.
- JOIN_PROJECT_BOTH_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that matches a
LogicalJoin
whose inputs areLogicalProject
s, and pulls the project expressions up. - JOIN_PROJECT_BOTH_TRANSPOSE_INCLUDE_OUTER - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.JOIN_PROJECT_BOTH_TRANSPOSE
but match outer as well as inner join. - JOIN_PROJECT_LEFT_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.JOIN_PROJECT_BOTH_TRANSPOSE
but only the left input is aLogicalProject
. - JOIN_PROJECT_LEFT_TRANSPOSE_INCLUDE_OUTER - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.JOIN_PROJECT_LEFT_TRANSPOSE
but match outer as well as inner join. - JOIN_PROJECT_RIGHT_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.JOIN_PROJECT_BOTH_TRANSPOSE
but only the right input is aLogicalProject
. - JOIN_PROJECT_RIGHT_TRANSPOSE_INCLUDE_OUTER - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.JOIN_PROJECT_RIGHT_TRANSPOSE
but match outer as well as inner join. - JOIN_PUSH_EXPRESSIONS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that matches a
Join
and pushes down expressions on either side of "equal" conditions. - JOIN_PUSH_TRANSITIVE_PREDICATES - Static variable in class org.apache.calcite.rel.rules.CoreRules
- JOIN_REDUCE_EXPRESSIONS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that reduces constants inside a
Join
. - JOIN_RIGHT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts a
Join
to empty if its right child is empty. - JOIN_RIGHT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.SingleValuesOptimizationRules
- JOIN_RIGHT_PROJECT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.SingleValuesOptimizationRules
- JOIN_RIGHT_UNION_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- JOIN_SELECTOR_COMPACT_CODE_THRESHOLD - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Minimum numbers of fields in a Join result that will trigger the "compact code generation".
- JOIN_SUB_QUERY_TO_CORRELATE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that converts sub-queries from join expressions into
Correlate
instances. - JOIN_TO_CORRELATE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that converts a
LogicalJoin
into aLogicalCorrelate
. - JOIN_TO_MULTI_JOIN - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that flattens a tree of
LogicalJoin
s into a singleMultiJoin
with N inputs. - JOIN_TO_SEMI_JOIN - Static variable in class org.apache.calcite.rel.rules.CoreRules
- JoinAddRedundantSemiJoinRule - Class in org.apache.calcite.rel.rules
-
Rule to add a semi-join into a join.
- JoinAddRedundantSemiJoinRule(Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.JoinAddRedundantSemiJoinRule
-
Deprecated.
- JoinAddRedundantSemiJoinRule(JoinAddRedundantSemiJoinRule.Config) - Constructor for class org.apache.calcite.rel.rules.JoinAddRedundantSemiJoinRule
-
Creates a JoinAddRedundantSemiJoinRule.
- JoinAddRedundantSemiJoinRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- JoinAssociateRule - Class in org.apache.calcite.rel.rules
-
Planner rule that changes a join based on the associativity rule.
- JoinAssociateRule(JoinAssociateRule.Config) - Constructor for class org.apache.calcite.rel.rules.JoinAssociateRule
-
Creates a JoinAssociateRule.
- JoinAssociateRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.JoinAssociateRule
-
Deprecated.
- JoinAssociateRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- JoinCommuteRule - Class in org.apache.calcite.rel.rules
-
Planner rule that permutes the inputs to a
Join
. - JoinCommuteRule(Class<? extends Join>, RelFactories.ProjectFactory) - Constructor for class org.apache.calcite.rel.rules.JoinCommuteRule
-
Deprecated.
- JoinCommuteRule(Class<? extends Join>, RelFactories.ProjectFactory, boolean) - Constructor for class org.apache.calcite.rel.rules.JoinCommuteRule
-
Deprecated.
- JoinCommuteRule(Class<? extends Join>, RelBuilderFactory, boolean) - Constructor for class org.apache.calcite.rel.rules.JoinCommuteRule
-
Deprecated.
- JoinCommuteRule(JoinCommuteRule.Config) - Constructor for class org.apache.calcite.rel.rules.JoinCommuteRule
-
Creates a JoinCommuteRule.
- JoinCommuteRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- JoinConditionPushRule(RelFactories.FilterFactory, RelFactories.ProjectFactory, FilterJoinRule.Predicate) - Constructor for class org.apache.calcite.rel.rules.FilterJoinRule.JoinConditionPushRule
-
Deprecated.
- JoinConditionPushRule(FilterJoinRule.JoinConditionPushRule.JoinConditionPushRuleConfig) - Constructor for class org.apache.calcite.rel.rules.FilterJoinRule.JoinConditionPushRule
-
Creates a JoinConditionPushRule.
- JoinConditionPushRule(RelBuilderFactory, FilterJoinRule.Predicate) - Constructor for class org.apache.calcite.rel.rules.FilterJoinRule.JoinConditionPushRule
-
Deprecated.
- JoinConditionType - Enum in org.apache.calcite.sql
-
Enumerates the types of condition in a join expression.
- joinContext(SqlImplementor.Context, SqlImplementor.Context) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- JoinDeriveIsNotNullFilterRule - Class in org.apache.calcite.rel.rules
- JoinDeriveIsNotNullFilterRule(JoinDeriveIsNotNullFilterRule.Config) - Constructor for class org.apache.calcite.rel.rules.JoinDeriveIsNotNullFilterRule
- JoinDeriveIsNotNullFilterRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- JoinExtractFilterRule - Class in org.apache.calcite.rel.rules
- JoinExtractFilterRule(Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.JoinExtractFilterRule
-
Deprecated.
- JoinExtractFilterRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- joinFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- joinFieldRefCountsMap - Variable in class org.apache.calcite.rel.rules.MultiJoin
- joinInfo - Variable in class org.apache.calcite.rel.core.Join
- JoinInfo - Class in org.apache.calcite.rel.core
-
An analyzed join condition.
- JoinInfo(ImmutableIntList, ImmutableIntList, ImmutableList<RexNode>) - Constructor for class org.apache.calcite.rel.core.JoinInfo
-
Creates a JoinInfo.
- JoinNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
Join
. - JoinNode(Compiler, Join) - Constructor for class org.apache.calcite.interpreter.JoinNode
- JoinOnUniqueToSemiJoinRule(SemiJoinRule.JoinOnUniqueToSemiJoinRule.JoinOnUniqueToSemiJoinRuleConfig) - Constructor for class org.apache.calcite.rel.rules.SemiJoinRule.JoinOnUniqueToSemiJoinRule
-
Creates a JoinOnUniqueToSemiJoinRule.
- JoinProjectTransposeRule - Class in org.apache.calcite.rel.rules
-
Planner rule that matches a
Join
one of whose inputs is aLogicalProject
, and pulls the project up. - JoinProjectTransposeRule(RelOptRuleOperand, String) - Constructor for class org.apache.calcite.rel.rules.JoinProjectTransposeRule
-
Deprecated.
- JoinProjectTransposeRule(RelOptRuleOperand, String, boolean, RelFactories.ProjectFactory) - Constructor for class org.apache.calcite.rel.rules.JoinProjectTransposeRule
-
Deprecated.
- JoinProjectTransposeRule(RelOptRuleOperand, String, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.JoinProjectTransposeRule
-
Deprecated.
- JoinProjectTransposeRule(RelOptRuleOperand, String, RelFactories.ProjectFactory) - Constructor for class org.apache.calcite.rel.rules.JoinProjectTransposeRule
-
Deprecated.
- JoinProjectTransposeRule(JoinProjectTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.JoinProjectTransposeRule
-
Creates a JoinProjectTransposeRule.
- JoinProjectTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- JoinPushExpressionsRule - Class in org.apache.calcite.rel.rules
-
Planner rule that pushes down expressions in "equal" join condition.
- JoinPushExpressionsRule(Class<? extends Join>, RelFactories.ProjectFactory) - Constructor for class org.apache.calcite.rel.rules.JoinPushExpressionsRule
-
Deprecated.
- JoinPushExpressionsRule(Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.JoinPushExpressionsRule
-
Deprecated.
- JoinPushExpressionsRule(JoinPushExpressionsRule.Config) - Constructor for class org.apache.calcite.rel.rules.JoinPushExpressionsRule
-
Creates a JoinPushExpressionsRule.
- JoinPushExpressionsRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- JoinPushThroughJoinRule - Class in org.apache.calcite.rel.rules
-
Rule that pushes the right input of a join into through the left input of the join, provided that the left input is also a join.
- JoinPushThroughJoinRule(String, boolean, Class<? extends Join>, RelFactories.ProjectFactory) - Constructor for class org.apache.calcite.rel.rules.JoinPushThroughJoinRule
-
Deprecated.
- JoinPushThroughJoinRule(String, boolean, Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.JoinPushThroughJoinRule
-
Deprecated.
- JoinPushThroughJoinRule(JoinPushThroughJoinRule.Config) - Constructor for class org.apache.calcite.rel.rules.JoinPushThroughJoinRule
-
Creates a JoinPushThroughJoinRule.
- JoinPushThroughJoinRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- JoinPushTransitivePredicatesRule - Class in org.apache.calcite.rel.rules
- JoinPushTransitivePredicatesRule(Class<? extends Join>, RelFactories.FilterFactory) - Constructor for class org.apache.calcite.rel.rules.JoinPushTransitivePredicatesRule
-
Deprecated.
- JoinPushTransitivePredicatesRule(Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.JoinPushTransitivePredicatesRule
-
Deprecated.
- JoinPushTransitivePredicatesRule(JoinPushTransitivePredicatesRule.Config) - Constructor for class org.apache.calcite.rel.rules.JoinPushTransitivePredicatesRule
-
Creates a JoinPushTransitivePredicatesRule.
- JoinPushTransitivePredicatesRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- JoinReduceExpressionsRule(Class<? extends Join>, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.JoinReduceExpressionsRule
-
Deprecated.
- JoinReduceExpressionsRule(Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.JoinReduceExpressionsRule
-
Deprecated.
- JoinReduceExpressionsRule(ReduceExpressionsRule.JoinReduceExpressionsRule.JoinReduceExpressionsRuleConfig) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.JoinReduceExpressionsRule
-
Creates a JoinReduceExpressionsRule.
- JoinRelType - Enum in org.apache.calcite.rel.core
-
Enumeration of join types.
- joinRequiresCondition() - Method in interface org.apache.calcite.runtime.CalciteResource
- JoinScope - Class in org.apache.calcite.sql.validate
-
The name-resolution context for expression inside a JOIN clause.
- JoinToCorrelateRule - Class in org.apache.calcite.rel.rules
-
Rule that converts a
Join
into aLogicalCorrelate
, which can then be implemented using nested loops. - JoinToCorrelateRule(RelFactories.FilterFactory) - Constructor for class org.apache.calcite.rel.rules.JoinToCorrelateRule
-
Deprecated.
- JoinToCorrelateRule(JoinToCorrelateRule.Config) - Constructor for class org.apache.calcite.rel.rules.JoinToCorrelateRule
-
Creates a JoinToCorrelateRule.
- JoinToCorrelateRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.JoinToCorrelateRule
-
Deprecated.
- JoinToCorrelateRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- JoinToMultiJoinRule - Class in org.apache.calcite.rel.rules
-
Planner rule to flatten a tree of
LogicalJoin
s into a singleMultiJoin
with N inputs. - JoinToMultiJoinRule(Class<? extends Join>) - Constructor for class org.apache.calcite.rel.rules.JoinToMultiJoinRule
-
Deprecated.
- JoinToMultiJoinRule(Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.JoinToMultiJoinRule
-
Deprecated.
- JoinToMultiJoinRule(JoinToMultiJoinRule.Config) - Constructor for class org.apache.calcite.rel.rules.JoinToMultiJoinRule
-
Creates a JoinToMultiJoinRule.
- JoinToMultiJoinRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- JoinToSemiJoinRule(Class<Join>, Class<Aggregate>, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.SemiJoinRule.JoinToSemiJoinRule
-
Deprecated.
- JoinToSemiJoinRule(SemiJoinRule.JoinToSemiJoinRule.JoinToSemiJoinRuleConfig) - Constructor for class org.apache.calcite.rel.rules.SemiJoinRule.JoinToSemiJoinRule
-
Creates a JoinToSemiJoinRule.
- joinType - Variable in class org.apache.calcite.rel.core.Correlate
- joinType - Variable in class org.apache.calcite.rel.core.Join
-
Values must be of enumeration
JoinRelType
, except thatJoinRelType.RIGHT
is disallowed. - joinType - Variable in class org.apache.calcite.rel.mutable.MutableCorrelate
- joinType - Variable in class org.apache.calcite.rel.mutable.MutableJoin
- joinType(JoinRelType) - Static method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- JoinType - Enum in org.apache.calcite.linq4j
-
Enumeration of join types.
- JoinType - Enum in org.apache.calcite.sql
-
Enumerates the types of join.
- JoinUnionTransposeRule - Class in org.apache.calcite.rel.rules
- JoinUnionTransposeRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.JoinUnionTransposeRule
-
Deprecated.
- JoinUnionTransposeRule(JoinUnionTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.JoinUnionTransposeRule
-
Creates a JoinUnionTransposeRule.
- JoinUnionTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- JpsTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "jps" ("Java Virtual Machine Process Status Tool") command to list all java processes of a user.
- JSON - Enum constant in enum org.apache.calcite.adapter.redis.RedisDataFormat
-
Treat redis key and value as a json format And parse the json string to get the corresponding field content.
- JSON - Enum constant in enum org.apache.calcite.sql.SqlExplainFormat
-
Indicates that the plan should be output in JSON format.
- JSON_API_COMMON_SYNTAX - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_API_COMMON_SYNTAX_WITH_CACHE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_ARRAY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_ARRAY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_ARRAYAGG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
JSON_ARRAYAGG
aggregate function. - JSON_ARRAYAGG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_ARRAYAGG_ADD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_DEPTH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_DEPTH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- JSON_DEPTH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Deprecated.
- JSON_EXISTS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_EXISTS2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_EXISTS3 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_INSERT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_INSERT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- JSON_INSERT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Deprecated.
- JSON_KEYS - Enum constant in enum org.apache.calcite.runtime.SqlFunctions.JsonScope
- JSON_KEYS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_KEYS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- JSON_KEYS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Deprecated.
- JSON_KEYS_AND_VALUES - Enum constant in enum org.apache.calcite.runtime.SqlFunctions.JsonScope
- JSON_LENGTH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_LENGTH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- JSON_LENGTH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Deprecated.
- JSON_OBJECT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_OBJECT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_OBJECTAGG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
JSON_OBJECTAGG
aggregate function. - JSON_OBJECTAGG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_OBJECTAGG_ADD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_PRETTY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_PRETTY - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- JSON_PRETTY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Deprecated.
- JSON_QUERY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_REMOVE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_REMOVE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- JSON_REMOVE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Deprecated.
- JSON_REPLACE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_REPLACE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- JSON_REPLACE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Deprecated.
- JSON_SET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_SET - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- JSON_SET - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Deprecated.
- JSON_STORAGE_SIZE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_STORAGE_SIZE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- JSON_STORAGE_SIZE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Deprecated.
- JSON_TYPE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
JSON
type function. - JSON_TYPE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_TYPE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- JSON_TYPE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Deprecated.
- JSON_TYPE_OPERATOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_VALUE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_VALUE_EXPRESSION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
JSON
value expression. - JSON_VALUE_EXPRESSION - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JSON_VALUE_EXPRESSION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_VALUES - Enum constant in enum org.apache.calcite.runtime.SqlFunctions.JsonScope
- jsonApiCommonSyntax(String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonApiCommonSyntax(String, String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonApiCommonSyntax(JsonFunctions.JsonValueContext) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonApiCommonSyntax(JsonFunctions.JsonValueContext, String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonApiCommonSyntaxWithCache(String, String) - Method in class org.apache.calcite.runtime.JsonFunctions.StatefulFunction
- jsonArray(SqlJsonConstructorNullClause, Object...) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonArrayAggAdd(List, Object, SqlJsonConstructorNullClause) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonBuilder - Variable in class org.apache.calcite.rel.externalize.RelJsonWriter
- JsonBuilder - Class in org.apache.calcite.util
- JsonBuilder() - Constructor for class org.apache.calcite.util.JsonBuilder
- JsonColumn - Class in org.apache.calcite.model
-
JSON object representing a column.
- JsonColumn(String) - Constructor for class org.apache.calcite.model.JsonColumn
- JsonCustomSchema - Class in org.apache.calcite.model
-
JSON schema element that represents a custom schema.
- JsonCustomSchema(String, List<Object>, Boolean, Boolean, String, Map<String, Object>) - Constructor for class org.apache.calcite.model.JsonCustomSchema
- JsonCustomTable - Class in org.apache.calcite.model
-
Custom table schema element.
- JsonCustomTable(String, JsonStream, String, Map<String, Object>) - Constructor for class org.apache.calcite.model.JsonCustomTable
- jsonDepth(String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonDepth(JsonFunctions.JsonValueContext) - Static method in class org.apache.calcite.runtime.JsonFunctions
- JsonEnumerator - Class in org.apache.calcite.adapter.file
-
Enumerator that reads from a Object List.
- JsonEnumerator(List<? extends Object>) - Constructor for class org.apache.calcite.adapter.file.JsonEnumerator
- jsonExists(String, String) - Method in class org.apache.calcite.runtime.JsonFunctions.StatefulFunction
- jsonExists(String, String, SqlJsonExistsErrorBehavior) - Method in class org.apache.calcite.runtime.JsonFunctions.StatefulFunction
- jsonExists(JsonFunctions.JsonPathContext) - Method in class org.apache.calcite.runtime.JsonFunctions.StatefulFunction
- jsonExists(JsonFunctions.JsonPathContext, SqlJsonExistsErrorBehavior) - Method in class org.apache.calcite.runtime.JsonFunctions.StatefulFunction
- jsonExists(JsonFunctions.JsonValueContext, String) - Method in class org.apache.calcite.runtime.JsonFunctions.StatefulFunction
- jsonExists(JsonFunctions.JsonValueContext, String, SqlJsonExistsErrorBehavior) - Method in class org.apache.calcite.runtime.JsonFunctions.StatefulFunction
- JsonFunction - Class in org.apache.calcite.model
-
Function schema element.
- JsonFunction(String, String, String, List<String>) - Constructor for class org.apache.calcite.model.JsonFunction
- JsonFunctions - Class in org.apache.calcite.runtime
-
A collection of functions used in JSON processing.
- JsonFunctions.JsonModifyMode - Enum in org.apache.calcite.runtime
-
Used in the JsonModify function.
- JsonFunctions.JsonPathContext - Class in org.apache.calcite.runtime
-
Returned path context of JsonApiCommonSyntax, public for testing.
- JsonFunctions.JsonValueContext - Class in org.apache.calcite.runtime
-
The Java output of
SqlJsonValueExpressionOperator
. - JsonFunctions.PathMode - Enum in org.apache.calcite.runtime
-
Path spec has two different modes: lax mode and strict mode.
- JsonFunctions.StatefulFunction - Class in org.apache.calcite.runtime
-
State for
JSON_EXISTS
,JSON_VALUE
,JSON_QUERY
. - jsonInsert(String, Object...) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonInsert(JsonFunctions.JsonValueContext, Object...) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonize(Object) - Static method in class org.apache.calcite.runtime.JsonFunctions
- JSONIZE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- JsonJdbcSchema - Class in org.apache.calcite.model
-
JSON object representing a schema that maps to a JDBC database.
- JsonJdbcSchema(String, List<Object>, Boolean, Boolean, String, String, String, String, String, String, String) - Constructor for class org.apache.calcite.model.JsonJdbcSchema
- jsonKeys(String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonKeys(String, String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonKeys(JsonFunctions.JsonPathContext) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonKeys(JsonFunctions.JsonValueContext) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonKeys(JsonFunctions.JsonValueContext, String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- JsonLattice - Class in org.apache.calcite.model
-
Element that describes a star schema and provides a framework for defining, recognizing, and recommending materialized views at various levels of aggregation.
- JsonLattice(String, Object, Boolean, Boolean, Long, Double, String, List<JsonMeasure>) - Constructor for class org.apache.calcite.model.JsonLattice
- jsonLength(String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonLength(String, String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonLength(JsonFunctions.JsonPathContext) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonLength(JsonFunctions.JsonValueContext) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonLength(JsonFunctions.JsonValueContext, String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- JsonMapSchema - Class in org.apache.calcite.model
-
JSON object representing a schema whose tables are explicitly specified.
- JsonMapSchema(String, List<Object>, Boolean, Boolean) - Constructor for class org.apache.calcite.model.JsonMapSchema
- JsonMaterialization - Class in org.apache.calcite.model
-
Element that describes how a table is a materialization of a query.
- JsonMaterialization(String, String, Object, List<String>) - Constructor for class org.apache.calcite.model.JsonMaterialization
- JsonMeasure - Class in org.apache.calcite.model
-
An aggregate function applied to a column (or columns) of a lattice.
- JsonMeasure(String, Object) - Constructor for class org.apache.calcite.model.JsonMeasure
- jsonObject(SqlJsonConstructorNullClause, Object...) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonObjectAggAdd(Map, String, Object, SqlJsonConstructorNullClause) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonPretty(String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonPretty(JsonFunctions.JsonValueContext) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonQuery(String, String, SqlJsonQueryWrapperBehavior, SqlJsonQueryEmptyOrErrorBehavior, SqlJsonQueryEmptyOrErrorBehavior, boolean) - Method in class org.apache.calcite.runtime.JsonFunctions.StatefulFunction
- jsonQuery(JsonFunctions.JsonPathContext, SqlJsonQueryWrapperBehavior, SqlJsonQueryEmptyOrErrorBehavior, SqlJsonQueryEmptyOrErrorBehavior, boolean) - Method in class org.apache.calcite.runtime.JsonFunctions.StatefulFunction
- jsonQuery(JsonFunctions.JsonValueContext, String, SqlJsonQueryWrapperBehavior, SqlJsonQueryEmptyOrErrorBehavior, SqlJsonQueryEmptyOrErrorBehavior, boolean) - Method in class org.apache.calcite.runtime.JsonFunctions.StatefulFunction
- jsonRemove(String, String...) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonRemove(JsonFunctions.JsonValueContext, String...) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonReplace(String, Object...) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonReplace(JsonFunctions.JsonValueContext, Object...) - Static method in class org.apache.calcite.runtime.JsonFunctions
- JsonRoot - Class in org.apache.calcite.model
-
Root schema element.
- JsonRoot(String, String) - Constructor for class org.apache.calcite.model.JsonRoot
- JsonScannableTable - Class in org.apache.calcite.adapter.file
-
Table based on a JSON file.
- JsonScannableTable(Source) - Constructor for class org.apache.calcite.adapter.file.JsonScannableTable
-
Creates a JsonScannableTable.
- JsonSchema - Class in org.apache.calcite.model
-
Schema schema element.
- JsonSchema(String, List<Object>, Boolean, Boolean) - Constructor for class org.apache.calcite.model.JsonSchema
- JsonSchema.Type - Enum in org.apache.calcite.model
-
Built-in schema types.
- jsonSet(String, Object...) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonSet(JsonFunctions.JsonValueContext, Object...) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonStorageSize(String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonStorageSize(JsonFunctions.JsonValueContext) - Static method in class org.apache.calcite.runtime.JsonFunctions
- JsonStream - Class in org.apache.calcite.model
-
Information about whether a table allows streaming.
- JsonStream(Boolean, Boolean) - Constructor for class org.apache.calcite.model.JsonStream
- JsonTable - Class in org.apache.calcite.adapter.file
-
Table based on a JSON file.
- JsonTable - Class in org.apache.calcite.model
-
Table schema element.
- JsonTable(String, JsonStream) - Constructor for class org.apache.calcite.model.JsonTable
- JsonTable(Source) - Constructor for class org.apache.calcite.adapter.file.JsonTable
- JsonTile - Class in org.apache.calcite.model
-
Materialized view within a
JsonLattice
. - JsonTile(List<JsonMeasure>) - Constructor for class org.apache.calcite.model.JsonTile
- jsonType(String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- jsonType(JsonFunctions.JsonValueContext) - Static method in class org.apache.calcite.runtime.JsonFunctions
- JsonType - Class in org.apache.calcite.model
-
Type schema element.
- JsonType(String, String) - Constructor for class org.apache.calcite.model.JsonType
- JsonTypeAttribute - Class in org.apache.calcite.model
-
JSON object representing a type attribute.
- JsonTypeAttribute(String, String) - Constructor for class org.apache.calcite.model.JsonTypeAttribute
- jsonValue(String, String, SqlJsonValueEmptyOrErrorBehavior, Object, SqlJsonValueEmptyOrErrorBehavior, Object) - Method in class org.apache.calcite.runtime.JsonFunctions.StatefulFunction
- jsonValue(JsonFunctions.JsonPathContext, SqlJsonValueEmptyOrErrorBehavior, Object, SqlJsonValueEmptyOrErrorBehavior, Object) - Method in class org.apache.calcite.runtime.JsonFunctions.StatefulFunction
- jsonValue(JsonFunctions.JsonValueContext, String, SqlJsonValueEmptyOrErrorBehavior, Object, SqlJsonValueEmptyOrErrorBehavior, Object) - Method in class org.apache.calcite.runtime.JsonFunctions.StatefulFunction
- jsonValueExpression(String) - Static method in class org.apache.calcite.runtime.JsonFunctions
- JsonView - Class in org.apache.calcite.model
-
View schema element.
- JsonView(String, JsonStream, Object, List<String>, Boolean) - Constructor for class org.apache.calcite.model.JsonView
- JULIAN - Enum constant in enum org.apache.calcite.util.format.postgresql.DateCalendarEnum
K
- KafkaMessageEnumerator<K,
V> - Class in org.apache.calcite.adapter.kafka -
Enumerator to read data from
Consumer
, and converted into SQL rows withKafkaRowConverter
. - KafkaRowConverter<K,
V> - Interface in org.apache.calcite.adapter.kafka -
Interface to handle formatting between Kafka message and Calcite row.
- KafkaRowConverterImpl - Class in org.apache.calcite.adapter.kafka
-
Default implementation of
KafkaRowConverter
, both key and value are byte[]. - KafkaRowConverterImpl() - Constructor for class org.apache.calcite.adapter.kafka.KafkaRowConverterImpl
- KafkaStreamTable - Class in org.apache.calcite.adapter.kafka
-
A table that maps to an Apache Kafka topic.
- KafkaTableFactory - Class in org.apache.calcite.adapter.kafka
-
Implementation of
TableFactory
for Apache Kafka. - KafkaTableFactory() - Constructor for class org.apache.calcite.adapter.kafka.KafkaTableFactory
- KafkaTableOptions - Class in org.apache.calcite.adapter.kafka
-
Available options for
KafkaStreamTable
. - KafkaTableOptions() - Constructor for class org.apache.calcite.adapter.kafka.KafkaTableOptions
- keepsOrdering(Mappings.TargetMapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Returns whether a mapping keeps order.
- keepSourceTypeAndTargetNullability(RelDataType, RelDataType, RelDataTypeFactory) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Creates a RelDataType having the same type of the sourceRelDataType, and the same nullability as the targetRelDataType.
- key() - Method in interface org.apache.calcite.adapter.enumerable.AggResultContext
-
Expression by which to reference the key upon which the values in the accumulator were aggregated.
- key() - Method in class org.apache.calcite.adapter.enumerable.impl.AggResultContextImpl
- key() - Element in annotation type org.apache.calcite.adapter.java.Map
-
Key type.
- keyField(int) - Method in interface org.apache.calcite.adapter.enumerable.AggResultContext
-
Returns an expression that references the
i
th field of the key, cast to the appropriate type. - keyField(int) - Method in class org.apache.calcite.adapter.enumerable.impl.AggResultContextImpl
- keyIsNullable() - Element in annotation type org.apache.calcite.adapter.java.Map
-
Whether keys may be null.
- keyIsNullable() - Method in class org.apache.calcite.linq4j.tree.Types.MapType
-
Returns whether keys may be null.
- keyList - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- keyOrdinals() - Method in interface org.apache.calcite.adapter.enumerable.AggContext
-
Returns the ordinals of the input fields that make up the key.
- keyOrdinals() - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase.AggContextImpl
- keyRelTypes() - Method in interface org.apache.calcite.adapter.enumerable.AggContext
-
Returns the types of the group key as
RelDataType
. - keyRelTypes() - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase.AggContextImpl
- keys - Variable in class org.apache.calcite.rel.core.Window.Group
- keys() - Method in class org.apache.calcite.rel.core.JoinInfo
- keysContainCollationsOrderless(List<Integer>, List<RelCollation>) - Static method in class org.apache.calcite.rel.RelCollations
-
Returns whether one of a list of collations is contained by the given list of keys regardless the order.
- keySet() - Method in class org.apache.calcite.util.CompositeMap
- keyTypes() - Method in interface org.apache.calcite.adapter.enumerable.AggContext
-
Returns the types of the group key as
Type
. - keyTypes() - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase.AggContextImpl
- keyword(String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- keyword(String) - Method in interface org.apache.calcite.sql.SqlWriter
-
Prints a sequence of keywords.
- KEYWORD - Enum constant in enum org.apache.calcite.sql.validate.SqlMonikerType
- keywords(String) - Static method in class org.apache.calcite.sql.parser.SqlParserTest
- keywordsLowerCase() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether to print keywords (SELECT, AS, etc.) in lower-case.
- kind - Variable in class org.apache.calcite.linq4j.tree.GotoStatement
- kind - Variable in class org.apache.calcite.rel.core.SetOp
- kind - Variable in class org.apache.calcite.rel.RelRoot
- kind - Variable in class org.apache.calcite.sql.SqlOperator
-
See
SqlKind
. - kind - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- kind() - Method in class org.apache.calcite.jdbc.CalcitePrepare.ParseResult
-
Returns the kind of statement.
- kind(StructKind) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
- kind(StructKind) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- KV_LIST - Enum constant in enum org.apache.calcite.sql.SqlHint.HintOptionFormat
-
The hint options are list of key-value pairs.
- kvOptions - Variable in class org.apache.calcite.rel.hint.RelHint
L
- label() - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a LabelTarget representing a label with X type and no name.
- label(Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a LabelTarget representing a label with the given type.
- label(Type, String) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a LabelTarget representing a label with the given type and name.
- label(String) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a LabelTarget representing a label with X type and the given name.
- label(LabelTarget) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a LabelExpression representing a label without a default value.
- label(LabelTarget, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a LabelExpression representing a label with the given default value.
- Label - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A label.
- LabelStatement - Class in org.apache.calcite.linq4j.tree
-
Represents a label, which can be put in any
Expression
context. - LabelStatement(Expression, ExpressionType) - Constructor for class org.apache.calcite.linq4j.tree.LabelStatement
- labelTarget - Variable in class org.apache.calcite.linq4j.tree.GotoStatement
- LabelTarget - Class in org.apache.calcite.linq4j.tree
-
Used to represent the target of a
GotoStatement
. - LabelTarget(String) - Constructor for class org.apache.calcite.linq4j.tree.LabelTarget
- LAG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
LAG
aggregate function. - LAG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
LAG
aggregate function. - LagImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.LagImplementor
- lambda(F) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a FunctionExpression from an actual function.
- lambda(Class<F>, BlockStatement, Iterable<? extends ParameterExpression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a LambdaExpression by first constructing a delegate type.
- lambda(Class<F>, BlockStatement, ParameterExpression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a LambdaExpression by first constructing a delegate type, using varargs.
- lambda(Class<F>, Expression, Iterable<? extends ParameterExpression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a LambdaExpression by first constructing a delegate type.
- lambda(Class<F>, Expression, ParameterExpression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a LambdaExpression by first constructing a delegate type, using varargs.
- lambda(BlockStatement, Iterable<? extends ParameterExpression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a LambdaExpression by first constructing a delegate type.
- lambda(BlockStatement, ParameterExpression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a LambdaExpression by first constructing a delegate type, using varargs.
- lambda(Expression, Iterable<? extends ParameterExpression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an Expression where the delegate type
F
is known at compile time. - lambda(Expression, ParameterExpression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an Expression where the delegate type
F
is known at compile time, using varargs. - Lambda - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A lambda expression, such as
a -> a + a
in Java. - LAMBDA - Enum constant in enum org.apache.calcite.sql.SqlKind
-
LAMBDA
expression. - LAMBDA_REF - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Reference to lambda expression parameter.
- LambdaExpression - Class in org.apache.calcite.linq4j.tree
-
Describes a lambda expression.
- LambdaExpression(ExpressionType, Class) - Constructor for class org.apache.calcite.linq4j.tree.LambdaExpression
- LambdaNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for
lambda expression
. - LARGEST_INT_OR_FIRST_NON_NULL - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Chooses a type to return.
- last() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- last() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the last element of a sequence.
- last(boolean) - Method in enum org.apache.calcite.config.NullCollation
-
Returns whether NULL values should appear last.
- last(List<E>) - Static method in class org.apache.calcite.util.Util
-
Returns the last element of a list.
- last(List<E>, int) - Static method in class org.apache.calcite.util.Util
-
Returns the last
n
elements of a list. - last(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the last element of a sequence.
- last(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the last element of a sequence that satisfies a specified condition.
- last(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- last(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the last element of a sequence that satisfies a specified condition.
- last(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the last element in a sequence.
- last(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the last element in a sequence.
- last(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- last(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the last element of a sequence that satisfies a specified condition.
- last(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the last element of a sequence that satisfies a specified condition.
- last(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- last(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- last(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns the last element of a sequence that satisfies a specified condition.
- LAST - Enum constant in enum org.apache.calcite.config.NullCollation
-
Nulls last for DESC and ASC.
- LAST - Enum constant in enum org.apache.calcite.rel.RelFieldCollation.NullDirection
- LAST - Enum constant in enum org.apache.calcite.sql.SqlKind
-
LAST
operator inMATCH_RECOGNIZE
. - LAST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
LAST
function to be used withinMATCH_RECOGNIZE
. - LAST_DAY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LAST_DAY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
LAST_DAY(date)
function. - LAST_VALUE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
LAST_VALUE
aggregate function. - LAST_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
LAST_VALUE
aggregate function. - lastIndexOf(int) - Method in class org.apache.calcite.util.ImmutableIntList
- lastIndexOf(Object) - Method in class org.apache.calcite.runtime.ConsList
- lastIndexOf(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat1List
- lastIndexOf(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat2List
- lastIndexOf(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat3List
- lastIndexOf(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat4List
- lastIndexOf(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat5List
- lastIndexOf(Object) - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- lastIndexOf(Object) - Method in class org.apache.calcite.sql.SqlNodeList
- lastIndexOf(Object) - Method in class org.apache.calcite.util.ImmutableIntList
- lastOperandTypeName - Variable in class org.apache.calcite.sql.type.SameOperandTypeExceptLastOperandChecker
- lastOrDefault() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- lastOrDefault() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the last element of a sequence, or a default value if the sequence contains no elements.
- lastOrDefault(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the last element of a sequence, or a default value if the sequence contains no elements.
- lastOrDefault(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the last element of a sequence that satisfies a condition or a default value if no such element is found.
- lastOrDefault(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- lastOrDefault(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the last element of a sequence that satisfies a condition or a default value if no such element is found.
- lastOrDefault(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the last element in a sequence, or a default value if the sequence contains no elements.
- lastOrDefault(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the last element in a sequence, or a default value if the sequence contains no elements.
- lastOrDefault(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- lastOrDefault(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the last element of a sequence that satisfies a condition or a default value if no such element is found.
- lastOrDefault(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the last element of a sequence that satisfies a condition or a default value if no such element is found.
- lastOrDefault(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- lastOrDefault(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- lastOrDefault(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns the last element of a sequence that satisfies a condition or a default value if no such element is found.
- lastWithSymbol(String, List<E>, List<String>, int) - Static method in class org.apache.calcite.adapter.enumerable.MatchUtils
-
Returns the row with the highest index whose corresponding symbol matches, null otherwise.
- LATERAL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The "LATERAL" qualifier to relations in the FROM clause.
- LATERAL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
LATERAL
operator. - latitude - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Coordinate
- lattice - Variable in class org.apache.calcite.materialize.Lattice.SqlWriter
- lattice - Variable in class org.apache.calcite.materialize.TileKey
- lattice - Variable in class org.apache.calcite.plan.RelOptLattice
- lattice - Variable in class org.apache.calcite.schema.impl.StarTable
- Lattice - Class in org.apache.calcite.materialize
-
Structure that allows materialized views based upon a star schema to be recognized and recommended.
- Lattice.BaseColumn - Class in org.apache.calcite.materialize
-
Column in a lattice.
- Lattice.Builder - Class in org.apache.calcite.materialize
-
Lattice builder.
- Lattice.Column - Class in org.apache.calcite.materialize
-
Column in a lattice.
- Lattice.DerivedColumn - Class in org.apache.calcite.materialize
-
Column in a lattice that is based upon a SQL expression.
- Lattice.Measure - Class in org.apache.calcite.materialize
-
A measure within a
Lattice
. - Lattice.SqlWriter - Class in org.apache.calcite.materialize
-
The information necessary to convert a column to SQL.
- Lattice.Tile - Class in org.apache.calcite.materialize
-
Materialized aggregate within a lattice.
- Lattice.TileBuilder - Class in org.apache.calcite.materialize
-
Tile builder.
- LatticeChildNode - Class in org.apache.calcite.materialize
-
Non-root node in a
Lattice
. - LatticeEntry(CalciteSchema, String) - Constructor for class org.apache.calcite.jdbc.CalciteSchema.LatticeEntry
- LatticeEntryImpl(CalciteSchema, String, Lattice) - Constructor for class org.apache.calcite.jdbc.CalciteSchema.LatticeEntryImpl
-
Creates a LatticeEntryImpl.
- latticeMap - Variable in class org.apache.calcite.jdbc.CalciteSchema
- LatticeNode - Class in org.apache.calcite.materialize
-
Source relation of a lattice.
- LatticeRootNode - Class in org.apache.calcite.materialize
-
Root node in a
Lattice
. - lattices - Variable in class org.apache.calcite.model.JsonSchema
- Lattices - Class in org.apache.calcite.materialize
-
Utilities for
Lattice
,LatticeStatisticProvider
. - LatticeStatisticProvider - Interface in org.apache.calcite.materialize
-
Estimates row counts for a lattice and its attributes.
- LatticeStatisticProvider.Factory - Interface in org.apache.calcite.materialize
-
Creates a
LatticeStatisticProvider
for a givenLattice
. - LatticeSuggester - Class in org.apache.calcite.materialize
-
Algorithm that suggests a set of lattices.
- LatticeSuggester(FrameworkConfig) - Constructor for class org.apache.calcite.materialize.LatticeSuggester
-
Creates a LatticeSuggester.
- LatticeTable - Class in org.apache.calcite.materialize
-
Table registered in the graph.
- lax() - Method in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Removes strictness.
- LAX - Enum constant in enum org.apache.calcite.runtime.JsonFunctions.PathMode
- LAZY - Enum constant in enum org.apache.calcite.rel.core.Spool.Type
- LAZY_AGGREGATE_LAMBDA_FACTORY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LAZY_COLLECTION_SPOOL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LazyAggregateLambdaFactory<TSource,
TKey, TOrigAccumulate, TResult> - Class in org.apache.calcite.adapter.enumerable -
Generate aggregate lambdas that preserve the input source before calling each aggregate adder, this implementation is generally used when we need to sort the input before performing aggregation.
- LazyAggregateLambdaFactory(Function0<TOrigAccumulate>, List<LazyAggregateLambdaFactory.LazyAccumulator<TOrigAccumulate, TSource>>) - Constructor for class org.apache.calcite.adapter.enumerable.LazyAggregateLambdaFactory
- LazyAggregateLambdaFactory.LazyAccumulator<TOrigAccumulate,
TSource> - Interface in org.apache.calcite.adapter.enumerable -
Accumulate on the cached input sources.
- LazyAggregateLambdaFactory.LazySource<TSource> - Class in org.apache.calcite.adapter.enumerable
-
Cache the input sources.
- lazyCollectionSpool(Collection<TSource>, Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Lazy read and lazy write spool that stores data into a collection.
- LazySource() - Constructor for class org.apache.calcite.adapter.enumerable.LazyAggregateLambdaFactory.LazySource
- le(boolean, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≤
operator applied to boolean values. - le(Object[], Object[]) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≤
operator applied to Object[] values. - le(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≤
operator applied to String values. - le(String, String, Comparator<String>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≤
operator applied to String values. - le(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≤
operator applied to BigDecimal values. - le(List<?>, List<?>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≤
operator applied to List values. - le(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≤
operator applied to ByteString values. - le(RexNode, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- LEAD - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
LEAD
aggregate function. - LEAD - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
LEAD
aggregate function. - LeadImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.LeadImplementor
- LEADING - Enum constant in enum org.apache.calcite.sql.fun.SqlTrimFunction.Flag
- leadingComma() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether commas in SELECT, GROUP BY and ORDER clauses should appear at the start of the line.
- Leaf(int, LoptJoinTree) - Constructor for class org.apache.calcite.rel.rules.LoptJoinTree.Leaf
- LEAF - Enum constant in enum org.apache.calcite.plan.RelOptRuleOperandChildPolicy
-
Signifies that operand has no children.
- leafToRanges(RexCall, boolean) - Static method in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
- leAny(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≤
operator applied to Object values (at least one operand has ANY type; neither may be null). - learnFinalStaticDeclarations(List<MemberDeclaration>) - Method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Processes the list of declarations when class expression detected.
- learnFinalStaticDeclarations(List<MemberDeclaration>) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Processes the list of declarations and learns final static ones as effectively constant.
- least(T, T) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
LEAST operator.
- LEAST - Enum constant in enum org.apache.calcite.sql.SqlKind
-
LEAST
function (Oracle). - LEAST - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
Deprecated.
- LEAST - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "LEAST(value, value)" function.
- LEAST_NULLABLE - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Type-inference strategy whereby the result is NOT NULL if any of the arguments is NOT NULL; otherwise the type is unchanged.
- LEAST_PG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
LEAST
function (PostgreSQL). - LEAST_PG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "GREATEST(value, value)" function.
- LEAST_RESTRICTIVE - Enum constant in enum org.apache.calcite.sql.type.SqlOperandTypeChecker.Consistency
-
Convert all arguments to the least restrictive type.
- LEAST_RESTRICTIVE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is using its operands biggest type, using the SQL:1999 rules described in "Data types of results of aggregations".
- leastRestrictive(List<RelDataType>) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Returns the most general of a set of types using the default type mapping rule.
- leastRestrictive(List<RelDataType>, SqlTypeMappingRule) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Returns the most general of a set of types (that is, one type to which they can all be cast), or null if conversion is not possible.
- leastRestrictive(List<RelDataType>, SqlTypeMappingRule) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- leastRestrictive(List<RelDataType>, SqlTypeMappingRule) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- leastRestrictiveArrayMultisetType(List<RelDataType>, SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- leastRestrictiveForComparison(RelDataTypeFactory, RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns the least restrictive type T, such that a value of type T can be compared with values of type
type1
andtype2
using=
. - leastRestrictiveIntervalDatetimeType(RelDataType, RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- leastRestrictiveMapType(List<RelDataType>, SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- leastRestrictiveStructuredType(List<RelDataType>) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- leaves - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- left - Variable in class org.apache.calcite.rel.BiRel
- left - Variable in class org.apache.calcite.rel.mutable.MutableJoin
- left - Variable in class org.apache.calcite.util.Pair
- left(int) - Method in interface org.apache.calcite.runtime.PairList
-
Returns the left part of the
index
th pair. - left(Iterable<? extends Map.Entry<? extends L, ? extends R>>) - Static method in class org.apache.calcite.util.Pair
-
Returns an iterable over the left slice of an iterable.
- left(String, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL LEFT(string, integer) function.
- left(List<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class org.apache.calcite.util.Pair
- left(List<IntPair>) - Static method in class org.apache.calcite.util.mapping.IntPair
-
Returns the left side of a list of pairs.
- left(ByteString, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL LEFT(ByteString, integer) function.
- LEFT - Enum constant in enum org.apache.calcite.linq4j.JoinType
-
Left-outer join.
- LEFT - Enum constant in enum org.apache.calcite.rel.core.JoinRelType
-
Left-outer join.
- LEFT - Enum constant in enum org.apache.calcite.sql.JoinType
-
Left outer join.
- LEFT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LEFT - Static variable in interface org.apache.calcite.rel.rules.JoinProjectTransposeRule.Config
- LEFT - Static variable in interface org.apache.calcite.rel.rules.JoinPushThroughJoinRule.Config
- LEFT - Static variable in class org.apache.calcite.rel.rules.JoinPushThroughJoinRule
-
Instance of the rule that works on logical joins only, and pushes to the left.
- LEFT - Static variable in interface org.apache.calcite.rel.rules.JoinUnionTransposeRule.Config
- LEFT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- LEFT - Static variable in class org.apache.calcite.util.mapping.IntPair
-
Deprecated.
- LEFT_ANTI_JOIN - Enum constant in enum org.apache.calcite.sql.JoinType
-
Left anti join.
- LEFT_ASOF - Enum constant in enum org.apache.calcite.linq4j.JoinType
-
The left version of an ASOF join, where each row from the left table is part of the output.
- LEFT_ASOF - Enum constant in enum org.apache.calcite.rel.core.JoinRelType
-
The left version of an ASOF join, where each row from the left table is part of the output.
- LEFT_ASOF - Enum constant in enum org.apache.calcite.sql.JoinType
-
The left version of an ASOF join, where each row from the left table is part of the output.
- LEFT_FIRST - Enum constant in enum org.apache.calcite.plan.DeriveMode
-
Uses the left most child's traits to decide what traits to require from the other children.
- LEFT_OUTER - Static variable in interface org.apache.calcite.rel.rules.JoinProjectTransposeRule.Config
- LEFT_PROJECT - Static variable in interface org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule.Config
- LEFT_RIGHT - Static variable in class org.apache.calcite.adapter.enumerable.EnumUtils
- LEFT_SEMI_JOIN - Enum constant in enum org.apache.calcite.sql.JoinType
-
Left semi join.
- leftInferredPredicates - Variable in class org.apache.calcite.plan.RelOptPredicateList
-
Predicates that were inferred from the right input.
- leftKeys - Variable in class org.apache.calcite.rel.core.EquiJoin
-
Deprecated.
- leftKeys - Variable in class org.apache.calcite.rel.core.JoinInfo
- leftList() - Method in interface org.apache.calcite.runtime.PairList
-
Returns an unmodifiable list view consisting of the left entry of each pair.
- leftPrec(int, boolean) - Static method in class org.apache.calcite.sql.SqlOperator
- leftSet() - Method in class org.apache.calcite.rel.core.JoinInfo
- leftShift(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise left-shift operation.
- leftShift(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise left-shift operation.
- LeftShift - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise left-shift operation, such as
a << b
in Java. - leftShiftAssign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise left-shift assignment operation.
- leftShiftAssign(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise left-shift assignment operation.
- leftShiftAssign(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise left-shift assignment operation.
- LeftShiftAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise left-shift compound assignment, such as (a <<= b).
- LEN - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "LEN(string)" function.
- length() - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Returns the length (character count).
- length() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns the "logical size" of this
ImmutableBitSet
: the index of the highest set bit in theImmutableBitSet
plus one. - LENGTH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "LENGTH(string)" function.
- LENIENT - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that allows just about everything supported by Calcite.
- LENIENT_OPERATOR_LOOKUP - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether to make create implicit functions if functions do not exist in the operator table, default false.
- lenientInstance() - Static method in class org.apache.calcite.sql.type.SqlTypeCoercionRule
-
Returns an instance that allows more lenient type coercion.
- lenientOperatorLookup() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.LENIENT_OPERATOR_LOOKUP
. - lenientOperatorLookup() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- lenientOperatorLookup() - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Returns whether this validator should be lenient upon encountering an unknown function, default false.
- LESS_THAN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Less-than operator, "<".
- LESS_THAN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Logical less-than operator, '
<
'. - LESS_THAN_OR_EQUAL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Less-than-or-equal operator, "<=".
- LESS_THAN_OR_EQUAL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Logical less-than-or-equal operator, '
<=
'. - lesser(boolean, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lesser(byte, byte) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lesser(char, char) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lesser(double, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lesser(float, float) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lesser(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lesser(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lesser(short, short) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lesser(T, T) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper for implementing MIN.
- LESSER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- lessThan(E, E) - Method in interface org.apache.calcite.util.PartiallyOrderedSet.Ordering
-
Returns whether element e1 is ≤ e2 according to the relation that defines a partially-ordered set.
- lessThan(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a "less than" numeric comparison.
- lessThan(Expression, Expression, boolean, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a "less than" numeric comparison.
- lessThan(RexNode, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
<
. - lessThan(V) - Method in interface org.apache.calcite.util.RangeSets.Consumer
- lessThan(V) - Method in interface org.apache.calcite.util.RangeSets.Handler
- LessThan - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A "less than" comparison, such as (a < b).
- lessThanOrEqual(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a " less than or equal" numeric comparison.
- lessThanOrEqual(Expression, Expression, boolean, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a "less than or equal" numeric comparison.
- lessThanOrEqual(RexNode, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
<=
. - LessThanOrEqual - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A "less than or equal to" comparison, such as (a <= b).
- let(Function<RelBuilder, R>) - Method in class org.apache.calcite.tools.RelBuilder
-
Performs an action on this RelBuilder.
- let(Function<RelBuilder.OverCall, R>) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Performs an action on this OverCall.
- letIn(T, Runnable) - Method in class org.apache.calcite.util.TryThreadLocal
-
Performs an action with this ThreadLocal set to a particular value in this thread, and restores the previous value afterward.
- letIn(T, Supplier<R>) - Method in class org.apache.calcite.util.TryThreadLocal
-
Calls a Supplier with this ThreadLocal set to a particular value, in this thread, and restores the previous value afterward.
- levenshtein(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL LEVENSHTEIN(string1, string2) function.
- LEVENSHTEIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LEVENSHTEIN - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "LEVENSHTEIN(string1, string2)" function.
- lex() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.LEX
. - lex() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- Lex - Enum in org.apache.calcite.config
-
Named, built-in lexical policy.
- LEX - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Lexical policy.
- lg - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- li(int) - Static method in class org.apache.calcite.test.schemata.tpch.TpchSchema
- liberal() - Static method in class org.apache.calcite.sql.validate.SqlNameMatchers
-
Creates a name matcher that can suggest corrections to what the user typed.
- libraries() - Element in annotation type org.apache.calcite.sql.fun.LibraryOperator
-
The set of libraries that this function or operator belongs to.
- library - Variable in class org.apache.calcite.sql.ddl.SqlCreateForeignSchema
- LibraryOperator - Annotation Type in org.apache.calcite.sql.fun
-
An annotation that is read by
SqlLibraryOperatorTableFactory
to add functions and operators to a library. - like(boolean, boolean) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Returns the operator for
LIKE
with given case-sensitivity, optionally negated. - like(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.LikeFunction
-
SQL
LIKE
function. - like(String, String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.LikeFunction
-
SQL
LIKE
function with escape. - Like - Class in org.apache.calcite.runtime
-
Utilities for converting SQL
LIKE
andSIMILAR
operators to regular expressions. - LIKE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
LIKE
operator. - LIKE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LIKE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- LIKE_ESCAPE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LikeFunction() - Constructor for class org.apache.calcite.runtime.SqlFunctions.LikeFunction
- likeToRegex(Meta.Pat) - Static method in class org.apache.calcite.jdbc.CalciteMetaImpl
-
Converts a LIKE-style pattern (where '%' represents a wild-card, escaped using '\') to a Java regex.
- limit(int) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Sets a limit on the number of rows returned.
- limit(int, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a limit and/or offset without a sort.
- limit(RelMetadataQuery, RelNode) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Helper method to determine a limit's collation.
- limit(RelMetadataQuery, RelNode) - Static method in class org.apache.calcite.rel.metadata.RelMdDistribution
-
Helper method to determine a limit's distribution.
- LIMIT - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- LIMIT - Static variable in class org.apache.calcite.adapter.cassandra.CassandraRules
- LIMIT_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- LIMIT_MERGE - Static variable in interface org.apache.calcite.rel.rules.SortMergeRule.Config
- limitStartCountOrAllNotAllowed(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- LimitStmt(SqlParserPos, Ast.Identifier, Ast.Identifier, Ast.Literal) - Constructor for class org.apache.calcite.piglet.Ast.LimitStmt
- line() - Method in interface org.apache.calcite.util.Puffin.Line
-
Returns the text of the current line.
- LINE_SEPARATOR - Static variable in class org.apache.calcite.util.Util
-
System-dependent newline character.
- linear(int, int, int, double, double) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Returns a point on a line.
- lineColToIndex(String, int, int) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Finds the position (0-based) in a string which corresponds to a given line and column (1-based).
- lineFolding() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the line-folding policy for lists in the SELECT, GROUP BY and ORDER clauses, for items in the SET clause of UPDATE, and for items in VALUES.
- lineitem - Variable in class org.apache.calcite.test.schemata.tpch.TpchSchema
- LineItem(int) - Constructor for class org.apache.calcite.test.schemata.tpch.TpchSchema.LineItem
- lineLength() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the maximum line length.
- LineParser() - Constructor for class org.apache.calcite.adapter.os.PsTableFunction.LineParser
- lines(Iterable<String>) - Static method in class org.apache.calcite.util.Util
-
Converts a list of strings to a string separated by newlines.
- LINESTRING - Enum constant in enum org.apache.calcite.runtime.SpatialTypeUtils.SpatialType
- LINGER - Static variable in class org.apache.calcite.runtime.SocketFactoryImpl
-
Amount of time to linger.
- LINGUAL - Enum constant in enum org.apache.calcite.test.CalciteAssert.Config
-
Configuration that creates a connection with an in-memory data set similar to the smoke test in Cascading Lingual.
- LINGUAL - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- LingualEmp - Class in org.apache.calcite.test.schemata.lingual
-
Lingual emp model.
- LingualEmp(int, int) - Constructor for class org.apache.calcite.test.schemata.lingual.LingualEmp
- LingualSchema - Class in org.apache.calcite.test.schemata.lingual
-
Lingual schema.
- LingualSchema() - Constructor for class org.apache.calcite.test.schemata.lingual.LingualSchema
- link - Variable in class org.apache.calcite.materialize.LatticeChildNode
- Linq4j - Class in org.apache.calcite.linq4j
-
Utility and factory methods for Linq4j.
- list - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- list() - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an empty fluent list.
- list() - Method in class org.apache.calcite.sql.parser.SqlParserFixture
-
Creates an instance of helper class
SqlParserListFixture
to test parsing a list of statements. - list() - Method in class org.apache.calcite.util.JsonBuilder
-
Creates a JSON object (represented by a
List
). - list(Iterable<T>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a fluent list with elements from the given collection.
- list(SqlWriter.FrameTypeEnum, Consumer<SqlWriter>) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- list(SqlWriter.FrameTypeEnum, Consumer<SqlWriter>) - Method in interface org.apache.calcite.sql.SqlWriter
-
Writes a list.
- list(SqlWriter.FrameTypeEnum, SqlBinaryOperator, SqlNodeList) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- list(SqlWriter.FrameTypeEnum, SqlBinaryOperator, SqlNodeList) - Method in interface org.apache.calcite.sql.SqlWriter
- list(T...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a fluent list with given elements.
- LIST - Enum constant in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
-
A list that is comparable and immutable.
- LIST - Enum constant in enum org.apache.calcite.adapter.redis.RedisDataType
-
Redis Lists are simply lists of strings, sorted by insertion order.
- LIST - Enum constant in enum org.apache.calcite.runtime.SqlFunctions.FlatProductInputType
- LIST_CONTAINS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LIST_GET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LIST_N - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LIST_TO_ARRAY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LIST2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LIST3 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LIST4 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LIST5 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LIST6 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LISTAGG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
LISTAGG
aggregate function. - LISTAGG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The LISTAGG operator.
- listBind(Member, Iterable<? extends ElementInit>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberListBinding where the member is a field or property.
- listBind(Member, ElementInit...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberListBinding where the member is a field or property, using varargs.
- listBind(Method, Iterable<? extends ElementInit>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberListBinding based on a specified property accessor method.
- listBind(Method, ElementInit...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberListBinding object based on a specified property accessor method, using varargs.
- listInit(NewExpression, Iterable<? extends ElementInit>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ListInitExpression that uses specified ElementInit objects to initialize a collection.
- listInit(NewExpression, Method, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ListInitExpression that uses a specified method to add elements to a collection.
- listInit(NewExpression, Method, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ListInitExpression that uses a specified method to add elements to a collection, using varargs.
- listInit(NewExpression, ElementInit...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ListInitExpression that uses specified ElementInit objects to initialize a collection, using varargs.
- listInit(NewExpression, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ListInitExpression that uses a method named "Add" to add elements to a collection, using varargs.
- ListInit - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An operation that creates a new IEnumerable object and initializes it from a list of elements, such as new List<SampleType>(){ a, b, c } in C# or Dim sampleList = { a, b, c } in Visual Basic.
- listInitE(NewExpression, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ListInitExpression that uses a method named "Add" to add elements to a collection.
- ListInitExpression - Class in org.apache.calcite.linq4j.tree
-
Represents a constructor call that has a collection initializer.
- ListInitExpression(ExpressionType, Class) - Constructor for class org.apache.calcite.linq4j.tree.ListInitExpression
- listIterator() - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- listIterator() - Method in class org.apache.calcite.runtime.ConsList
- listIterator() - Method in class org.apache.calcite.sql.SqlNodeList
- listIterator() - Method in class org.apache.calcite.util.ImmutableIntList
- listIterator(int) - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- listIterator(int) - Method in class org.apache.calcite.runtime.ConsList
- listIterator(int) - Method in class org.apache.calcite.sql.SqlNodeList
- listIterator(int) - Method in class org.apache.calcite.util.ChunkList
- listIterator(int) - Method in class org.apache.calcite.util.ImmutableIntList
- listOf(List<RuleSet>) - Static method in class org.apache.calcite.tools.Programs
-
Creates a list of programs based on a list of rule sets.
- listOf(RuleSet...) - Static method in class org.apache.calcite.tools.Programs
-
Creates a list of programs based on an array of rule sets.
- listOptions - Variable in class org.apache.calcite.rel.hint.RelHint
- ListScope - Class in org.apache.calcite.sql.validate
-
Abstract base for a scope which is defined by a list of child namespaces and which inherits from a parent scope.
- ListScope(SqlValidatorScope) - Constructor for class org.apache.calcite.sql.validate.ListScope
- ListSqlOperatorTable - Class in org.apache.calcite.sql.util
-
Implementation of the
SqlOperatorTable
interface by using a list ofoperators
. - ListSqlOperatorTable() - Constructor for class org.apache.calcite.sql.util.ListSqlOperatorTable
-
Deprecated.Use
SqlOperatorTables.of(java.lang.Iterable<? extends org.apache.calcite.sql.SqlOperator>)
, which creates an immutable table. - ListSqlOperatorTable(List<SqlOperator>) - Constructor for class org.apache.calcite.sql.util.ListSqlOperatorTable
-
Deprecated.Use
SqlOperatorTables.of(java.lang.Iterable<? extends org.apache.calcite.sql.SqlOperator>)
, which creates an immutable table. - listToString(List<String>) - Static method in class org.apache.calcite.util.Util
-
Converts ["ab", "c"] to "ab"."c".
- ListTransientTable - Class in org.apache.calcite.schema.impl
-
TransientTable
backed by a Java list. - ListTransientTable(String, RelDataType) - Constructor for class org.apache.calcite.schema.impl.ListTransientTable
- literal(int) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- literal(Object) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a literal (constant expression).
- literal(Object, RelDataType) - Method in class org.apache.calcite.piglet.PigRelBuilder
- literal(String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- literal(String) - Method in interface org.apache.calcite.sql.SqlWriter
-
Prints a literal, exactly as provided.
- literal(String) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Appends a string literal to this buffer.
- literal(Timestamp) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Appends a timestamp literal to this buffer.
- Literal(SqlParserPos, Object) - Constructor for class org.apache.calcite.piglet.Ast.Literal
- LITERAL - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- LITERAL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
A literal.
- LITERAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy type must be a non-NULL literal.
- LITERAL_AGG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
LITERAL_AGG
aggregate function that always returns the same literal (even if the group is empty). - LITERAL_AGG - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
Aggregate function that always returns a given literal.
- LITERAL_CHAIN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Literal chain operator (for composite string literals).
- LITERAL_CHAIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- LITERAL_LIST - Enum constant in enum org.apache.calcite.sql.SqlHint.HintOptionFormat
-
The hint options are as literal list.
- LITERAL_OUT_OF_RANGE_MESSAGE - Static variable in interface org.apache.calcite.sql.test.SqlOperatorFixture
- literalAgg(Object) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
LITERAL_AGG
aggregate function. - LiteralCompiledItem - Class in org.apache.calcite.util.format.postgresql.format.compiled
-
A literal string in a date/time format.
- LiteralCompiledItem(String) - Constructor for class org.apache.calcite.util.format.postgresql.format.compiled.LiteralCompiledItem
- literalElement(String) - Static method in class org.apache.calcite.util.format.FormatModels
-
Creates a literal format element.
- literalEndQuoteString - Variable in class org.apache.calcite.sql.SqlDialect
- literalEscapedQuote - Variable in class org.apache.calcite.sql.SqlDialect
- literalEscapedQuoteString() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- LiteralOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Parameter type-checking strategy type must be a literal (whether null is allowed is determined by the constructor).
- LiteralOperandTypeChecker(boolean) - Constructor for class org.apache.calcite.sql.type.LiteralOperandTypeChecker
- literalQuoteString - Variable in class org.apache.calcite.sql.SqlDialect
- literalQuoteString() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- literalValue(RexNode) - Static method in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
-
Returns the literal value for the given node, assuming it is a literal with datetime type, or a cast that only alters nullability on top of a literal with datetime type.
- litmus - Variable in class org.apache.calcite.rex.RexChecker
- Litmus - Interface in org.apache.calcite.util
-
Callback to be called when a test for validity succeeds or fails.
- LN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
LN(numeric)
function. - load(String, RexNode, RelDataType) - Method in class org.apache.calcite.tools.PigRelBuilder
-
Loads a data set.
- LOAD - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- LoadStmt(SqlParserPos, Ast.Identifier, Ast.Literal) - Constructor for class org.apache.calcite.piglet.Ast.LoadStmt
- LOCAL - Enum constant in enum org.apache.calcite.sql.SqlDialect.CalendarPolicy
- LOCAL_REF - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Reference to a sub-expression computed within the current relational operator.
- LOCAL_TEMPORARY - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
A table that is only visible to one connection.
- LOCAL_TIME - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LOCAL_TIMESTAMP - Enum constant in enum org.apache.calcite.DataContext.Variable
-
The time at which the current statement started executing.
- LOCAL_TIMESTAMP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LOCAL_TZ - Static variable in class org.apache.calcite.test.SqlOperatorTest
- locale - Variable in class org.apache.calcite.sql.SqlCollation
- locale() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.LOCALE
. - locale() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- locale(DataContext) - Static method in class org.apache.calcite.runtime.SqlFunctions
- LOCALE - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Returns the locale from the connect string.
- LOCALE - Enum constant in enum org.apache.calcite.DataContext.Variable
-
Locale in which the current statement is executing.
- LOCALE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- localTime(DataContext) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LOCAL_TIME
function. - LOCALTIME - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
LOCALTIME [(precision)]
function. - localTimestamp(DataContext) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LOCAL_TIMESTAMP
function. - LOCALTIMESTAMP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
LOCALTIMESTAMP [(precision)]
function. - locateAllRefs() - Method in class org.apache.calcite.rel.rules.PushProjector
-
Locates all references found in either the projection expressions a filter, as well as references to expressions that should be preserved.
- location - Variable in class org.apache.calcite.test.schemata.hr.Department
- Location - Class in org.apache.calcite.test.schemata.hr
-
Location model.
- Location(int, int) - Constructor for class org.apache.calcite.test.schemata.hr.Location
- locations - Variable in class org.apache.calcite.test.schemata.hr.HrSchema
- LOCATOR_HOST - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeSchemaFactory
- LOCATOR_HOST - Static variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchemaFactory
- LOCATOR_PORT - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeSchemaFactory
- LOCATOR_PORT - Static variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchemaFactory
- log(double, double, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LOG(number, base)
function applied to double values. - log(double, BigDecimal, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LOG(number, base)
function applied to double and BigDecimal values. - log(BigDecimal, double, Boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LOG(number, base)
function applied to BigDecimal and double values. - log(BigDecimal, BigDecimal, Boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LOG(number, base)
function applied to double values. - LOG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
LOG
function. - LOG - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LOG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "LOG(value [, value2])" function.
- LOG_MYSQL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "LOG(numeric1 [, numeric2 ]) " function.
- LOG_POSTGRES - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "LOG(numeric1 [, numeric2 ]) " function.
- LOG10 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
LOG10(numeric)
function. - log1p(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LOG1P
operator applied to double values. - log1p(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LOG1P
operator applied to BigDecimal values. - LOG1P - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LOG1P - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "LOG1p(numeric)" function.
- LOG2 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "LOG2(numeric)" function.
- logFile - Variable in class org.apache.calcite.test.DiffTestCase
-
Name of current .log file.
- LOGGER - Static variable in class org.apache.calcite.adapter.cassandra.CassandraSchema
- LOGGER - Static variable in class org.apache.calcite.adapter.cassandra.CassandraSchemaFactory
- LOGGER - Static variable in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
- LOGGER - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- LOGGER - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- LOGGER - Static variable in class org.apache.calcite.adapter.geode.util.GeodeUtils
- LOGGER - Static variable in class org.apache.calcite.adapter.jdbc.JdbcRules
- LOGGER - Static variable in class org.apache.calcite.adapter.mongodb.MongoRules
- LOGGER - Static variable in interface org.apache.calcite.plan.RelOptPlanner
- LOGGER - Static variable in class org.apache.calcite.plan.RelOptRuleCall
- LOGGER - Static variable in class org.apache.calcite.prepare.Prepare
- LOGGER - Static variable in class org.apache.calcite.sql.advise.SqlAdvisor
- LOGGER - Static variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- LOGGER - Static variable in class org.apache.calcite.sql.SqlDialect
- LOGGER - Static variable in class org.apache.calcite.util.Benchmark
-
Certain tests are enabled only if logging is enabled at debug level or higher.
- LOGICAL - Enum constant in enum org.apache.calcite.sql.SqlExplain.Depth
- LOGICAL_AND - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "LOGICAL_AND(condition)" aggregate function, BigQuery's equivalent to
SqlStdOperatorTable.EVERY
. - LOGICAL_BUILDER - Static variable in class org.apache.calcite.rel.core.RelFactories
-
A
RelBuilderFactory
that creates aRelBuilder
that will create logical relational expressions for everything. - LOGICAL_OR - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "LOGICAL_OR(condition)" aggregate function, BigQuery's equivalent to
SqlStdOperatorTable.SOME
. - LogicalAggregate - Class in org.apache.calcite.rel.logical
-
LogicalAggregate
is a relational operator which eliminates duplicates and computes totals. - LogicalAggregate(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.rel.logical.LogicalAggregate
-
Creates a LogicalAggregate.
- LogicalAggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.rel.logical.LogicalAggregate
-
Deprecated.
- LogicalAggregate(RelOptCluster, RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.rel.logical.LogicalAggregate
-
Deprecated.
- LogicalAggregate(RelOptCluster, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.rel.logical.LogicalAggregate
-
Deprecated.
- LogicalAggregate(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalAggregate
-
Creates a LogicalAggregate by parsing serialized output.
- LogicalAsofJoin - Class in org.apache.calcite.rel.logical
-
Sub-class of
AsofJoin
encoding ASOF joins. - LogicalAsofJoin(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RelNode, RexNode, RexNode, JoinRelType, ImmutableList<RelDataTypeField>) - Constructor for class org.apache.calcite.rel.logical.LogicalAsofJoin
-
Creates a LogicalAsofJoin.
- LogicalAsofJoin(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalAsofJoin
-
Creates a LogicalAsofJoin by parsing serialized output.
- LogicalCalc - Class in org.apache.calcite.rel.logical
-
A relational expression which computes project expressions and also filters.
- LogicalCalc(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RexProgram) - Constructor for class org.apache.calcite.rel.logical.LogicalCalc
-
Creates a LogicalCalc.
- LogicalCalc(RelOptCluster, RelTraitSet, RelNode, RexProgram) - Constructor for class org.apache.calcite.rel.logical.LogicalCalc
-
Deprecated.
- LogicalCalc(RelOptCluster, RelTraitSet, RelNode, RexProgram, List<RelCollation>) - Constructor for class org.apache.calcite.rel.logical.LogicalCalc
-
Deprecated.
- LogicalCalc(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalCalc
-
Creates a LogicalCalc by parsing serialized output.
- LogicalChi - Class in org.apache.calcite.rel.stream
-
Sub-class of
Chi
not targeted at any particular engine or calling convention. - LogicalChi(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.rel.stream.LogicalChi
- LogicalCorrelate - Class in org.apache.calcite.rel.logical
-
A relational operator that performs nested-loop joins.
- LogicalCorrelate(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RelNode, CorrelationId, ImmutableBitSet, JoinRelType) - Constructor for class org.apache.calcite.rel.logical.LogicalCorrelate
-
Creates a LogicalCorrelate.
- LogicalCorrelate(RelOptCluster, RelTraitSet, RelNode, RelNode, CorrelationId, ImmutableBitSet, JoinRelType) - Constructor for class org.apache.calcite.rel.logical.LogicalCorrelate
-
Deprecated.
- LogicalCorrelate(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalCorrelate
-
Creates a LogicalCorrelate by parsing serialized output.
- LogicalDelta - Class in org.apache.calcite.rel.stream
-
Sub-class of
Delta
not targeted at any particular engine or calling convention. - LogicalDelta(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.rel.stream.LogicalDelta
-
Creates a LogicalDelta.
- LogicalDelta(RelInput) - Constructor for class org.apache.calcite.rel.stream.LogicalDelta
-
Creates a LogicalDelta by parsing serialized output.
- LogicalExchange - Class in org.apache.calcite.rel.logical
-
Sub-class of
Exchange
not targeted at any particular engine or calling convention. - LogicalExchange(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalExchange
-
Creates a LogicalExchange by parsing serialized output.
- LogicalFilter - Class in org.apache.calcite.rel.logical
-
Sub-class of
Filter
not targeted at any particular engine or calling convention. - LogicalFilter(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RexNode, ImmutableSet<CorrelationId>) - Constructor for class org.apache.calcite.rel.logical.LogicalFilter
-
Creates a LogicalFilter.
- LogicalFilter(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.calcite.rel.logical.LogicalFilter
-
Deprecated.
- LogicalFilter(RelOptCluster, RelTraitSet, RelNode, RexNode, ImmutableSet<CorrelationId>) - Constructor for class org.apache.calcite.rel.logical.LogicalFilter
-
Creates a LogicalFilter.
- LogicalFilter(RelOptCluster, RelNode, RexNode) - Constructor for class org.apache.calcite.rel.logical.LogicalFilter
-
Deprecated.
- LogicalFilter(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalFilter
-
Creates a LogicalFilter by parsing serialized output.
- LogicalIntersect - Class in org.apache.calcite.rel.logical
-
Sub-class of
Intersect
not targeted at any particular engine or calling convention. - LogicalIntersect(RelOptCluster, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.logical.LogicalIntersect
-
Deprecated.
- LogicalIntersect(RelOptCluster, RelTraitSet, List<RelHint>, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.logical.LogicalIntersect
-
Creates a LogicalIntersect.
- LogicalIntersect(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.logical.LogicalIntersect
-
Creates a LogicalIntersect.
- LogicalIntersect(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalIntersect
-
Creates a LogicalIntersect by parsing serialized output.
- LogicalJoin - Class in org.apache.calcite.rel.logical
-
Sub-class of
Join
not targeted at any particular engine or calling convention. - LogicalJoin(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType, boolean, ImmutableList<RelDataTypeField>) - Constructor for class org.apache.calcite.rel.logical.LogicalJoin
-
Creates a LogicalJoin.
- LogicalJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType, boolean, ImmutableList<RelDataTypeField>) - Constructor for class org.apache.calcite.rel.logical.LogicalJoin
-
Deprecated.
- LogicalJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, Set<String>, boolean, ImmutableList<RelDataTypeField>) - Constructor for class org.apache.calcite.rel.logical.LogicalJoin
-
Deprecated.
- LogicalJoin(RelOptCluster, RelNode, RelNode, RexNode, JoinRelType, Set<String>) - Constructor for class org.apache.calcite.rel.logical.LogicalJoin
-
Deprecated.
- LogicalJoin(RelOptCluster, RelNode, RelNode, RexNode, JoinRelType, Set<String>, boolean, ImmutableList<RelDataTypeField>) - Constructor for class org.apache.calcite.rel.logical.LogicalJoin
-
Deprecated.
- LogicalJoin(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalJoin
-
Creates a LogicalJoin by parsing serialized output.
- LogicalMatch - Class in org.apache.calcite.rel.logical
-
Sub-class of
Match
not targeted at any particular engine or calling convention. - LogicalMatch(RelOptCluster, RelTraitSet, RelNode, RelDataType, RexNode, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, ImmutableBitSet, RelCollation, RexNode) - Constructor for class org.apache.calcite.rel.logical.LogicalMatch
-
Creates a LogicalMatch.
- LogicalMinus - Class in org.apache.calcite.rel.logical
-
Sub-class of
Minus
not targeted at any particular engine or calling convention. - LogicalMinus(RelOptCluster, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.logical.LogicalMinus
-
Deprecated.
- LogicalMinus(RelOptCluster, RelTraitSet, List<RelHint>, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.logical.LogicalMinus
-
Creates a LogicalMinus.
- LogicalMinus(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.logical.LogicalMinus
-
Creates a LogicalMinus.
- LogicalMinus(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalMinus
-
Creates a LogicalMinus by parsing serialized output.
- LogicalProject - Class in org.apache.calcite.rel.logical
-
Sub-class of
Project
not targeted at any particular engine or calling convention. - LogicalProject(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.rel.logical.LogicalProject
-
Deprecated.
- LogicalProject(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, List<? extends RexNode>, RelDataType, Set<CorrelationId>) - Constructor for class org.apache.calcite.rel.logical.LogicalProject
-
Creates a LogicalProject.
- LogicalProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.rel.logical.LogicalProject
-
Deprecated.
- LogicalProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType, int) - Constructor for class org.apache.calcite.rel.logical.LogicalProject
-
Deprecated.
- LogicalProject(RelOptCluster, RelNode, List<RexNode>, List<? extends String>, int) - Constructor for class org.apache.calcite.rel.logical.LogicalProject
-
Deprecated.
- LogicalProject(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalProject
-
Creates a LogicalProject by parsing serialized output.
- LogicalRepeatUnion - Class in org.apache.calcite.rel.logical
-
Sub-class of
RepeatUnion
not targeted at any particular engine or calling convention. - LogicalSnapshot - Class in org.apache.calcite.rel.logical
-
Sub-class of
Snapshot
not targeted at any particular engine or calling convention. - LogicalSnapshot(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RexNode) - Constructor for class org.apache.calcite.rel.logical.LogicalSnapshot
-
Creates a LogicalSnapshot.
- LogicalSnapshot(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.calcite.rel.logical.LogicalSnapshot
-
Creates a LogicalSnapshot.
- LogicalSnapshot(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalSnapshot
-
Creates a LogicalSnapshot by parsing serialized output.
- LogicalSort - Class in org.apache.calcite.rel.logical
-
Sub-class of
Sort
not targeted at any particular engine or calling convention. - LogicalSort(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalSort
-
Creates a LogicalSort by parsing serialized output.
- LogicalSortExchange - Class in org.apache.calcite.rel.logical
-
Sub-class of
SortExchange
not targeted at any particular engine or calling convention. - LogicalSortExchange(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalSortExchange
-
Creates a LogicalSortExchange by parsing serialized output.
- LogicalTableFunctionScan - Class in org.apache.calcite.rel.logical
-
Sub-class of
TableFunctionScan
not targeted at any particular engine or calling convention. - LogicalTableFunctionScan(RelOptCluster, List<RelNode>, RexNode, Type, RelDataType, Set<RelColumnMapping>) - Constructor for class org.apache.calcite.rel.logical.LogicalTableFunctionScan
-
Deprecated.
- LogicalTableFunctionScan(RelOptCluster, RelTraitSet, List<RelHint>, List<RelNode>, RexNode, Type, RelDataType, Set<RelColumnMapping>) - Constructor for class org.apache.calcite.rel.logical.LogicalTableFunctionScan
-
Creates a
LogicalTableFunctionScan
. - LogicalTableFunctionScan(RelOptCluster, RelTraitSet, List<RelNode>, RexNode, Type, RelDataType, Set<RelColumnMapping>) - Constructor for class org.apache.calcite.rel.logical.LogicalTableFunctionScan
-
Creates a
LogicalTableFunctionScan
. - LogicalTableFunctionScan(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalTableFunctionScan
-
Creates a LogicalTableFunctionScan by parsing serialized output.
- LogicalTableModify - Class in org.apache.calcite.rel.logical
-
Sub-class of
TableModify
not targeted at any particular engine or calling convention. - LogicalTableModify(RelOptCluster, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, boolean) - Constructor for class org.apache.calcite.rel.logical.LogicalTableModify
-
Deprecated.
- LogicalTableModify(RelOptCluster, RelTraitSet, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean) - Constructor for class org.apache.calcite.rel.logical.LogicalTableModify
-
Creates a LogicalTableModify.
- LogicalTableModify(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalTableModify
-
Creates a LogicalTableModify by parsing serialized output.
- LogicalTableScan - Class in org.apache.calcite.rel.logical
-
A
LogicalTableScan
reads all the rows from aRelOptTable
. - LogicalTableScan(RelOptCluster, RelOptTable) - Constructor for class org.apache.calcite.rel.logical.LogicalTableScan
-
Deprecated.
- LogicalTableScan(RelOptCluster, RelTraitSet, List<RelHint>, RelOptTable) - Constructor for class org.apache.calcite.rel.logical.LogicalTableScan
-
Creates a LogicalTableScan.
- LogicalTableScan(RelOptCluster, RelTraitSet, RelOptTable) - Constructor for class org.apache.calcite.rel.logical.LogicalTableScan
-
Deprecated.
- LogicalTableScan(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalTableScan
-
Creates a LogicalTableScan by parsing serialized output.
- LogicalTableSpool - Class in org.apache.calcite.rel.logical
-
Sub-class of
TableSpool
not targeted at any particular engine or calling convention. - LogicalTableSpool(RelOptCluster, RelTraitSet, RelNode, Spool.Type, Spool.Type, RelOptTable) - Constructor for class org.apache.calcite.rel.logical.LogicalTableSpool
- LogicalUnion - Class in org.apache.calcite.rel.logical
-
Sub-class of
Union
not targeted at any particular engine or calling convention. - LogicalUnion(RelOptCluster, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.logical.LogicalUnion
-
Deprecated.
- LogicalUnion(RelOptCluster, RelTraitSet, List<RelHint>, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.logical.LogicalUnion
-
Creates a LogicalUnion.
- LogicalUnion(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.logical.LogicalUnion
-
Creates a LogicalUnion.
- LogicalUnion(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalUnion
-
Creates a LogicalUnion by parsing serialized output.
- LogicalValues - Class in org.apache.calcite.rel.logical
-
Sub-class of
Values
not targeted at any particular engine or calling convention. - LogicalValues(RelOptCluster, RelTraitSet, List<RelHint>, RelDataType, ImmutableList<ImmutableList<RexLiteral>>) - Constructor for class org.apache.calcite.rel.logical.LogicalValues
-
Creates a LogicalValues.
- LogicalValues(RelOptCluster, RelTraitSet, RelDataType, ImmutableList<ImmutableList<RexLiteral>>) - Constructor for class org.apache.calcite.rel.logical.LogicalValues
-
Creates a LogicalValues.
- LogicalValues(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>) - Constructor for class org.apache.calcite.rel.logical.LogicalValues
-
Deprecated.
- LogicalValues(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalValues
-
Creates a LogicalValues by parsing serialized output.
- LogicalWindow - Class in org.apache.calcite.rel.logical
-
Sub-class of
Window
not targeted at any particular engine or calling convention. - LogicalWindow(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, List<RexLiteral>, RelDataType, List<Window.Group>) - Constructor for class org.apache.calcite.rel.logical.LogicalWindow
-
Creates a LogicalWindow.
- LogicalWindow(RelOptCluster, RelTraitSet, RelNode, List<RexLiteral>, RelDataType, List<Window.Group>) - Constructor for class org.apache.calcite.rel.logical.LogicalWindow
-
Creates a LogicalWindow.
- LogicVisitor - Class in org.apache.calcite.rex
-
Visitor pattern for traversing a tree of
RexNode
objects. - login(EnvironmentFairy.User) - Static method in class org.apache.calcite.chinook.EnvironmentFairy
- logOutputStream - Variable in class org.apache.calcite.test.DiffTestCase
-
OutputStream for current test log.
- LONG - Enum constant in enum org.apache.calcite.adapter.druid.DruidType
- LONG - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive
- LONG_INTERVAL_DECIMAL_CAST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LONG_INTERVAL_DECIMAL_CAST_ROUNDING_MODE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LONG_VALUE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- longCount() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- longCount() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns an long that represents the total number of elements in a sequence.
- longCount(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns an long that represents the total number of elements in a sequence.
- longCount(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns an long that represents how many elements in a sequence satisfy a condition.
- longCount(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- longCount(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns an long that represents how many elements in a sequence satisfy a condition.
- longCount(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns an long that represents the total number of elements in a sequence.
- longCount(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns an long that represents the total number of elements in a sequence.
- longCount(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- longCount(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns an long that represents the number of elements in a sequence that satisfy a condition.
- longCount(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns an long that represents the number of elements in a sequence that satisfy a condition.
- longCount(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- longCount(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- longCount(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns an long that represents the number of elements in a sequence that satisfy a condition.
- LongFunction1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function that takes one parameter and returns a native
long
value. - longIntervalToDecimalCast(Integer, int, int, BigDecimal) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Convert a long time interval to a decimal value.
- longIntervalToDecimalCast(Integer, int, int, BigDecimal, RoundingMode) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Convert a long time interval to a decimal value.
- longLiteral(long) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- LONGNVARCHAR - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- longRelDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- LongSchemaVersion - Class in org.apache.calcite.schema.impl
-
Implementation of SchemaVersion that uses a long value as representation.
- LongSchemaVersion(long) - Constructor for class org.apache.calcite.schema.impl.LongSchemaVersion
- LongSum() - Constructor for class org.apache.calcite.interpreter.AggregateNode.LongSum
- longtitude - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Coordinate
- longValue(boolean) - Method in class org.apache.calcite.sql.SqlLiteral
-
Returns the long value of this literal.
- lookup(DataType) - Method in class org.apache.calcite.adapter.cassandra.CqlToSqlTypeConversionRules
-
Returns a corresponding
SqlTypeName
for a given CQL type name. - lookup(Class) - Method in class org.apache.calcite.sql.type.JavaToSqlTypeConversionRules
-
Returns a corresponding
SqlTypeName
for a given Java class. - lookup(Class<?>) - Static method in class org.apache.calcite.test.DiffRepository
-
Finds the repository instance for a given class, with no base repository or filter.
- lookup(Class<?>, DiffRepository, DiffRepository.Filter, int) - Static method in class org.apache.calcite.test.DiffRepository
-
Finds the repository instance for a given class.
- lookup(Method) - Static method in enum org.apache.calcite.adapter.spark.SparkMethod
- lookup(String) - Method in class org.apache.calcite.adapter.innodb.ColumnTypeToSqlTypeConversionRules
-
Returns a corresponding
SqlTypeName
for a given InnoDB type name. - lookup(String) - Static method in enum org.apache.calcite.sql.type.SqlTypeName
-
Returns the SqlTypeName value whose name or
SqlTypeName.getSpaceName()
matches the given name, or throwsIllegalArgumentException
; never returns null. - lookup(SqlValidatorScope, List<String>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Resolves a multi-part identifier such as "SCHEMA.EMP.EMPNO" to a namespace.
- Lookup<K,
V> - Interface in org.apache.calcite.linq4j -
Represents a collection of keys each mapped to one or more values.
- lookupChild(String) - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- lookupChild(String) - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- lookupChild(String) - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Looks up a child namespace of a given name.
- lookupConstructor(Type, Class<?>...) - Static method in class org.apache.calcite.linq4j.tree.Types
-
Finds a constructor of a given class that accepts a given set of arguments.
- lookupCorrel(String) - Method in class org.apache.calcite.plan.RelOptQuery
-
Returns the relational expression which populates a correlating variable.
- lookupField(boolean, RelDataType, String) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Deprecated.
- lookupField(Type, String) - Static method in class org.apache.calcite.linq4j.tree.Types
- lookupGroupingExpr(SqlNode) - Method in class org.apache.calcite.sql.validate.AggregatingSelectScope.Resolved
- lookupHints(SqlNode, SqlParserPos) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- lookupHints(SqlNode, SqlParserPos) - Method in interface org.apache.calcite.sql.validate.SqlValidatorWithHints
-
Looks up completion hints for a syntactically correct SQL statement that has been parsed into an expression tree.
- lookupMeasure(String) - Method in class org.apache.calcite.sql.validate.MeasureScope
- lookupMeasure(SqlIdentifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- lookupMethod(Class<?>, String, Class<?>...) - Static method in class org.apache.calcite.linq4j.tree.Types
-
Finds a method of a given name that accepts a given set of arguments.
- lookupNameCompletionHints(SqlValidatorScope, List<String>, SqlParserPos, Collection<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Populates a list of all the valid alternatives for an identifier.
- lookupOperatorOverloads(SqlIdentifier, SqlFunctionCategory, SqlSyntax, List<SqlOperator>, SqlNameMatcher) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- lookupOperatorOverloads(SqlIdentifier, SqlFunctionCategory, SqlSyntax, List<SqlOperator>, SqlNameMatcher) - Method in interface org.apache.calcite.sql.SqlOperatorTable
-
Retrieves a list of operators with a given name and syntax.
- lookupOperatorOverloads(SqlIdentifier, SqlFunctionCategory, SqlSyntax, List<SqlOperator>, SqlNameMatcher) - Method in class org.apache.calcite.sql.SqlSpatialTypeOperatorTable
- lookupOperatorOverloads(SqlIdentifier, SqlFunctionCategory, SqlSyntax, List<SqlOperator>, SqlNameMatcher) - Method in class org.apache.calcite.sql.util.ChainedSqlOperatorTable
- lookupOperatorOverloads(SqlIdentifier, SqlFunctionCategory, SqlSyntax, List<SqlOperator>, SqlNameMatcher) - Method in class org.apache.calcite.sql.util.ListSqlOperatorTable
- lookupOperatorOverloads(SqlIdentifier, SqlFunctionCategory, SqlSyntax, List<SqlOperator>, SqlNameMatcher) - Method in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
- lookUpOperators(String, boolean, Consumer<SqlOperator>) - Method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- lookUpOperators(String, boolean, Consumer<SqlOperator>) - Method in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
-
Looks up operators, optionally matching case-sensitively.
- lookupPrivate(Class<T>) - Method in interface org.apache.calcite.util.Compatible
-
Same as
MethodHandles#privateLookupIn()
. - lookupQualifiedName(SqlNode, SqlParserPos) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- lookupQualifiedName(SqlNode, SqlParserPos) - Method in interface org.apache.calcite.sql.validate.SqlValidatorWithHints
-
Looks up the fully qualified name for a
SqlIdentifier
at a given Parser Position in a parsed expression tree Note: call this only afterSqlValidator.validate(org.apache.calcite.sql.SqlNode)
has been called. - lookupRoutine(SqlOperatorTable, RelDataTypeFactory, SqlIdentifier, List<RelDataType>, List<String>, SqlFunctionCategory, SqlSyntax, SqlKind, SqlNameMatcher, boolean) - Static method in class org.apache.calcite.sql.SqlUtil
-
Looks up a (possibly overloaded) routine based on name and argument types.
- lookupSqlFunctionByID(SqlOperatorTable, SqlIdentifier, SqlFunctionCategory) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Lookup sql function by sql identifier and function category.
- lookupSubjectRoutines(SqlOperatorTable, RelDataTypeFactory, SqlIdentifier, List<RelDataType>, List<String>, SqlSyntax, SqlKind, SqlFunctionCategory, SqlNameMatcher, boolean) - Static method in class org.apache.calcite.sql.SqlUtil
-
Looks up all subject routines matching the given name and argument types.
- lookupVisitMethod(Class<?>, Class<?>, String) - Static method in class org.apache.calcite.util.ReflectUtil
-
Looks up a visit method.
- lookupVisitMethod(Class<?>, Class<?>, String, List<Class>) - Static method in class org.apache.calcite.util.ReflectUtil
-
Looks up a visit method taking additional parameters beyond the overloaded visitee type.
- lookupVisitMethod(Class<? extends R>, Class<? extends E>, String) - Method in interface org.apache.calcite.util.ReflectiveVisitDispatcher
-
Looks up a visit method.
- lookupVisitMethod(Class<? extends R>, Class<? extends E>, String, List<Class>) - Method in interface org.apache.calcite.util.ReflectiveVisitDispatcher
-
Looks up a visit method taking additional parameters beyond the overloaded visitee type.
- lookupWindow(String) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- lookupWindow(String) - Method in class org.apache.calcite.sql.validate.ParameterScope
- lookupWindow(String) - Method in class org.apache.calcite.sql.validate.JoinScope
- lookupWindow(String) - Method in class org.apache.calcite.sql.validate.SelectScope
- lookupWindow(String) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Finds a window with a given name.
- Loop - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A loop, such as for or while.
- LoptJoinTree - Class in org.apache.calcite.rel.rules
-
Utility class used to store a
Join
tree and the factors that make up the tree. - LoptJoinTree(RelNode, int) - Constructor for class org.apache.calcite.rel.rules.LoptJoinTree
-
Creates a join-tree consisting of a single node.
- LoptJoinTree(RelNode, LoptJoinTree.BinaryTree, boolean) - Constructor for class org.apache.calcite.rel.rules.LoptJoinTree
-
Associates the factor ids with a join-tree.
- LoptJoinTree(RelNode, LoptJoinTree.BinaryTree, LoptJoinTree.BinaryTree) - Constructor for class org.apache.calcite.rel.rules.LoptJoinTree
-
Associates the factor ids with a join-tree given the factors corresponding to the left and right subtrees of the join.
- LoptJoinTree(RelNode, LoptJoinTree.BinaryTree, LoptJoinTree.BinaryTree, boolean) - Constructor for class org.apache.calcite.rel.rules.LoptJoinTree
-
Associates the factor ids with a join-tree given the factors corresponding to the left and right subtrees of the join.
- LoptJoinTree.BinaryTree - Class in org.apache.calcite.rel.rules
-
Simple binary tree class that stores an id in the leaf nodes and keeps track of the parent LoptJoinTree object associated with the binary tree.
- LoptJoinTree.Leaf - Class in org.apache.calcite.rel.rules
-
Binary tree node that has no children.
- LoptJoinTree.Node - Class in org.apache.calcite.rel.rules
-
Binary tree node that has two children.
- LoptMultiJoin - Class in org.apache.calcite.rel.rules
-
Utility class that keeps track of the join factors that make up a
MultiJoin
. - LoptMultiJoin(MultiJoin) - Constructor for class org.apache.calcite.rel.rules.LoptMultiJoin
- LoptOptimizeJoinRule - Class in org.apache.calcite.rel.rules
-
Planner rule that implements the heuristic planner for determining optimal join orderings.
- LoptOptimizeJoinRule(RelFactories.JoinFactory, RelFactories.ProjectFactory, RelFactories.FilterFactory) - Constructor for class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Deprecated.
- LoptOptimizeJoinRule(LoptOptimizeJoinRule.Config) - Constructor for class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Creates an LoptOptimizeJoinRule.
- LoptOptimizeJoinRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Deprecated.
- LoptOptimizeJoinRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- LoptSemiJoinOptimizer - Class in org.apache.calcite.rel.rules
-
Implements the logic for determining the optimal semi-joins to be used in processing joins in a query.
- LoptSemiJoinOptimizer(RelMetadataQuery, LoptMultiJoin, RexBuilder) - Constructor for class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
- LOW - Enum constant in enum org.apache.calcite.config.NullCollation
-
Nulls last for DESC, nulls first for ASC.
- lower() - Method in class org.apache.calcite.runtime.SpaceFillingCurve2D.AbstractRange
- lower() - Method in interface org.apache.calcite.runtime.SpaceFillingCurve2D.IndexRange
- lower(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL LOWER(string) function.
- LOWER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LOWER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- LOWER_BOUND_COST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LOWER_OPERAND - Static variable in class org.apache.calcite.sql.fun.SqlBetweenOperator
-
Ordinal of the 'lower' operand.
- lowerBound - Variable in class org.apache.calcite.rel.core.Window.Group
- lowerBound(T[], K, int, int, Function1<T, K>, Comparator<K>) - Static method in class org.apache.calcite.runtime.BinarySearch
-
Taken from http://en.wikipedia.org/wiki/Binary_search_algorithm #Deferred_detection_of_equality
- lowerBound(T[], K, Function1<T, K>, Comparator<K>) - Static method in class org.apache.calcite.runtime.BinarySearch
-
Performs binary search of the lower bound in the given array.
- lowerBound(T[], T, int, int, Comparator<T>) - Static method in class org.apache.calcite.runtime.BinarySearch
-
Performs binary search of the lower bound in the given section of array.
- lowerBound(T[], T, Comparator<T>) - Static method in class org.apache.calcite.runtime.BinarySearch
-
Performs binary search of the lower bound in the given array.
- lowerName - Variable in enum org.apache.calcite.adapter.druid.Granularity.Type
-
Lower-case name, e.g.
- lowerName - Variable in enum org.apache.calcite.rel.core.JoinRelType
-
Lower-case name.
- lowerName - Variable in enum org.apache.calcite.sql.JoinType
-
Lower-case name.
- lowerName - Variable in enum org.apache.calcite.sql.SqlKind
-
Lower-case name.
- lpad(String, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LPAD(string, integer)
function. - lpad(String, int, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LPAD(string, integer, string)
function. - lpad(ByteString, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LPAD(binary, integer, binary)
function. - lpad(ByteString, int, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LPAD(binary, integer, binary)
function. - LPAD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LPAD - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "LPAD(original_value, return_length[, pattern])" function.
- lt(boolean, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
<
operator applied to boolean values. - lt(byte, byte) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lt(char, char) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lt(double, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lt(float, float) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lt(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lt(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lt(short, short) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lt(Object[], Object[]) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lt(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
<
operator applied to String values. - lt(String, String, Comparator<String>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
<
operator applied to String values. - lt(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
<
operator applied to BigDecimal values. - lt(List<?>, List<?>) - Static method in class org.apache.calcite.runtime.SqlFunctions
- lt(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
<
operator applied to ByteString values. - lt(RexNode, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- LT - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- LT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LT_NULLABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ltAny(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
<
operator applied to Object values. - LTE - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- ltNullable(T, T) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Returns whether
b0
is less thanb1
(orb1
is null). - ltrim(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LTRIM
function. - LTRIM - Enum constant in enum org.apache.calcite.sql.SqlKind
-
LTRIM
function (Oracle). - LTRIM - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- LTRIM - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
Deprecated.
- LTRIM - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "LTRIM(string)" function.
- LUCIDDB - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- LucidDbSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the LucidDB database. - LucidDbSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.LucidDbSqlDialect
-
Creates a LucidDbSqlDialect.
M
- M2V - Enum constant in enum org.apache.calcite.sql.SqlKind
-
M2V
(measure-to-value) internal operator. - M2V - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
V2M
operator converts a measure to a value. - M2V_FINDER - Static variable in class org.apache.calcite.rex.RexUtil
-
Finds calls to the
SqlInternalOperators.M2V
function. - M2X - Enum constant in enum org.apache.calcite.sql.SqlKind
-
M2X
(evaluate measure in context) internal operator. - M2X - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
M2X
operator evaluates an expression in a context. - main(String[]) - Static method in class org.apache.calcite.adapter.os.SqlShell
-
Main entry point.
- main(String[]) - Static method in class org.apache.calcite.adapter.spark.SparkRules
- main(String[]) - Static method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- main(String[]) - Static method in class org.apache.calcite.adapter.splunk.util.StringUtils
- main(String[]) - Static method in class org.apache.calcite.Demo
- major - Variable in class org.apache.calcite.jdbc.CalciteFactory
- makeAbstractCast(RelDataType, RexNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Deprecated.
- makeAbstractCast(RelDataType, RexNode, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call to CAST or SAFE_CAST operator.
- makeAbstractCast(RelDataType, RexNode, boolean, RexLiteral) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call to CAST or SAFE_CAST operator with a FORMAT clause.
- makeAbstractCast(SqlParserPos, RelDataType, RexNode, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call to CAST or SAFE_CAST operator.
- makeAbstractCast(SqlParserPos, RelDataType, RexNode, boolean, RexLiteral) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call to CAST or SAFE_CAST operator with a FORMAT clause.
- makeApproxLiteral(Double, RelDataType) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates an approximate numeric literal (double or float) from a Double value.
- makeApproxLiteral(BigDecimal, RelDataType) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates an approximate numeric literal (double or float).
- makeApproxLiteral(BigDecimal) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Makes an approximate literal of double precision.
- makeApproxLiteral(BigDecimal) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a double-precision literal.
- makeApproxScaleFactor(int) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Makes an approximate literal to be used for scaling.
- makeBetween(RexNode, RexNode, RexNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a
RexNode
representation a SQL "arg BETWEEN lower AND upper" expression. - makeBigintLiteral(BigDecimal) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a BIGINT literal.
- makeBinary(ExpressionType, Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression, given the left and right operands, by calling an appropriate factory method.
- makeBinary(ExpressionType, Expression, Expression, boolean, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression, given the left operand, right operand and implementing method, by calling the appropriate factory method.
- makeBinary(ExpressionType, Expression, Expression, boolean, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression, given the left operand, right operand, implementing method and type conversion function, by calling the appropriate factory method.
- makeBinaryLiteral(ByteString) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a byte array literal.
- makeCall(RelDataType, SqlOperator, List<RexNode>) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call with a list of arguments and a predetermined type.
- makeCall(SqlParserPos, RelDataType, SqlOperator, List<RexNode>) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call with a list of arguments and a predetermined type.
- makeCall(SqlParserPos, SqlOperator, List<? extends RexNode>) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call with an array of arguments.
- makeCall(SqlParserPos, SqlOperator, RexNode...) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call with a list of arguments.
- makeCall(SqlOperator, List<? extends RexNode>) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call with an array of arguments.
- makeCall(SqlOperator, RexNode...) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call with a list of arguments.
- makeCase(RexNode, RexNode, RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
- makeCase(RexNode, RexNode, RexNode, RexNode, RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
- makeCast(RelDataType, RexNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call to the CAST operator.
- makeCast(RelDataType, RexNode, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Deprecated.
- makeCast(RelDataType, RexNode, boolean, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call to the CAST operator, expanding if possible, and optionally also preserving nullability, and optionally in safe mode.
- makeCast(RelDataType, RexNode, boolean, boolean, RexLiteral) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call to the CAST operator, expanding if possible, and optionally also preserving nullability, and optionally in safe mode.
- makeCast(SqlParserPos, RelDataType, RexNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call to the CAST operator.
- makeCast(SqlParserPos, RelDataType, RexNode, boolean, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call to the CAST operator, expanding if possible, and optionally also preserving nullability, and optionally in safe mode.
- makeCast(SqlParserPos, RelDataType, RexNode, boolean, boolean, RexLiteral) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call to the CAST operator, expanding if possible, and optionally also preserving nullability, and optionally in safe mode.
- makeCatchBlock(Type, ParameterExpression, Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a CatchBlock representing a catch statement with the specified elements.
- makeCharLiteral(NlsString) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a character string literal from an
NlsString
. - makeCorrel(RelDataType, CorrelationId) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates an expression referencing a correlation variable.
- makeCost(double, double, double) - Method in interface org.apache.calcite.plan.RelOptCostFactory
-
Creates a cost object.
- makeDateLiteral(Calendar) - Method in class org.apache.calcite.rex.RexBuilder
-
Deprecated.
- makeDateLiteral(DateString) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a Date literal.
- makeDivide(SqlParserPos, RexNode, RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
- makeDynamic(Type, CallSiteBinder, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a DynamicExpression that represents a dynamic operation bound by the provided CallSiteBinder.
- makeDynamic(Type, CallSiteBinder, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a DynamicExpression that represents a dynamic operation bound by the provided CallSiteBinder, using varargs.
- makeDynamicParam(RelDataType, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a reference to a dynamic parameter.
- makeExactLiteral(long) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Makes an exact, non-nullable literal of Bigint type.
- makeExactLiteral(BigDecimal, RelDataType) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a numeric literal.
- makeExactLiteral(BigDecimal) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a numeric literal.
- makeFieldAccess(RexNode, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates an expression accessing a field with a given ordinal from a record.
- makeFieldAccess(RexNode, String, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates an expression accessing a given named field from a record.
- makeFlag(Enum) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a literal representing a flag.
- makeGoto(GotoExpressionKind, LabelTarget, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- makeGoto(GotoExpressionKind, LabelTarget, Expression, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a jump of the specified GotoExpressionKind.
- makeHugeCost() - Method in interface org.apache.calcite.plan.RelOptCostFactory
-
Creates a cost object representing an enormous non-infinite cost.
- makeImmutable(DirectedGraph<V, E>) - Static method in class org.apache.calcite.util.graph.Graphs
-
Returns a map of the shortest paths between any pair of nodes.
- makeIn(RexNode, List<? extends RexNode>) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a
RexNode
representation a SQL "arg IN (point, ...)" expression. - makeInfiniteCost() - Method in interface org.apache.calcite.plan.RelOptCostFactory
-
Creates a cost object representing infinite cost.
- makeInputRef(int) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Creates a reference to a given input field.
- makeInputRef(RelNode, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a reference to a given field of the input relational expression.
- makeInputRef(RelDataType, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a reference to a given field of the input record.
- makeIntervalLiteral(BigDecimal, SqlIntervalQualifier) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a literal representing an interval value, for example
INTERVAL '3-7' YEAR TO MONTH
. - makeIntervalLiteral(SqlIntervalQualifier) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a literal representing an interval type, for example
YEAR TO MONTH
orDOW
. - makeIsNegative(RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
- makeIsPositive(RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
- makeKey(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Creates a key for
RexNode
which is the same as another key of another RexNode only if the two have both the same type and textual representation. - makeLambdaCall(RexNode, List<RexLambdaRef>) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a lambda expression.
- makeLiteral(boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a boolean literal.
- makeLiteral(Comparable, RelDataType, SqlTypeName) - Method in class org.apache.calcite.rex.RexBuilder
-
Internal method to create a call to a literal.
- makeLiteral(Object, RelDataType) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a literal of a given type, padding values of constant-width types to match their type, not allowing casts.
- makeLiteral(Object, RelDataType, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a literal of a given type, padding values of constant-width types to match their type.
- makeLiteral(Object, RelDataType, boolean, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a literal of a given type.
- makeLiteral(String) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a character string literal.
- makeLocalRef(RelDataType, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Create a reference to local variable.
- makeMemberAccess(Expression, PseudoField) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberExpression that represents accessing a field.
- makeMinus(SqlParserPos, RexNode, RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
- makeMultiply(SqlParserPos, RexNode, RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
- makeNewInvocation(RelDataType, List<RexNode>) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates an invocation of the NEW operator.
- makeNotNull(RexNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Makes a cast of an expression to NOT NULL; returns the expression unchanged if its type already has NOT NULL.
- makeNullable() - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- makeNullable() - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- makeNullable() - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Deprecated.
- makeNullable(boolean) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Returns a copy of this type that allows nulls if
nullable
is true. - makeNullable(boolean) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- makeNullable(RexNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Makes a cast of an expression to nullable; returns the expression unchanged if its type is already nullable.
- makeNullable(RexNode, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Makes a cast of an expression to the required nullability; returns the expression unchanged if its type already has the desired nullability.
- makeNullableIfOperandsAre(RelDataTypeFactory, List<RelDataType>, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Recreates a given RelDataType with nullability iff any of the param argTypes are nullable.
- makeNullableIfOperandsAre(SqlValidator, SqlValidatorScope, SqlCall, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Recreates a given RelDataType with nullability iff any of the operands of a call are nullable.
- makeNullaryCall(SqlIdentifier) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
If an identifier is a legitimate call to a function that has no arguments and requires no parentheses (for example "CURRENT_USER"), returns a call to that function, otherwise returns null.
- makeNullaryCall(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- makeNullLiteral(RelDataType) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a literal whose value is NULL, with a particular type.
- makeNullLiteral(SqlTypeName) - Method in class org.apache.calcite.rex.RexBuilder
-
Deprecated.
- makeNullLiteral(SqlTypeName, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Deprecated.
- makeOver(RelDataType, SqlAggFunction, List<RexNode>, List<RexNode>, ImmutableList<RexFieldCollation>, RexWindowBound, RexWindowBound, boolean, boolean, boolean, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Deprecated.
- makeOver(RelDataType, SqlAggFunction, List<RexNode>, List<RexNode>, ImmutableList<RexFieldCollation>, RexWindowBound, RexWindowBound, boolean, boolean, boolean, boolean, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call to a windowed agg.
- makeOver(RelDataType, SqlAggFunction, List<RexNode>, List<RexNode>, ImmutableList<RexFieldCollation>, RexWindowBound, RexWindowBound, RexWindowExclusion, boolean, boolean, boolean, boolean, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call to a windowed agg.
- makePatternFieldRef(String, RelDataType, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a reference to a given field of the pattern.
- makePlus(SqlParserPos, RexNode, RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
- makePossibleSemiJoins(LoptMultiJoin) - Method in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
-
Determines all possible semijoins that can be used by dimension tables to filter fact tables.
- makePreciseStringLiteral(String) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a character string literal with type CHAR and default charset and collation.
- makePreciseStringLiteral(ByteString, String, SqlCollation) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a character string literal with type CHAR.
- makeRangeReference(RelNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a reference to all the fields in the row.
- makeRangeReference(RelDataType, int, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a reference to all the fields in the row.
- makeReinterpretCast(RelDataType, RexNode, RexNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Makes a reinterpret cast.
- makeReinterpretCast(SqlParserPos, RelDataType, RexNode, RexNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Makes a reinterpret cast.
- makeRel(RelOptCluster, RelTraitSet, RelBuilder, RelNode, RexProgram) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.RelType
- makeRoundFactor(int) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Makes an exact numeric value to be used for rounding.
- makeScaleFactor(int) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Makes an exact numeric literal to be used for scaling.
- makeSearchArgumentLiteral(Sarg, RelDataType) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a search argument literal.
- makeSemiJoinSelectivityRexNode(RelMetadataQuery, Join) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Creates a RexNode that stores a selectivity value corresponding to the selectivity of a semijoin.
- makeTernary(ExpressionType, Expression, Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a TernaryExpression, given the left and right operands, by calling an appropriate factory method.
- makeTimeLiteral(Calendar, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Deprecated.
- makeTimeLiteral(TimeString, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a Time literal.
- makeTimestampLiteral(Calendar, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Deprecated.
- makeTimestampLiteral(TimestampString, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a Timestamp literal.
- makeTimestampTzLiteral(TimestampWithTimeZoneString, int) - Method in class org.apache.calcite.rex.RexBuilder
- makeTimestampWithLocalTimeZoneLiteral(TimestampString, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a Timestamp with local time-zone literal.
- makeTimeTzLiteral(TimeWithTimeZoneString, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a Time with time-zone literal.
- makeTimeWithLocalTimeZoneLiteral(TimeString, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a Time with local time-zone literal.
- makeTinyCost() - Method in interface org.apache.calcite.plan.RelOptCostFactory
-
Creates a cost object representing a small positive cost.
- makeTry(Type, Expression, Expression, Expression, Iterable<? extends CatchBlock>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a TryExpression representing a try block with the specified elements.
- makeTry(Type, Expression, Expression, Expression, CatchBlock...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a TryExpression representing a try block with the specified elements, using varargs.
- makeUnary(ExpressionType, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression, given an operand, by calling the appropriate factory method.
- makeUnary(ExpressionType, Expression, Type, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression, given an operand and implementing method, by calling the appropriate factory method.
- makeWindow(List<RexNode>, ImmutableList<RexFieldCollation>, RexWindowBound, RexWindowBound, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a window specification.
- makeWindow(List<RexNode>, ImmutableList<RexFieldCollation>, RexWindowBound, RexWindowBound, boolean, RexWindowExclusion) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a window specification.
- makeZeroCost() - Method in interface org.apache.calcite.plan.RelOptCostFactory
-
Creates a cost object representing zero cost.
- makeZeroLiteral(RelDataType) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a literal of the default value for the given type.
- managerid - Variable in class org.apache.calcite.test.schemata.hr.HierarchySchema.Hierarchy
- MANDATORY - Enum constant in enum org.apache.calcite.util.Optionality
-
A property is mandatory if an instance must possess it; it is an error if it does not.
- map - Variable in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- map - Variable in class org.apache.calcite.rel.metadata.RelMetadataQueryBase
-
Set of active metadata queries, and cache of previous results.
- map - Variable in class org.apache.calcite.sql2rel.RelDecorrelator
-
Built during decorrelation, of rel to all the newly created correlated variables in its output, and to map old input positions to new input positions.
- map() - Method in class org.apache.calcite.util.EquivalenceSet
-
Returns a map of the canonical element in each equivalence class to the set of elements in that class.
- map() - Method in class org.apache.calcite.util.JsonBuilder
-
Creates a JSON object (represented by a
Map
). - map() - Method in class org.apache.calcite.util.NameMap
-
Returns the underlying map.
- map() - Method in class org.apache.calcite.util.NameMultimap
-
Returns the underlying map.
- map(Range<C>, RangeSets.Handler<C, R>) - Static method in class org.apache.calcite.util.RangeSets
-
Calls the appropriate handler method for the type of range.
- map(RangeSet<C>, RangeSets.Handler<C, Range<C2>>) - Static method in class org.apache.calcite.util.RangeSets
-
Calls the appropriate handler method for each range in a range set, creating a new range set from the results.
- map(Object...) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MAP function.
- map(RelNode) - Static method in class org.apache.calcite.rex.RexSubQuery
-
Creates a MAP sub-query.
- Map - Annotation Type in org.apache.calcite.adapter.java
-
Annotation that indicates that a field is a map type.
- MAP - Enum constant in enum org.apache.calcite.model.JsonSchema.Type
- MAP - Enum constant in enum org.apache.calcite.runtime.SqlFunctions.FlatProductInputType
- MAP - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- MAP - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- MAP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MAP - Static variable in enum org.apache.calcite.adapter.cassandra.CassandraMethod
- MAP - Static variable in enum org.apache.calcite.adapter.innodb.InnodbMethod
- MAP - Static variable in enum org.apache.calcite.adapter.mongodb.MongoMethod
- MAP - Static variable in enum org.apache.calcite.sql.fun.SqlLibrary
-
Map from
name
andSqlLibrary.fun
to library. - MAP - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "MAP(key, value, ...)" function (Spark); compare with the standard map value constructor, "MAP[key, value, ...]".
- MAP - Static variable in class org.apache.calcite.sql.type.OperandTypes
- MAP_CLEAR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MAP_CONCAT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MAP_CONCAT
function (Spark semantics). - MAP_CONCAT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MAP_CONCAT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "MAP_CONCAT(map [, map]*)" function.
- MAP_CONTAINS_KEY - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MAP_CONTAINS_KEY
function (Spark semantics). - MAP_CONTAINS_KEY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MAP_CONTAINS_KEY - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "MAP_CONTAINS_KEY(map, key)" function.
- MAP_ENTRIES - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MAP_ENTRIES
function (Spark semantics). - MAP_ENTRIES - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MAP_ENTRIES - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "MAP_ENTRIES(map)" function.
- MAP_FROM_ARRAYS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MAP_FROM_ARRAYS
function (Spark semantics). - MAP_FROM_ARRAYS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MAP_FROM_ARRAYS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "MAP_FROM_ARRAYS(keysArray, valuesArray)" function.
- MAP_FROM_ENTRIES - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MAP_FROM_ENTRIES
function (Spark semantics). - MAP_FROM_ENTRIES - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MAP_FROM_ENTRIES - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "MAP_FROM_ENTRIES(arrayOfEntries)" function.
- MAP_FROM_ENTRIES - Static variable in class org.apache.calcite.sql.type.OperandTypes
- MAP_FUNCTION - Static variable in class org.apache.calcite.sql.type.OperandTypes
- MAP_GET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MAP_GET_OR_DEFAULT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MAP_ITEM - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MAP_KEY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- MAP_KEY_COLUMN_NAME - Static variable in class org.apache.calcite.sql.SqlUnnestOperator
- MAP_KEYS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MAP_KEYS
function (Spark semantics). - MAP_KEYS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MAP_KEYS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "MAP_KEYS(map)" function.
- MAP_PUT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MAP_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The MAP Query Constructor.
- MAP_QUERY_CONSTRUCTOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MAP query constructor, e.g.
- MAP_TYPE - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- MAP_VALUE_COLUMN_NAME - Static variable in class org.apache.calcite.sql.SqlUnnestOperator
- MAP_VALUE_CONSTRUCTOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MAP value constructor, e.g.
- MAP_VALUE_CONSTRUCTOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The MAP Value Constructor, e.g.
- MAP_VALUES - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MAP_VALUES
function (Spark semantics). - MAP_VALUES - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MAP_VALUES - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "MAP_VALUES(map)" function.
- mapConcat(Map...) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MAP_CONCAT function.
- mapContainsKey(Map, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MAP_CONTAINS_KEY function.
- mapCorrel(String, RelNode) - Method in class org.apache.calcite.plan.RelOptQuery
-
Maps a correlating variable to a
RelNode
. - mapDescToRule - Variable in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Maps rule description to rule, just to ensure that rules' descriptions are unique.
- mapEntries(Map<Object, Object>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MAP_ENTRIES function.
- MapEntry<T,
U> - Class in org.apache.calcite.runtime -
Simple implementation of
Map.Entry
. - MapEntry(T, U) - Constructor for class org.apache.calcite.runtime.MapEntry
-
Creates a MapEntry.
- mapFromArrays(List, List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MAP_FROM_ARRAYS function.
- mapFromEntries(List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MAP_FROM_ENTRIES function.
- MapFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.MapFunction
- mapItem(Map, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper for "map element reference".
- mapItemOptional(Map, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
As
SqlFunctions.mapItem(java.util.Map, java.lang.Object)
method, but allows map to be nullable. - mapKeys(Map) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MAP_KEYS function.
- mapNameToIndex(List<RelDataTypeField>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Returns a map from field names to indexes.
- mapOf(K, V, Object...) - Static method in class org.apache.calcite.util.Util
-
Returns a hashmap with given contents.
- Mapping - Interface in org.apache.calcite.util.mapping
-
A Mapping is a relationship between a source domain to target domain of integers.
- Mappings - Class in org.apache.calcite.util.mapping
-
Utility functions related to mappings.
- Mappings.AbstractMapping - Class in org.apache.calcite.util.mapping
-
Abstract implementation of
Mapping
. - Mappings.CoreMapping - Interface in org.apache.calcite.util.mapping
-
Core interface of all mappings.
- Mappings.FiniteAbstractMapping - Class in org.apache.calcite.util.mapping
-
Abstract implementation of mapping where both source and target domains are finite.
- Mappings.FunctionMapping - Interface in org.apache.calcite.util.mapping
-
Mapping where every source has a target.
- Mappings.IdentityMapping - Class in org.apache.calcite.util.mapping
-
The identity mapping, of a given size, or infinite.
- Mappings.NoElementException - Exception Class in org.apache.calcite.util.mapping
-
Thrown when a mapping is expected to return one element but returns none.
- Mappings.OverridingSourceMapping - Class in org.apache.calcite.util.mapping
-
Source mapping that returns the same result as a parent
Mappings.SourceMapping
except for specific overriding elements. - Mappings.OverridingTargetMapping - Class in org.apache.calcite.util.mapping
-
Target mapping that returns the same result as a parent
Mappings.TargetMapping
except for specific overriding elements. - Mappings.PartialMapping - Class in org.apache.calcite.util.mapping
-
A mapping where a source has at most one target, and every target has at most one source.
- Mappings.SourceMapping - Interface in org.apache.calcite.util.mapping
-
Mapping suitable for sourcing columns.
- Mappings.TargetMapping - Interface in org.apache.calcite.util.mapping
-
Mapping suitable for mapping columns to a target.
- Mappings.TooManyElementsException - Exception Class in org.apache.calcite.util.mapping
-
Thrown when a mapping is expected to return one element but returns several.
- MappingType - Enum in org.apache.calcite.util.mapping
-
Describes the type of a mapping, from the most general
MappingType.MULTI_FUNCTION
(every element in the source and target domain can participate in many mappings) to the most restrictedMappingType.BIJECTION
(every element in the source and target domain must be paired with precisely one element in the other domain). - mapQuery(Function<RelBuilder, RelNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a MAP sub-query.
- mapRequiresEvenArgCount() - Method in interface org.apache.calcite.runtime.CalciteResource
- mapRequiresTwoOrMoreArgs() - Method in interface org.apache.calcite.runtime.CalciteResource
- MapSqlStatisticProvider - Enum in org.apache.calcite.statistic
-
Implementation of
SqlStatisticProvider
that looks up values in a table. - MapSqlType - Class in org.apache.calcite.sql.type
-
SQL map type.
- MapSqlType(RelDataType, RelDataType, boolean) - Constructor for class org.apache.calcite.sql.type.MapSqlType
-
Creates a MapSqlType.
- mapTableModOp(boolean, SqlKind) - Method in class org.apache.calcite.prepare.Prepare
- MapType(Type, boolean, Type, boolean) - Constructor for class org.apache.calcite.linq4j.tree.Types.MapType
- MapType(SqlParserPos) - Constructor for class org.apache.calcite.piglet.Ast.MapType
- mapValues(Map) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MAP_VALUES function.
- mask(Comparable) - Static method in enum org.apache.calcite.rel.metadata.NullSentinel
- mask(Object) - Static method in enum org.apache.calcite.rel.metadata.NullSentinel
- match(E...) - Method in class org.apache.calcite.runtime.Matcher
- match(Iterable<E>) - Method in class org.apache.calcite.runtime.Matcher
- match(Enumerable<E>, Function1<E, TKey>, Matcher<E>, Enumerables.Emitter<E, TResult>, int, int) - Static method in class org.apache.calcite.runtime.Enumerables
- match(SubstitutionVisitor, MutableRel, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRule
- match(RelMetadataQuery, RelNode, RelDataType, RexNode, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, ImmutableBitSet, RelCollation, RexNode) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Helper method to determine a
Match
's collation. - match(RexNode, boolean, boolean, Map<String, RexNode>, Iterable<? extends RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, Iterable<? extends RexNode>, Iterable<? extends RexNode>, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Match
. - match(RexNode, RexAction) - Method in interface org.apache.calcite.rex.RexPattern
-
Deprecated.Calls
action
for every combination of tokens for which this pattern matches. - Match - Class in org.apache.calcite.rel.core
-
Relational expression that represent a MATCH_RECOGNIZE node.
- Match(RelOptCluster, RelTraitSet, RelNode, RelDataType, RexNode, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, ImmutableBitSet, RelCollation, RexNode) - Constructor for class org.apache.calcite.rel.core.Match
-
Creates a Match.
- MATCH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MATCH - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that converts a
LogicalMatch
to the result of callingLogicalMatch.copy(org.apache.calcite.plan.RelTraitSet, java.util.List<org.apache.calcite.rel.RelNode>)
. - MATCH_FACTORY - Static variable in class org.apache.calcite.adapter.jdbc.JdbcRules
- MATCH_NUMBER - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MATCH_NUMBER
operator inMATCH_RECOGNIZE
. - MATCH_NUMBER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
MATCH_NUMBER
function to be used withinMATCH_RECOGNIZE
. - MATCH_RECOGNIZE - Enum constant in enum org.apache.calcite.sql.SqlFunctionCategory
- MATCH_RECOGNIZE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MATCH_RECOGNIZE clause.
- MATCH_UNTIL_FIXPOINT - Static variable in class org.apache.calcite.plan.hep.HepProgram
-
Symbolic constant for matching until no more matches occur.
- MATCH_UTILS_LAST_WITH_SYMBOL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- Match.RexMRAggCall - Class in org.apache.calcite.rel.core
-
Aggregate calls in match recognize.
- matchCondition - Variable in class org.apache.calcite.rel.core.AsofJoin
-
Compared to standard joins, ASOF joins have an additional condition for comparing columns that usually contain timestamp values (however, the data type of these columns can be any type that supports comparisons, and is not restricted to be TIMESTAMP).
- matchConditionRequiresAsof() - Method in interface org.apache.calcite.runtime.CalciteResource
- matcher(String) - Method in interface org.apache.calcite.util.Puffin.Line
- Matcher<E> - Class in org.apache.calcite.runtime
-
Workspace that partialMatches patterns against an automaton.
- MATCHER_BUILDER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MATCHER_BUILDER_ADD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MATCHER_BUILDER_BUILD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- Matcher.Builder<E> - Class in org.apache.calcite.runtime
-
Builds a Matcher.
- Matchers - Class in org.apache.calcite.test
-
Matchers for testing SQL queries.
- Matchers.IsWithin<T extends Number> - Class in org.apache.calcite.test
-
Matcher that tests whether the numeric value is within a given difference another value.
- matches(boolean, String, String) - Static method in class org.apache.calcite.util.Util
-
Returns whether a name matches another according to a given case-sensitivity policy.
- matches(Object) - Method in class org.apache.calcite.test.Matchers.IsWithin
- matches(String) - Method in interface org.apache.calcite.util.Puffin.Line
-
Returns whether the current line matches
regex
. - matches(String, String) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- matches(String, String) - Method in interface org.apache.calcite.sql.validate.SqlNameMatcher
-
Returns a name matches another.
- matches(String, String) - Method in interface org.apache.calcite.sql.validate.SqlValidatorCatalogReader
- matches(RelOptRuleCall) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraFilterRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraProjectRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraSortRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.adapter.druid.DruidRules.DruidProjectRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoinRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMergeUnionRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeFilterRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.adapter.innodb.InnodbRules.InnodbProjectRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.adapter.innodb.InnodbRules.InnodbSortFilterRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.adapter.innodb.InnodbRules.InnodbSortTableScanRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcJoinRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcProjectRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.interpreter.Bindables.BindableProjectRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.plan.RelOptRule
-
Returns whether this rule could possibly match the given operands.
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateCaseToFilterRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateProjectConstantToDummyJoinRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterFlattenCorrelatedConditionRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinCommuteRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinToCorrelateRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinToMultiJoinRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectMergeRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SemiJoinRule.JoinOnUniqueToSemiJoinRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SortJoinTransposeRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SortUnionTransposeRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.UnionEliminatorRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.UnionMergeRule
- matches(RelTraitSet) - Method in class org.apache.calcite.plan.RelTraitSet
-
Compares two RelTraitSet objects to see if they match for the purposes of firing a rule.
- matches(SubstitutionVisitor, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor.Operand
- matches(RelNode) - Method in class org.apache.calcite.plan.RelOptRule.ConverterRelOptRuleOperand
- matches(RelNode) - Method in class org.apache.calcite.plan.RelOptRuleOperand
-
Returns whether a relational expression matches this operand.
- matches(Matcher<T>, Object) - Static method in class org.apache.calcite.test.Unsafe
-
Matcher.matches(Object)
is forbidden in regular test code in favour ofMatcherAssert.assertThat(T, org.hamcrest.Matcher<? super T>)
. - matchFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- MatchFailed() - Constructor for exception class org.apache.calcite.plan.SubstitutionVisitor.MatchFailed
- matchFolding() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the line-folding policy for the MATCH_RECOGNIZE clause.
- matchHandler() - Method in interface org.apache.calcite.rel.rules.ExchangeRemoveConstantKeysRule.Config
-
Forwards a call to
RelOptRule.onMatch(RelOptRuleCall)
. - matchHandler() - Method in interface org.apache.calcite.rel.rules.SortMergeRule.Config
-
Forwards a call to
RelOptRule.onMatch(RelOptRuleCall)
. - matchHandler() - Method in interface org.apache.calcite.rel.rules.SubQueryRemoveRule.Config
-
Forwards a call to
RelOptRule.onMatch(RelOptRuleCall)
. - matchHandler() - Method in interface org.apache.calcite.rel.rules.ValuesReduceRule.Config
-
Forwards a call to
RelOptRule.onMatch(RelOptRuleCall)
. - MatchImplementor - Interface in org.apache.calcite.adapter.enumerable
-
Implementor of Functions used in MATCH_RECOGNIZE Context.
- MatchNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
Match
. - matchNullability() - Method in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.Config
-
Whether to add a CAST when a nullable expression reduces to a NOT NULL literal.
- matchNullability(RelDataType, RexNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Ensures that a type's nullability matches a value's nullability.
- matchNullFetch() - Method in interface org.apache.calcite.rel.rules.SortUnionTransposeRule.Config
-
Whether to match a Sort whose
Sort.fetch
is null. - matchOne(MemoryFactory.Memory<E>, Matcher.PartitionState<E>, Consumer<Matcher.PartialMatch<E>>) - Method in class org.apache.calcite.runtime.Matcher
-
Feeds a single input row into the given partition state, and writes the resulting output rows (if any).
- matchOneWithSymbols(MemoryFactory.Memory<E>, Matcher.PartitionState<E>) - Method in class org.apache.calcite.runtime.Matcher
- matchRecognizeContext(SqlImplementor.Context) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- MatchRecognizeContext(SqlDialect, Map<String, RelDataType>) - Constructor for class org.apache.calcite.rel.rel2sql.SqlImplementor.MatchRecognizeContext
- MatchRecognizeNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for a
MATCH_RECOGNIZE
clause. - MatchRecognizeNamespace(SqlValidatorImpl, SqlMatchRecognize, SqlNode) - Constructor for class org.apache.calcite.sql.validate.MatchRecognizeNamespace
-
Creates a MatchRecognizeNamespace.
- MatchRecognizeScope - Class in org.apache.calcite.sql.validate
-
Scope for expressions in a
MATCH_RECOGNIZE
clause. - MatchRecognizeScope(SqlValidatorScope, SqlMatchRecognize) - Constructor for class org.apache.calcite.sql.validate.MatchRecognizeScope
-
Creates a MatchRecognizeScope.
- MatchReturnTypeInference - Class in org.apache.calcite.sql.type
-
Returns the first type that matches a set of given
SqlTypeName
s. - MatchReturnTypeInference(int, Iterable<SqlTypeName>) - Constructor for class org.apache.calcite.sql.type.MatchReturnTypeInference
-
Returns the first type matching any type in typeNames at or after position start (zero based).
- MatchReturnTypeInference(int, SqlTypeName...) - Constructor for class org.apache.calcite.sql.type.MatchReturnTypeInference
-
Returns the first type of typeName at or after position start (zero based).
- matchRoutinesByParameterCount(SqlOperatorTable, SqlIdentifier, List<RelDataType>, SqlFunctionCategory, SqlNameMatcher) - Static method in class org.apache.calcite.sql.SqlUtil
-
Determines whether there is a routine matching the given name and number of arguments.
- MatchRule - Class in org.apache.calcite.rel.rules
-
Planner rule that converts a
LogicalMatch
to the result of callingLogicalMatch.copy(org.apache.calcite.plan.RelTraitSet, java.util.List<org.apache.calcite.rel.RelNode>)
. - MatchRule(MatchRule.Config) - Constructor for class org.apache.calcite.rel.rules.MatchRule
-
Creates a MatchRule.
- MatchRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- MatchUtils - Class in org.apache.calcite.adapter.enumerable
-
Class with static Helpers for MATCH_RECOGNIZE.
- Materialization(CalciteSchema.TableEntry, String, List<String>) - Constructor for class org.apache.calcite.prepare.Prepare.Materialization
- MATERIALIZATION_CONNECTION - Static variable in class org.apache.calcite.schema.impl.MaterializedViewTable
-
Internal connection, used to execute queries to materialize views.
- MATERIALIZATION_RULES - Static variable in class org.apache.calcite.plan.RelOptRules
- MaterializationKey - Class in org.apache.calcite.materialize
-
Unique identifier for a materialization.
- MaterializationKey() - Constructor for class org.apache.calcite.materialize.MaterializationKey
- materializations - Variable in class org.apache.calcite.model.JsonSchema
-
List of tables in this schema that are materializations of queries.
- MATERIALIZATIONS_ENABLED - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether Calcite should use materializations.
- materializationsEnabled() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.MATERIALIZATIONS_ENABLED
. - materializationsEnabled() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- MaterializationService - Class in org.apache.calcite.materialize
-
Manages the collection of materialized tables known to the system, and the process by which they become valid and invalid.
- MaterializationService.DefaultTableFactory - Class in org.apache.calcite.materialize
-
Default implementation of
MaterializationService.TableFactory
. - MaterializationService.TableFactory - Interface in org.apache.calcite.materialize
-
Creates tables that represent a materialized view.
- materialize(RelNode, RelOptTable) - Method in class org.apache.calcite.prepare.Prepare.Materialization
- MATERIALIZED_QUERY_TABLE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
A materialized query table.
- MATERIALIZED_VIEW - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
Materialized view.
- MaterializedViewAggregateRule<C extends MaterializedViewAggregateRule.Config> - Class in org.apache.calcite.rel.rules.materialize
-
Materialized view rewriting for aggregate.
- MaterializedViewAggregateRule.Config - Interface in org.apache.calcite.rel.rules.materialize
-
Rule configuration.
- MaterializedViewFilterScanRule - Class in org.apache.calcite.rel.rules
- MaterializedViewFilterScanRule(MaterializedViewFilterScanRule.Config) - Constructor for class org.apache.calcite.rel.rules.MaterializedViewFilterScanRule
-
Creates a MaterializedViewFilterScanRule.
- MaterializedViewFilterScanRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.MaterializedViewFilterScanRule
-
Deprecated.
- MaterializedViewFilterScanRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- MaterializedViewJoinRule<C extends MaterializedViewRule.Config> - Class in org.apache.calcite.rel.rules.materialize
-
Materialized view rewriting for join.
- MaterializedViewOnlyAggregateRule - Class in org.apache.calcite.rel.rules.materialize
-
Rule that matches Aggregate.
- MaterializedViewOnlyAggregateRule(RelOptRuleOperand, RelBuilderFactory, String, boolean, HepProgram, RelOptRule, RelOptRule, RelOptRule, RelOptRule) - Constructor for class org.apache.calcite.rel.rules.materialize.MaterializedViewOnlyAggregateRule
-
Deprecated.
- MaterializedViewOnlyAggregateRule(RelBuilderFactory, boolean, HepProgram) - Constructor for class org.apache.calcite.rel.rules.materialize.MaterializedViewOnlyAggregateRule
-
Deprecated.
- MaterializedViewOnlyAggregateRule.Config - Interface in org.apache.calcite.rel.rules.materialize
-
Rule configuration.
- MaterializedViewOnlyFilterRule - Class in org.apache.calcite.rel.rules.materialize
-
Rule that matches Filter.
- MaterializedViewOnlyFilterRule(RelBuilderFactory, boolean, HepProgram, boolean) - Constructor for class org.apache.calcite.rel.rules.materialize.MaterializedViewOnlyFilterRule
-
Deprecated.
- MaterializedViewOnlyFilterRule.Config - Interface in org.apache.calcite.rel.rules.materialize
-
Rule configuration.
- MaterializedViewOnlyJoinRule - Class in org.apache.calcite.rel.rules.materialize
-
Rule that matches Join.
- MaterializedViewOnlyJoinRule(RelBuilderFactory, boolean, HepProgram, boolean) - Constructor for class org.apache.calcite.rel.rules.materialize.MaterializedViewOnlyJoinRule
-
Deprecated.
- MaterializedViewOnlyJoinRule.Config - Interface in org.apache.calcite.rel.rules.materialize
-
Rule configuration.
- MaterializedViewProjectAggregateRule - Class in org.apache.calcite.rel.rules.materialize
-
Rule that matches Project on Aggregate.
- MaterializedViewProjectAggregateRule(RelBuilderFactory, boolean, HepProgram) - Constructor for class org.apache.calcite.rel.rules.materialize.MaterializedViewProjectAggregateRule
-
Deprecated.
- MaterializedViewProjectAggregateRule(RelBuilderFactory, boolean, HepProgram, RelOptRule, RelOptRule, RelOptRule, RelOptRule) - Constructor for class org.apache.calcite.rel.rules.materialize.MaterializedViewProjectAggregateRule
-
Deprecated.
- MaterializedViewProjectAggregateRule.Config - Interface in org.apache.calcite.rel.rules.materialize
-
Rule configuration.
- MaterializedViewProjectFilterRule - Class in org.apache.calcite.rel.rules.materialize
-
Rule that matches Project on Filter.
- MaterializedViewProjectFilterRule(RelBuilderFactory, boolean, HepProgram, boolean) - Constructor for class org.apache.calcite.rel.rules.materialize.MaterializedViewProjectFilterRule
-
Deprecated.
- MaterializedViewProjectFilterRule.Config - Interface in org.apache.calcite.rel.rules.materialize
-
Rule configuration.
- MaterializedViewProjectJoinRule - Class in org.apache.calcite.rel.rules.materialize
-
Rule that matches Project on Join.
- MaterializedViewProjectJoinRule(RelBuilderFactory, boolean, HepProgram, boolean) - Constructor for class org.apache.calcite.rel.rules.materialize.MaterializedViewProjectJoinRule
-
Deprecated.
- MaterializedViewProjectJoinRule.Config - Interface in org.apache.calcite.rel.rules.materialize
-
Rule configuration.
- MaterializedViewRule<C extends MaterializedViewRule.Config> - Class in org.apache.calcite.rel.rules.materialize
- MaterializedViewRule.Config - Interface in org.apache.calcite.rel.rules.materialize
-
Rule configuration.
- MaterializedViewRule.Edge - Class in org.apache.calcite.rel.rules.materialize
-
Edge for graph.
- MaterializedViewRule.EquivalenceClasses - Class in org.apache.calcite.rel.rules.materialize
-
Class representing an equivalence class, i.e., a set of equivalent columns
- MaterializedViewRule.MatchModality - Enum in org.apache.calcite.rel.rules.materialize
-
Complete, view partial, or query partial.
- MaterializedViewRule.NodeLineage - Class in org.apache.calcite.rel.rules.materialize
-
Expression lineage details.
- MaterializedViewRule.ViewPartialRewriting - Class in org.apache.calcite.rel.rules.materialize
-
View partitioning result.
- MaterializedViewRules - Class in org.apache.calcite.rel.rules.materialize
-
Collection of rules pertaining to materialized views.
- MaterializedViewSubstitutionVisitor - Class in org.apache.calcite.plan
-
Deprecated.
- MaterializedViewSubstitutionVisitor(RelNode, RelNode) - Constructor for class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor
-
Deprecated.
- MaterializedViewSubstitutionVisitor(RelNode, RelNode, RelBuilderFactory) - Constructor for class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor
-
Deprecated.
- MaterializedViewTable - Class in org.apache.calcite.schema.impl
-
Table that is a materialized view.
- MaterializedViewTable(Type, RelProtoDataType, String, List<String>, List<String>, MaterializationKey) - Constructor for class org.apache.calcite.schema.impl.MaterializedViewTable
- MaterializedViewTable.MaterializedViewTableMacro - Class in org.apache.calcite.schema.impl
-
Table function that returns the table that materializes a view.
- MATH_MAX - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MATH_MIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- max - Variable in enum org.apache.calcite.linq4j.tree.Primitive
-
The maximum value of this primitive class.
- max() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- max() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the maximum value in a generic sequence.
- max(String, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
MAX
aggregate function. - max(Double, Double) - Static method in class org.apache.calcite.util.NumberUtil
-
Like
Math.max(int, int)
but null safe; returns the greater of two numbers, or null if either is null. - max(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.interpreter.AggregateNode.MaxBigDecimal
- max(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the maximum value in a generic sequence.
- max(Enumerable<TSource>, BigDecimalFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the maximum Decimal value.
- max(Enumerable<TSource>, DoubleFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the maximum Double value.
- max(Enumerable<TSource>, FloatFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the maximum Float value.
- max(Enumerable<TSource>, Function1<TSource, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a generic sequence and returns the maximum resulting value.
- max(Enumerable<TSource>, IntegerFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the maximum int value.
- max(Enumerable<TSource>, LongFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the maximum long value.
- max(Enumerable<TSource>, NullableBigDecimalFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the maximum nullable Decimal value.
- max(Enumerable<TSource>, NullableDoubleFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the maximum nullable Double value.
- max(Enumerable<TSource>, NullableFloatFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the maximum nullable Float value.
- max(Enumerable<TSource>, NullableIntegerFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the maximum nullable int value.
- max(Enumerable<TSource>, NullableLongFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the maximum nullable long value.
- max(BigDecimalFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- max(BigDecimalFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the maximum Decimal value.
- max(DoubleFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- max(DoubleFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the maximum Double value.
- max(FloatFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- max(FloatFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the maximum Float value.
- max(Function1<T, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- max(Function1<TSource, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a generic sequence and returns the maximum resulting value.
- max(IntegerFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- max(IntegerFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the maximum int value.
- max(LongFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- max(LongFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the maximum long value.
- max(NullableBigDecimalFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- max(NullableBigDecimalFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the maximum nullable Decimal value.
- max(NullableDoubleFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- max(NullableDoubleFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the maximum nullable Double value.
- max(NullableFloatFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- max(NullableFloatFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the maximum nullable Float value.
- max(NullableIntegerFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- max(NullableIntegerFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the maximum nullable int value.
- max(NullableLongFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- max(NullableLongFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the maximum nullable long value.
- max(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the maximum value in a generic
IQueryable<T>
. - max(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the maximum value in a generic
IQueryable<T>
. - max(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- max(Queryable<T>, FunctionExpression<Function1<T, TResult>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Invokes a projection function on each element of a generic
IQueryable<T>
and returns the maximum resulting value. - max(Queryable<T>, FunctionExpression<Function1<T, TResult>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Invokes a projection function on each element of a generic
IQueryable<T>
and returns the maximum resulting value. - max(Queryable<T>, FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- max(FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- max(FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Invokes a projection function on each element of a generic
IQueryable<TSource>
and returns the maximum resulting value. - max(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
MAX
aggregate function, optionally with an alias. - MAX - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
MAX
aggregate function. - MAX - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
MAX
aggregate function. - MAX_BY - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "MAX_BY(value, comp)" aggregate function, Spark's equivalent to
SqlStdOperatorTable.ARG_MAX
. - MAX_DATETIME_PRECISION - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- MAX_INTERVAL_FRACTIONAL_SECOND_PRECISION - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- MAX_INTERVAL_START_PRECISION - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- MAX_ROW_COUNT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MaxBigDecimal() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MaxBigDecimal
- MaxBoolean() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MaxBoolean
- maxClause() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Deprecated.
- MaxDouble() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MaxDouble
- MaxFloat() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MaxFloat
- maximumCardinality() - Element in annotation type org.apache.calcite.adapter.java.Array
-
Maximum number of elements in the array.
- maximumCardinality() - Method in class org.apache.calcite.linq4j.tree.Types.ArrayType
-
Returns the maximum cardinality; -1 if there is no maximum.
- MaxInt() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MaxInt
- MaxLong() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MaxLong
- maxNegative - Variable in enum org.apache.calcite.linq4j.tree.Primitive
-
The largest value that is less than zero.
- maxNodeLabelLength() - Method in interface org.apache.calcite.rel.externalize.RelDotWriter.WriteOption
-
The max length of node labels.
- maxNodeLabelPerLine() - Method in interface org.apache.calcite.rel.externalize.RelDotWriter.WriteOption
-
The max length of node label in a line.
- maxPrecision(int, int) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns the larger of two precisions, treating
RelDataType.PRECISION_NOT_SPECIFIED
as infinity. - maxRowCount - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- maxValue(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns the maximum value of an integral type, as a long value.
- mayBeSatisfiable(RexNode) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
-
Returns whether a boolean expression ever returns true.
- maybeUnwrap(Class<C>) - Method in interface org.apache.calcite.schema.Wrapper
-
Finds an instance of an interface implemented by this object, or returns
Optional.empty()
if this object does not support that interface. - mayRepeat() - Method in enum org.apache.calcite.sql.validate.SqlMonotonicity
-
Returns whether values of this monotonicity may ever repeat after moving to another value: true for
SqlMonotonicity.NOT_MONOTONIC
andSqlMonotonicity.CONSTANT
, false otherwise. - MAZE_METHOD - Static variable in class org.apache.calcite.util.Smalls
- MAZE2_METHOD - Static variable in class org.apache.calcite.util.Smalls
- MAZE3_METHOD - Static variable in class org.apache.calcite.util.Smalls
- MazeTable - Class in org.apache.calcite.example.maze
-
User-defined table function that generates a Maze and prints it in text form.
- MazeTable(String) - Constructor for class org.apache.calcite.util.Smalls.MazeTable
- md5(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL MD5(string) function.
- md5(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL MD5(string) function for binary string.
- MD5 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MD5 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- MDX_PRECEDENCE - Static variable in class org.apache.calcite.sql.SqlOperator
-
Maximum precedence.
- measure(RelMetadataProvider) - Static method in class org.apache.calcite.tools.Programs
- Measure(SqlAggFunction, boolean, String, Iterable<Lattice.Column>) - Constructor for class org.apache.calcite.materialize.Lattice.Measure
- MEASURE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MEASURE
operator. - MEASURE - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- MEASURE - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
MEASURE
operator wraps an expression in the SELECT clause that is a measure. - MEASURE - Static variable in class org.apache.calcite.sql.type.OperandTypes
- MEASURE_BOOLEAN - Static variable in class org.apache.calcite.sql.type.OperandTypes
- MEASURE_EXPAND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- measureExprList - Variable in class org.apache.calcite.sql.validate.AggregatingSelectScope.Resolved
- measureIllegal() - Method in interface org.apache.calcite.runtime.CalciteResource
- measureInAggregateQuery() - Method in interface org.apache.calcite.runtime.CalciteResource
- measureIsCyclic(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- measureList - Variable in class org.apache.calcite.sql.SqlUnpivot
- measureMustBeInAggregateQuery() - Method in interface org.apache.calcite.runtime.CalciteResource
- MeasureRules - Class in org.apache.calcite.rel.rules
-
Collection of planner rules that deal with measures.
- MeasureRules.AggregateMeasure2Rule - Class in org.apache.calcite.rel.rules
-
Rule that matches an
Aggregate
with at least one call toSqlInternalOperators.AGG_M2V
and expands these calls by asking the measure for its expression. - MeasureRules.AggregateMeasure2RuleConfig - Interface in org.apache.calcite.rel.rules
-
Configuration for
MeasureRules.AggregateMeasure2Rule
. - MeasureRules.AggregateMeasureRule - Class in org.apache.calcite.rel.rules
-
Rule that matches an
Aggregate
with at least one call toSqlInternalOperators.AGG_M2V
and converts those calls toSqlInternalOperators.M2X
. - MeasureRules.AggregateMeasureRuleConfig - Interface in org.apache.calcite.rel.rules
-
Configuration for
MeasureRules.AggregateMeasureRule
. - MeasureRules.FilterSortMeasureRule - Class in org.apache.calcite.rel.rules
- MeasureRules.FilterSortMeasureRuleConfig - Interface in org.apache.calcite.rel.rules
-
Configuration for
MeasureRules.FilterSortMeasureRule
. - MeasureRules.ProjectMeasureRule - Class in org.apache.calcite.rel.rules
- MeasureRules.ProjectMeasureRuleConfig - Interface in org.apache.calcite.rel.rules
-
Configuration for
MeasureRules.ProjectMeasureRule
. - MeasureRules.ProjectSortMeasureRule - Class in org.apache.calcite.rel.rules
- MeasureRules.ProjectSortMeasureRuleConfig - Interface in org.apache.calcite.rel.rules
-
Configuration for
MeasureRules.ProjectSortMeasureRule
. - measures - Variable in class org.apache.calcite.materialize.Lattice.Tile
- measures - Variable in class org.apache.calcite.materialize.TileKey
- measures - Variable in class org.apache.calcite.model.JsonTile
-
List of measures in this tile.
- measures - Variable in class org.apache.calcite.rel.core.Match
- measures - Variable in class org.apache.calcite.rel.mutable.MutableMatch
- MeasureScope - Class in org.apache.calcite.sql.validate
-
Scope for resolving identifiers within a SELECT item that is annotated "AS MEASURE".
- MeasureSqlType - Class in org.apache.calcite.sql.type
-
Measure SQL type.
- MEDIATOR_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Define an object that encapsulates how a set of objects interact.
- Member - Interface in org.apache.calcite.schema
-
A named expression in a schema.
- MEMBER_OF - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MEMBER_OF - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Multiset
MEMBER OF
, which returns whether a element belongs to a multiset. - MemberAccess - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An operation that reads from a field or property, such as obj.SampleProperty.
- MemberAssignment - Class in org.apache.calcite.linq4j.tree
-
Represents assignment operation for a field or property of an object.
- MemberAssignment() - Constructor for class org.apache.calcite.linq4j.tree.MemberAssignment
- memberBind(Member, Iterable<? extends MemberBinding>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberMemberBinding that represents the recursive initialization of members of a field or property.
- memberBind(Member, MemberBinding...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberMemberBinding that represents the recursive initialization of members of a field or property, using varargs.
- memberBind(Method, Iterable<? extends MemberBinding>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberMemberBinding that represents the recursive initialization of members of a member that is accessed by using a property accessor method.
- memberBind(Method, MemberBinding...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberMemberBinding that represents the recursive initialization of members of a member that is accessed by using a property accessor method, using varargs.
- MemberBinding - Class in org.apache.calcite.linq4j.tree
-
Provides the base class from which the classes that represent bindings that are used to initialize members of a newly created object derive.
- MemberBinding() - Constructor for class org.apache.calcite.linq4j.tree.MemberBinding
- MemberDeclaration - Class in org.apache.calcite.linq4j.tree
-
Declaration of a member of a class.
- MemberDeclaration() - Constructor for class org.apache.calcite.linq4j.tree.MemberDeclaration
- memberDeclarations - Variable in class org.apache.calcite.linq4j.tree.ClassDeclaration
- memberDeclarations - Variable in class org.apache.calcite.linq4j.tree.NewExpression
- MemberExpression - Class in org.apache.calcite.linq4j.tree
-
Represents accessing a field or property.
- MemberExpression(Expression, PseudoField) - Constructor for class org.apache.calcite.linq4j.tree.MemberExpression
- MemberExpression(Expression, Field) - Constructor for class org.apache.calcite.linq4j.tree.MemberExpression
- memberInit(NewExpression, Iterable<? extends MemberBinding>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Represents an expression that creates a new object and initializes a property of the object.
- memberInit(NewExpression, MemberBinding...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Represents an expression that creates a new object and initializes a property of the object, using varargs.
- MemberInit - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An operation that creates a new object and initializes one or more of its members, such as new Point { X = 1, Y = 2 } in C# or New Point With {.X = 1, .Y = 2} in Visual Basic.
- MemberInitExpression - Class in org.apache.calcite.linq4j.tree
-
Represents calling a constructor and initializing one or more members of the new object.
- MemberInitExpression() - Constructor for class org.apache.calcite.linq4j.tree.MemberInitExpression
- MemberListBinding - Class in org.apache.calcite.linq4j.tree
-
Represents initializing the elements of a collection member of a newly created object.
- MemberListBinding() - Constructor for class org.apache.calcite.linq4j.tree.MemberListBinding
- MemberMemberBinding - Class in org.apache.calcite.linq4j.tree
-
Represents initializing members of a member of a newly created object.
- MemberMemberBinding() - Constructor for class org.apache.calcite.linq4j.tree.MemberMemberBinding
- memberOf(Object, Collection) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MEMBER OF function.
- MEMENTO_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Without violating encapsulation, capture and externalize an objects's internal state so that the object can be restored to this state later.
- memory() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Memory
-
Returns the expected amount of memory, in bytes, required by a physical operator implementing this relational expression, across all splits.
- memory(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.Memory.memory()
statistic. - memory(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Memory.Handler
- memory(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdMemory
-
Catch-all implementation for
BuiltInMetadata.Memory.memory()
, invoked using reflection. - Memory(int, int, ModularInteger, Object[]) - Constructor for class org.apache.calcite.linq4j.MemoryFactory.Memory
- MEMORY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MEMORY_GET0 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MEMORY_GET1 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MEMORY_INFO - Enum constant in enum org.apache.calcite.adapter.os.OsQueryType
- MemoryEnumerable<E> - Class in org.apache.calcite.linq4j
-
Enumerable that has a (limited) memory for n past and m future steps.
- MemoryEnumerator<E> - Class in org.apache.calcite.linq4j
-
Enumerator that keeps some recent and some "future" values.
- MemoryFactory<E> - Class in org.apache.calcite.linq4j
-
Contains the State and changes internally.
- MemoryFactory(int, int) - Constructor for class org.apache.calcite.linq4j.MemoryFactory
- MemoryFactory.Memory<E> - Class in org.apache.calcite.linq4j
-
Contents of a "memory segment", used for implementing the
MATCH_RECOGNIZE
operator. - MemoryInfoTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "memory_info".
- merge(double, double) - Method in class org.apache.calcite.interpreter.AggregateNode.DoubleSum
- merge(int, int) - Method in class org.apache.calcite.interpreter.AggregateNode.IntSum
- merge(int, int) - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter1
- merge(long, long) - Method in class org.apache.calcite.interpreter.AggregateNode.LongSum
- merge(long, long) - Static method in class org.apache.calcite.util.Smalls.MyStaticSumFunction
- merge(long, long) - Method in class org.apache.calcite.util.Smalls.MySumFunction
- merge(long, long) - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter1
- merge(long, long) - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter2
- merge(long, long) - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter2
- merge(Boolean, Boolean) - Method in class org.apache.calcite.interpreter.AggregateNode.MaxBoolean
- merge(Boolean, Boolean) - Method in class org.apache.calcite.interpreter.AggregateNode.MinBoolean
- merge(Integer, Integer) - Method in class org.apache.calcite.util.Smalls.MySum3
- merge(BigDecimal, BigDecimal) - Method in class org.apache.calcite.interpreter.AggregateNode.BigDecimalSum
- merge(RelTraitSet) - Method in class org.apache.calcite.plan.RelTraitSet
- merge(AggregateCall, AggregateCall) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.AbstractSumSplitter
- merge(AggregateCall, AggregateCall) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.CountSplitter
- merge(AggregateCall, AggregateCall) - Method in interface org.apache.calcite.sql.SqlSplittableAggFunction
-
Merge top and bottom aggregate calls into a single aggregate call, if they are legit to merge.
- merge(AggregateCall, AggregateCall) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.SelfSplitter
- merge(Mappings.TargetMapping, Mappings.TargetMapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Creates a mapping by merging two mappings.
- merge(T, T) - Method in class org.apache.calcite.interpreter.AggregateNode.NumericComparison
- MERGE - Enum constant in enum org.apache.calcite.rel.core.TableModify.Operation
- MERGE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MERGE statement.
- MERGE - Enum constant in enum org.apache.calcite.tools.PigRelBuilder.GroupOption
- MERGE_JOIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MERGE_UNION - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- mergeJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Predicate2<TSource, TInner>, Function2<TSource, TInner, TResult>, JoinType, Comparator<TKey>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Joins two inputs that are sorted on the key, with an extra predicate for non equi-join conditions.
- mergeJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, TInner, TResult>, boolean, boolean) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- mergeJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, TInner, TResult>, JoinType, Comparator<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Joins two inputs that are sorted on the key.
- mergeJoin(RelMetadataQuery, RelNode, RelNode, ImmutableIntList, ImmutableIntList) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
- mergeJoin(RelMetadataQuery, RelNode, RelNode, ImmutableIntList, ImmutableIntList, JoinRelType) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Helper method to determine a
Join
's collation assuming that it uses a merge-join algorithm. - mergeMethod - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- mergePrograms(RexProgram, RexProgram, RexBuilder) - Static method in class org.apache.calcite.rex.RexProgramBuilder
-
Merges two programs together, and normalizes the result.
- mergePrograms(RexProgram, RexProgram, RexBuilder, boolean) - Static method in class org.apache.calcite.rex.RexProgramBuilder
-
Merges two programs together.
- mergeUnion(List<Enumerable<TSource>>, Function1<TSource, TKey>, Comparator<TKey>, boolean, EqualityComparer<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Merge Union Enumerable.
- META_COLUMN_FACTORY - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
MetaColumnFactory plugin.
- META_TABLE_FACTORY - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
MetaTableFactory plugin.
- metaColumnFactory(Class<T>, T) - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.META_COLUMN_FACTORY
, or a default meta column factory if not set. - metaColumnFactory(Class<T>, T) - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- metadata(Class<M>, RelMetadataQuery) - Method in class org.apache.calcite.rel.AbstractRelNode
-
Deprecated.
- metadata(Class<M>, RelMetadataQuery) - Method in interface org.apache.calcite.rel.RelNode
-
Deprecated.Use
RelMetadataQuery
viaRelOptNode.getCluster()
. - metaData(Function<Connection, ResultSet>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- Metadata - Interface in org.apache.calcite.rel.metadata
-
Metadata about a relational expression.
- METADATA_HANDLER_CACHE_MAXIMUM_SIZE - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
The maximum size of the cache of metadata handlers.
- METADATA_REL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- metadataClass - Variable in class org.apache.calcite.rel.metadata.MetadataDef
- metadataConfig - Variable in class org.apache.calcite.test.RelMetadataFixture
- MetadataConfig(String, Function<RelMetadataProvider, MetadataHandlerProvider>, Supplier<RelMetadataProvider>, boolean) - Constructor for class org.apache.calcite.test.RelMetadataFixture.MetadataConfig
- MetadataDef<M extends Metadata> - Class in org.apache.calcite.rel.metadata
-
Definition of metadata.
- MetadataFactory - Interface in org.apache.calcite.rel.metadata
-
Source of metadata about relational expressions.
- MetadataFactoryImpl - Class in org.apache.calcite.rel.metadata
-
Deprecated.Use
RelMetadataQuery
. - MetadataFactoryImpl(RelMetadataProvider) - Constructor for class org.apache.calcite.rel.metadata.MetadataFactoryImpl
-
Deprecated.
- MetadataHandler<M extends Metadata> - Interface in org.apache.calcite.rel.metadata
-
Marker interface for a handler of metadata.
- metadataHandlerCacheMaximumSize() - Method in interface org.apache.calcite.util.SaffronProperties
-
Deprecated.The string property "saffron.metadata.handler.cache.maximum.size" is the maximum size of the cache of metadata handlers.
- MetadataHandlerProvider - Interface in org.apache.calcite.rel.metadata
-
Provides
MetadataHandler
call sites forRelMetadataQuery
. - MetadataHandlerProvider.NoHandler - Exception Class in org.apache.calcite.rel.metadata
-
Exception that indicates there there should be a handler for this class but there is not.
- metadataProvider - Variable in class org.apache.calcite.rel.metadata.RelMetadataQueryBase
-
Deprecated.
- metaTableFactory(Class<T>, T) - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.META_TABLE_FACTORY
, or a default meta table factory if not set. - metaTableFactory(Class<T>, T) - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- method - Variable in enum org.apache.calcite.adapter.cassandra.CassandraMethod
- method - Variable in class org.apache.calcite.adapter.enumerable.ReflectiveCallNotNullImplementor
- method - Variable in enum org.apache.calcite.adapter.innodb.InnodbMethod
- method - Variable in enum org.apache.calcite.adapter.mongodb.MongoMethod
- method - Variable in enum org.apache.calcite.adapter.spark.SparkMethod
- method - Variable in class org.apache.calcite.linq4j.tree.MethodCallExpression
- method - Variable in class org.apache.calcite.schema.impl.ReflectiveFunctionBase
-
Method that implements the function.
- method - Variable in enum org.apache.calcite.util.BuiltInMethod
- MethodCallExpression - Class in org.apache.calcite.linq4j.tree
-
Represents a call to either a static or an instance method.
- methodDecl(int, Type, String, Iterable<? extends ParameterExpression>, BlockStatement) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Declares a method.
- MethodDeclaration - Class in org.apache.calcite.linq4j.tree
-
Declaration of a method.
- MethodDeclaration(int, String, Type, List<ParameterExpression>, BlockStatement) - Constructor for class org.apache.calcite.linq4j.tree.MethodDeclaration
- methodName - Variable in class org.apache.calcite.model.JsonFunction
-
Name of the method that implements this function.
- methods - Variable in class org.apache.calcite.rel.metadata.MetadataDef
- MI - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- MICROS - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- MICROSECOND_VARIANTS - Static variable in class org.apache.calcite.test.SqlOperatorTest
- mightBeAssignableFrom(Class<?>, Class<?>) - Static method in class org.apache.calcite.util.ReflectUtil
-
Returns whether a parameter of a given type could possibly have an argument of a given type.
- MILLIS - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- min - Variable in enum org.apache.calcite.linq4j.tree.Primitive
-
The minimum value of this primitive class.
- min() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- min() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the minimum value in a generic sequence.
- min(String, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
MIN
aggregate function, optionally with an alias. - min(Double, Double) - Static method in class org.apache.calcite.util.NumberUtil
-
Like
Math.min(int, int)
but null safe; returns the lesser of two numbers, ignoring numbers that are null, or null if both are null. - min(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.interpreter.AggregateNode.MinBigDecimal
- min(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the minimum value in a generic sequence.
- min(Enumerable<TSource>, BigDecimalFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the minimum Decimal value.
- min(Enumerable<TSource>, DoubleFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the minimum Double value.
- min(Enumerable<TSource>, FloatFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the minimum Float value.
- min(Enumerable<TSource>, Function1<TSource, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a generic sequence and returns the minimum resulting value.
- min(Enumerable<TSource>, IntegerFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the minimum int value.
- min(Enumerable<TSource>, LongFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the minimum long value.
- min(Enumerable<TSource>, NullableBigDecimalFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the minimum nullable Decimal value.
- min(Enumerable<TSource>, NullableDoubleFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the minimum nullable Double value.
- min(Enumerable<TSource>, NullableFloatFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the minimum nullable Float value.
- min(Enumerable<TSource>, NullableIntegerFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the minimum nullable int value.
- min(Enumerable<TSource>, NullableLongFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Invokes a transform function on each element of a sequence and returns the minimum nullable long value.
- min(BigDecimalFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- min(BigDecimalFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the minimum Decimal value.
- min(DoubleFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- min(DoubleFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the minimum Double value.
- min(FloatFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- min(FloatFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the minimum Float value.
- min(Function1<T, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- min(Function1<TSource, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a generic sequence and returns the minimum resulting value.
- min(IntegerFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- min(IntegerFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the minimum int value.
- min(LongFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- min(LongFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the minimum long value.
- min(NullableBigDecimalFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- min(NullableBigDecimalFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the minimum nullable Decimal value.
- min(NullableDoubleFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- min(NullableDoubleFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the minimum nullable Double value.
- min(NullableFloatFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- min(NullableFloatFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the minimum nullable Float value.
- min(NullableIntegerFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- min(NullableIntegerFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the minimum nullable int value.
- min(NullableLongFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- min(NullableLongFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Invokes a transform function on each element of a sequence and returns the minimum nullable long value.
- min(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the minimum value in a generic
IQueryable<T>
. - min(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the minimum value in a generic
IQueryable<T>
. - min(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- min(Queryable<T>, FunctionExpression<Function1<T, TResult>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Invokes a projection function on each element of a generic
IQueryable<T>
and returns the minimum resulting value. - min(Queryable<T>, FunctionExpression<Function1<T, TResult>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Invokes a projection function on each element of a generic
IQueryable<T>
and returns the minimum resulting value. - min(Queryable<T>, FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- min(FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- min(FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Invokes a projection function on each element of a generic
IQueryable<TSource>
and returns the minimum resulting value. - min(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
MIN
aggregate function. - MIN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
MIN
aggregate function. - MIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
MIN
aggregate function. - MIN_BY - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "MIN_BY(condition)" aggregate function, Spark's equivalent to
SqlStdOperatorTable.ARG_MIN
. - MIN_INTERVAL_FRACTIONAL_SECOND_PRECISION - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- MIN_INTERVAL_START_PRECISION - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- MIN_ROW_COUNT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MinBigDecimal() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MinBigDecimal
- MinBoolean() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MinBoolean
- MinDouble() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MinDouble
- MinFloat() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MinFloat
- MinInt() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MinInt
- MinLong() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MinLong
- MINMAX_COMPARABLE - Static variable in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
- MINMAX_COMPARATOR - Static variable in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
- MINMAX_INVALID - Static variable in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
- MINMAX_PRIMITIVE - Static variable in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
- minMaxBadType(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- minor - Variable in class org.apache.calcite.jdbc.CalciteFactory
- minPositive - Variable in enum org.apache.calcite.linq4j.tree.Primitive
-
The smallest value that is greater than zero.
- minus(boolean) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Minus
of the two most recent relational expressions on the stack. - minus(boolean, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Minus
of then
most recent relational expressions on the stack. - minus(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
-
operator applied to int values. - minus(int, Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
-
operator applied to int values; right side may be null. - minus(RangeSet<C>, Range<C>) - Static method in class org.apache.calcite.util.RangeSets
-
Subtracts a range from a range set.
- minus(Integer, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
-
operator applied to int values; left side may be null. - minus(Integer, Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
-
operator applied to nullable int values. - minus(Integer, Long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
-
operator applied to nullable int and long values. - minus(Long, Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
-
operator applied to nullable long and int values. - minus(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
-
operator applied to nullable BigDecimal values. - minus(Set<T>, Set<T>) - Static method in class org.apache.calcite.util.Util
-
Returns a set of the elements which are in
set1
but not inset2
, without modifying either. - minus(RelOptCost) - Method in interface org.apache.calcite.plan.RelOptCost
-
Subtracts another cost from this.
- minus(RelOptCost) - Method in class org.apache.calcite.plan.RelOptCostImpl
- Minus - Class in org.apache.calcite.rel.core
-
Relational expression that returns the rows of its first input minus any matching rows from its other inputs.
- Minus(RelOptCluster, RelTraitSet, List<RelHint>, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.core.Minus
- Minus(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.core.Minus
- Minus(RelInput) - Constructor for class org.apache.calcite.rel.core.Minus
-
Creates a Minus by parsing serialized output.
- MINUS - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- MINUS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Arithmetic minus operator, "-".
- MINUS - Static variable in interface org.apache.calcite.rel.rules.UnionMergeRule.Config
- MINUS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Infix arithmetic minus operator, '
-
'. - MINUS_DATE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
A special operator for the subtraction of two DATETIMEs.
- MINUS_DATE_OPERATOR - Static variable in class org.apache.calcite.sql.type.OperandTypes
- MINUS_DATE2 - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
2-argument form of the special minus-date operator to be used with BigQuery subtraction functions.
- MINUS_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that removes empty children of a
Minus
. - MINUS_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- MINUS_OPERATOR - Static variable in class org.apache.calcite.sql.type.OperandTypes
- MINUS_PREFIX - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Unary minus operator, as in "-1".
- MINUS_TO_DISTINCT - Static variable in class org.apache.calcite.rel.rules.CoreRules
- minusAny(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
-
operator applied to Object values (at least one operand has ANY type; either may be null). - minusNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- minusPreds(RexBuilder, RexNode, RexNode) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Takes the difference between two predicates, removing from the first any predicates also in the second.
- MinusToDistinctRule - Class in org.apache.calcite.rel.rules
- MinusToDistinctRule(Class<? extends Minus>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.MinusToDistinctRule
-
Deprecated.
- MinusToDistinctRule(MinusToDistinctRule.Config) - Constructor for class org.apache.calcite.rel.rules.MinusToDistinctRule
- MinusToDistinctRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- MINUTE - Enum constant in enum org.apache.calcite.adapter.druid.Granularity.Type
- MINUTE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
MINUTE
operator. - MINUTE_VARIANTS - Static variable in class org.apache.calcite.test.SqlOperatorTest
- MINUTES_IN_HOUR - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- MM - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- MockCatalogReader - Class in org.apache.calcite.test.catalog
-
Mock implementation of
SqlValidatorCatalogReader
which returns tables "EMP", "DEPT", "BONUS", "SALGRADE" (same as Oracle's SCOTT schema). - MockCatalogReader(RelDataTypeFactory, boolean) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader
-
Creates a MockCatalogReader.
- MockCatalogReader.ColumnResolver - Interface in org.apache.calcite.test.catalog
-
Column resolver.
- MockCatalogReader.MockDynamicTable - Class in org.apache.calcite.test.catalog
-
Mock implementation of
AbstractQueryableTable
with dynamic record type. - MockCatalogReader.MockModifiableViewRelOptTable - Class in org.apache.calcite.test.catalog
-
Alternative to MockViewTable that exercises code paths in ModifiableViewTable and ModifiableViewTableInitializerExpressionFactory.
- MockCatalogReader.MockModifiableViewRelOptTable.MockModifiableViewTable - Class in org.apache.calcite.test.catalog
-
A mock of ModifiableViewTable that can unwrap a mock RelOptTable.
- MockCatalogReader.MockModifiableViewRelOptTable.MockViewTableMacro - Class in org.apache.calcite.test.catalog
-
A TableMacro that creates mock ModifiableViewTable.
- MockCatalogReader.MockRelViewTable - Class in org.apache.calcite.test.catalog
-
Mock implementation of
Prepare.AbstractPreparingTable
which holdsViewTable
and delegatesMockCatalogReader.MockTable.toRel(org.apache.calcite.plan.RelOptTable.ToRelContext)
call to the view. - MockCatalogReader.MockSchema - Class in org.apache.calcite.test.catalog
-
Mock schema.
- MockCatalogReader.MockTable - Class in org.apache.calcite.test.catalog
-
Mock implementation of
Prepare.PreparingTable
. - MockCatalogReader.MockViewTable - Class in org.apache.calcite.test.catalog
-
Mock implementation of
Prepare.PreparingTable
for views. - MockCatalogReader.MustFilterMockTable - Class in org.apache.calcite.test.catalog
-
Mock implementation of
MockCatalogReader.MockTable
that supports must-filter fields. - MockCatalogReaderDynamic - Class in org.apache.calcite.test.catalog
-
Registers dynamic tables.
- MockCatalogReaderDynamic(RelDataTypeFactory, boolean) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReaderDynamic
-
Creates a MockCatalogReader.
- MockCatalogReaderExtended - Class in org.apache.calcite.test.catalog
-
Adds some extra tables to the mock catalog.
- MockCatalogReaderExtended(RelDataTypeFactory, boolean) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReaderExtended
-
Creates a MockCatalogReader.
- MockCatalogReaderSimple - Class in org.apache.calcite.test.catalog
-
Simple catalog reader for testing.
- MockCatalogReaderSimple(RelDataTypeFactory, boolean) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReaderSimple
-
Creates a MockCatalogReader.
- MockDdlExecutor - Class in org.apache.calcite.test
-
Executes the few DDL commands.
- MockDdlExecutor() - Constructor for class org.apache.calcite.test.MockDdlExecutor
- MockRelOptPlanner - Class in org.apache.calcite.test
-
MockRelOptPlanner is a mock implementation of the
RelOptPlanner
interface. - MockRelOptPlanner(Context) - Constructor for class org.apache.calcite.test.MockRelOptPlanner
-
Creates MockRelOptPlanner.
- MockSchema(String) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockSchema
- MockSqlOperatorTable - Class in org.apache.calcite.test
-
Mock operator table for testing purposes.
- MockSqlOperatorTable.BadTableFunction - Class in org.apache.calcite.test
-
Another bad table function: declares itself as a table function but does not return CURSOR.
- MockSqlOperatorTable.CompositeFunction - Class in org.apache.calcite.test
-
"COMPOSITE" user-defined scalar function.
- MockSqlOperatorTable.DedupFunction - Class in org.apache.calcite.test
-
"DEDUP" user-defined table function.
- MockSqlOperatorTable.DynamicTypeFunction - Class in org.apache.calcite.test
-
"DYNTYPE" user-defined table function.
- MockSqlOperatorTable.InvalidTableFunction - Class in org.apache.calcite.test
-
Invalid user-defined table function with multiple input tables with row semantics.
- MockSqlOperatorTable.MapFunction - Class in org.apache.calcite.test
-
"MAP" user-defined function.
- MockSqlOperatorTable.MyAggFunc - Class in org.apache.calcite.test
-
"MYAGGFUNC" user-defined aggregate function.
- MockSqlOperatorTable.MyAvgAggFunction - Class in org.apache.calcite.test
-
"MYAGG" user-defined aggregate function.
- MockSqlOperatorTable.MyFunction - Class in org.apache.calcite.test
-
"MYFUN" user-defined scalar function.
- MockSqlOperatorTable.NotATableFunction - Class in org.apache.calcite.test
-
Not valid as a table function, even though it returns CURSOR, because it does not implement
SqlTableFunction
. - MockSqlOperatorTable.RampFunction - Class in org.apache.calcite.test
-
"RAMP" user-defined table function.
- MockSqlOperatorTable.RowFunction - Class in org.apache.calcite.test
-
"ROW_FUNC" user-defined table function whose return type is row type with nullable and non-nullable fields.
- MockSqlOperatorTable.ScoreTableFunction - Class in org.apache.calcite.test
-
"Score" user-defined table function.
- MockSqlOperatorTable.SimilarlityTableFunction - Class in org.apache.calcite.test
-
Similarity performs an analysis on two data sets, which are both tables of two columns, treated as the x and y axes of a graph.
- MockSqlOperatorTable.SplitFunction - Class in org.apache.calcite.test
-
"SPLIT" user-defined function.
- MockSqlOperatorTable.StructuredFunction - Class in org.apache.calcite.test
-
"STRUCTURED_FUNC" user-defined function whose return type is structured type.
- MockSqlOperatorTable.TopNTableFunction - Class in org.apache.calcite.test
-
"TopN" user-defined table function.
- MockTable(MockCatalogReader, boolean, boolean, double, List<Map.Entry<String, RelDataType>>, List<Integer>, RelDataType, List<RelCollation>, List<String>, Set<String>, StructKind, MockCatalogReader.ColumnResolver, InitializerExpressionFactory) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
-
Copy constructor.
- MockTable(MockCatalogReader, String, String, String, boolean, boolean, double, MockCatalogReader.ColumnResolver, InitializerExpressionFactory) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- MockTable(MockCatalogReader, String, String, String, boolean, boolean, double, MockCatalogReader.ColumnResolver, InitializerExpressionFactory, Double) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- mod(byte, byte) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
MOD
operator applied to byte values. - mod(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
MOD
operator applied to int values. - mod(int, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
- mod(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
MOD
operator applied to long values. - mod(short, short) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
MOD
operator applied to short values. - mod(BigDecimal, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- mod(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
- Mod - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A percent remainder operation, such as (a % b), for numeric operands.
- MOD - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Arithmetic remainder operator, "MOD" (and "%" in some dialects).
- MOD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MOD - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Arithmetic remainder function
MOD
. - mode - Variable in class org.apache.calcite.runtime.JsonFunctions.JsonPathContext
- MODE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
MODE
aggregate function. - MODE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
MODE
aggregate function. - model() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.MODEL
. - model() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- model(String) - Static method in class org.apache.calcite.test.CalciteAssert
-
Short-hand for
CalciteAssert.that().with(Config.EMPTY).withModel(model)
. - MODEL - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
URI of the model.
- MODEL_URI - Enum constant in enum org.apache.calcite.model.ModelHandler.ExtraOperand
-
URI of model, e.g.
- ModelHandler - Class in org.apache.calcite.model
-
Reads a model and creates schema objects accordingly.
- ModelHandler(CalciteConnection, String) - Constructor for class org.apache.calcite.model.ModelHandler
- ModelHandler.ExtraOperand - Enum in org.apache.calcite.model
-
Extra operands automatically injected into a
JsonCustomSchema.operand
, as extra context for the adapter. - modifiable - Variable in class org.apache.calcite.jdbc.CalcitePrepare.AnalyzeViewResult
- modifiable - Variable in class org.apache.calcite.model.JsonView
-
Whether this view should allow INSERT requests.
- MODIFIABLE_TABLE_GET_MODIFIABLE_COLLECTION - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ModifiableTable - Interface in org.apache.calcite.schema
-
A table that can be modified.
- ModifiableView - Interface in org.apache.calcite.schema
-
A modifiable view onto
ModifiableTable
. - modifiableViewMustBeBasedOnSingleTable() - Method in interface org.apache.calcite.runtime.CalciteResource
- modifiableViewMustHaveOnlyEqualityPredicates() - Method in interface org.apache.calcite.runtime.CalciteResource
- modifiableViewTable(CalcitePrepare.AnalyzeViewResult, String, List<String>, List<String>, CalciteSchema) - Method in class org.apache.calcite.schema.impl.ViewTableMacro
-
Allows a sub-class to return an extension of
ModifiableViewTable
by overriding this method. - modifiableViewTable(CalcitePrepare.AnalyzeViewResult, String, List<String>, List<String>, CalciteSchema) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable.MockViewTableMacro
- ModifiableViewTable - Class in org.apache.calcite.schema.impl
-
Extension to
ViewTable
that is modifiable. - ModifiableViewTable(Type, RelProtoDataType, String, List<String>, List<String>, Table, Path, RexNode, ImmutableIntList) - Constructor for class org.apache.calcite.schema.impl.ModifiableViewTable
-
Creates a ModifiableViewTable.
- modifier - Variable in class org.apache.calcite.linq4j.tree.ClassDeclaration
- modifier - Variable in class org.apache.calcite.linq4j.tree.ConstructorDeclaration
- modifier - Variable in class org.apache.calcite.linq4j.tree.FieldDeclaration
- modifier - Variable in class org.apache.calcite.linq4j.tree.MethodDeclaration
- modifier - Variable in class org.apache.calcite.linq4j.tree.ParameterExpression
- modifiers - Variable in class org.apache.calcite.linq4j.tree.DeclarationStatement
- modifiers - Variable in class org.apache.calcite.util.format.postgresql.format.compiled.CompiledPattern
- modulo(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic remainder operation.
- modulo(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic remainder operation.
- Modulo - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An arithmetic remainder operation, such as (a % b) in C# or (a Mod b) in Visual Basic.
- moduloAssign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a remainder assignment operation.
- moduloAssign(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a remainder assignment operation.
- moduloAssign(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a remainder assignment operation.
- ModuloAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An arithmetic remainder compound assignment operation, such as (a %= b) in C#.
- mon - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- Mon - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- MON - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- MONGO_QUERYABLE_AGGREGATE - Enum constant in enum org.apache.calcite.adapter.mongodb.MongoMethod
- MONGO_QUERYABLE_FIND - Enum constant in enum org.apache.calcite.adapter.mongodb.MongoMethod
- MongoAggregate - Class in org.apache.calcite.adapter.mongodb
-
Implementation of
Aggregate
relational expression in MongoDB. - MongoAggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.adapter.mongodb.MongoAggregate
-
Deprecated.
- MongoAggregate(RelOptCluster, RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.adapter.mongodb.MongoAggregate
- MongoFilter - Class in org.apache.calcite.adapter.mongodb
-
Implementation of a
Filter
relational expression in MongoDB. - MongoFilter(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.calcite.adapter.mongodb.MongoFilter
- MongoMethod - Enum in org.apache.calcite.adapter.mongodb
-
Builtin methods in the MongoDB adapter.
- MongoProject - Class in org.apache.calcite.adapter.mongodb
-
Implementation of
Project
relational expression in MongoDB. - MongoProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.adapter.mongodb.MongoProject
- MongoProject(RelOptCluster, RelTraitSet, RelNode, List<RexNode>, RelDataType, int) - Constructor for class org.apache.calcite.adapter.mongodb.MongoProject
-
Deprecated.
- MongoRel - Interface in org.apache.calcite.adapter.mongodb
-
Relational expression that uses Mongo calling convention.
- MongoRel.Implementor - Class in org.apache.calcite.adapter.mongodb
-
Callback for the implementation process that converts a tree of
MongoRel
nodes into a MongoDB query. - MongoRules - Class in org.apache.calcite.adapter.mongodb
-
Rules and relational operators for
MONGO
calling convention. - MongoSchema - Class in org.apache.calcite.adapter.mongodb
-
Schema mapped onto a directory of MONGO files.
- MongoSchemaFactory - Class in org.apache.calcite.adapter.mongodb
-
Factory that creates a
MongoSchema
. - MongoSchemaFactory() - Constructor for class org.apache.calcite.adapter.mongodb.MongoSchemaFactory
- MongoSort - Class in org.apache.calcite.adapter.mongodb
-
Implementation of
Sort
relational expression in MongoDB. - MongoSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.calcite.adapter.mongodb.MongoSort
- MongoTable - Class in org.apache.calcite.adapter.mongodb
-
Table based on a MongoDB collection.
- MongoTable.MongoQueryable<T> - Class in org.apache.calcite.adapter.mongodb
-
Implementation of
Queryable
based on aMongoTable
. - MongoTableScan - Class in org.apache.calcite.adapter.mongodb
-
Relational expression representing a scan of a MongoDB collection.
- MongoTableScan(RelOptCluster, RelTraitSet, RelOptTable, MongoTable, RelDataType) - Constructor for class org.apache.calcite.adapter.mongodb.MongoTableScan
-
Creates a MongoTableScan.
- MongoToEnumerableConverter - Class in org.apache.calcite.adapter.mongodb
-
Relational expression representing a scan of a table in a Mongo data source.
- MongoToEnumerableConverter(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.adapter.mongodb.MongoToEnumerableConverter
- MongoToEnumerableConverterRule - Class in org.apache.calcite.adapter.mongodb
-
Rule to convert a relational expression from
MongoRel.CONVENTION
toEnumerableConvention
. - MongoToEnumerableConverterRule(ConverterRule.Config) - Constructor for class org.apache.calcite.adapter.mongodb.MongoToEnumerableConverterRule
-
Called from the Config.
- MONOTONIC - Enum constant in enum org.apache.calcite.sql.validate.SqlMonotonicity
-
Catch-all value for expressions that have some monotonic properties.
- monotonicColumnSet - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- monotonicity() - Method in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Converts the direction to a
SqlMonotonicity
. - MonotonicSupplier<E> - Class in org.apache.calcite.util
-
Supplier that awaits a value and allows the value to be set, once, to a not-null value.
- MonotonicSupplier() - Constructor for class org.apache.calcite.util.MonotonicSupplier
- month - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- Month - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- MONTH - Enum constant in enum org.apache.calcite.adapter.druid.Granularity.Type
- MONTH - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- MONTH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
MONTH
operator. - MONTH_VARIANTS - Static variable in class org.apache.calcite.test.SqlOperatorTest
- MonthCompiledPattern - Class in org.apache.calcite.util.format.postgresql.format.compiled
-
The date/time format compiled component for a text representation of a month.
- MonthCompiledPattern(Set<PatternModifier>, CapitalizationEnum, TextStyle) - Constructor for class org.apache.calcite.util.format.postgresql.format.compiled.MonthCompiledPattern
- monthEpoch() - Method in interface org.apache.calcite.rel.type.TimeFrame
-
Returns a month number where this time frame is at the start of a cycle.
- MonthFormatPattern - Class in org.apache.calcite.util.format.postgresql.format
-
The date/time format component for a text representation of a month.
- MonthFormatPattern(String) - Constructor for class org.apache.calcite.util.format.postgresql.format.MonthFormatPattern
- MONTHNAME - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "MONTHNAME(datetime)" function; returns the name of the month, in the current locale, of a TIMESTAMP or DATE argument.
- MONTHNAME_WITH_DATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MONTHNAME_WITH_TIMESTAMP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- monthNameWithDate(int, Locale) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
MONTHNAME
function, applied to a DATE argument. - monthNameWithTimestamp(long, Locale) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
MONTHNAME
function, applied to a TIMESTAMP argument. - MONTHS_IN_YEAR - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- moreThanOneMappedColumn(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- moreThanOneValueInList(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- MOUNTS - Enum constant in enum org.apache.calcite.adapter.os.OsQueryType
- MountsTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "mounts".
- moveNext() - Method in class org.apache.calcite.adapter.file.CsvEnumerator
- moveNext() - Method in class org.apache.calcite.adapter.file.JsonEnumerator
- moveNext() - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleEnumerator
- moveNext() - Method in class org.apache.calcite.adapter.kafka.KafkaMessageEnumerator
- moveNext() - Method in class org.apache.calcite.adapter.os.OsQuery
- moveNext() - Method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.SplunkResultEnumerator
- moveNext() - Method in class org.apache.calcite.linq4j.CartesianProductEnumerator
- moveNext() - Method in class org.apache.calcite.linq4j.DelegatingEnumerator
- moveNext() - Method in interface org.apache.calcite.linq4j.Enumerator
-
Advances the enumerator to the next element of the collection.
- moveNext() - Method in class org.apache.calcite.linq4j.MemoryEnumerator
- moveNext() - Method in class org.apache.calcite.linq4j.TransformedEnumerator
- moveToHead(List<? extends E>, Predicate<? super E>) - Static method in class org.apache.calcite.util.Util
-
Returns a list with any elements for which the predicate is true moved to the head of the list.
- MS - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- MSSQL - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
A collection of operators that are in Microsoft SQL Server (MSSql) but not in standard SQL.
- MSSQL - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- MSSQL_CONVERT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "CONVERT(type, expr [,style])" function (Microsoft SQL Server).
- MSSQL_TYPE_SYSTEM - Static variable in class org.apache.calcite.sql.dialect.MssqlSqlDialect
-
Mssql type system.
- MssqlSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Microsoft SQL Server database. - MssqlSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.MssqlSqlDialect
-
Creates a MssqlSqlDialect.
- MULTI_FUNCTION - Enum constant in enum org.apache.calcite.util.mapping.MappingType
- MULTI_JOIN_BOTH_PROJECT - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that matches a
LogicalJoin
whose inputs are both aMultiJoin
with interveningLogicalProject
s, and pulls the Projects up above the Join. - MULTI_JOIN_LEFT_PROJECT - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.MULTI_JOIN_BOTH_PROJECT
but only the left input has an intervening Project. - MULTI_JOIN_OPTIMIZE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that re-orders a
Join
using a heuristic planner. - MULTI_JOIN_OPTIMIZE_BUSHY - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that finds an approximately optimal ordering for join operators using a heuristic algorithm and can handle bushy joins.
- MULTI_JOIN_RIGHT_PROJECT - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.MULTI_JOIN_BOTH_PROJECT
but only the right input has an intervening Project. - MULTI_STRING_CONCAT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MULTI_STRING_CONCAT_WITH_NULL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MULTI_STRING_CONCAT_WITH_SEPARATOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MULTI_TYPE_OBJECT_CONCAT_WITH_SEPARATOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MULTI_TYPE_STRING_ARRAY_CONCAT_WITH_SEPARATOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MulticastRelOptListener - Class in org.apache.calcite.plan
-
MulticastRelOptListener implements the
RelOptListener
interface by forwarding events on to a collection of other listeners. - MulticastRelOptListener() - Constructor for class org.apache.calcite.plan.MulticastRelOptListener
-
Creates a new empty multicast listener.
- MultiJoin - Class in org.apache.calcite.rel.rules
-
A MultiJoin represents a join of N inputs, whereas regular Joins represent strictly binary joins.
- MultiJoin(RelOptCluster, List<RelNode>, RexNode, RelDataType, boolean, List<? extends RexNode>, List<JoinRelType>, List<? extends ImmutableBitSet>, ImmutableMap<Integer, ImmutableIntList>, RexNode) - Constructor for class org.apache.calcite.rel.rules.MultiJoin
-
Constructs a MultiJoin.
- MultiJoinOptimizeBushyRule - Class in org.apache.calcite.rel.rules
-
Planner rule that finds an approximately optimal ordering for join operators using a heuristic algorithm.
- MultiJoinOptimizeBushyRule(RelFactories.JoinFactory, RelFactories.ProjectFactory) - Constructor for class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule
-
Deprecated.
- MultiJoinOptimizeBushyRule(MultiJoinOptimizeBushyRule.Config) - Constructor for class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule
-
Creates a MultiJoinOptimizeBushyRule.
- MultiJoinOptimizeBushyRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule
-
Deprecated.
- MultiJoinOptimizeBushyRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- MultiJoinProjectTransposeRule - Class in org.apache.calcite.rel.rules
-
MultiJoinProjectTransposeRule implements the rule for pulling
LogicalProject
s that are on top of aMultiJoin
and beneath aLogicalJoin
so theLogicalProject
appears above theLogicalJoin
. - MultiJoinProjectTransposeRule(RelOptRuleOperand, String) - Constructor for class org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule
-
Deprecated.
- MultiJoinProjectTransposeRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule
-
Deprecated.
- MultiJoinProjectTransposeRule(MultiJoinProjectTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule
-
Creates a MultiJoinProjectTransposeRule.
- MultiJoinProjectTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- MULTILINESTRING - Enum constant in enum org.apache.calcite.runtime.SpatialTypeUtils.SpatialType
- multiple() - Method in class org.apache.calcite.plan.RelTraitDef
-
Whether a relational expression may possess more than one instance of this trait simultaneously.
- multiple() - Method in class org.apache.calcite.rel.RelCollationTraitDef
- multipleCapturingGroupsForRegexpFunctions(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- multipleRowSemanticsTables(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- MULTIPLICATION_TABLE_METHOD - Static variable in class org.apache.calcite.util.Smalls
- multiplicationTable(int, int, Integer) - Static method in class org.apache.calcite.util.Smalls
-
A function that generates multiplication table of
ncol
columns xnrow
rows. - multiply(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
*
operator applied to int values. - multiply(int, Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
*
operator applied to int values; right side may be null. - multiply(Double, Double) - Static method in class org.apache.calcite.util.NumberUtil
-
Returns the product of two numbers, or null if either is null.
- multiply(Integer, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
*
operator applied to int values; left side may be null. - multiply(Integer, Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
*
operator applied to nullable int values. - multiply(Integer, Long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
*
operator applied to nullable int and long values. - multiply(Long, Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
*
operator applied to nullable long and int values. - multiply(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
*
operator applied to nullable BigDecimal values. - multiply(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic multiplication operation that does not have overflow checking.
- multiply(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic multiplication operation that does not have overflow checking.
- multiply(Mapping, Mapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Multiplies one mapping by another.
- Multiply - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A multiplication operation, such as (a * b), without overflow checking, for numeric operands.
- MULTIPLY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Arithmetic multiplication operator, '
*
'. - MULTIPLY_OPERATOR - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Type-checking strategy for the "*" operator.
- multiplyAny(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
*
operator applied to Object values (at least one operand has ANY type; either may be null). - multiplyAssign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a multiplication assignment operation that does not have overflow checking.
- multiplyAssign(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a multiplication assignment operation that does not have overflow checking.
- multiplyAssign(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a multiplication assignment operation that does not have overflow checking.
- MultiplyAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A multiplication compound assignment operation, such as (a *= b), without overflow checking, for numeric operands.
- multiplyAssignChecked(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a multiplication assignment operation that has overflow checking.
- multiplyAssignChecked(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a multiplication assignment operation that has overflow checking.
- multiplyAssignChecked(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a multiplication assignment operation that has overflow checking.
- MultiplyAssignChecked - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A multiplication compound assignment operation, such as (a *= b), that has overflow checking, for numeric operands.
- multiplyBy(double) - Method in interface org.apache.calcite.plan.RelOptCost
-
Multiplies this cost by a scalar factor.
- multiplyBy(double) - Method in class org.apache.calcite.plan.RelOptCostImpl
- multiplyChecked(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic multiplication operation that has overflow checking.
- multiplyChecked(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic multiplication operation that has overflow checking.
- MultiplyChecked - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An multiplication operation, such as (a * b), that has overflow checking, for numeric operands.
- multiplyDivide(Expression, BigDecimal, BigDecimal) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
-
Multiplies an expression by a constant and divides by another constant, optimizing appropriately.
- multiplyDivide(RexNode, BigDecimal, BigDecimal) - Method in class org.apache.calcite.rex.RexBuilder
- multiplyDivide(SqlParserPos, RexNode, BigDecimal, BigDecimal) - Method in class org.apache.calcite.rex.RexBuilder
- MULTIPOINT - Enum constant in enum org.apache.calcite.runtime.SpatialTypeUtils.SpatialType
- MULTIPOLYGON - Enum constant in enum org.apache.calcite.runtime.SpatialTypeUtils.SpatialType
- multiset(RelNode) - Static method in class org.apache.calcite.rex.RexSubQuery
-
Creates a MULTISET sub-query.
- MULTISET - Enum constant in enum org.apache.calcite.sql.babel.TableCollectionType
-
Duplicate rows are permitted, in compliance with the ANSI SQL:2011 standard.
- MULTISET - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- MULTISET - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- MULTISET - Static variable in class org.apache.calcite.sql.type.OperandTypes
- MULTISET - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns the same type as the multiset carries.
- MULTISET_ELEMENT_FORCE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns the element type of a MULTISET, with nullability enforced.
- MULTISET_EXCEPT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
MULTISET EXCEPT [ALL]
operator. - MULTISET_EXCEPT_ALL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MULTISET_EXCEPT_DISTINCT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MULTISET_EXCEPT_DISTINCT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
MULTISET EXCEPT DISTINCT
operator. - MULTISET_INTERSECT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
MULTISET INTERSECT [ALL]
operator. - MULTISET_INTERSECT_ALL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MULTISET_INTERSECT_DISTINCT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MULTISET_INTERSECT_DISTINCT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
MULTISET INTERSECT DISTINCT
operator. - MULTISET_MULTISET - Static variable in class org.apache.calcite.sql.type.OperandTypes
- MULTISET_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.MULTISET
but returns with nullability if any of the operands is nullable. - MULTISET_PROJECT_ONLY - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns the type of the only column of a multiset.
- MULTISET_PROJECT0 - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns a multiset of column #0 of a multiset.
- MULTISET_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The MULTISET Query Constructor.
- MULTISET_QUERY_CONSTRUCTOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MULTISET
query constructor. - MULTISET_RECORD - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns a multiset of the first column of a multiset.
- MULTISET_UNION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
MULTISET UNION [ALL]
operator. - MULTISET_UNION_ALL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MULTISET_UNION_DISTINCT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- MULTISET_UNION_DISTINCT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
MULTISET UNION DISTINCT
operator. - MULTISET_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The MULTISET Value Constructor.
- MULTISET_VALUE_CONSTRUCTOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
MULTISET
value constructor. - multisetExceptAll(Collection<E>, Collection<E>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MULTISET EXCEPT ALL function.
- multisetExceptDistinct(Collection<E>, Collection<E>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MULTISET EXCEPT DISTINCT function.
- multiSetFlatten() - Method in class org.apache.calcite.piglet.PigRelBuilder
-
Flattens the top relation will all multiset columns.
- multiSetFlatten(List<Integer>, List<String>) - Method in class org.apache.calcite.piglet.PigRelBuilder
-
Flattens the top relation on provided columns.
- multisetIntersectAll(Collection<E>, Collection<E>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MULTISET INTERSECT ALL function.
- multisetIntersectDistinct(Collection<E>, Collection<E>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MULTISET INTERSECT DISTINCT function.
- MultisetOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Parameter type-checking strategy where types must be ([nullable] Multiset, [nullable] Multiset), and the two types must have the same element type.
- MultisetOperandTypeChecker() - Constructor for class org.apache.calcite.sql.type.MultisetOperandTypeChecker
- multisetQuery(Function<RelBuilder, RelNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a MULTISET sub-query.
- MultisetSqlType - Class in org.apache.calcite.sql.type
-
MultisetSqlType represents a standard SQL2003 multiset type.
- MultisetSqlType(RelDataType, boolean) - Constructor for class org.apache.calcite.sql.type.MultisetSqlType
-
Constructs a new MultisetSqlType.
- multisetUnionAll(Collection, Collection) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MULTISET UNION ALL function.
- multisetUnionDistinct(Collection, Collection) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the MULTISET UNION function.
- MULTIVALENT_STRING_SUM_PRECISION - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy for String concatenation.
- MULTIVALENT_STRING_SUM_PRECISION_NOT_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.MULTIVALENT_STRING_SUM_PRECISION
and usingSqlTypeTransforms.TO_NOT_NULLABLE
. - MULTIVALENT_STRING_SUM_PRECISION_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.MULTIVALENT_STRING_SUM_PRECISION
and usingSqlTypeTransforms.TO_NULLABLE
. - MULTIVALENT_STRING_SUM_PRECISION_NULLABLE_ALL - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.MULTIVALENT_STRING_SUM_PRECISION
and usingSqlTypeTransforms.TO_NULLABLE_ALL
. - MULTIVALENT_STRING_WITH_SEP_SUM_PRECISION - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy for String concatenation with separator.
- MULTIVALENT_STRING_WITH_SEP_SUM_PRECISION_ARG0_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- MULTIVALENT_STRING_WITH_SEP_SUM_PRECISION_NOT_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- mustFilter(int) - Method in interface org.apache.calcite.sql.validate.SemanticTable
-
Returns whether
column
must be filtered in any query that references this table. - mustFilter(int) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MustFilterMockTable
- mustFilterFields - Variable in class org.apache.calcite.sql.validate.IdentifierNamespace
-
Ordinals of fields that must be filtered.
- mustFilterFieldsMissing(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- MustFilterMockCatalogReader - Class in org.apache.calcite.test.catalog
-
Mock catalog reader that tags a few columns in the tables as must-filter.
- mustNotNullInElse() - Method in interface org.apache.calcite.runtime.CalciteResource
- MutableAggregate - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Aggregate
. - MutableCalc - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Calc
. - MutableCollect - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Collect
. - MutableCorrelate - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Correlate
. - MutableExchange - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Exchange
. - MutableFilter - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Filter
. - MutableIntersect - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Intersect
. - MutableJoin - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Join
. - MutableMatch - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Match
. - MutableMinus - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Minus
. - MutableProject - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Project
. - MutableRel - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
RelNode
. - MutableRel(RelOptCluster, RelDataType, MutableRelType) - Constructor for class org.apache.calcite.rel.mutable.MutableRel
- MutableRels - Class in org.apache.calcite.rel.mutable
-
Utilities for dealing with
MutableRel
s. - MutableRels() - Constructor for class org.apache.calcite.rel.mutable.MutableRels
- MutableRelVisitor - Class in org.apache.calcite.rel.mutable
-
Visitor over
MutableRel
. - MutableRelVisitor() - Constructor for class org.apache.calcite.rel.mutable.MutableRelVisitor
- MutableSample - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Sample
. - MutableScan - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
TableScan
. - MutableSetOp - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
SetOp
. - MutableSetOp(RelOptCluster, RelDataType, MutableRelType, List<MutableRel>, boolean) - Constructor for class org.apache.calcite.rel.mutable.MutableSetOp
- MutableSort - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Sort
. - MutableTableFunctionScan - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
TableFunctionScan
. - MutableTableModify - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
TableModify
. - MutableUncollect - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Uncollect
. - MutableUnion - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Union
. - MutableValues - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Values
. - MutableWindow - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Window
. - mutate(List<T>) - Method in class org.apache.calcite.rex.RexShuttle
-
Applies this shuttle to each expression in a list.
- MY_DB - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- MY_PLUS_EVAL_METHOD - Static variable in class org.apache.calcite.util.Smalls
- MY_PLUS_INIT_EVAL_METHOD - Static variable in class org.apache.calcite.util.Smalls
- MyAbcdeFunction() - Constructor for class org.apache.calcite.util.Smalls.MyAbcdeFunction
- MyAggFunc() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.MyAggFunc
- MyAvgAggFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.MyAvgAggFunction
- MyDeterministicPlusFunction() - Constructor for class org.apache.calcite.util.Smalls.MyDeterministicPlusFunction
- MyExceptionFunction() - Constructor for class org.apache.calcite.util.Smalls.MyExceptionFunction
- MyFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.MyFunction
- MyIncrement() - Constructor for class org.apache.calcite.util.Smalls.MyIncrement
- MyLeftFunction() - Constructor for class org.apache.calcite.util.Smalls.MyLeftFunction
- MyPlusFunction() - Constructor for class org.apache.calcite.util.Smalls.MyPlusFunction
- MyPlusInitFunction(FunctionContext) - Constructor for class org.apache.calcite.util.Smalls.MyPlusInitFunction
- MYSQL - Enum constant in enum org.apache.calcite.config.Lex
-
Lexical policy similar to MySQL.
- MYSQL - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
A collection of operators that are in MySQL but not in standard SQL.
- MYSQL - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- MYSQL - Enum constant in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
- MYSQL_5 - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that instructs Calcite to use SQL semantics consistent with MySQL version 5.x.
- MYSQL_ANSI - Enum constant in enum org.apache.calcite.config.Lex
-
Lexical policy similar to MySQL with ANSI_QUOTES option enabled.
- MYSQL_TYPE_SYSTEM - Static variable in class org.apache.calcite.sql.dialect.MysqlSqlDialect
-
MySQL type system.
- MysqlSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the MySQL database. - MysqlSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.MysqlSqlDialect
-
Creates a MysqlSqlDialect.
- MyStaticSumFunction() - Constructor for class org.apache.calcite.util.Smalls.MyStaticSumFunction
- MySum3() - Constructor for class org.apache.calcite.util.Smalls.MySum3
- MySumFunction() - Constructor for class org.apache.calcite.util.Smalls.MySumFunction
- MyTableFunction() - Constructor for class org.apache.calcite.util.Smalls.MyTableFunction
- MyThreeParamsSumFunctionWithFilter1() - Constructor for class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter1
- MyThreeParamsSumFunctionWithFilter2() - Constructor for class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter2
- MyToStringFunction() - Constructor for class org.apache.calcite.util.Smalls.MyToStringFunction
- MyTwoParamsSumFunctionFilter1(FunctionContext) - Constructor for class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter1
- MyTwoParamsSumFunctionFilter2() - Constructor for class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter2
N
- n - Variable in class org.apache.calcite.util.Smalls.IntString
- nakedMeasuresInAggregateQuery() - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Returns whether the validator allows measures to be used without AGGREGATE function in an aggregate query.
- nakedMeasuresInNonAggregateQuery() - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Returns whether the validator allows measures to be used without AGGREGATE function in a non-aggregate query.
- name - Variable in class org.apache.calcite.jdbc.CalciteSchema.Entry
- name - Variable in class org.apache.calcite.jdbc.CalciteSchema
- name - Variable in class org.apache.calcite.linq4j.tree.ClassDeclaration
- name - Variable in class org.apache.calcite.linq4j.tree.LabelTarget
- name - Variable in class org.apache.calcite.linq4j.tree.MethodDeclaration
- name - Variable in class org.apache.calcite.linq4j.tree.ParameterExpression
- name - Variable in class org.apache.calcite.materialize.Lattice.Measure
- name - Variable in class org.apache.calcite.model.JsonColumn
-
Column name.
- name - Variable in class org.apache.calcite.model.JsonFunction
-
Name of this function.
- name - Variable in class org.apache.calcite.model.JsonLattice
-
The name of this lattice.
- name - Variable in class org.apache.calcite.model.JsonSchema
-
Name of the schema.
- name - Variable in class org.apache.calcite.model.JsonTable
-
Name of this table.
- name - Variable in class org.apache.calcite.model.JsonType
-
Name of this type.
- name - Variable in class org.apache.calcite.model.JsonTypeAttribute
-
Name of this attribute.
- name - Variable in class org.apache.calcite.plan.RelOptAbstractTable
- name - Variable in class org.apache.calcite.profile.Profiler.Column
- name - Variable in class org.apache.calcite.rel.core.AggregateCall
- name - Variable in class org.apache.calcite.rex.RexVariable
- name - Variable in class org.apache.calcite.sql.ddl.SqlAttributeDefinition
- name - Variable in class org.apache.calcite.sql.ddl.SqlColumnDeclaration
- name - Variable in class org.apache.calcite.sql.ddl.SqlCreateForeignSchema
- name - Variable in class org.apache.calcite.sql.ddl.SqlCreateMaterializedView
- name - Variable in class org.apache.calcite.sql.ddl.SqlCreateSchema
- name - Variable in class org.apache.calcite.sql.ddl.SqlCreateTable
- name - Variable in class org.apache.calcite.sql.ddl.SqlCreateTableLike
- name - Variable in class org.apache.calcite.sql.ddl.SqlCreateType
- name - Variable in class org.apache.calcite.sql.ddl.SqlCreateView
- name - Variable in class org.apache.calcite.sql.ddl.SqlDropObject
- name - Variable in class org.apache.calcite.sql.ddl.SqlDropSchema
- name - Variable in class org.apache.calcite.sql.ddl.SqlTruncateTable
- name - Variable in class org.apache.calcite.sql.SqlWithItem
- name - Variable in class org.apache.calcite.sql.validate.SqlValidatorScope.Step
- name - Variable in class org.apache.calcite.test.RelMetadataFixture.MetadataConfig
- name - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Author
- name - Variable in class org.apache.calcite.test.schemata.hr.Department
- name - Variable in class org.apache.calcite.test.schemata.hr.Dependent
- name - Variable in class org.apache.calcite.test.schemata.hr.Employee
- name() - Element in annotation type org.apache.calcite.linq4j.function.Parameter
-
The name of the parameter.
- name() - Method in interface org.apache.calcite.rel.type.TimeFrame
-
Name of this time frame.
- name() - Method in interface org.apache.calcite.sql.SqlLiteral.SqlSymbol
-
Deprecated.
- nameExists(String) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Returns whether a field exists with the given name.
- NameMap<V> - Class in org.apache.calcite.util
-
Map whose keys are names and can be accessed with and without case sensitivity.
- NameMap() - Constructor for class org.apache.calcite.util.NameMap
-
Creates a NameMap, initially empty.
- nameMatch(String) - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- nameMatcher - Variable in class org.apache.calcite.prepare.CalciteCatalogReader
- nameMatcher() - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- nameMatcher() - Method in interface org.apache.calcite.sql.validate.SqlValidatorCatalogReader
-
Returns an implementation of
SqlNameMatcher
that matches the case-sensitivity policy. - nameMatcher() - Method in class org.apache.calcite.test.catalog.MockCatalogReader
- NameMultimap<V> - Class in org.apache.calcite.util
-
Multimap whose keys are names and can be accessed with and without case sensitivity.
- NameMultimap() - Constructor for class org.apache.calcite.util.NameMultimap
-
Creates a NameMultimap, initially empty.
- names - Variable in class org.apache.calcite.sql.advise.SqlAdvisorHint
-
Fully qualified object name as array of names.
- names - Variable in class org.apache.calcite.sql.SqlIdentifier
-
Array of the components of this compound identifier.
- names - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockDynamicTable
- names - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- names() - Method in interface org.apache.calcite.schema.Path
-
Returns the names of this path, not including the name of the root.
- names(Set<CorrelationId>) - Static method in class org.apache.calcite.rel.core.CorrelationId
-
Converts a set of names to a set of correlation ids.
- NameSet - Class in org.apache.calcite.util
-
Set of names that can be accessed with and without case sensitivity.
- NameSet() - Constructor for class org.apache.calcite.util.NameSet
-
Creates a NameSet, initially empty.
- namespace - Variable in class org.apache.calcite.sql.validate.DelegatingNamespace
- namespace - Variable in class org.apache.calcite.sql.validate.SqlQualified
- namespace - Variable in class org.apache.calcite.sql.validate.SqlValidatorScope.Resolve
- namespaces - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- NANOSECOND_VARIANTS - Static variable in class org.apache.calcite.test.SqlOperatorTest
- nAryOperatorCall(String, List<String>) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- NaryOperatorConverter - Class in org.apache.calcite.adapter.druid
-
Converts Calcite n-ary operators to Druid expressions, for example
arg1 Op arg2 Op arg3
. - NaryOperatorConverter(SqlOperator, String) - Constructor for class org.apache.calcite.adapter.druid.NaryOperatorConverter
- nation_name - Variable in class org.apache.calcite.test.schemata.tpch.TpchSchema.Customer
- NATIVE_UTF16_CHARSET_NAME - Static variable in class org.apache.calcite.util.ConversionUtil
- naturalDisallowsOnOrUsing() - Method in interface org.apache.calcite.runtime.CalciteResource
- naturalOrUsingColumnNotCompatible(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- NCHAR - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- NCLOB - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- ne(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
<gt;
operator applied to Object values (including String; neither side may be null). - ne(String, String, Comparator<String>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
<gt;
operator applied to OString values with a certain Comparator. - ne(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
<gt;
operator applied to BigDecimal values. - ne(RexNode, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- NE - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- neAny(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
<gt;
operator applied to Object values (at least one operand has ANY type, including String; neither may be null). - needCacheWhenFrameIntact() - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.LagImplementor
- needCacheWhenFrameIntact() - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- needCacheWhenFrameIntact() - Method in interface org.apache.calcite.adapter.enumerable.WinAggImplementor
- needQueryOp(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- needSameTypeParameter() - Method in interface org.apache.calcite.runtime.CalciteResource
- needsIndent() - Method in interface org.apache.calcite.sql.SqlWriter.FrameType
-
Returns whether this frame type should cause the code be further indented.
- needsIndent() - Method in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
- needsNullIndicator(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- needToCast(SqlValidatorScope, SqlNode, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
-
Returns whether a SqlNode should be cast to a target type.
- needToCast(SqlValidatorScope, SqlNode, RelDataType, SqlTypeMappingRule) - Method in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
-
Returns whether a SqlNode should be cast to a target type, using a type mapping rule to determine casting validity.
- needToImplement(Object) - Static method in class org.apache.calcite.util.Util
-
Returns a
RuntimeException
indicating that a particular feature has not been implemented, but should be. - needTypeCast(Type, Type) - Static method in class org.apache.calcite.linq4j.tree.Types
-
When trying to cast/convert a
Type
to anotherType
, it is necessary to pre-check whether the cast operation is needed. - negate() - Method in enum org.apache.calcite.plan.RelOptUtil.Logic
- negate() - Method in enum org.apache.calcite.rex.RexUnknownAs
- negate() - Method in enum org.apache.calcite.sql.SqlKind
-
Returns the kind that you get if you apply NOT to this kind.
- negate() - Method in class org.apache.calcite.util.Sarg
-
Returns a Sarg that matches a value if and only this Sarg does not.
- negate(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents an arithmetic negation operation.
- negate(Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents an arithmetic negation operation.
- negate(RexBuilder, RexCall) - Static method in class org.apache.calcite.rex.RexUtil
- negate(SqlParserPos) - Method in class org.apache.calcite.piglet.Ast.NumericLiteral
- Negate - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An arithmetic negation operation, such as (-a).
- negate2() - Method in enum org.apache.calcite.plan.RelOptUtil.Logic
-
Variant of
RelOptUtil.Logic.negate()
to be used withinLogicVisitor
, where FALSE values may exist. - negateChecked(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents an arithmetic negation operation that has overflow checking.
- negateChecked(Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents an arithmetic negation operation that has overflow checking.
- NegateChecked - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An arithmetic negation operation, such as (-a), that has overflow checking.
- NEGATED_POSIX_REGEX_CASE_INSENSITIVE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- NEGATED_POSIX_REGEX_CASE_SENSITIVE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- negateNullSafe() - Method in enum org.apache.calcite.sql.SqlKind
-
Returns the kind that you get if you negate this kind.
- NEGATIVE_SCALE - Static variable in class org.apache.calcite.test.CustomTypeSystems
-
Type system that supports negative scale and has rounding mode
RoundingMode.DOWN
. - NEGATIVE_SCALE_ROUNDING_MODE_HALF_UP - Static variable in class org.apache.calcite.test.CustomTypeSystems
-
Type system that supports negative scale and has rounding mode
RoundingMode.HALF_UP
. - NEOVIEW - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- NeoviewSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Neoview database. - NeoviewSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.NeoviewSqlDialect
-
Creates a NeoviewSqlDialect.
- nest() - Method in class org.apache.calcite.rel.externalize.RelJsonWriter
- nest() - Method in interface org.apache.calcite.rel.RelWriter
-
Returns whether the writer prefers nested values.
- nestBlock() - Method in interface org.apache.calcite.adapter.enumerable.NestedBlockBuilder
-
Starts nested code block.
- nestBlock() - Method in class org.apache.calcite.adapter.enumerable.NestedBlockBuilderImpl
-
Starts nested code block.
- nestBlock(BlockBuilder) - Method in interface org.apache.calcite.adapter.enumerable.NestedBlockBuilder
-
Uses given block as the new code context.
- nestBlock(BlockBuilder) - Method in class org.apache.calcite.adapter.enumerable.NestedBlockBuilderImpl
-
Uses given block as the new code context.
- NESTED_LOOP_JOIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- nestedAggIllegal() - Method in interface org.apache.calcite.runtime.CalciteResource
- NestedBlockBuilder - Interface in org.apache.calcite.adapter.enumerable
-
Allows to build nested code blocks with tracking of current context.
- NestedBlockBuilderImpl - Class in org.apache.calcite.adapter.enumerable
-
Allows to build nested code blocks with tracking of current context.
- NestedBlockBuilderImpl(BlockBuilder) - Constructor for class org.apache.calcite.adapter.enumerable.NestedBlockBuilderImpl
-
Constructs nested block builders starting of a given code block.
- nestedLoopJoin(Enumerable<TSource>, Enumerable<TInner>, Predicate2<TSource, TInner>, Function2<? super TSource, ? super TInner, TResult>, JoinType) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Correlates the elements of two sequences based on a predicate.
- NETEZZA - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- NetezzaSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Netezza database. - NetezzaSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.NetezzaSqlDialect
-
Creates a NetezzaSqlDialect.
- New - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An operation that calls a constructor to create a new object, such as new SampleType().
- NEW - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- new_(Constructor) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewExpression that represents calling the specified constructor that takes no arguments.
- new_(Constructor, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewExpression that represents calling the specified constructor with the specified arguments.
- new_(Constructor, Iterable<? extends Expression>, Iterable<? extends MemberDeclaration>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewExpression that represents calling the specified constructor with the specified arguments.
- new_(Constructor, Iterable<? extends Expression>, MemberDeclaration...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewExpression that represents calling the specified constructor with the specified arguments, using varargs.
- new_(Constructor, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewExpression that represents calling the specified constructor with the specified arguments, using varargs.
- new_(Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewExpression that represents calling the parameterless constructor of the specified type.
- new_(Type, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewExpression that represents calling the constructor of the specified type whose parameters are assignable from the specified arguments.
- new_(Type, Iterable<? extends Expression>, Iterable<? extends MemberDeclaration>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewExpression that represents calling the constructor of the specified type whose parameters are assignable from the specified arguments.
- new_(Type, Iterable<? extends Expression>, MemberDeclaration...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewExpression that represents calling the constructor of the specified type whose parameters are assignable from the specified arguments, using varargs.
- new_(Type, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewExpression that represents calling the constructor of the specified type whose parameters are assignable from the specified arguments, using varargs.
- NEW_SPECIFICATION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
New specification.
- newAggregateRel(RelBuilder, Aggregate, List<AggregateCall>) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Does a shallow clone of oldAggRel and updates aggCalls.
- newArrayBounds(Type, int, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewArrayExpression that represents creating an array that has a specified rank.
- NewArrayBounds - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An operation that creates a new array, in which the bounds for each dimension are specified, such as new SampleType[dim1, dim2] in C# or New SampleType(dim1, dim2) in Visual Basic.
- NewArrayExpression - Class in org.apache.calcite.linq4j.tree
-
Represents creating a new array and possibly initializing the elements of the new array.
- NewArrayExpression(Type, int, Expression, List<Expression>) - Constructor for class org.apache.calcite.linq4j.tree.NewArrayExpression
- newArrayInit(Type, int, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewArrayExpression that represents creating a n-dimensional array and initializing it from a list of elements.
- newArrayInit(Type, int, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewArrayExpression that represents creating an n-dimensional array and initializing it from a list of elements, using varargs.
- newArrayInit(Type, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewArrayExpression that represents creating a one-dimensional array and initializing it from a list of elements.
- newArrayInit(Type, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a NewArrayExpression that represents creating a one-dimensional array and initializing it from a list of elements, using varargs.
- NewArrayInit - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An operation that creates a new one-dimensional array and initializes it from a list of elements, such as new SampleType[]{a, b, c} in C# or New SampleType(){a, b, c} in Visual Basic.
- newAttributeInitializer(RelDataType, SqlFunction, int, List<RexNode>, InitializerContext) - Method in interface org.apache.calcite.sql2rel.InitializerExpressionFactory
-
Creates an expression which evaluates to the initializer expression for a particular attribute of a structured type.
- newAttributeInitializer(RelDataType, SqlFunction, int, List<RexNode>, InitializerContext) - Method in class org.apache.calcite.sql2rel.NullInitializerExpressionFactory
- newAttributeInitializer(RelDataType, SqlFunction, int, List<RexNode>, InitializerContext) - Method in class org.apache.calcite.test.catalog.CountingFactory
- newBuilder(int) - Static method in class org.apache.calcite.interpreter.Row
-
Create a RowBuilder object that eases creation of a new row.
- newCalcRel(RelBuilder, RelDataType, List<RexNode>) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Adds a calculation with the expressions to compute the original aggregate calls from the decomposed ones.
- newColumnDefaultValue(RelOptTable, int, InitializerContext) - Method in interface org.apache.calcite.sql2rel.InitializerExpressionFactory
-
Creates an expression which evaluates to the default value for a particular column.
- newColumnDefaultValue(RelOptTable, int, InitializerContext) - Method in class org.apache.calcite.sql2rel.NullInitializerExpressionFactory
- newColumnDefaultValue(RelOptTable, int, InitializerContext) - Method in class org.apache.calcite.test.catalog.CountingFactory
- newColumnDefaultValue(RelOptTable, int, InitializerContext) - Method in class org.apache.calcite.test.catalog.VirtualColumnsExpressionFactory
- newConfigBuilder() - Static method in class org.apache.calcite.tools.Frameworks
-
Creates a config builder with each setting initialized to its default value.
- newConfigBuilder(FrameworkConfig) - Static method in class org.apache.calcite.tools.Frameworks
-
Creates a config builder initializing each setting from an existing config.
- newConnection(UnregisteredDriver, AvaticaFactory, String, Properties) - Method in class org.apache.calcite.jdbc.CalciteFactory
- newConnection(UnregisteredDriver, AvaticaFactory, String, Properties, CalciteSchema, JavaTypeFactory) - Method in class org.apache.calcite.jdbc.CalciteFactory
-
Creates a connection with a root schema.
- newConnection(UnregisteredDriver, AvaticaFactory, String, Properties, CalciteSchema, JavaTypeFactory) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory
- newContextException(int, int, int, int, Resources.ExInst<?>) - Static method in class org.apache.calcite.sql.SqlUtil
-
Wraps an exception with context.
- newContextException(SqlParserPos, Resources.ExInst<?>) - Static method in class org.apache.calcite.sql.SqlUtil
-
Wraps an exception with context.
- newContextException(SqlParserPos, Resources.ExInst<?>, String) - Static method in class org.apache.calcite.sql.SqlUtil
-
Wraps an exception with context.
- newDatabaseMetaData(AvaticaConnection) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory
- newError(Resources.ExInst<SqlValidatorException>) - Method in class org.apache.calcite.rel.core.Aggregate.AggCallBinding
- newError(Resources.ExInst<SqlValidatorException>) - Method in class org.apache.calcite.rex.RexCallBinding
- newError(Resources.ExInst<SqlValidatorException>) - Method in class org.apache.calcite.sql.ExplicitOperatorBinding
- newError(Resources.ExInst<SqlValidatorException>) - Method in class org.apache.calcite.sql.SqlCallBinding
- newError(Resources.ExInst<SqlValidatorException>) - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Wraps a validation error with context appropriate to this operator call.
- NewExpression - Class in org.apache.calcite.linq4j.tree
-
Represents a constructor call.
- NewExpression(Type, List<Expression>, List<MemberDeclaration>) - Constructor for class org.apache.calcite.linq4j.tree.NewExpression
- newFieldTrimmer() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Creates a RelFieldTrimmer.
- newInternal() - Static method in class org.apache.calcite.util.Util
-
Deprecated.Throw new
AssertionError
- newInternal(String) - Static method in class org.apache.calcite.util.Util
-
Deprecated.Throw new
AssertionError
- newInternal(Throwable) - Static method in class org.apache.calcite.util.Util
-
Deprecated.Throw new
RuntimeException
if checked; throw raw exception if unchecked orError
- newInternal(Throwable, String) - Static method in class org.apache.calcite.sql.SqlDialect.FakeUtil
-
Deprecated.
- newInternal(Throwable, String) - Static method in class org.apache.calcite.util.Util
-
Deprecated.Throw new
AssertionError
if applicable; orRuntimeException
if e is checked; or raw exception if e is unchecked orError
. - newlineAfterClose - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- newlineAfterOpen - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- newlineAfterSep - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
-
Whether to print a newline after each separator.
- newlineAndIndent() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- newlineAndIndent() - Method in interface org.apache.calcite.sql.SqlWriter
-
Prints a new line, and indents.
- newlineAndIndent(int) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- newlineBeforeClose - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- newlineBeforeSep - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
-
Whether to print a newline before each separator.
- newName(String) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Creates a name for a new variable, unique within this block.
- newPreparedStatement(AvaticaConnection, Meta.StatementHandle, Meta.Signature, int, int, int) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory
- newResultSet(AvaticaStatement, QueryState, Meta.Signature, TimeZone, Meta.Frame) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory
- newResultSetMetaData(AvaticaStatement, Meta.Signature) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory
- newStatement(AvaticaConnection, Meta.StatementHandle, int, int, int) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory
- newValidationError(Resources.ExInst<SqlValidatorException>) - Method in class org.apache.calcite.sql.SqlCallBinding
-
Constructs a new validation error for the call.
- newValidationError(SqlNode, Resources.ExInst<SqlValidatorException>) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Adds "line x, column y" context to a validator exception.
- newValidationError(SqlNode, Resources.ExInst<SqlValidatorException>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- newValidationSignatureError() - Method in class org.apache.calcite.sql.SqlCallBinding
-
Constructs a new validation signature error for the call.
- newValidator(SqlOperatorTable, SqlValidatorCatalogReader, RelDataTypeFactory) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Deprecated.
- newValidator(SqlOperatorTable, SqlValidatorCatalogReader, RelDataTypeFactory, SqlValidator.Config) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Factory method for
SqlValidator
. - next() - Method in class org.apache.calcite.runtime.EnumeratorCursor
- next() - Method in class org.apache.calcite.runtime.ObjectEnumeratorCursor
- next() - Method in class org.apache.calcite.util.Filterator
- next() - Method in class org.apache.calcite.util.graph.BreadthFirstIterator
- next() - Method in class org.apache.calcite.util.graph.DepthFirstIterator
- next() - Method in class org.apache.calcite.util.graph.TopologicalOrderIterator
- NEXT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
NEXT
operator inMATCH_RECOGNIZE
. - NEXT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
NEXT
function to be used withinMATCH_RECOGNIZE
. - NEXT_VALUE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The "NEXT VALUE OF sequence" operator.
- NEXT_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The sequence next value function:
NEXT VALUE FOR sequence
. - nextClearBit(int) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns the index of the first bit that is set to
false
that occurs on or after the specified starting index. - nextLine(String, int) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- nextSetBit(int) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns the index of the first bit that is set to
true
that occurs on or after the specified starting index. - nextToken() - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Tokenizer
- nextWhitespace - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- NICKNAME - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
A nickname.
- NILADIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy for an operator which takes no operands.
- NL - Static variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- NL - Static variable in class org.apache.calcite.sql.SqlOperator
- NL - Static variable in class org.apache.calcite.test.SqlToRelTestBase
- nLogM(double, double) - Static method in class org.apache.calcite.util.Util
- nLogN(double) - Static method in class org.apache.calcite.util.Util
- NlsString - Class in org.apache.calcite.util
-
A string, optionally with
character set
andSqlCollation
. - NlsString(String, String, SqlCollation) - Constructor for class org.apache.calcite.util.NlsString
-
Easy constructor for Java string.
- NlsString(ByteString, String, SqlCollation) - Constructor for class org.apache.calcite.util.NlsString
-
Creates a string in a specified character set.
- NO_ACCESS - Enum constant in enum org.apache.calcite.plan.TableAccessMap.Mode
-
Deprecated.Table is not accessed at all.
- NO_ATTRIBUTES - Enum constant in enum org.apache.calcite.sql.SqlExplainLevel
-
Suppress all attributes.
- NO_INDICATOR - Static variable in class org.apache.calcite.rel.core.Aggregate
-
Deprecated.
- NO_TYPE - Enum constant in enum org.apache.calcite.rex.RexDigestIncludeType
- node - Variable in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- node - Variable in class org.apache.calcite.sql.SqlSpecialOperator.ReduceResult
- node - Variable in class org.apache.calcite.tools.Hoist.Variable
-
Parse tree node (typically a literal).
- node() - Method in class org.apache.calcite.sql.parser.SqlParserFixture
- node(int) - Method in interface org.apache.calcite.sql.SqlSpecialOperator.TokenSequence
- node(Matcher<SqlNode>) - Method in class org.apache.calcite.sql.parser.SqlParserFixture
- Node - Interface in org.apache.calcite.interpreter
-
Relational expression that can be executed using an interpreter.
- Node - Interface in org.apache.calcite.linq4j.tree
-
Parse tree node.
- Node(LoptJoinTree.BinaryTree, LoptJoinTree.BinaryTree, LoptJoinTree) - Constructor for class org.apache.calcite.rel.rules.LoptJoinTree.Node
- Node(SqlParserPos, Ast.Op) - Constructor for class org.apache.calcite.piglet.Ast.Node
- NODE_TYPES - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- nodeCount - Variable in class org.apache.calcite.rex.RexCall
- nodeCount - Variable in class org.apache.calcite.rex.RexWindow
- nodeCount() - Method in class org.apache.calcite.rex.RexCall
- nodeCount() - Method in class org.apache.calcite.rex.RexNode
-
Returns the number of nodes in this expression.
- nodeCount() - Method in class org.apache.calcite.rex.RexOver
- nodeCount() - Method in class org.apache.calcite.rex.RexWindowBound
-
Returns the number of nodes in this bound.
- nodeCount(List<? extends RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns the number of nodes (including leaves) in a list of expressions.
- nodeInputs - Variable in class org.apache.calcite.plan.RelOptRuleCall
- nodeList() - Method in class org.apache.calcite.sql.parser.SqlParserFixture
- nodePredicate() - Method in interface org.apache.calcite.rel.externalize.RelDotWriter.WriteOption
-
Predicate for nodes that need to be highlighted.
- Nodes - Class in org.apache.calcite.interpreter
-
Helper methods for
Node
and implementations for core relational expressions. - Nodes() - Constructor for class org.apache.calcite.interpreter.Nodes
- Nodes.CoreCompiler - Class in org.apache.calcite.interpreter
-
Extension to
Interpreter.CompilerImpl
that knows how to handle the core logicalRelNode
s. - nodeType - Variable in class org.apache.calcite.linq4j.tree.AbstractNode
- NodeTypeHintPredicate - Class in org.apache.calcite.rel.hint
-
A hint predicate that specifies which kind of relational expression the hint can be applied to.
- NodeTypeHintPredicate(NodeTypeHintPredicate.NodeType) - Constructor for class org.apache.calcite.rel.hint.NodeTypeHintPredicate
- NoElementException(String) - Constructor for exception class org.apache.calcite.util.mapping.Mappings.NoElementException
-
Creates a NoElementException.
- NoHandler(Class<? extends RelNode>) - Constructor for exception class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider.NoHandler
-
Deprecated.
- NoHandler(Class<? extends RelNode>) - Constructor for exception class org.apache.calcite.rel.metadata.MetadataHandlerProvider.NoHandler
- noIndicator(Aggregate) - Static method in class org.apache.calcite.rel.core.Aggregate
-
Deprecated.
- noInputs() - Method in interface org.apache.calcite.plan.RelRule.OperandDetailBuilder
-
Indicates that this operand takes no inputs.
- noMatch(BiPredicate<T, U>) - Method in interface org.apache.calcite.runtime.PairList
-
Returns whether the predicate is true for no pairs in this list.
- noMethod(Method) - Method in class org.apache.calcite.util.BarfingInvocationHandler
-
Called when this class (or its derived class) does not have the required method from the interface.
- NON_COST_ATTRIBUTES - Enum constant in enum org.apache.calcite.sql.SqlExplainLevel
-
Display all attributes, including id, except cost.
- NON_CUMULATIVE_COST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- NON_NULLABLE_SUFFIX - Static variable in class org.apache.calcite.rel.type.RelDataTypeImpl
-
Suffix for the digests of non-nullable types.
- nonDefaultOnEmptySet(AggContext) - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- nonDefaultOnEmptySet(AggContext) - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- nonDefaultOnEmptySet(WinAggContext) - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- NonDeterministic - Annotation Type in org.apache.calcite.linq4j.function
-
Specifies that function is NOT deterministic (i.e.
- none() - Static method in class org.apache.calcite.plan.RelOptRule
-
Deprecated.
- NONE - Enum constant in enum org.apache.calcite.adapter.enumerable.NullPolicy
- NONE - Enum constant in enum org.apache.calcite.rel.type.RelDataTypeComparability
- NONE - Enum constant in enum org.apache.calcite.rel.type.StructKind
-
This is not a structured type.
- NONE - Enum constant in enum org.apache.calcite.runtime.JsonFunctions.PathMode
- NONE - Enum constant in enum org.apache.calcite.sql.JoinConditionType
-
Join clause has no condition, for example "
FROM EMP, DEPT
". - NONE - Enum constant in enum org.apache.calcite.sql.SqlCollation.Coercibility
-
Weakest coercibility.
- NONE - Enum constant in enum org.apache.calcite.sql.SqlDialect.CalendarPolicy
- NONE - Enum constant in enum org.apache.calcite.sql.type.SqlOperandTypeChecker.Consistency
-
Do not try to make arguments consistent.
- NONE - Enum constant in enum org.apache.calcite.util.format.postgresql.DateCalendarEnum
- NONE - Static variable in interface org.apache.calcite.plan.Convention
-
Convention that for a relational expression that does not support any convention.
- NONE - Static variable in class org.apache.calcite.rel.core.Project.Flags
-
Deprecated.
- NoneConverter - Class in org.apache.calcite.rel.convert
- NoneConverter(RelOptCluster, RelNode) - Constructor for class org.apache.calcite.rel.convert.NoneConverter
- nonEquiConditions - Variable in class org.apache.calcite.rel.core.JoinInfo
- NoneToBindableConverterRule - Class in org.apache.calcite.interpreter
-
Rule to convert a relational expression from
Convention.NONE
toBindableConvention
. - NoneToBindableConverterRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.NoneToBindableConverterRule
-
Called from the Config.
- NonLeafReplayableQueryable(Queryable<T>) - Constructor for class org.apache.calcite.linq4j.QueryableDefaults.NonLeafReplayableQueryable
- NONNULL_NONNULL - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where all types must be non-NULL value.
- NonNullableAccessors - Class in org.apache.calcite.sql.type
-
This class provides non-nullable accessors for common getters.
- nonStandardFeatureUsed(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- nonStatic(int) - Method in class org.apache.calcite.util.Smalls.MultipleFunction
- noOperator(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- nOperands - Variable in class org.apache.calcite.sql.type.SameOperandTypeChecker
- normalize(RexBuilder, boolean) - Method in class org.apache.calcite.rex.RexProgram
-
Deprecated.
- normalize(RexBuilder, RexSimplify) - Method in class org.apache.calcite.rex.RexProgram
-
Creates a simplified/normalized copy of this program.
- normalize(RexBuilder, RexProgram) - Static method in class org.apache.calcite.rex.RexProgramBuilder
-
Deprecated.
- normalize(SqlOperator, List<RexNode>) - Static method in class org.apache.calcite.rex.RexNormalize
-
Normalizes the variables of a rex call.
- normalizePlan(String) - Static method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Normalizes references to subsets within the string representation of a plan.
- not() - Method in class org.apache.calcite.sql.fun.SqlBetweenOperator
- not() - Method in class org.apache.calcite.sql.fun.SqlInOperator
- not() - Method in class org.apache.calcite.sql.fun.SqlLikeOperator
- not() - Method in class org.apache.calcite.sql.fun.SqlPosixRegexOperator
- not() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns the operator that is the logical inverse of this operator.
- not(Boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
NULL → NULL, FALSE → TRUE, TRUE → FALSE.
- not(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents a bitwise complement operation.
- not(Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents a bitwise complement operation.
- not(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Negates a logical expression by adding or removing a NOT.
- not(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a NOT.
- Not - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise complement or logical negation operation.
- NOT - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- NOT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Logical
NOT
operator. - NOT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- NOT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- NOT_BETWEEN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- NOT_DEFERRABLE - Enum constant in enum org.apache.calcite.sql.babel.postgresql.SqlBegin.TransactionMode
- NOT_EQUALS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Not-equals operator, "!=" or "<>".
- NOT_EQUALS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Logical not-equals operator, '
<>
'. - NOT_ILIKE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The case-insensitive variant of the NOT LIKE operator.
- NOT_IN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
NOT IN
operator. - NOT_IN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
NOT IN
operator tests for a value's membership in a sub-query or a list of values. - NOT_LIKE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- NOT_MONOTONIC - Enum constant in enum org.apache.calcite.sql.validate.SqlMonotonicity
- NOT_NULL - Enum constant in enum org.apache.calcite.plan.Strong.Policy
-
This kind of expression is never null.
- NOT_NULLABLE - Enum constant in enum org.apache.calcite.schema.ColumnStrategy
-
Column does not have a default value, and does not allow nulls.
- NOT_POSSIBLE - Enum constant in enum org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
It is not possible for any of the arguments to be null.
- NOT_RLIKE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The regex variant of the NOT LIKE operator.
- NOT_SIMILAR_TO - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- NOT_SPECIFIED - Enum constant in enum org.apache.calcite.piglet.Ast.Direction
- NOT_SUBMULTISET_OF - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- notASequence(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- NotATableFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.NotATableFunction
- notContainsCorrelation(RelNode, CorrelationId, Litmus) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns true, and calls
Litmus.succeed()
if a given relational expression does not contain a given correlation. - notContainsWindowedAgg(Calc) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Predicate for if a
Calc
does not contain windowed aggregates. - notContainsWindowedAgg(Filter) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Predicate for if a
Filter
does not contain windowed aggregates. - notContainsWindowedAgg(Project) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Predicate for if a
Project
does not contain windowed aggregates. - notEqual(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an inequality comparison.
- notEqual(Expression, Expression, boolean, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an inequality comparison.
- NotEqual - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An inequality comparison, such as (a != b) in C# or (a <> b) in Visual Basic.
- notEquals(RexNode, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
<>
. - notFn(RexBuilder) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- notGroupExpr(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- notifyAll(Object) - Static method in class org.apache.calcite.util.Unsafe
-
Calls
Object.notifyAll()
. - notifyChosen(RelNode) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Takes care of tracing and listener notification when a rel is chosen as part of the final plan.
- notifyDiscard(RelNode) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Takes care of tracing and listener notification when a rel is discarded.
- notifyEquivalence(RelNode, Object, boolean) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Takes care of tracing and listener notification when a rel equivalence is detected.
- notifyTransformation(RelOptRuleCall, RelNode, boolean) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Takes care of tracing and listener notification when a rule's transformation is applied.
- notInCalc(Calc) - Method in class org.apache.calcite.rex.RexUtil.RexFinder
-
Returns not
RexUtil.RexFinder.inCalc(Calc)
. - notInFilter(Filter) - Method in class org.apache.calcite.rex.RexUtil.RexFinder
-
Returns not
RexUtil.RexFinder.inFilter(Filter)
. - notInJoin(Join) - Method in class org.apache.calcite.rex.RexUtil.RexFinder
-
Returns not
RexUtil.RexFinder.inJoin(Join)
. - notInProject(Project) - Method in class org.apache.calcite.rex.RexUtil.RexFinder
-
Returns not
RexUtil.RexFinder.inProject(Project)
. - notNull(RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- NotNullImplementor - Interface in org.apache.calcite.adapter.enumerable
-
Simplified version of
CallImplementor
that does not know about null semantics. - NotNullOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Parameter type-checking strategy where all operand types must not be NULL.
- NotNullOperandTypeChecker(int, boolean) - Constructor for class org.apache.calcite.sql.type.NotNullOperandTypeChecker
- notSelectDistinctExpr(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- notTemporalTable(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- noValueSuppliedForViewColumn(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- nth(int) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns the
n
th set bit. - nth(int, int, SqlSingleOperandTypeChecker) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates an operand checker that applies a single-operand checker to the
ordinal
th operand. - NTH_VALUE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
NTH_VALUE
aggregate function. - NTH_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
NTH_VALUE
aggregate function. - nthField(int, Class<?>) - Static method in class org.apache.calcite.linq4j.tree.Types
- nthField(int, Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- NTILE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
NTILE
aggregate function. - NTILE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
NTILE
aggregate function. - NULL - Enum constant in enum org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
The most common policy among the SQL built-in operators.
- NULL - Enum constant in enum org.apache.calcite.sql.SqlDialect.CalendarPolicy
- NULL - Enum constant in enum org.apache.calcite.sql.SqlJsonQueryEmptyOrErrorBehavior
- NULL - Enum constant in enum org.apache.calcite.sql.SqlJsonValueEmptyOrErrorBehavior
- NULL - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- NULL - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- NULL - Static variable in exception class org.apache.calcite.util.Util.FoundOne
-
Singleton instance.
- NULL_EQUAL_TO_EMPTY - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether to treat empty strings as null for Druid Adapter.
- NULL_EXPR - Static variable in class org.apache.calcite.adapter.enumerable.RexImpTable
- NULL_MATCHES_ANYTHING - Enum constant in enum org.apache.calcite.sql.SqlNullSemantics
-
Wildcard semantics: logically, this is not present in any SQL construct.
- NULL_MATCHES_NOTHING - Enum constant in enum org.apache.calcite.sql.SqlNullSemantics
-
Predicate semantics: e.g.
- NULL_MATCHES_NULL - Enum constant in enum org.apache.calcite.sql.SqlNullSemantics
-
GROUP BY key semantics: e.g.
- NULL_ON_NULL - Enum constant in enum org.apache.calcite.sql.SqlJsonConstructorNullClause
- NULL_SAFE_EQUAL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
NULL-safe "<=>" equal operator used by MySQL, for example
1<=>NULL
. - NULL_VALUE_NOT_ALLOWED - Enum constant in enum org.apache.calcite.sql.SqlStateCodes
-
Deprecated.
- Null4Function() - Constructor for class org.apache.calcite.util.Smalls.Null4Function
- Null8Function() - Constructor for class org.apache.calcite.util.Smalls.Null8Function
- nullable() - Method in class org.apache.calcite.linq4j.tree.ArrayLengthRecordField
- nullable() - Method in interface org.apache.calcite.linq4j.tree.Types.RecordField
- nullable(boolean) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Changes the nullability of the last field added.
- nullable(boolean) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- NULLABLE - Enum constant in enum org.apache.calcite.schema.ColumnStrategy
-
Column does not have a default value, but does allow null values.
- NULLABLE_LITERAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where type must be a literal or NULL.
- NULLABLE_MOD - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is
ReturnTypes.DECIMAL_MOD_NULLABLE
with a fallback toReturnTypes.ARG1_NULLABLE
These rules are used for modulus. - NULLABLE_SUM - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is
ReturnTypes.DECIMAL_SUM_NULLABLE
with a fallback toReturnTypes.LEAST_RESTRICTIVE
These rules are used for addition and subtraction. - nullableAll(List<? extends E>, Function1<E, Boolean>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Returns whether
predicate
is true for all elements oflist
. - NullableBigDecimalFunction1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function that takes one parameter and returns a
BigDecimal
value that may be null. - NullableDoubleFunction1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function that takes one parameter and returns a
Double
value that may be null. - nullableExists(List<? extends E>, Function1<E, Boolean>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Returns whether there is an element in
list
for whichpredicate
is true. - NullableFloatFunction1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function that takes one parameter and returns a
Float
value that may be null. - NullableIntegerFunction1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function that takes one parameter and returns an
Integer
value that may be null. - NullableLongFunction1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function that takes one parameter and returns a
Long
value that may be null. - nullableRecord(boolean) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Sets whether the record type will be nullable.
- nullables - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- NullableTest - Class in org.apache.calcite.test.schemata.hr
-
A table model that contains nullable columns.
- NullableTest(Integer, Integer, int) - Constructor for class org.apache.calcite.test.schemata.hr.NullableTest
- nullaryFunctionMap - Variable in class org.apache.calcite.jdbc.CalciteSchema
- nullAs - Variable in class org.apache.calcite.util.Sarg
- nullCollation - Variable in class org.apache.calcite.sql.SqlDialect
- nullCollation() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- NullCollation - Enum in org.apache.calcite.config
-
Strategy for how NULL values are to be sorted if NULLS FIRST or NULLS LAST are not specified in an item in the ORDER BY clause.
- nullComparison - Variable in enum org.apache.calcite.rel.RelFieldCollation.NullDirection
- nullDirection - Variable in class org.apache.calcite.rel.RelFieldCollation
-
Direction of sorting of nulls.
- nullEqualToEmpty() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.NULL_EQUAL_TO_EMPTY
. - nullEqualToEmpty() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- NULLIF - Enum constant in enum org.apache.calcite.sql.SqlKind
-
NULLIF
operator. - NULLIF - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- nullifyType(SqlNode, RelDataType) - Method in class org.apache.calcite.sql.validate.AggregatingSelectScope
- nullifyType(SqlNode, RelDataType) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- nullifyType(SqlNode, RelDataType) - Method in class org.apache.calcite.sql.validate.ParameterScope
- nullifyType(SqlNode, RelDataType) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Converts the type of an expression to nullable, if the context warrants it.
- nullIllegal() - Method in interface org.apache.calcite.runtime.CalciteResource
- NullInitializerExpressionFactory - Class in org.apache.calcite.sql2rel
-
An implementation of
InitializerExpressionFactory
that always supplies NULL. - NullInitializerExpressionFactory() - Constructor for class org.apache.calcite.sql2rel.NullInitializerExpressionFactory
- nullKeyOfJsonObjectNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- nullLiteral() - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- Nullness - Class in org.apache.calcite.linq4j
-
The methods in this class allow to cast nullable reference to a non-nullable one.
- NullPolicy - Enum in org.apache.calcite.adapter.enumerable
-
Describes when a function/operator will return null.
- NULLS_COMPARATOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- NULLS_COMPARATOR2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- NULLS_FIRST - Enum constant in enum org.apache.calcite.sql.SqlKind
-
NULLS FIRST
clause inORDER BY
. - NULLS_FIRST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- NULLS_LAST - Enum constant in enum org.apache.calcite.sql.SqlKind
-
NULLS LAST
clause inORDER BY
. - NULLS_LAST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- nullsComparator(boolean, boolean) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns a
Comparator
that handles null values. - nullsComparator(boolean, boolean, Comparator<T>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns a
Comparator
that handles null values. - NullSentinel - Enum in org.apache.calcite.rel.metadata
-
Placeholder for null values.
- nullsFirst(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Converts a sort expression to nulls first.
- nullsLast(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Converts a sort expression to nulls last.
- nullWhenCountZero(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets whether the aggregate function should evaluate to null if no rows are in the window; default false.
- number(Number) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Creates a number value of this primitive's box type.
- NumberCompiledPattern - Class in org.apache.calcite.util.format.postgresql.format.compiled
-
A date/time format compiled component that will parse a sequence of digits into a value (such as "DD").
- NumberCompiledPattern(ChronoUnitEnum, Function<ZonedDateTime, Integer>, Function<Integer, Integer>, int, int, int, int, String, Set<PatternModifier>) - Constructor for class org.apache.calcite.util.format.postgresql.format.compiled.NumberCompiledPattern
- NumberFormatPattern - Class in org.apache.calcite.util.format.postgresql.format
-
A date/time format component that will parse a sequence of digits into a value (such as "DD").
- NumberFormatPattern(String, ChronoUnitEnum, Function<ZonedDateTime, Integer>, int, int, int, int) - Constructor for class org.apache.calcite.util.format.postgresql.format.NumberFormatPattern
- NumberFormatPattern(String, ChronoUnitEnum, Function<ZonedDateTime, Integer>, Function<Integer, Integer>, int, int, int, int) - Constructor for class org.apache.calcite.util.format.postgresql.format.NumberFormatPattern
- numberLiteral(Number) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- numberLiteralOutOfRange(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- NumberUtil - Class in org.apache.calcite.util
-
Utility functions for working with numbers.
- numberValue(Number, RoundingMode) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Converts a number into a value of the type specified by this primitive using the SQL CAST rules.
- numberValue(RexNode) - Static method in class org.apache.calcite.rex.RexLiteral
-
Returns the value of a literal, cast, or unary minus, as a number; never null.
- numberValueRoundDown(Number) - Method in enum org.apache.calcite.linq4j.tree.Primitive
- numDistinctVals(Double, Double) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Returns the number of distinct values provided numSelected are selected where there are domainSize distinct values.
- NUMERIC - Enum constant in enum org.apache.calcite.sql.SqlFunctionCategory
- NUMERIC - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- NUMERIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
- NUMERIC_CHARACTER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- NUMERIC_INT32 - Static variable in class org.apache.calcite.sql.type.OperandTypes
- NUMERIC_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- NUMERIC_INTERVAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
- NUMERIC_NUMERIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
- NUMERIC_OPTIONAL_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- NUMERIC_OPTIONAL_NUMERIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
- NUMERIC_OR_INTERVAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
- NUMERIC_OR_STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- NUMERIC_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- NUMERIC_UNIT_INTERVAL_NUMERIC_LITERAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where the first operand must be numeric and the second operand must be a numeric non-NULL literal in the range 0 to 1 inclusive.
- NUMERIC_VALUE_OUT_OF_RANGE - Enum constant in enum org.apache.calcite.sql.SqlStateCodes
-
Deprecated.
- NumericComparison(T, BiFunction<T, T, T>) - Constructor for class org.apache.calcite.interpreter.AggregateNode.NumericComparison
- numericFields() - Static method in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- numTagsWritten() - Method in class org.apache.calcite.util.XmlOutput
-
Returns the total number of tags written.
- NVARCHAR - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- NVL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
NVL
function (Oracle, Spark). - NVL - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
Deprecated.
- NVL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "NVL(value, value)" function.
- NVL2 - Enum constant in enum org.apache.calcite.sql.SqlKind
-
NVL2
function (Oracle, Spark). - NVL2 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "NVL2(value, value, value)" function.
- NVL2_RESTRICTIVE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy for NVL2 function.
O
- o - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Token
- o() - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Op
- o() - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Token
-
Returns
o
. - obj - Variable in class org.apache.calcite.runtime.JsonFunctions.JsonPathContext
- obj - Variable in class org.apache.calcite.runtime.JsonFunctions.JsonValueContext
- OBJECT - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive.Flavor
-
Neither a primitive nor a boxing type.
- OBJECT_TO_STRING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ObjectEnumeratorCursor - Class in org.apache.calcite.runtime
- ObjectEnumeratorCursor(Enumerator<Object>) - Constructor for class org.apache.calcite.runtime.ObjectEnumeratorCursor
-
Creates an ObjectEnumeratorCursor.
- objectNotFound(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- objectNotFoundDidYouMean(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- objectNotFoundWithin(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- objectNotFoundWithinDidYouMean(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- OBJECTS_EQUAL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ObjectSqlType - Class in org.apache.calcite.sql.type
-
ObjectSqlType represents an SQL structured user-defined type.
- ObjectSqlType(SqlTypeName, SqlIdentifier, boolean, List<? extends RelDataTypeField>, RelDataTypeComparability) - Constructor for class org.apache.calcite.sql.type.ObjectSqlType
-
Constructs an object type.
- OBSERVER_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Define a one-to-many dependency between objects so that when one object changes state, all its dependents are notified and updated automatically.
- occurrenceNotZero() - Method in interface org.apache.calcite.runtime.CalciteResource
- OCTET_LENGTH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- OCTET_LENGTH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- octetLength(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL OCTET_LENGTH(binary) function.
- of() - Static method in class org.apache.calcite.runtime.FlatLists
-
Creates a flat list with 0 elements.
- of() - Static method in interface org.apache.calcite.runtime.ImmutablePairList
-
Creates an empty ImmutablePairList.
- of() - Static method in interface org.apache.calcite.runtime.PairList
-
Creates an empty PairList.
- of() - Static method in class org.apache.calcite.sql.parser.Span
-
Creates an empty Span.
- of() - Static method in interface org.apache.calcite.sql.SqlWriterConfig
-
Create a default SqlWriterConfig object.
- of() - Static method in class org.apache.calcite.util.CompositeList
-
Creates a CompositeList of zero lists.
- of() - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Creates an ImmutableBitSet with no bits.
- of() - Static method in class org.apache.calcite.util.ImmutableIntList
-
Returns an empty ImmutableIntList.
- of(boolean) - Static method in enum org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
- of(boolean, RangeSet<C>) - Static method in class org.apache.calcite.util.Sarg
-
Deprecated.
- of(double, List<ImmutableBitSet>) - Static method in class org.apache.calcite.schema.Statistics
-
Returns a statistic with a given row count and set of unique keys.
- of(double, List<ImmutableBitSet>, List<RelCollation>) - Static method in class org.apache.calcite.schema.Statistics
-
Returns a statistic with a given row count, set of unique keys, and collations.
- of(int) - Static method in class org.apache.calcite.rel.RelCollations
-
Creates a collation containing one field.
- of(int) - Static method in class org.apache.calcite.sql.type.SqlOperandCountRanges
- of(int) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Creates an ImmutableBitSet with the given bit set.
- of(int...) - Static method in class org.apache.calcite.util.BitSets
-
Creates a bitset with given bits set.
- of(int...) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Creates an ImmutableBitSet with the given bits set.
- of(int...) - Static method in class org.apache.calcite.util.ImmutableIntList
-
Creates an ImmutableIntList from an array of
int
. - of(int...) - Static method in class org.apache.calcite.util.Version
-
Creates a Version from a sequence of integers.
- of(int, int) - Static method in class org.apache.calcite.util.mapping.IntPair
- of(int, E) - Static method in class org.apache.calcite.linq4j.Ord
-
Creates an Ord.
- of(int, List<RelDataTypeField>) - Static method in class org.apache.calcite.rex.RexInputRef
-
Creates a reference to a given field in a list of fields.
- of(int, RelDataType) - Static method in class org.apache.calcite.rex.RexInputRef
-
Creates a reference to a given field in a row type.
- of(E) - Static method in class org.apache.calcite.util.ImmutableNullableList
-
Creates an immutable list of 1 element.
- of(ImmutableSet<RexFieldAccess>) - Static method in class org.apache.calcite.plan.Strong
-
Returns a checker that consults a set to find out whether particular field may be null.
- of(SortedSetMultimap<RelNode, RelDecorrelator.CorRef>, NavigableMap<CorrelationId, RelNode>, Map<RexFieldAccess, RelDecorrelator.CorRef>) - Static method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMap
-
Creates a CorelMap with given contents.
- of(E) - Static method in class org.apache.calcite.util.Holder
-
Creates a holder containing a given value.
- of(E) - Static method in class org.apache.calcite.util.ImmutableNullableSet
-
Creates an immutable set of 1 element.
- of(E...) - Static method in class org.apache.calcite.util.UnmodifiableArrayList
- of(E, E) - Static method in class org.apache.calcite.util.ImmutableNullableList
-
Creates an immutable list of 2 elements.
- of(E, E) - Static method in class org.apache.calcite.util.ImmutableNullableSet
-
Creates an immutable set of 2 elements.
- of(E, E, E) - Static method in class org.apache.calcite.util.ImmutableNullableList
-
Creates an immutable list of 3 elements.
- of(E, E, E) - Static method in class org.apache.calcite.util.ImmutableNullableSet
-
Creates an immutable set of 3 elements.
- of(E, E, E, E) - Static method in class org.apache.calcite.util.ImmutableNullableList
-
Creates an immutable list of 4 elements.
- of(E, E, E, E) - Static method in class org.apache.calcite.util.ImmutableNullableSet
-
Creates an immutable set of 4 elements.
- of(E, E, E, E, E) - Static method in class org.apache.calcite.util.ImmutableNullableList
-
Creates an immutable list of 5 elements.
- of(E, E, E, E, E, E) - Static method in class org.apache.calcite.util.ImmutableNullableList
-
Creates an immutable list of 6 elements.
- of(E, E, E, E, E, E...) - Static method in class org.apache.calcite.util.ImmutableNullableSet
-
Creates an immutable set of 5 or more elements.
- of(E, E, E, E, E, E, E) - Static method in class org.apache.calcite.util.ImmutableNullableList
-
Creates an immutable list of 7 elements.
- of(E, E, E, E, E, E, E, E, E...) - Static method in class org.apache.calcite.util.ImmutableNullableList
-
Creates an immutable list of 8 or more elements.
- of(E, List<? extends E>) - Static method in class org.apache.calcite.runtime.ConsList
-
Creates a ConsList.
- of(File) - Static method in class org.apache.calcite.util.Sources
- of(Double, List<ImmutableBitSet>, List<RelReferentialConstraint>, List<RelCollation>) - Static method in class org.apache.calcite.schema.Statistics
-
Returns a statistic with a given row count, set of unique keys, referential constraints, and collations.
- of(Object) - Static method in class org.apache.calcite.interpreter.Row
-
Creates a Row with one column value.
- of(Object...) - Static method in class org.apache.calcite.interpreter.Row
-
Creates a Row with variable number of values.
- of(Object...) - Static method in class org.apache.calcite.plan.Contexts
-
Returns a context that wraps an array of objects, ignoring any nulls.
- of(Object, Object) - Static method in class org.apache.calcite.interpreter.Row
-
Creates a Row with two column values.
- of(Object, Object, Object) - Static method in class org.apache.calcite.interpreter.Row
-
Creates a Row with three column values.
- of(CharSequence) - Static method in class org.apache.calcite.util.Sources
- of(Class<M>, Class<? extends MetadataHandler<M>>, Method...) - Static method in class org.apache.calcite.rel.metadata.MetadataDef
-
Creates a
MetadataDef
. - of(Integer[]) - Static method in class org.apache.calcite.util.BitSets
-
Creates a BitSet with given bits set.
- of(Iterable<? extends Number>) - Static method in class org.apache.calcite.util.BitSets
-
Creates a BitSet with given bits set.
- of(Iterable<? extends SqlOperator>) - Static method in class org.apache.calcite.sql.util.SqlOperatorTables
-
Creates an operator table that contains an immutable list of operators.
- of(Iterable<Integer>) - Static method in class org.apache.calcite.util.ImmutableBitSet
- of(Object) - Static method in class org.apache.calcite.plan.Contexts
-
Returns a context that wraps an object.
- of(Type) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Returns the Primitive object for a given primitive class.
- of(Type, Type...) - Static method in class org.apache.calcite.linq4j.tree.Types
-
Creates a type with generic parameters.
- of(String) - Static method in class org.apache.calcite.jdbc.CalcitePrepare.Query
- of(String) - Static method in enum org.apache.calcite.sql.fun.SqlLibrary
-
Looks up a value.
- of(String) - Static method in class org.apache.calcite.sql.parser.StringAndPos
-
Looks for one or two carets in a SQL string, and if present, converts them into a parser position.
- of(String) - Static method in class org.apache.calcite.util.IntegerIntervalSet
-
Parses a range of integers expressed as a string.
- of(String) - Static method in class org.apache.calcite.util.Template
-
Creates a Template for the default locale and the specified pattern.
- of(String) - Static method in class org.apache.calcite.util.Version
-
Creates a Version by parsing a string.
- of(String, int, RelDataType) - Static method in class org.apache.calcite.rex.RexPatternFieldRef
- of(String, Locale) - Static method in class org.apache.calcite.util.Template
-
Creates a Template for the specified locale and pattern.
- of(String, RexInputRef) - Static method in class org.apache.calcite.rex.RexPatternFieldRef
- of(URL) - Static method in class org.apache.calcite.util.Sources
- of(List<RelReferentialConstraint>) - Static method in class org.apache.calcite.schema.Statistics
-
Returns a statistic with a given set of referential constraints.
- of(Collection<? extends SqlNode>) - Static method in class org.apache.calcite.sql.parser.Span
-
Creates a Span of a list of nodes.
- of(BiFunction<SqlValidator, SqlCall, SqlCall>) - Static method in class org.apache.calcite.sql.type.OperandHandlers
-
Creates an operand handler that applies a function to a call.
- of(Function<String, ? extends Object>) - Static method in class org.apache.calcite.DataContexts
-
Returns an instance of
DataContext
with the given function. - of(List<? extends T>...) - Static method in class org.apache.calcite.util.CompositeList
-
Creates a CompositeList.
- of(List<? extends T>, List<? extends T>) - Static method in class org.apache.calcite.util.CompositeList
-
Creates a CompositeList of two lists.
- of(List<? extends T>, List<? extends T>, List<? extends T>) - Static method in class org.apache.calcite.util.CompositeList
-
Creates a CompositeList of three lists.
- of(List<String>, List<String>, List<IntPair>) - Static method in class org.apache.calcite.rel.RelReferentialConstraintImpl
- of(List<RelMetadataProvider>) - Static method in class org.apache.calcite.rel.metadata.ChainedRelMetadataProvider
-
Creates a chain.
- of(List<RelFieldCollation>) - Static method in class org.apache.calcite.rel.RelCollationImpl
-
Deprecated.
- of(List<RelFieldCollation>) - Static method in class org.apache.calcite.rel.RelCollations
- of(List<T>) - Static method in class org.apache.calcite.runtime.FlatLists
-
Creates a memory-, CPU- and cache-efficient immutable list from an existing list.
- of(List<T>) - Static method in class org.apache.calcite.util.CompositeList
-
Creates a CompositeList of one list.
- of(Map.Entry<? extends K, ? extends V>) - Static method in class org.apache.calcite.util.Pair
-
Creates a
Pair
from aMap.Entry
. - of(Map<String, ?>) - Static method in class org.apache.calcite.DataContexts
-
Returns an instance of
DataContext
with the given map. - of(Map<K, V>, Map<K, V>...) - Static method in class org.apache.calcite.util.CompositeMap
-
Creates a CompositeMap.
- of(Map<T, U>) - Static method in interface org.apache.calcite.runtime.PairList
-
Creates a PairList from a Map.
- of(DataSource, String) - Static method in class org.apache.calcite.runtime.ResultSetEnumerable
-
Creates a ResultSetEnumerable.
- of(DataSource, String, Function1<ResultSet, Function0<T>>) - Static method in class org.apache.calcite.runtime.ResultSetEnumerable
-
Executes a SQL query and returns the results as an enumerator, using a row builder to convert JDBC column values into rows.
- of(DataSource, String, Function1<ResultSet, Function0<T>>, ResultSetEnumerable.PreparedStatementEnricher) - Static method in class org.apache.calcite.runtime.ResultSetEnumerable
-
Executes a SQL query and returns the results as an enumerator, using a row builder to convert JDBC column values into rows.
- of(DataSource, String, Primitive[]) - Static method in class org.apache.calcite.runtime.ResultSetEnumerable
-
Creates a ResultSetEnumerable that retrieves columns as specific Java types.
- of(L, R) - Static method in class org.apache.calcite.sql.util.IdPair
-
Creates an IdPair.
- of(JavaRowFormat) - Method in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
- of(JavaTypeFactory, RelDataType, JavaRowFormat) - Static method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- of(JavaTypeFactory, RelDataType, JavaRowFormat, boolean) - Static method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- of(DataContext, Object[]) - Static method in class org.apache.calcite.runtime.FunctionContexts
-
Creates a FunctionContext.
- of(CalciteConnection, SchemaPlus) - Static method in class org.apache.calcite.DataContexts
-
Returns an instance of
DataContext
with the given connection and root schema but no variables. - of(Queryable<T>) - Static method in class org.apache.calcite.jdbc.CalcitePrepare.Query
- of(Lattice, List<Table>) - Static method in class org.apache.calcite.schema.impl.StarTable
-
Creates a StarTable and registers it in a schema.
- of(HepProgram, boolean, RelMetadataProvider) - Static method in class org.apache.calcite.tools.Programs
-
Creates a program that executes a
HepProgram
. - of(RelOptCluster, RelDataType, List<MutableRel>, RexNode, Type, Set<RelColumnMapping>) - Static method in class org.apache.calcite.rel.mutable.MutableTableFunctionScan
-
Creates a MutableTableFunctionScan.
- of(RelOptTable, int) - Static method in class org.apache.calcite.rex.RexTableInputRef.RelTableRef
- of(TableScan) - Static method in class org.apache.calcite.rel.mutable.MutableScan
-
Creates a MutableScan.
- of(Values) - Static method in class org.apache.calcite.rel.mutable.MutableValues
-
Creates a MutableValue.
- of(RelMetadataProvider) - Static method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
-
Creates a JaninoRelMetadataProvider.
- of(MutableRel) - Static method in class org.apache.calcite.rel.mutable.Holder
-
Creates a Holder.
- of(MutableRel, List<RexNode>, List<String>) - Static method in class org.apache.calcite.rel.mutable.MutableProject
-
Creates a MutableProject.
- of(MutableRel, RelOptSamplingParameters) - Static method in class org.apache.calcite.rel.mutable.MutableSample
-
Creates a MutableSample.
- of(MutableRel, RelCollation, RexNode, RexNode) - Static method in class org.apache.calcite.rel.mutable.MutableSort
-
Creates a MutableSort.
- of(MutableRel, RelDistribution) - Static method in class org.apache.calcite.rel.mutable.MutableExchange
-
Creates a MutableExchange.
- of(MutableRel, RexNode) - Static method in class org.apache.calcite.rel.mutable.MutableFilter
-
Creates a MutableFilter.
- of(MutableRel, RexProgram) - Static method in class org.apache.calcite.rel.mutable.MutableCalc
-
Creates a MutableCalc.
- of(MutableRel, ImmutableBitSet, ImmutableList<ImmutableBitSet>, List<AggregateCall>) - Static method in class org.apache.calcite.rel.mutable.MutableAggregate
-
Creates a MutableAggregate.
- of(RelDistribution.Type, ImmutableIntList) - Static method in class org.apache.calcite.rel.RelDistributions
- of(RelFieldCollation...) - Static method in class org.apache.calcite.rel.RelCollationImpl
-
Deprecated.
- of(RelFieldCollation...) - Static method in class org.apache.calcite.rel.RelCollations
- of(RelNode) - Static method in class org.apache.calcite.jdbc.CalcitePrepare.Query
- of(RelNode, Project, RelNode) - Static method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule.ViewPartialRewriting
- of(RelNode, LogicalFilter) - Static method in class org.apache.calcite.plan.VisitorDataContext
- of(RelNode, RelNode, RexNode) - Static method in class org.apache.calcite.rel.core.JoinInfo
-
Creates a
JoinInfo
by analyzing a condition. - of(RelNode, RelDataType, SqlKind) - Static method in class org.apache.calcite.rel.RelRoot
-
Creates a simple RelRoot.
- of(RelNode, SqlKind) - Static method in class org.apache.calcite.rel.RelRoot
-
Creates a simple RelRoot.
- of(RelDataType, List<? extends Pair<RexInputRef, ? extends RexNode>>) - Static method in class org.apache.calcite.plan.VisitorDataContext
- of(RelDataType, List<MutableRel>, boolean) - Static method in class org.apache.calcite.rel.mutable.MutableIntersect
-
Creates a MutableIntersect.
- of(RelDataType, List<MutableRel>, boolean) - Static method in class org.apache.calcite.rel.mutable.MutableMinus
-
Creates a MutableMinus.
- of(RelDataType, List<MutableRel>, boolean) - Static method in class org.apache.calcite.rel.mutable.MutableUnion
-
Creates a MutableUnion.
- of(RelDataType, MutableRel, boolean) - Static method in class org.apache.calcite.rel.mutable.MutableUncollect
-
Creates a MutableUncollect.
- of(RelDataType, MutableRel, String) - Static method in class org.apache.calcite.rel.mutable.MutableCollect
-
Creates a MutableCollect.
- of(RelDataType, MutableRel, List<Window.Group>, List<RexLiteral>) - Static method in class org.apache.calcite.rel.mutable.MutableWindow
-
Creates a MutableWindow.
- of(RelDataType, MutableRel, List<RexNode>) - Static method in class org.apache.calcite.rel.mutable.MutableProject
-
Creates a MutableProject.
- of(RelDataType, MutableRel, RelOptTable, Prepare.CatalogReader, TableModify.Operation, List<String>, List<RexNode>, boolean) - Static method in class org.apache.calcite.rel.mutable.MutableTableModify
-
Creates a MutableTableModify.
- of(RelDataType, MutableRel, MutableRel, CorrelationId, ImmutableBitSet, JoinRelType) - Static method in class org.apache.calcite.rel.mutable.MutableCorrelate
-
Creates a MutableCorrelate.
- of(RelDataType, MutableRel, MutableRel, RexNode, JoinRelType, Set<CorrelationId>) - Static method in class org.apache.calcite.rel.mutable.MutableJoin
-
Creates a MutableJoin.
- of(RelDataType, MutableRel, RexNode, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, ImmutableBitSet, RelCollation, RexNode) - Static method in class org.apache.calcite.rel.mutable.MutableMatch
-
Creates a MutableMatch.
- of(RelDataType, RexNode) - Static method in class org.apache.calcite.plan.VisitorDataContext
- of(RexBuilder, Iterable<RexNode>) - Static method in class org.apache.calcite.plan.RelOptPredicateList
-
Creates a RelOptPredicateList with only pulled-up predicates, no inferred predicates.
- of(RexBuilder, Iterable<RexNode>, Iterable<RexNode>, Iterable<RexNode>) - Static method in class org.apache.calcite.plan.RelOptPredicateList
-
Creates a RelOptPredicateList for a join.
- of(RexTableInputRef.RelTableRef, int, RelDataType) - Static method in class org.apache.calcite.rex.RexTableInputRef
- of(RexTableInputRef.RelTableRef, RexInputRef) - Static method in class org.apache.calcite.rex.RexTableInputRef
- of(RexUnknownAs, RangeSet<C>) - Static method in class org.apache.calcite.util.Sarg
-
Creates a search argument.
- of(SqlParserPos) - Static method in class org.apache.calcite.sql.parser.Span
-
Creates a Span with one position.
- of(SqlParserPos, List<SqlNode>) - Static method in class org.apache.calcite.sql.SqlNodeList
-
Creates a SqlNodeList with a given backing list.
- of(SqlDialect, Expression, String) - Static method in class org.apache.calcite.adapter.jdbc.JdbcConvention
- of(SqlNode) - Static method in class org.apache.calcite.sql.parser.Span
-
Creates a Span of one node.
- of(SqlNode) - Static method in class org.apache.calcite.sql.SqlNodeList
- of(SqlNodeList) - Static method in class org.apache.calcite.sql.parser.Span
-
Creates a Span of a node list.
- of(SqlNode, SqlNode) - Static method in class org.apache.calcite.sql.parser.Span
-
Creates a Span between two nodes.
- of(SqlNode, SqlNode) - Static method in class org.apache.calcite.sql.SqlNodeList
- of(SqlNode, SqlNode, SqlNode...) - Static method in class org.apache.calcite.sql.SqlNodeList
- of(SqlOperator...) - Static method in class org.apache.calcite.sql.util.SqlOperatorTables
-
Creates an operator table that contains the given operator or operators.
- of(SqlOperatorTable) - Static method in class org.apache.calcite.test.MockSqlOperatorTable
-
Returns a mock operator table based on the given operator table.
- of(SqlMonotonicity) - Static method in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Converts a
SqlMonotonicity
to a direction. - of(RuleSet) - Static method in class org.apache.calcite.tools.Programs
-
Creates a program that executes a rule set.
- of(DirectedGraph<V, E>) - Static method in class org.apache.calcite.util.graph.TopologicalOrderIterator
- of(DirectedGraph<V, E>, V) - Static method in class org.apache.calcite.util.graph.BreadthFirstIterator
- of(DirectedGraph<V, E>, V) - Static method in class org.apache.calcite.util.graph.DepthFirstIterator
-
Creates an iterable over the vertices in the given graph in a depth-first iteration order.
- of(ImmutableBitSet) - Static method in class org.apache.calcite.plan.Strong
-
Returns a checker that consults a bit set to find out whether particular inputs may be null.
- of(ImmutableIntList) - Static method in class org.apache.calcite.rel.RelCollations
-
Creates a collation containing multiple fields.
- of(ImmutableIntList) - Static method in class org.apache.calcite.util.BitSets
-
Creates a BitSet with given bits set.
- of(ImmutableIntList) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Creates an ImmutableBitSet with given bits set.
- of(ImmutableIntList, ImmutableIntList) - Static method in class org.apache.calcite.rel.core.JoinInfo
-
Creates an equi-join.
- of(Mappings.TargetMapping) - Static method in class org.apache.calcite.rex.RexPermuteInputsShuttle
-
Creates a shuttle with an empty field list.
- of(S) - Static method in class org.apache.calcite.util.TryThreadLocal
-
Creates a TryThreadLocal with a fixed initial value.
- of(T) - Static method in class org.apache.calcite.runtime.FlatLists
-
Creates a flat list with 1 element.
- of(T...) - Static method in class org.apache.calcite.runtime.FlatLists
-
Creates a memory-, CPU- and cache-efficient immutable list.
- of(T1, T2) - Static method in class org.apache.calcite.util.Pair
-
Creates a Pair of appropriate type.
- of(T, T) - Static method in class org.apache.calcite.runtime.FlatLists
-
Creates a flat list with 2 elements.
- of(T, T, T) - Static method in class org.apache.calcite.runtime.FlatLists
-
Creates a flat list with 3 elements.
- of(T, T, T, T) - Static method in class org.apache.calcite.runtime.FlatLists
-
Creates a flat list with 4 elements.
- of(T, T, T, T, T) - Static method in class org.apache.calcite.runtime.FlatLists
-
Creates a flat list with 6 elements.
- of(T, T, T, T, T, T) - Static method in class org.apache.calcite.runtime.FlatLists
-
Creates a flat list with 6 elements.
- of(T, U) - Static method in interface org.apache.calcite.runtime.ImmutablePairList
-
Creates a singleton ImmutablePairList.
- of(T, U) - Static method in interface org.apache.calcite.runtime.PairList
-
Creates a singleton PairList.
- of2(int, List<RelDataTypeField>) - Static method in class org.apache.calcite.rex.RexInputRef
-
Creates a reference to a given field in a list of fields.
- ofBox(Type) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Returns the Primitive object for a given boxing class.
- ofBoxOr(Type) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Returns the Primitive object for a given primitive or boxing class.
- ofComparable(List<T>) - Static method in class org.apache.calcite.runtime.FlatLists
- ofCopy(Iterable<List<T>>) - Static method in class org.apache.calcite.util.CompositeList
-
Creates a CompositeList.
- offset - Variable in class org.apache.calcite.adapter.cassandra.CassandraLimit
- offset - Variable in class org.apache.calcite.adapter.enumerable.EnumerableLimit
- offset - Variable in class org.apache.calcite.rel.core.Sort
- offset - Variable in class org.apache.calcite.rel.mutable.MutableSort
- offset - Variable in class org.apache.calcite.sql.fun.SqlItemOperator
- offset - Variable in class org.apache.calcite.sql.SqlOrderBy
- offset(Mappings.TargetMapping, int, int) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Returns a mapping that shifts a given mapping's source and target by a given offset.
- OFFSET - Enum constant in enum org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- OFFSET - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
OFFSET clause.
- OFFSET - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
Offset operator is ONLY used for its precedence during unparsing.
- OFFSET - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "OFFSET(index)" array subscript operator used by BigQuery.
- offsetLimitNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- offsetSource(Mappings.TargetMapping, int) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Returns a mapping that shifts a given mapping's source by a given offset, incrementing the number of sources by the minimum possible.
- offsetSource(Mappings.TargetMapping, int, int) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Returns a mapping that shifts a given mapping's source by a given offset.
- offsetTarget(Mappings.TargetMapping, int) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Returns a mapping that shifts a given mapping's target by a given offset, incrementing the number of targets by the minimum possible.
- offsetTarget(Mappings.TargetMapping, int, int) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Returns a mapping that shifts a given mapping's target by a given offset.
- ofList(Iterable<? extends RelOptRule>) - Static method in class org.apache.calcite.tools.RuleSets
-
Creates a rule set with a given collection of rules.
- ofList(RelOptRule...) - Static method in class org.apache.calcite.tools.RuleSets
-
Creates a rule set with a given array of rules.
- ofNonNull(S) - Static method in class org.apache.calcite.util.TryThreadLocal
-
Creates a TryThreadLocal with a fixed initial value whose values are never null.
- ofRules(Iterable<? extends RelOptRule>) - Static method in class org.apache.calcite.tools.Programs
-
Creates a program from a list of rules.
- ofRules(RelOptRule...) - Static method in class org.apache.calcite.tools.Programs
-
Creates a program from a list of rules.
- ofType(Class<TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- ofType(Class<TResult>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- ofType(Class<TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Filters the elements of an Enumerable based on a specified type.
- ofType(Class<TResult>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Filters the elements of an IQueryable based on a specified type.
- ofType(Iterable<TSource>, Class<TResult>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Returns elements of a given
Iterable
that are of the specified type. - ofType(Enumerable<TSource>, Class<TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Filters the elements of an Enumerable based on a specified type.
- ofType(Queryable<?>, Class<TResult>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Filters the elements of an IQueryable based on a specified type.
- ofType(Queryable<T>, Class<TResult>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Filters the elements of an IQueryable based on a specified type.
- ofType(Queryable<T>, Class<TResult>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- ofTypePredicate(Class<T2>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Creates a predicate that returns whether an object is an instance of a particular type or is null.
- ok() - Method in class org.apache.calcite.test.SqlToRelFixture
- ok() - Method in class org.apache.calcite.test.SqlValidatorFixture
- ok(String) - Method in class org.apache.calcite.sql.parser.SqlParserFixture
- OMAKASE - Enum constant in enum org.apache.calcite.plan.DeriveMode
-
Leave it to you, you decide what you cook.
- ON - Enum constant in enum org.apache.calcite.sql.JoinConditionType
-
Join clause has an
ON
condition, for example "FROM EMP JOIN DEPT ON EMP.DEPTNO = DEPT.DEPTNO
". - onCopy(RelNode, RelNode) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- onCopy(RelNode, RelNode) - Method in class org.apache.calcite.plan.hep.HepPlanner
- onCopy(RelNode, RelNode) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Called when a relational expression is copied to a similar expression.
- ONE_OR_MORE - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy that allows one or more operands.
- ONE_ROW - Enum constant in enum org.apache.calcite.sql.SqlMatchRecognize.RowsPerMatchOption
- oneInput(RelRule.OperandTransform) - Method in interface org.apache.calcite.plan.RelRule.OperandDetailBuilder
-
Indicates that this operand has a single input.
- onesComplement(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Returns the expression representing the ones complement.
- onesComplement(Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Returns the expression representing the ones complement.
- OnesComplement - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A ones complement operation, such as (~a) in C#.
- only() - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.ResolvedImpl
- ONLY_COLUMN - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy where a derived type must be a struct type with precisely one field and the returned type is the type of that field.
- onlyScalarSubQueryAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- onMatch() - Method in class org.apache.calcite.plan.volcano.VolcanoRuleCall
-
Called when all operands have matched.
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.arrow.ArrowRules.ArrowFilterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraFilterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraLimitRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraSortRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.csv.CsvProjectTableScanRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.druid.DruidRules.DruidAggregateProjectRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.druid.DruidRules.DruidAggregateRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.druid.DruidRules.DruidFilterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.druid.DruidRules.DruidHavingFilterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.druid.DruidRules.DruidPostAggregationProjectRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.druid.DruidRules.DruidProjectRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.druid.DruidRules.DruidSortRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.enumerable.EnumerableFilterToCalcRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.enumerable.EnumerableLimitRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.enumerable.EnumerableLimitSortRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMergeUnionRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.enumerable.EnumerableProjectToCalcRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.file.CsvProjectTableScanRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeFilterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeSortLimitRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.innodb.InnodbRules.InnodbSortTableScanRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.innodb.InnodbRules.InnodbFilterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.interpreter.Bindables.BindableTableScanRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.piglet.PigToSqlAggregateRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.RelOptRule
-
Receives notification about a rule match.
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.AbstractConverter.ExpandConversionRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.convert.ConverterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.convert.TraitMatchingRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AbstractJoinExtractFilterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateCaseToFilterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateExpandWithinDistinctRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateExtractProjectRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateFilterTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateJoinJoinRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateJoinRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateMergeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateProjectConstantToDummyJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateProjectMergeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateProjectPullUpConstantsRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateProjectStarTableRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateStarTableRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateUnionAggregateRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateUnionTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateValuesRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.CalcMergeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.CalcRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.CalcSplitRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.CoerceInputsRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.DateRangeRules.FilterDateRangeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ExchangeRemoveConstantKeysRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterAggregateTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterCalcMergeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterCorrelateRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterFlattenCorrelatedConditionRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterJoinRule.FilterIntoJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterJoinRule.JoinConditionPushRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterMergeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterMultiJoinMergeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterProjectTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterRemoveIsNotDistinctFromRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterSampleTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterSetOpTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterTableFunctionTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterTableScanRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterToCalcRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterWindowTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.IntersectToDistinctRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinAddRedundantSemiJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinAssociateRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinCommuteRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinDeriveIsNotNullFilterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinProjectTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinPushExpressionsRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinPushThroughJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinPushTransitivePredicatesRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinToCorrelateRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinToMultiJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinUnionTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MatchRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewOnlyAggregateRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewOnlyFilterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewOnlyJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewProjectAggregateRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewProjectFilterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewProjectJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MaterializedViewFilterScanRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MeasureRules.AggregateMeasure2Rule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MeasureRules.AggregateMeasureRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MeasureRules.FilterSortMeasureRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MeasureRules.ProjectMeasureRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MeasureRules.ProjectSortMeasureRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MinusToDistinctRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectAggregateMergeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectCalcMergeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectFilterTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectJoinJoinRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectJoinRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectJoinTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectMergeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectMultiJoinMergeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectOverSumToSum0Rule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectSetOpTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectTableScanRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectToCalcRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectToWindowRule.CalcToWindowRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectToWindowRule.ProjectToLogicalProjectAndWindowRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectWindowTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.PruneEmptyRules.RemoveEmptySingleRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.CalcReduceExpressionsRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.FilterReduceExpressionsRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.JoinReduceExpressionsRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ProjectReduceExpressionsRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.WindowReduceExpressionsRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SampleToFilterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SemiJoinFilterTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SemiJoinJoinTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SemiJoinProjectTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SemiJoinRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SemiJoinRule.JoinOnUniqueToSemiJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SemiJoinRule.JoinToSemiJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SemiJoinRule.ProjectToSemiJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SortJoinCopyRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SortJoinTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SortMergeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SortProjectTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SortRemoveConstantKeysRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SortRemoveRedundantRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SortRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SortUnionTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SpatialRules.FilterHilbertRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SubQueryRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.TableScanRule
-
Deprecated.
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.UnionEliminatorRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.UnionMergeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.UnionPullUpConstantsRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.UnionToDistinctRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.UnionToValuesRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ValuesReduceRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.stream.StreamRules.DeltaAggregateTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.stream.StreamRules.DeltaFilterTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.stream.StreamRules.DeltaJoinTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.stream.StreamRules.DeltaProjectTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.stream.StreamRules.DeltaSortTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.stream.StreamRules.DeltaTableScanRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.stream.StreamRules.DeltaTableScanToEmptyRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.stream.StreamRules.DeltaUnionTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.AdjustProjectForCountAggregateRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationForScalarAggregateRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationForScalarProjectRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.RemoveSingleAggregateRule
- onMatch(RelOptRuleCall, Values, Project, Join, RelNode, boolean) - Method in class org.apache.calcite.rel.rules.SingleValuesOptimizationRules.PruneSingleValueRule
-
onMatch function contains common optimization logic for all the SingleValueOptimization rules.
- onMatch(RexNode[]) - Method in interface org.apache.calcite.rex.RexAction
-
Deprecated.
- onNewClass(RelNode) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Called when a new class of
RelNode
is seen. - onNewClass(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- onRegister(RelOptPlanner) - Method in class org.apache.calcite.rel.AbstractRelNode
- onRegister(RelOptPlanner) - Method in interface org.apache.calcite.rel.RelNode
-
Receives notification that this expression is about to be registered.
- onRegister(RelDataTypeFactory) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- onRegister(RelDataTypeFactory) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable
- OOBINLINE - Static variable in class org.apache.calcite.runtime.SocketFactoryImpl
-
Whether out-of-band in-line is enabled.
- op - Variable in class org.apache.calcite.piglet.Ast.Node
- op - Variable in class org.apache.calcite.rex.RexCall
- op - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Call
- op(int) - Method in interface org.apache.calcite.sql.SqlSpecialOperator.TokenSequence
- op(SqlKind) - Static method in class org.apache.calcite.rex.RexUtil
- op(SqlKind, SqlOperator) - Static method in class org.apache.calcite.plan.RelOptUtil
- open(V, V) - Method in interface org.apache.calcite.util.RangeSets.Consumer
- open(V, V) - Method in interface org.apache.calcite.util.RangeSets.Handler
- OPEN_SQL_IDENTIFIER - Static variable in class org.apache.calcite.util.StackWriter
-
Directive for beginning an SQL identifier.
- OPEN_SQL_STRING_LITERAL - Static variable in class org.apache.calcite.util.StackWriter
-
Directive for beginning an SQL string literal.
- openClosed(V, V) - Method in interface org.apache.calcite.util.RangeSets.Consumer
- openClosed(V, V) - Method in interface org.apache.calcite.util.RangeSets.Handler
- openStream() - Method in interface org.apache.calcite.util.Source
- openTestLog() - Method in class org.apache.calcite.test.DiffTestCase
-
Initializes a diff-based test.
- openTestLogOutputStream(File) - Method in class org.apache.calcite.test.DiffTestCase
-
Initializes a diff-based test, overriding the default log file naming scheme altogether.
- operand - Variable in class org.apache.calcite.model.JsonCustomSchema
-
Contains attributes to be passed to the factory.
- operand - Variable in class org.apache.calcite.model.JsonCustomTable
-
Contains attributes to be passed to the factory.
- operand(int) - Method in class org.apache.calcite.sql.SqlBasicCall
- operand(int) - Method in class org.apache.calcite.sql.SqlCall
-
Returns i-th operand (0-based).
- operand(int) - Method in class org.apache.calcite.sql.SqlCallBinding
-
Returns a particular operand.
- operand(Class<? extends MutableRel>, SubstitutionVisitor.Operand...) - Static method in class org.apache.calcite.plan.SubstitutionVisitor.AbstractUnifyRule
-
Creates an operand with given inputs.
- operand(Class<R>) - Method in interface org.apache.calcite.plan.RelRule.OperandBuilder
-
Starts building an operand by specifying its class.
- operand(Class<R>, RelOptRuleOperandChildren) - Static method in class org.apache.calcite.plan.RelOptRule
-
Deprecated.
- operand(Class<R>, RelOptRuleOperand, RelOptRuleOperand...) - Static method in class org.apache.calcite.plan.RelOptRule
-
Deprecated.
- operand(Class<R>, RelTrait, Predicate<? super R>, RelOptRuleOperandChildren) - Static method in class org.apache.calcite.plan.RelOptRule
- operand(Class<R>, RelTrait, Predicate<? super R>, RelOptRuleOperand, RelOptRuleOperand...) - Static method in class org.apache.calcite.plan.RelOptRule
-
Deprecated.
- operand(Class<R>, RelTrait, RelOptRuleOperandChildren) - Static method in class org.apache.calcite.plan.RelOptRule
-
Deprecated.
- Operand(Class<? extends MutableRel>) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.Operand
- OPERAND_1_MIGHT_BE_TIME_FRAME - Static variable in class org.apache.calcite.sql.type.OperandHandlers
-
An operand handler that tries to convert operand #1 (0-based) into a time frame.
- OPERAND_AFTER - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- OPERAND_INTERVAL - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- OPERAND_MEASURES - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- OPERAND_ORDER_BY - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- OPERAND_PARTITION_BY - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- OPERAND_PATTERN - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- OPERAND_PATTERN_DEFINES - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- OPERAND_ROWS_PER_MATCH - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- OPERAND_STRICT_END - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- OPERAND_STRICT_START - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- OPERAND_SUBSET - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- OPERAND_TABLE_REF - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- operand0 - Variable in class org.apache.calcite.plan.RelOptRuleCall
- operandCount() - Method in class org.apache.calcite.rex.RexCall
- operandCount() - Method in class org.apache.calcite.sql.SqlBasicCall
- operandCount() - Method in class org.apache.calcite.sql.SqlCall
- OperandHandlers - Class in org.apache.calcite.sql.type
-
Strategies for handling operands.
- OperandHandlers() - Constructor for class org.apache.calcite.sql.type.OperandHandlers
- operandJ(Class<R>, RelTrait, Predicate<? super R>, RelOptRuleOperandChildren) - Static method in class org.apache.calcite.plan.RelOptRule
-
Deprecated.
- operandJ(Class<R>, RelTrait, Predicate<? super R>, RelOptRuleOperand, RelOptRuleOperand...) - Static method in class org.apache.calcite.plan.RelOptRule
-
Deprecated.
- operandMap(JsonSchema, Map<String, Object>) - Method in class org.apache.calcite.model.ModelHandler
-
Adds extra entries to an operand to a custom schema.
- operandMetadata(List<SqlTypeFamily>, Function<RelDataTypeFactory, List<RelDataType>>, IntFunction<String>, Predicate<Integer>) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a checker for user-defined functions (including user-defined aggregate functions, table functions, and table macros).
- OperandMetadataImpl - Class in org.apache.calcite.sql.type
-
Operand type-checking strategy user-defined functions (including user-defined aggregate functions, table functions, and table macros).
- operandNotComparable(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- operands - Variable in class org.apache.calcite.plan.RelOptRule
-
Flattened list of operands.
- operands - Variable in class org.apache.calcite.rex.RexCall
- operands() - Method in class org.apache.calcite.rex.RexCallBinding
- operands() - Method in class org.apache.calcite.sql.SqlCallBinding
-
Returns the operands to a call permuted into the same order as the formal parameters of the function.
- OperandsTypeChecking - Class in org.apache.calcite.sql.type
-
Strategies to check for allowed operand types of an operator call.
- OperandsTypeChecking() - Constructor for class org.apache.calcite.sql.type.OperandsTypeChecking
- operandSupplier() - Method in interface org.apache.calcite.plan.RelRule.Config
-
Creates the operands for the rule instance.
- operandSupplier() - Method in interface org.apache.calcite.rel.rules.AggregateProjectPullUpConstantsRule.Config
- operandSupplier() - Method in interface org.apache.calcite.rel.rules.ProjectFilterTransposeRule.Config
- OperandTypes - Class in org.apache.calcite.sql.type
-
Strategies for checking operand types.
- operation - Variable in class org.apache.calcite.rel.mutable.MutableTableModify
- OPERATOR - Static variable in class org.apache.calcite.sql.babel.postgresql.SqlBegin
- OPERATOR - Static variable in class org.apache.calcite.sql.babel.postgresql.SqlCommit
- OPERATOR - Static variable in class org.apache.calcite.sql.babel.postgresql.SqlDiscard
- OPERATOR - Static variable in class org.apache.calcite.sql.babel.postgresql.SqlRollback
- OPERATOR - Static variable in class org.apache.calcite.sql.babel.postgresql.SqlShow
- OPERATOR - Static variable in class org.apache.calcite.sql.SqlDelete
- OPERATOR - Static variable in class org.apache.calcite.sql.SqlDescribeSchema
- OPERATOR - Static variable in class org.apache.calcite.sql.SqlDescribeTable
- OPERATOR - Static variable in class org.apache.calcite.sql.SqlExplain
- OPERATOR - Static variable in class org.apache.calcite.sql.SqlInsert
- OPERATOR - Static variable in class org.apache.calcite.sql.SqlJoin
- OPERATOR - Static variable in class org.apache.calcite.sql.SqlLambda
- OPERATOR - Static variable in class org.apache.calcite.sql.SqlMerge
- OPERATOR - Static variable in class org.apache.calcite.sql.SqlOrderBy
- OPERATOR - Static variable in class org.apache.calcite.sql.SqlSetOption
- OPERATOR - Static variable in class org.apache.calcite.sql.SqlUpdate
- operators - Variable in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
-
Contains all (name, operator) pairs.
- operatorTable(String...) - Static method in class org.apache.calcite.prepare.CalciteCatalogReader
-
Creates an operator table that contains functions in the given class or classes.
- operatorTable(SqlOperatorTable) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- optimize(RelRoot, List<Prepare.Materialization>, List<CalciteSchema.LatticeEntry>) - Method in class org.apache.calcite.prepare.Prepare
-
Optimizes a query plan.
- optimize(RelDataType) - Method in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
- optimizeDeclarations(List<MemberDeclaration>) - Method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Adds new declarations (e.g.
- OptimizeShuttle - Class in org.apache.calcite.linq4j.tree
-
Shuttle that optimizes expressions.
- OptimizeShuttle() - Constructor for class org.apache.calcite.linq4j.tree.OptimizeShuttle
- optional - Variable in class org.apache.calcite.sql.type.FamilyOperandTypeChecker
- optional() - Element in annotation type org.apache.calcite.linq4j.function.Parameter
-
Returns whether the parameter is optional.
- optional() - Method in class org.apache.calcite.runtime.Pattern.PatternBuilder
- OPTIONAL - Enum constant in enum org.apache.calcite.rex.RexDigestIncludeType
- OPTIONAL - Enum constant in enum org.apache.calcite.runtime.Pattern.Op
-
Pattern that matches a pattern one time or zero times.
- OPTIONAL - Enum constant in enum org.apache.calcite.util.Optionality
-
A property is optional if an instance may or may not possess it; neither state is an error.
- Optionality - Enum in org.apache.calcite.util
-
Four states that describe whether a particular behavior or property is allowed and/or not allowed.
- optionChecker(HintOptionChecker) - Method in class org.apache.calcite.rel.hint.HintStrategy.Builder
-
Registers a hint option checker to validate the hint options.
- options() - Method in class org.apache.calcite.sql.ddl.SqlCreateForeignSchema
-
Returns options as a list of (name, value) pairs.
- options() - Method in class org.apache.calcite.sql.ddl.SqlCreateTableLike
- OpType - Enum in org.apache.calcite.linq4j
-
Operator type.
- or() - Method in class org.apache.calcite.runtime.Pattern.PatternBuilder
-
Creates a pattern that matches either of the two patterns at the top of the stack, and pushes it onto the stack.
- or(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an OR.
- or(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise OR operation.
- or(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise OR operation.
- or(HintPredicate...) - Static method in class org.apache.calcite.rel.hint.HintPredicates
-
Returns a composed hint predicate that represents a short-circuiting logical OR of an array of hint predicates
hintPredicates
. - or(RexNode...) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- or(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an OR.
- or(RexUnknownAs) - Method in enum org.apache.calcite.rex.RexUnknownAs
-
Combines this with another
RexUnknownAs
in the same way as the three-valued logic of OR. - or(SqlOperandTypeChecker) - Method in interface org.apache.calcite.sql.type.SqlOperandTypeChecker
-
Composes this with another checker using OR.
- or(SqlOperandTypeChecker...) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a checker that passes if any one of the rules passes.
- or(SqlSingleOperandTypeChecker) - Method in interface org.apache.calcite.sql.type.SqlSingleOperandTypeChecker
-
Composes this with another single-operand checker using OR.
- or(SqlSingleOperandTypeChecker...) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a single-operand checker that passes if any one of the rules passes.
- Or - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise or logical OR operation, such as (a | b) in C# or (a Or b) in Visual Basic.
- OR - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- OR - Enum constant in enum org.apache.calcite.rel.hint.CompositeHintPredicate.Composition
- OR - Enum constant in enum org.apache.calcite.runtime.Pattern.Op
-
Pattern that matches one pattern or another.
- OR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Logical "OR" operator.
- OR - Enum constant in enum org.apache.calcite.sql.type.CompositeOperandTypeChecker.Composition
- OR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Logical
OR
operator. - ORACLE - Enum constant in enum org.apache.calcite.config.Lex
-
Lexical policy similar to Oracle.
- ORACLE - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
A collection of operators that are in Oracle but not in standard SQL.
- ORACLE - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- ORACLE - Enum constant in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
- ORACLE_10 - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that instructs Calcite to use SQL semantics consistent with Oracle version 10.
- ORACLE_10 - Static variable in interface org.apache.calcite.sql.validate.SqlConformance
-
Deprecated.
- ORACLE_12 - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that instructs Calcite to use SQL semantics consistent with Oracle version 12.
- OracleSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Oracle database. - OracleSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.OracleSqlDialect
-
Creates an OracleSqlDialect.
- OracleSqlOperatorTable - Class in org.apache.calcite.sql.fun
-
Deprecated.Use
SqlLibraryOperatorTableFactory.getOperatorTable(SqlLibrary...)
instead, passingSqlLibrary.ORACLE
as argument. - OracleSqlOperatorTable() - Constructor for class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
Deprecated.
- orAssign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise OR assignment operation.
- orAssign(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise OR assignment operation.
- orAssign(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise OR assignment operation.
- OrAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise or logical OR compound assignment, such as (a |= b) in C#.
- Ord<E> - Class in org.apache.calcite.linq4j
-
Pair of an element and an ordinal.
- Ord(int, E) - Constructor for class org.apache.calcite.linq4j.Ord
-
Creates an Ord.
- ORDER - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- ORDER_BY - Enum constant in enum org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- ORDER_BY - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ORDER BY clause.
- ORDER_BY - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
ORDER BY clause of a SELECT statement.
- ORDER_BY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ORDER_BY_LIST - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
ORDER BY list.
- ORDER_BY_WITH_FETCH_AND_OFFSET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ORDER_COMPARISON - Static variable in enum org.apache.calcite.sql.SqlKind
-
Comparison operators that order values.
- orderBy(Iterable<? extends RexNode>) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets the ORDER BY BY clause to a list of expressions.
- orderBy(Enumerable<TSource>, Function1<TSource, TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Sorts the elements of a sequence in ascending order according to a key.
- orderBy(Enumerable<TSource>, Function1<TSource, TKey>, Comparator<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Sorts the elements of a sequence in ascending order by using a specified comparer.
- orderBy(Enumerable<TSource>, Function1<TSource, TKey>, Comparator<TKey>, int, int) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
A sort implementation optimized for a sort with a fetch size (LIMIT).
- orderBy(Function1<T, TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- orderBy(Function1<T, TKey>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- orderBy(Function1<TSource, TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Sorts the elements of a sequence in ascending order according to a key.
- orderBy(Function1<TSource, TKey>, Comparator<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Sorts the elements of a sequence in ascending order by using a specified comparer.
- orderBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Sorts the elements of a sequence in ascending order according to a key.
- orderBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Sorts the elements of a sequence in ascending order according to a key.
- orderBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- orderBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Sorts the elements of a sequence in ascending order by using a specified comparer.
- orderBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Sorts the elements of a sequence in ascending order by using a specified comparer.
- orderBy(Queryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- orderBy(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- orderBy(FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- orderBy(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Sorts the elements of a sequence in ascending order according to a key.
- orderBy(FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Sorts the elements of a sequence in ascending order by using a specified comparer.
- orderBy(RexNode...) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets the ORDER BY BY clause to an array of expressions.
- orderByDataTypeProhibitsRange() - Method in interface org.apache.calcite.runtime.CalciteResource
- orderByDescending(Enumerable<TSource>, Function1<TSource, TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Sorts the elements of a sequence in descending order according to a key.
- orderByDescending(Enumerable<TSource>, Function1<TSource, TKey>, Comparator<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Sorts the elements of a sequence in descending order by using a specified comparer.
- orderByDescending(Function1<T, TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- orderByDescending(Function1<T, TKey>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- orderByDescending(Function1<TSource, TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Sorts the elements of a sequence in descending order according to a key.
- orderByDescending(Function1<TSource, TKey>, Comparator<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Sorts the elements of a sequence in descending order by using a specified comparer.
- orderByDescending(Queryable<T>, FunctionExpression<Function1<T, TKey>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Sorts the elements of a sequence in descending order according to a key.
- orderByDescending(Queryable<T>, FunctionExpression<Function1<T, TKey>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Sorts the elements of a sequence in descending order according to a key.
- orderByDescending(Queryable<T>, FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- orderByDescending(Queryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Sorts the elements of a sequence in descending order by using a specified comparer.
- orderByDescending(Queryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Sorts the elements of a sequence in descending order by using a specified comparer.
- orderByDescending(Queryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- orderByDescending(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- orderByDescending(FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- orderByDescending(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Sorts the elements of a sequence in descending order according to a key.
- orderByDescending(FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Sorts the elements of a sequence in descending order by using a specified comparer.
- orderByFolding() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the line-folding policy for the ORDER BY clause.
- orderByOrdinalOutOfRange() - Method in interface org.apache.calcite.runtime.CalciteResource
- orderByOverlap() - Method in interface org.apache.calcite.runtime.CalciteResource
- orderByRangeMismatch() - Method in interface org.apache.calcite.runtime.CalciteResource
- orderByRequiresOneKey(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- OrderByScope - Class in org.apache.calcite.sql.validate
-
Represents the name-resolution context for expressions in an ORDER BY clause.
- orderbyShouldNotContainOver() - Method in interface org.apache.calcite.runtime.CalciteResource
- orderCall - Variable in class org.apache.calcite.sql.validate.SqlValidatorUtil.FlatAggregate
- ORDERED_FUNCTION - Enum constant in enum org.apache.calcite.sql.SqlSyntax
-
Function syntax with optional ORDER BY, as in "STRING_AGG(x, y ORDER BY z)".
- OrderedEnumerable<T> - Interface in org.apache.calcite.linq4j
-
Represents the result of applying a sorting operation to an
Enumerable
. - OrderedQueryable<T> - Interface in org.apache.calcite.linq4j
-
Represents the result of applying a sorting operation to a
Queryable
. - orderField(int) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
-
Creates a reference to a field to be used in an ORDER BY clause.
- ORDERING - Static variable in class org.apache.calcite.rel.RelNodes
-
Ordering for
RelNode
s. - ORDERING - Static variable in class org.apache.calcite.util.ImmutableBitSet
- ORDERING - Static variable in class org.apache.calcite.util.mapping.IntPair
-
Ordering that compares pairs lexicographically: first by their source, then by their target.
- orderKeys - Variable in class org.apache.calcite.rel.core.Match
- orderKeys - Variable in class org.apache.calcite.rel.core.Window.Group
- orderKeys - Variable in class org.apache.calcite.rel.mutable.MutableMatch
- orderKeys - Variable in class org.apache.calcite.rex.RexWindow
- orderList - Variable in class org.apache.calcite.sql.SqlOrderBy
- orderList - Variable in class org.apache.calcite.sql.validate.SqlValidatorUtil.FlatAggregate
- OrdersHistoryTable - Class in org.apache.calcite.test.schemata.orderstream
-
Table representing the history of the ORDERS stream.
- OrdersHistoryTable(ImmutableList<Object[]>) - Constructor for class org.apache.calcite.test.schemata.orderstream.OrdersHistoryTable
- OrdersStreamTableFactory - Class in org.apache.calcite.test.schemata.orderstream
-
Mock table that returns a stream of orders from a fixed array.
- OrdersStreamTableFactory() - Constructor for class org.apache.calcite.test.schemata.orderstream.OrdersStreamTableFactory
- OrdersTable - Class in org.apache.calcite.test.schemata.orderstream
-
Table representing the ORDERS stream.
- OrdersTable(ImmutableList<Object[]>) - Constructor for class org.apache.calcite.test.schemata.orderstream.OrdersTable
- OrderStmt(SqlParserPos, Ast.Identifier, Ast.Identifier, List<Pair<Ast.Identifier, Ast.Direction>>) - Constructor for class org.apache.calcite.piglet.Ast.OrderStmt
- ordinal - Variable in class org.apache.calcite.materialize.Lattice.Column
-
Ordinal of the column within the lattice.
- ordinal - Variable in class org.apache.calcite.profile.Profiler.Column
- ordinal - Variable in class org.apache.calcite.rel.core.Match.RexMRAggCall
- ordinal - Variable in class org.apache.calcite.rel.core.Window.RexWinAggCall
-
Ordinal of this aggregate within its partition.
- ordinal - Variable in class org.apache.calcite.tools.Hoist.Variable
-
Zero-based ordinal in statement.
- ordinal() - Method in interface org.apache.calcite.sql.SqlLiteral.SqlSymbol
-
Deprecated.
- ORDINAL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ORDINAL(index)" array subscript operator used by BigQuery.
- ordinalInParent - Variable in class org.apache.calcite.plan.RelOptRuleOperand
- ordinalInParent - Variable in class org.apache.calcite.rel.mutable.MutableRel
- ordinalInRule - Variable in class org.apache.calcite.plan.RelOptRuleOperand
- ORDINALITY_COLUMN_NAME - Static variable in class org.apache.calcite.sql.SqlUnnestOperator
- OrdinalReturnTypeInference - Class in org.apache.calcite.sql.type
-
Returns the type of the operand at a particular 0-based ordinal position.
- OrdinalReturnTypeInference(int) - Constructor for class org.apache.calcite.sql.type.OrdinalReturnTypeInference
- ordinals(List<RelFieldCollation>) - Static method in class org.apache.calcite.rel.RelCollations
-
Returns the indexes of the fields in a list of field collations.
- ordinals(RelCollation) - Static method in class org.apache.calcite.rel.RelCollationImpl
-
Deprecated.
- ordinals(RelCollation) - Static method in class org.apache.calcite.rel.RelCollations
-
Returns the indexes of the field collations in a given collation.
- ordinalString(Hoist.Variable) - Static method in class org.apache.calcite.tools.Hoist
-
Converts a
Hoist.Variable
to a string "?N", where N is theHoist.Variable.ordinal
. - ordinalStringIfChar(Hoist.Variable) - Static method in class org.apache.calcite.tools.Hoist
-
Converts a
Hoist.Variable
to a string "?N", where N is theHoist.Variable.ordinal
, if the fragment is a character literal. - orElse(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a conditional OR operation that evaluates the second operand only if the first operand evaluates to false.
- orElse(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a conditional OR operation that evaluates the second operand only if the first operand evaluates to false.
- orElse(SqlReturnTypeInference) - Method in interface org.apache.calcite.sql.type.SqlReturnTypeInference
-
Returns a return-type inference that applies this rule then another rule, until one of them returns a not-null result.
- OrElse - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A short-circuiting conditional OR operation, such as (a || b) in C# or (a OrElse b) in Visual Basic.
- orEmpty(Iterable<T>) - Static method in class org.apache.calcite.util.Util
- org.apache.calcite - package org.apache.calcite
-
Main package for Calcite, the dynamic data management platform.
- org.apache.calcite.adapter.arrow - package org.apache.calcite.adapter.arrow
-
Query provider that reads from Arrow files.
- org.apache.calcite.adapter.cassandra - package org.apache.calcite.adapter.cassandra
-
Cassandra query provider.
- org.apache.calcite.adapter.clone - package org.apache.calcite.adapter.clone
-
Provides utility classes.
- org.apache.calcite.adapter.csv - package org.apache.calcite.adapter.csv
-
Calcite query provider that reads from CSV (comma-separated value) files.
- org.apache.calcite.adapter.druid - package org.apache.calcite.adapter.druid
-
Query provider based on a Druid database.
- org.apache.calcite.adapter.elasticsearch - package org.apache.calcite.adapter.elasticsearch
-
Query provider based on an Elasticsearch2 DB.
- org.apache.calcite.adapter.enumerable - package org.apache.calcite.adapter.enumerable
-
Query optimizer rules for Java calling convention.
- org.apache.calcite.adapter.enumerable.impl - package org.apache.calcite.adapter.enumerable.impl
-
Calcite-specific classes for implementation of regular and window aggregates.
- org.apache.calcite.adapter.file - package org.apache.calcite.adapter.file
-
Query provider that reads from files and web pages in various formats.
- org.apache.calcite.adapter.geode.rel - package org.apache.calcite.adapter.geode.rel
-
Query provider based on Apache Geode (Gemfire) in-memory data grid.
- org.apache.calcite.adapter.geode.simple - package org.apache.calcite.adapter.geode.simple
-
Query evaluation runtime for Apache Geode adapter.
- org.apache.calcite.adapter.geode.util - package org.apache.calcite.adapter.geode.util
-
Utilities for Apache Geode adapter.
- org.apache.calcite.adapter.innodb - package org.apache.calcite.adapter.innodb
-
InnoDB query provider.
- org.apache.calcite.adapter.java - package org.apache.calcite.adapter.java
-
Query provider based on Java in-memory data structures.
- org.apache.calcite.adapter.jdbc - package org.apache.calcite.adapter.jdbc
-
Query provider based on a JDBC data source.
- org.apache.calcite.adapter.kafka - package org.apache.calcite.adapter.kafka
-
Kafka query provider.
- org.apache.calcite.adapter.mongodb - package org.apache.calcite.adapter.mongodb
-
Query provider based on a MongoDB database.
- org.apache.calcite.adapter.os - package org.apache.calcite.adapter.os
-
The OS adapter contains various table functions that let you query data sources in your operating system and environment.
- org.apache.calcite.adapter.pig - package org.apache.calcite.adapter.pig
-
Pig query provider.
- org.apache.calcite.adapter.redis - package org.apache.calcite.adapter.redis
-
Redis adapter.
- org.apache.calcite.adapter.spark - package org.apache.calcite.adapter.spark
-
Adapter based on the Apache Spark data management system.
- org.apache.calcite.adapter.splunk - package org.apache.calcite.adapter.splunk
-
Splunk query provider.
- org.apache.calcite.adapter.splunk.search - package org.apache.calcite.adapter.splunk.search
-
Executes queries via Splunk's REST API.
- org.apache.calcite.adapter.splunk.util - package org.apache.calcite.adapter.splunk.util
-
Utilities for RPC to Splunk.
- org.apache.calcite.adapter.tpcds - package org.apache.calcite.adapter.tpcds
-
TPC-DS schema.
- org.apache.calcite.adapter.tpch - package org.apache.calcite.adapter.tpch
-
TPC-H schema.
- org.apache.calcite.adapter.utils - package org.apache.calcite.adapter.utils
-
Used to put OS adapter related util classes.
- org.apache.calcite.chinook - package org.apache.calcite.chinook
-
End to end tests.
- org.apache.calcite.config - package org.apache.calcite.config
-
Configuration.
- org.apache.calcite.example.maze - package org.apache.calcite.example.maze
-
User-defined table function that generates a maze.
- org.apache.calcite.interpreter - package org.apache.calcite.interpreter
-
Provides an implementation of relational expressions using an interpreter.
- org.apache.calcite.jdbc - package org.apache.calcite.jdbc
-
JDBC driver for Calcite.
- org.apache.calcite.linq4j - package org.apache.calcite.linq4j
-
Language-integrated query for Java (linq4j) main package.
- org.apache.calcite.linq4j.function - package org.apache.calcite.linq4j.function
-
Contains definitions of functions and predicates.
- org.apache.calcite.linq4j.tree - package org.apache.calcite.linq4j.tree
-
Object model for Java expressions.
- org.apache.calcite.linq4j.util - package org.apache.calcite.linq4j.util
-
Provides utility classes.
- org.apache.calcite.materialize - package org.apache.calcite.materialize
-
Management of materialized query results.
- org.apache.calcite.model - package org.apache.calcite.model
-
Provides model files, in JSON format, defining schemas and other metadata.
- org.apache.calcite.piglet - package org.apache.calcite.piglet
-
Piglet, a Pig-like language.
- org.apache.calcite.plan - package org.apache.calcite.plan
-
Defines interfaces for constructing rule-based optimizers of relational expressions.
- org.apache.calcite.plan.hep - package org.apache.calcite.plan.hep
-
Provides a heuristic planner implementation for the interfaces in
org.apache.calcite.plan
. - org.apache.calcite.plan.visualizer - package org.apache.calcite.plan.visualizer
-
A visualizer showing how the rules are applied step-by-step.
- org.apache.calcite.plan.volcano - package org.apache.calcite.plan.volcano
-
Optimizes relational expressions.
- org.apache.calcite.prepare - package org.apache.calcite.prepare
-
Preparation of queries (parsing, planning and implementation).
- org.apache.calcite.profile - package org.apache.calcite.profile
-
Utilities to analyze data sets.
- org.apache.calcite.rel - package org.apache.calcite.rel
-
Defines relational expressions.
- org.apache.calcite.rel.convert - package org.apache.calcite.rel.convert
-
Defines relational expressions and rules for converting between calling conventions.
- org.apache.calcite.rel.core - package org.apache.calcite.rel.core
-
Defines core relational expressions.
- org.apache.calcite.rel.externalize - package org.apache.calcite.rel.externalize
-
Facilities to externalize
RelNode
s to and from XML and JSON format. - org.apache.calcite.rel.hint - package org.apache.calcite.rel.hint
-
Defines hints interfaces and utilities for relational expressions.
- org.apache.calcite.rel.logical - package org.apache.calcite.rel.logical
-
Defines logical relational expressions.
- org.apache.calcite.rel.metadata - package org.apache.calcite.rel.metadata
-
Defines metadata interfaces and utilities for relational expressions.
- org.apache.calcite.rel.metadata.janino - package org.apache.calcite.rel.metadata.janino
-
Code for generating metadata handlers.
- org.apache.calcite.rel.mutable - package org.apache.calcite.rel.mutable
-
Defines mutable relational expressions.
- org.apache.calcite.rel.rel2sql - package org.apache.calcite.rel.rel2sql
-
Translates a relational expression to SQL parse tree.
- org.apache.calcite.rel.rules - package org.apache.calcite.rel.rules
-
Provides a core set of planner rules.
- org.apache.calcite.rel.rules.materialize - package org.apache.calcite.rel.rules.materialize
-
Provides a materialized rewriting algorithm encapsulated within a planner rule.
- org.apache.calcite.rel.stream - package org.apache.calcite.rel.stream
-
Defines relational expressions for streaming.
- org.apache.calcite.rel.type - package org.apache.calcite.rel.type
-
Defines a type system for relational expressions.
- org.apache.calcite.rex - package org.apache.calcite.rex
-
Provides a language for representing row-expressions.
- org.apache.calcite.runtime - package org.apache.calcite.runtime
-
Utilities required at runtime.
- org.apache.calcite.schema - package org.apache.calcite.schema
-
Schema SPI.
- org.apache.calcite.schema.impl - package org.apache.calcite.schema.impl
-
Utilities to help implement Calcite's SPIs.
- org.apache.calcite.server - package org.apache.calcite.server
-
Provides a server for hosting Calcite connections.
- org.apache.calcite.sql - package org.apache.calcite.sql
-
Provides a SQL parser and object model.
- org.apache.calcite.sql.advise - package org.apache.calcite.sql.advise
-
Provides hints and corrections for editing SQL statements.
- org.apache.calcite.sql.babel - package org.apache.calcite.sql.babel
-
Parse tree for SQL extensions used by the Babel parser.
- org.apache.calcite.sql.babel.postgresql - package org.apache.calcite.sql.babel.postgresql
-
Parse tree for PostgreSQL extensions used by the Babel parser.
- org.apache.calcite.sql.ddl - package org.apache.calcite.sql.ddl
-
Parse tree for SQL DDL statements.
- org.apache.calcite.sql.dialect - package org.apache.calcite.sql.dialect
-
SQL unparsers for JDBC dialects.
- org.apache.calcite.sql.fun - package org.apache.calcite.sql.fun
-
Defines the set of standard SQL row-level functions and operators.
- org.apache.calcite.sql.parser - package org.apache.calcite.sql.parser
-
Classes for testing SQL Parser.
- org.apache.calcite.sql.pretty - package org.apache.calcite.sql.pretty
-
Provides a pretty-printer for SQL statements.
- org.apache.calcite.sql.test - package org.apache.calcite.sql.test
-
Classes for testing SQL.
- org.apache.calcite.sql.type - package org.apache.calcite.sql.type
-
SQL type system.
- org.apache.calcite.sql.util - package org.apache.calcite.sql.util
-
Utility classes for the SQL object model, parsing, and validation.
- org.apache.calcite.sql.validate - package org.apache.calcite.sql.validate
-
SQL validation.
- org.apache.calcite.sql.validate.implicit - package org.apache.calcite.sql.validate.implicit
-
SQL Implicit Type Cast
- org.apache.calcite.sql2rel - package org.apache.calcite.sql2rel
-
Translates a SQL parse tree to relational expression.
- org.apache.calcite.statistic - package org.apache.calcite.statistic
-
Implementations of statistics providers.
- org.apache.calcite.test - package org.apache.calcite.test
-
Classes for testing Calcite.
- org.apache.calcite.test.catalog - package org.apache.calcite.test.catalog
-
Classes for testing Catalog.
- org.apache.calcite.test.schemata.bookstore - package org.apache.calcite.test.schemata.bookstore
- org.apache.calcite.test.schemata.catchall - package org.apache.calcite.test.schemata.catchall
- org.apache.calcite.test.schemata.countries - package org.apache.calcite.test.schemata.countries
- org.apache.calcite.test.schemata.foodmart - package org.apache.calcite.test.schemata.foodmart
- org.apache.calcite.test.schemata.hr - package org.apache.calcite.test.schemata.hr
- org.apache.calcite.test.schemata.lingual - package org.apache.calcite.test.schemata.lingual
- org.apache.calcite.test.schemata.orderstream - package org.apache.calcite.test.schemata.orderstream
- org.apache.calcite.test.schemata.tpch - package org.apache.calcite.test.schemata.tpch
- org.apache.calcite.tools - package org.apache.calcite.tools
-
Provides utility classes.
- org.apache.calcite.util - package org.apache.calcite.util
-
Classes for testing Calcite.
- org.apache.calcite.util.format - package org.apache.calcite.util.format
-
Utility classes for handling format strings.
- org.apache.calcite.util.format.postgresql - package org.apache.calcite.util.format.postgresql
-
Classes for handling date/time format strings for PostgreSQL.
- org.apache.calcite.util.format.postgresql.format - package org.apache.calcite.util.format.postgresql.format
-
Classes used to build up a list of supported date/time format components.
- org.apache.calcite.util.format.postgresql.format.compiled - package org.apache.calcite.util.format.postgresql.format.compiled
-
Classes for that represent components of a parsed date/time format.
- org.apache.calcite.util.graph - package org.apache.calcite.util.graph
-
Graph-theoretic algorithms and data structures.
- org.apache.calcite.util.javac - package org.apache.calcite.util.javac
-
Provides compilers for Java code.
- org.apache.calcite.util.mapping - package org.apache.calcite.util.mapping
-
Support for algebraic maps.
- org.apache.calcite.util.trace - package org.apache.calcite.util.trace
-
Tracing services.
- originalSql - Variable in class org.apache.calcite.tools.Hoist.Hoisted
- originalSql - Variable in class org.apache.calcite.tools.Hoist.Variable
-
Original SQL of whole statement.
- ORINOCO - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- OS_VERSION - Enum constant in enum org.apache.calcite.adapter.os.OsQueryType
- OsQuery - Class in org.apache.calcite.adapter.os
-
Enumerator that reads from OS's System.
- OsQuery(String) - Constructor for class org.apache.calcite.adapter.os.OsQuery
- OsQueryTableUtil - Class in org.apache.calcite.adapter.utils
-
Used to put OS query related func.
- OsQueryType - Enum in org.apache.calcite.adapter.os
-
Get system enumeration information.
- OsVersionTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "os_version".
- other(RelDataTypeFactory, AggregateCall) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.AbstractSumSplitter
- other(RelDataTypeFactory, AggregateCall) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.CountSplitter
- other(RelDataTypeFactory, AggregateCall) - Method in interface org.apache.calcite.sql.SqlSplittableAggFunction
-
Called to generate an aggregate for the other side of the join than the side aggregate call's arguments come from.
- other(RelDataTypeFactory, AggregateCall) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.SelfSplitter
- OTHER - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive
- OTHER - Enum constant in enum org.apache.calcite.rel.core.Aggregate.Group
- OTHER - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
Table type not known to Calcite.
- OTHER - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Expression not covered by any other
SqlKind
value. - OTHER - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Same behavior as user-defined frame type.
- OTHER - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- OTHER_DDL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
DDL statement not handled above.
- OTHER_FUNCTION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Function that is not a special function.
- out - Variable in class org.apache.calcite.rel.convert.ConverterRule
- out(StringBuilder) - Method in class org.apache.calcite.util.PartiallyOrderedSet
- OUT_OF_RANGE_MESSAGE - Static variable in interface org.apache.calcite.sql.test.SqlOperatorFixture
- OUTDENT - Static variable in class org.apache.calcite.util.StackWriter
-
Directive for decreasing the indentation level.
- OUTER - Static variable in interface org.apache.calcite.rel.rules.JoinProjectTransposeRule.Config
- outerJoin - Variable in class org.apache.calcite.plan.RelOptUtil.Exists
- outOfOrderItems(List<E>) - Static method in class org.apache.calcite.util.TestUtil
-
Given a list, returns the number of elements that are not between an element that is less and an element that is greater.
- outTrait() - Method in interface org.apache.calcite.rel.convert.ConverterRule.Config
- over() - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
-
Converts this aggregate call to a windowed aggregate call.
- OVER - Enum constant in enum org.apache.calcite.sql.SqlKind
-
OVER
operator. - OVER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
OVER
operator, which applies an aggregate functions to awindow
. - OverFinder() - Constructor for class org.apache.calcite.util.Util.OverFinder
- OVERFLOW - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName.Limit
- overFolding() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the line-folding policy for the OVER clause or a window declaration.
- overlaps(SqlParserPos) - Method in class org.apache.calcite.sql.parser.SqlParserPos
- OVERLAPS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
OVERLAPS
operator for periods. - OVERLAPS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- overlay(String, String, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
OVERLAY
function. - overlay(String, String, int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
OVERLAY
function. - overlay(ByteString, ByteString, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
OVERLAY
function applied to binary strings. - overlay(ByteString, ByteString, int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
OVERLAY
function applied to binary strings. - overlay(SqlWindow, SqlValidator) - Method in class org.apache.calcite.sql.SqlWindow
-
Creates a new window by combining this one with another.
- OVERLAY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- OVERLAY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- OVERLAY3 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- overMissingOrderBy() - Method in interface org.apache.calcite.runtime.CalciteResource
- overNonAggregate() - Method in interface org.apache.calcite.runtime.CalciteResource
- overridingMethodDecl(Method, Iterable<ParameterExpression>, BlockStatement) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
-
Declares a method that overrides another method.
- OverridingSourceMapping(Mappings.SourceMapping, int, int) - Constructor for class org.apache.calcite.util.mapping.Mappings.OverridingSourceMapping
- OverridingTargetMapping(Mappings.TargetMapping, int, int) - Constructor for class org.apache.calcite.util.mapping.Mappings.OverridingTargetMapping
- OverScope - Class in org.apache.calcite.sql.validate
-
The name-resolution scope of a OVER clause.
P
- p(int) - Static method in class org.apache.calcite.test.schemata.tpch.TpchSchema
- p_brand - Variable in class org.apache.calcite.test.schemata.tpch.TpchSchema.Part
- PackageMarker - Annotation Type in org.apache.calcite.linq4j
-
This is a dummy annotation that forces javac to produce output for otherwise empty package-info.java.
- PACKAGES - Static variable in class org.apache.calcite.rel.externalize.RelJson
- Page(int, String) - Constructor for class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Page
- pageNo - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Page
- pages - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Book
- Pair<T1,
T2> - Class in org.apache.calcite.util -
Pair of objects.
- Pair(T1, T2) - Constructor for class org.apache.calcite.util.Pair
-
Creates a Pair.
- PAIR_LIST_COPY_OF - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- Pair.PairWithOrdinalConsumer<K,
V> - Interface in org.apache.calcite.util -
Represents an operation that accepts two input arguments and an ordinal, and returns no result.
- PairList<T,
U> - Interface in org.apache.calcite.runtime -
A list of pairs, stored as a quotient list.
- PairList.Builder<T,
U> - Class in org.apache.calcite.runtime -
Builds a PairList.
- PairList.Helper - Class in org.apache.calcite.runtime
-
Deprecated.
- PairList.IndexedBiConsumer<T,
U> - Interface in org.apache.calcite.runtime -
Action to be taken each step of an indexed iteration over a PairList.
- pairs() - Method in class org.apache.calcite.rel.core.JoinInfo
-
Returns a list of (left, right) key ordinals.
- pairs(List<E>) - Static method in class org.apache.calcite.util.Util
-
Given a list with N elements [e0, e1, ..., eN-1] (where N is even), returns a list of the N / 2 elements [ (e0, e1), (e2, e3), ...
- PAIRWISE_STRING_EQUIVALENCE - Static variable in class org.apache.calcite.rel.mutable.MutableRel
-
Equivalence that compares
Lists
s by theObject.toString()
of their elements. - PARACCEL - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
-
Paraccel, now called Actian Matrix.
- ParaccelSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Paraccel database. - ParaccelSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.ParaccelSqlDialect
-
Creates a ParaccelSqlDialect.
- PARAM_DATA - Static variable in class org.apache.calcite.sql.SqlWindowTableFunction
-
The data source which the table function computes with.
- PARAM_KEY - Static variable in class org.apache.calcite.sql.SqlWindowTableFunction
-
The session key(s), only used for SESSION window.
- PARAM_OFFSET - Static variable in class org.apache.calcite.sql.SqlWindowTableFunction
-
The optional align offset for each window.
- PARAM_SIZE - Static variable in class org.apache.calcite.sql.SqlWindowTableFunction
-
The window duration INTERVAL.
- PARAM_SLIDE - Static variable in class org.apache.calcite.sql.SqlWindowTableFunction
-
The slide interval, only used for HOP window.
- PARAM_TIMECOL - Static variable in class org.apache.calcite.sql.SqlWindowTableFunction
-
The time attribute column.
- parameter - Variable in class org.apache.calcite.linq4j.tree.CatchBlock
- parameter - Variable in class org.apache.calcite.linq4j.tree.DeclarationStatement
- parameter - Variable in class org.apache.calcite.linq4j.tree.FieldDeclaration
- parameter - Variable in class org.apache.calcite.linq4j.tree.ForEachStatement
- parameter(int, Type, String) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ParameterExpression.
- parameter(Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ParameterExpression node that can be used to identify a parameter or a variable in an expression tree.
- parameter(Type, String) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ParameterExpression node that can be used to identify a parameter or a variable in an expression tree.
- Parameter - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A reference to a parameter or variable that is defined in the context of the expression.
- Parameter - Annotation Type in org.apache.calcite.linq4j.function
-
Annotation that supplies metadata about a function parameter.
- ParameterExpression - Class in org.apache.calcite.linq4j.tree
-
Represents a named parameter expression.
- ParameterExpression(int, Type, String) - Constructor for class org.apache.calcite.linq4j.tree.ParameterExpression
- ParameterExpression(Type) - Constructor for class org.apache.calcite.linq4j.tree.ParameterExpression
- parameterList - Variable in class org.apache.calcite.linq4j.tree.FunctionExpression
- ParameterListBuilder() - Constructor for class org.apache.calcite.schema.impl.ReflectiveFunctionBase.ParameterListBuilder
- parameterRelTypes() - Method in interface org.apache.calcite.adapter.enumerable.AggContext
-
Returns the parameter types of the aggregate as
RelDataType
. - parameterRelTypes() - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase.AggContextImpl
- parameterRowType - Variable in class org.apache.calcite.prepare.Prepare
- parameterRowType - Variable in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- parameters - Variable in class org.apache.calcite.linq4j.tree.ConstructorDeclaration
- parameters - Variable in class org.apache.calcite.linq4j.tree.MethodDeclaration
- parameters - Variable in class org.apache.calcite.schema.impl.ReflectiveFunctionBase
-
Types of parameter for the function call.
- ParameterScope - Class in org.apache.calcite.sql.validate
-
A scope which contains nothing besides a few parameters.
- ParameterScope(SqlValidatorImpl, Map<String, RelDataType>) - Constructor for class org.apache.calcite.sql.validate.ParameterScope
- parameterTypes() - Method in interface org.apache.calcite.adapter.enumerable.AggContext
-
Returns the parameter types of the aggregate as
Type
. - parameterTypes() - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase.AggContextImpl
- paramNames() - Method in class org.apache.calcite.sql.SqlWindowTableFunction.AbstractOperandMetadata
- paramNames() - Method in class org.apache.calcite.sql.type.OperandMetadataImpl
- paramNames() - Method in interface org.apache.calcite.sql.type.SqlOperandMetadata
-
Returns the names of the parameters.
- paramNotFoundInFunctionDidYouMean(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- paramNotFoundInLambdaExpression(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- params - Variable in class org.apache.calcite.rel.mutable.MutableSample
- paramTypes(RelDataTypeFactory) - Method in class org.apache.calcite.sql.SqlWindowTableFunction.AbstractOperandMetadata
- paramTypes(RelDataTypeFactory) - Method in class org.apache.calcite.sql.type.OperandMetadataImpl
- paramTypes(RelDataTypeFactory) - Method in interface org.apache.calcite.sql.type.SqlOperandMetadata
-
Returns the types of the parameters.
- parent - Variable in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
- parent - Variable in class org.apache.calcite.materialize.LatticeChildNode
- parent - Variable in class org.apache.calcite.rel.mutable.MutableRel
- parent - Variable in enum org.apache.calcite.sql.fun.SqlLibrary
-
The current library will by default inherit functions from parent.
- parent - Variable in class org.apache.calcite.sql.validate.DelegatingScope
-
Parent scope.
- parent() - Method in interface org.apache.calcite.schema.Path
-
Returns the parent path, or null if the path is empty.
- PARENTHESES - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Comma-separated list surrounded by parentheses.
- parks(boolean) - Static method in class org.apache.calcite.test.schemata.countries.StatesTableFunction
- parse() - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- parse(Reader) - Method in class org.apache.calcite.prepare.PlannerImpl
- parse(Reader) - Method in interface org.apache.calcite.tools.Planner
-
Parses and validates a SQL statement.
- parse(String) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Calls the appropriate
valueOf(String)
method. - parse(String) - Static method in enum org.apache.calcite.sql.fun.SqlLibrary
-
Parses a comma-separated string such as "standard,oracle".
- parse(String) - Method in interface org.apache.calcite.tools.Planner
-
Parses and validates a SQL statement.
- parse(String) - Method in interface org.apache.calcite.util.format.FormatModel
-
Parses a format string using element identifiers supplied by
format
. - parse(List<String>) - Method in class org.apache.calcite.adapter.redis.RedisDataProcess
- parse(CalciteConnection, CalciteSchema, List<String>, String) - Static method in class org.apache.calcite.schema.Schemas
-
Parses and validates a SQL query.
- parse(CalcitePrepare.Context, String) - Method in interface org.apache.calcite.jdbc.CalcitePrepare
- parse(CalcitePrepare.Context, String) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- PARSE - Enum constant in enum org.apache.calcite.sql.test.SqlTests.Stage
- PARSE_DATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- PARSE_DATE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "PARSE_DATE(string, string)" function (BigQuery); Converts a string representation of date to a DATE object.
- PARSE_DATETIME - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- PARSE_DATETIME - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "PARSE_DATETIME(string, string [, timezone])" function (BigQuery); Formats a timestamp object according to the specified string.
- PARSE_TIME - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- PARSE_TIME - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "PARSE_TIME(string, string)" function (BigQuery); converts a string representation of time to a TIME value.
- PARSE_TIMESTAMP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- PARSE_TIMESTAMP - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "PARSE_TIMESTAMP(string, string [, timezone])" function (BigQuery); Formats a timestamp object according to the specified string.
- PARSE_TREE - Enum constant in enum org.apache.calcite.runtime.Hook
-
Called with the SQL string and parse tree, in an array.
- PARSE_URL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "PARSE_URL(urlString, partToExtract [, keyToExtract] )" function.
- PARSE_URL2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- PARSE_URL3 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- parseArgs(String[], Map<String, String>) - Static method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- parseArrayLiteral(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Parses string to array literal using
SqlParserImpl
parser. - parseBinaryString(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Deprecated.
- parseBoolean(String, boolean, boolean) - Static method in class org.apache.calcite.adapter.splunk.util.StringUtils
- parseCollation(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Extracts the values from a collation name.
- parseCString(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Converts the contents of a SQL quoted character literal with C-style escapes into the corresponding Java string representation.
- parseDate(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Deprecated.this method is not localized for Farrago standards
- parseDate(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.DateParseFunction
- parseDateLiteral(String, SqlParserPos) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- parseDatetime(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.DateParseFunction
- parseDateTime(String, ZoneId, Locale) - Method in class org.apache.calcite.util.format.postgresql.CompiledDateTimeFormat
-
Parses a date/time value from a string.
- ParsedCollation(Charset, Locale, String) - Constructor for class org.apache.calcite.sql.parser.SqlParserUtil.ParsedCollation
- parseDecimal(int, int, String) - Static method in class org.apache.calcite.adapter.file.CsvEnumerator
- parseDecimal(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- parseDecimalLiteral(String, SqlParserPos) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- parseExpression() - Method in class org.apache.calcite.sql.parser.SqlParser
-
Parses a SQL expression.
- parseExpression(SqlParser.Config, String) - Method in interface org.apache.calcite.sql2rel.InitializerContext
-
Parses a column computation expression for a table.
- parseExpression(SqlTestFactory, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- parseExpression(SqlTestFactory, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Parses an expression.
- parseExpressionAndHandleEx(SqlTestFactory, String, Consumer<SqlParser>) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- parseInteger(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- parseIntervalLiteral(SqlParserPos, int, String, SqlIntervalQualifier) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- parseLocale(String) - Static method in class org.apache.calcite.util.Util
-
Parses a locale string.
- parseNoCache(String) - Method in interface org.apache.calcite.util.format.FormatModel
-
As
FormatModel.parse(java.lang.String)
, but does not cache. - parsePositiveInt(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Parses a positive int.
- parseQuery() - Method in class org.apache.calcite.sql.parser.SqlParser
-
Parses a
SELECT
statement. - parseQuery(String) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
-
Wrapper function to parse a SQL query (SELECT or VALUES, but not INSERT, UPDATE, DELETE, CREATE, DROP etc.), throwing a
SqlParseException
if the statement is not syntactically valid. - parseQuery(String) - Method in class org.apache.calcite.sql.parser.SqlParser
-
Parses a
SELECT
statement and reuses parser. - parseQuery(SqlTestFactory, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- parseQuery(SqlTestFactory, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Parses a query.
- parser() - Method in class org.apache.calcite.sql.parser.SqlParserFixture
- parser(int, Predicate<PrecedenceClimbingParser.Token>) - Method in interface org.apache.calcite.sql.SqlSpecialOperator.TokenSequence
-
Creates a parser whose token sequence is a copy of a subset of this token sequence.
- PARSER_FACTORY - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Parser factory.
- PARSER_FACTORY - Static variable in class org.apache.calcite.server.ServerDdlExecutor
-
Parser factory.
- PARSER_LOGGER - Static variable in class org.apache.calcite.util.trace.CalciteTrace
-
The "org.apache.calcite.sql.parser" tracer reports parser events in
SqlParser
and other classes at DEBUG. - parserChecker - Variable in class org.apache.calcite.sql.parser.SqlParserFixture
- parserConfig() - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Factory method for SQL parser configuration.
- parserConfig() - Method in class org.apache.calcite.sql.test.SqlTestFactory
- parserConfig() - Method in class org.apache.calcite.test.SqlValidatorFixture
- parserConfig() - Method in interface org.apache.calcite.tools.Hoist.Config
-
Returns the configuration for the SQL parser.
- parserConfig(SqlParser.Config) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- parserContext(int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- ParseResult(CalcitePrepareImpl, SqlValidator, String, SqlNode, RelDataType) - Constructor for class org.apache.calcite.jdbc.CalcitePrepare.ParseResult
- parserFactory() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- parserFactory(Class<T>, T) - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.PARSER_FACTORY
, or a default parser if not set. - parserFactory(Class<T>, T) - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- parseStmt() - Method in class org.apache.calcite.sql.parser.SqlParser
-
Parses an SQL statement.
- parseStmtAndHandleEx(SqlTestFactory, String, Consumer<SqlParser>) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- parseStmtList() - Method in class org.apache.calcite.sql.parser.SqlParser
-
Parses a list of SQL statements separated by semicolon.
- parseStmtsAndHandleEx(SqlTestFactory, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
-
Parses a list of statements.
- parseString(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Converts the contents of an sql quoted string literal into the corresponding Java string representation (removing leading and trailing quotes and unescaping internal doubled quotes).
- parseTime(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Deprecated.Does not parse SQL:99 milliseconds
- parseTime(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.DateParseFunction
- parseTimeLiteral(String, SqlParserPos) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- parseTimestamp(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Deprecated.this method is not localized for Farrago standards
- parseTimestamp(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.DateParseFunction
- parseTimestamp(String, String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.DateParseFunction
- parseTimestampLiteral(String, SqlParserPos) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- parseTimestampTzLiteral(String, SqlParserPos) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- parseTimestampWithLocalTimeZoneLiteral(String, SqlParserPos) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- parseTimeTzLiteral(String, SqlParserPos) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- parseUrl(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.ParseUrlFunction
-
SQL
PARSE_URL(urlStr, partToExtract)
function. - parseUrl(String, String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.ParseUrlFunction
-
SQL
PARSE_URL(urlStr, partToExtract, keyToExtract)
function. - ParseUrlFunction() - Constructor for class org.apache.calcite.runtime.SqlFunctions.ParseUrlFunction
- parseValue(ParsePosition, String, boolean, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.AmPmCompiledPattern
- parseValue(ParsePosition, String, boolean, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.BcAdCompiledPattern
- parseValue(ParsePosition, String, boolean, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.CompiledPattern
-
Parse this date/time component from a String.
- parseValue(ParsePosition, String, boolean, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.DayOfWeekCompiledPattern
- parseValue(ParsePosition, String, boolean, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.MonthCompiledPattern
- parseValue(ParsePosition, String, boolean, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.NumberCompiledPattern
- parseValue(ParsePosition, String, boolean, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.RomanNumeralsCompiledPattern
- parseValue(ParsePosition, String, boolean, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneCompiledPattern
- parseValue(ParsePosition, String, boolean, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneHoursCompiledPattern
- parseValue(ParsePosition, String, boolean, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneMinutesCompiledPattern
- parseValue(ParsePosition, String, boolean, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneOffsetCompiledPattern
- parseValue(ParsePosition, String, boolean, Locale) - Method in class org.apache.calcite.util.format.postgresql.format.compiled.YearWithCommasCompiledPattern
- part - Variable in class org.apache.calcite.test.schemata.tpch.TpchSchema
- Part(int) - Constructor for class org.apache.calcite.test.schemata.tpch.TpchSchema.Part
- PARTIAL_FUNCTION - Enum constant in enum org.apache.calcite.util.mapping.MappingType
- PARTIAL_INJECTION - Enum constant in enum org.apache.calcite.util.mapping.MappingType
- PARTIAL_SURJECTION - Enum constant in enum org.apache.calcite.util.mapping.MappingType
-
A partial surjection has no more than one source for any target, and no more than one target for any source.
- PartiallyOrderedSet<E> - Class in org.apache.calcite.util
-
Partially-ordered set.
- PartiallyOrderedSet(PartiallyOrderedSet.Ordering<E>) - Constructor for class org.apache.calcite.util.PartiallyOrderedSet
-
Creates a partially-ordered set.
- PartiallyOrderedSet(PartiallyOrderedSet.Ordering<E>, Function<E, Iterable<E>>, Function<E, Iterable<E>>) - Constructor for class org.apache.calcite.util.PartiallyOrderedSet
-
Deprecated.
- PartiallyOrderedSet(PartiallyOrderedSet.Ordering<E>, Collection<E>) - Constructor for class org.apache.calcite.util.PartiallyOrderedSet
-
Creates a partially-ordered set, and populates it with a given collection.
- PartiallyOrderedSet(PartiallyOrderedSet.Ordering<E>, Function<E, Iterable<E>>, Function<E, Iterable<E>>) - Constructor for class org.apache.calcite.util.PartiallyOrderedSet
-
Creates a partially-ordered set with a parent-generating function.
- PartiallyOrderedSet.Ordering<E> - Interface in org.apache.calcite.util
-
Ordering relation.
- PartialMapping(int, int, MappingType) - Constructor for class org.apache.calcite.util.mapping.Mappings.PartialMapping
-
Creates a partial mapping.
- PartialMapping(List<Integer>, int, MappingType) - Constructor for class org.apache.calcite.util.mapping.Mappings.PartialMapping
-
Creates a partial mapping from a list.
- partialParse() - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- partitionBy(Iterable<? extends RexNode>) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets the PARTITION BY clause to a list of expressions.
- partitionBy(RexNode...) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets the PARTITION BY clause to an array of expressions.
- partitionbyShouldNotContainOver() - Method in interface org.apache.calcite.runtime.CalciteResource
- partitionKeys - Variable in class org.apache.calcite.rel.core.Match
- partitionKeys - Variable in class org.apache.calcite.rel.mutable.MutableMatch
- partitionKeys - Variable in class org.apache.calcite.rex.RexWindow
- partitionNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- partsupp - Variable in class org.apache.calcite.test.schemata.tpch.TpchSchema
- PartSupp(int, int) - Constructor for class org.apache.calcite.test.schemata.tpch.TpchSchema.PartSupp
- passColumnsThrough - Variable in class org.apache.calcite.sql.TableCharacteristic
-
If the value is true, for each input row, the table function makes the entire input row available in the output, qualified by a range variable associated with the input table.
- passColumnsThrough() - Method in class org.apache.calcite.sql.TableCharacteristic.Builder
-
Input table supports pass-through columns.
- passThrough(RelTraitSet) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
-
Code snippet to demonstrate how to generate IndexScan on demand by passing required collation through TableScan.
- passThrough(RelTraitSet) - Method in class org.apache.calcite.adapter.enumerable.EnumerableValues
- passThrough(RelTraitSet) - Method in interface org.apache.calcite.rel.PhysicalNode
-
Pass required traitset from parent node to child nodes, returns new node after traits is passed down.
- passThroughTraits(RelTraitSet) - Method in class org.apache.calcite.adapter.enumerable.EnumerableAsofJoin
- passThroughTraits(RelTraitSet) - Method in class org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoin
- passThroughTraits(RelTraitSet) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCalc
- passThroughTraits(RelTraitSet) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCorrelate
- passThroughTraits(RelTraitSet) - Method in class org.apache.calcite.adapter.enumerable.EnumerableFilter
- passThroughTraits(RelTraitSet) - Method in class org.apache.calcite.adapter.enumerable.EnumerableHashJoin
- passThroughTraits(RelTraitSet) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMergeJoin
-
Pass collations through can have three cases:
- passThroughTraits(RelTraitSet) - Method in class org.apache.calcite.adapter.enumerable.EnumerableNestedLoopJoin
- passThroughTraits(RelTraitSet) - Method in class org.apache.calcite.adapter.enumerable.EnumerableProject
- passThroughTraits(RelTraitSet) - Method in interface org.apache.calcite.adapter.enumerable.EnumerableRel
- passThroughTraits(RelTraitSet) - Method in class org.apache.calcite.adapter.enumerable.EnumerableSortedAggregate
- passThroughTraits(RelTraitSet) - Method in interface org.apache.calcite.rel.PhysicalNode
-
Pass required traitset from parent node to child nodes, returns a pair of traits after traits is passed down.
- password - Variable in class org.apache.calcite.test.ConnectionSpec
- path - Variable in class org.apache.calcite.model.JsonFunction
-
Path for resolving this function.
- path - Variable in class org.apache.calcite.model.JsonSchema
-
SQL path that is used to resolve functions used in this schema.
- path - Variable in class org.apache.calcite.model.JsonView
-
Schema name(s) to use when resolving query.
- path - Variable in exception class org.apache.calcite.sql.validate.CyclicDefinitionException
- path - Variable in class org.apache.calcite.sql.validate.SqlValidatorScope.Resolve
- path() - Method in class org.apache.calcite.jdbc.CalciteSchema.Entry
-
Returns this object's path.
- path() - Method in interface org.apache.calcite.util.Source
- path(String) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns the path of an object in this schema.
- path(Iterable<? extends Map.Entry<String, Schema>>) - Static method in class org.apache.calcite.schema.Schemas
- path(CalciteSchema, Iterable<String>) - Static method in class org.apache.calcite.schema.Schemas
-
Creates a path with a given list of names starting from a given root schema.
- path(SchemaPlus) - Static method in class org.apache.calcite.schema.Schemas
-
Returns the path to get to a schema from its root.
- Path - Interface in org.apache.calcite.schema
-
Path from a root schema to a particular object (schema, table, function).
- Path() - Constructor for class org.apache.calcite.sql.validate.SqlValidatorScope.Path
- pattern - Variable in class org.apache.calcite.rel.core.Match
- pattern - Variable in class org.apache.calcite.rel.mutable.MutableMatch
- pattern - Variable in class org.apache.calcite.util.format.postgresql.format.FormatPattern
- Pattern - Interface in org.apache.calcite.runtime
-
Regular expression, to be compiled into an
Automaton
. - PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
This table shows how and where the Gang of Four patterns are applied.
- PATTERN_ALTER - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Alternation operator in a pattern expression within a
MATCH_RECOGNIZE
clause. - PATTERN_ALTER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
|
operator to create alternate patterns withinMATCH_RECOGNIZE
. - PATTERN_BUILDER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- PATTERN_BUILDER_BUILD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- PATTERN_BUILDER_SEQ - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- PATTERN_BUILDER_SYMBOL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- PATTERN_CONCAT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Concatenation operator in a pattern expression within a
MATCH_RECOGNIZE
clause. - PATTERN_CONCAT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Operator to concatenate patterns within
MATCH_RECOGNIZE
. - PATTERN_EXCLUDE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
EXCLUDE
operator withinMATCH_RECOGNIZE
. - PATTERN_EXCLUDED - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The special patterns to exclude enclosing pattern from output in a MATCH_RECOGNIZE clause.
- PATTERN_INPUT_REF - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Reference to an input field, with pattern var as modifier.
- PATTERN_PERMUTE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The internal "permute" function in a MATCH_RECOGNIZE clause.
- PATTERN_PERMUTE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
PERMUTE
operator to combine patterns withinMATCH_RECOGNIZE
. - PATTERN_QUANTIFIER - Enum constant in enum org.apache.calcite.sql.SqlKind
-
the repetition quantifier of a pattern factor in a match_recognize clause.
- PATTERN_QUANTIFIER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Operator to quantify patterns within
MATCH_RECOGNIZE
. - PATTERN_TO_AUTOMATON - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- Pattern.AbstractPattern - Class in org.apache.calcite.runtime
-
Base class for implementations of
Pattern
. - Pattern.Op - Enum in org.apache.calcite.runtime
-
Operator that constructs composite
Pattern
instances. - Pattern.OpPattern - Class in org.apache.calcite.runtime
-
Pattern with one or more arguments.
- Pattern.PatternBuilder - Class in org.apache.calcite.runtime
-
Builds a pattern expression.
- Pattern.RepeatPattern - Class in org.apache.calcite.runtime
-
Pattern that matches a pattern repeated between
minRepeat
andmaxRepeat
times. - Pattern.SymbolPattern - Class in org.apache.calcite.runtime
-
Pattern that matches a symbol.
- patternAggregationInNavigation(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- patternAlter(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call that creates alternate patterns; for use in
RelBuilder.match(org.apache.calcite.rex.RexNode, boolean, boolean, java.util.Map<java.lang.String, org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode, java.util.Map<java.lang.String, ? extends java.util.SortedSet<java.lang.String>>, boolean, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode)
. - patternAlter(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call that creates alternate patterns; for use in
RelBuilder.match(org.apache.calcite.rex.RexNode, boolean, boolean, java.util.Map<java.lang.String, org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode, java.util.Map<java.lang.String, ? extends java.util.SortedSet<java.lang.String>>, boolean, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode)
. - patternBuilder() - Static method in class org.apache.calcite.runtime.Utilities
-
Creates a pattern builder.
- patternConcat(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call that concatenates patterns; for use in
RelBuilder.match(org.apache.calcite.rex.RexNode, boolean, boolean, java.util.Map<java.lang.String, org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode, java.util.Map<java.lang.String, ? extends java.util.SortedSet<java.lang.String>>, boolean, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode)
. - patternConcat(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call that concatenates patterns; for use in
RelBuilder.match(org.apache.calcite.rex.RexNode, boolean, boolean, java.util.Map<java.lang.String, org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode, java.util.Map<java.lang.String, ? extends java.util.SortedSet<java.lang.String>>, boolean, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode)
. - patternCountFunctionArg() - Method in interface org.apache.calcite.runtime.CalciteResource
- patternDefinitions - Variable in class org.apache.calcite.rel.core.Match
- patternDefinitions - Variable in class org.apache.calcite.rel.mutable.MutableMatch
- patternExclude(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call that creates an exclude pattern; for use in
RelBuilder.match(org.apache.calcite.rex.RexNode, boolean, boolean, java.util.Map<java.lang.String, org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode, java.util.Map<java.lang.String, ? extends java.util.SortedSet<java.lang.String>>, boolean, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode)
. - patternField(String, RelDataType, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a reference to a given field of the pattern.
- patternFunctionNullCheck(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- patternFunctionVariableCheck(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- PatternModifier - Enum in org.apache.calcite.util.format.postgresql
-
Flags that can be added to a date/time format component.
- patternPermute(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call that creates permute patterns; for use in
RelBuilder.match(org.apache.calcite.rex.RexNode, boolean, boolean, java.util.Map<java.lang.String, org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode, java.util.Map<java.lang.String, ? extends java.util.SortedSet<java.lang.String>>, boolean, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode)
. - patternPermute(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call that creates permute patterns; for use in
RelBuilder.match(org.apache.calcite.rex.RexNode, boolean, boolean, java.util.Map<java.lang.String, org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode, java.util.Map<java.lang.String, ? extends java.util.SortedSet<java.lang.String>>, boolean, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode)
. - patternPrevFunctionInMeasure(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- patternPrevFunctionOrder(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- patternQuantify(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call that creates quantify patterns; for use in
RelBuilder.match(org.apache.calcite.rex.RexNode, boolean, boolean, java.util.Map<java.lang.String, org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode, java.util.Map<java.lang.String, ? extends java.util.SortedSet<java.lang.String>>, boolean, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode)
. - patternQuantify(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call that creates quantify patterns; for use in
RelBuilder.match(org.apache.calcite.rex.RexNode, boolean, boolean, java.util.Map<java.lang.String, org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode, java.util.Map<java.lang.String, ? extends java.util.SortedSet<java.lang.String>>, boolean, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, java.lang.Iterable<? extends org.apache.calcite.rex.RexNode>, org.apache.calcite.rex.RexNode)
. - patternRunningFunctionInDefine(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- patternVarAlreadyDefined(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- pctY - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- PDX_SERIALIZABLE_PACKAGE_PATH - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeSchemaFactory
- PDX_SERIALIZABLE_PACKAGE_PATH - Static variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchemaFactory
- peek() - Static method in class org.apache.calcite.jdbc.CalcitePrepare.Dummy
- peek() - Method in class org.apache.calcite.tools.RelBuilder
-
Returns the relational expression at the top of the stack, but does not remove it.
- peek(int) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns the relational expression
n
positions from the top of the stack, but does not remove it. - peek(int, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns the relational expression
n
positions from the top of the stack, but does not remove it. - peek(int, List<T>) - Static method in class org.apache.calcite.util.Stacks
-
Deprecated.Returns the
n
th most recently added element in the stack. - peek(List<T>) - Static method in class org.apache.calcite.util.Stacks
-
Deprecated.Returns the most recently added element in the stack.
- PEEK_FIELDS - Enum constant in enum org.apache.calcite.rel.type.StructKind
-
If a field has this type, you can see its fields without qualifying them with the name of this field.
- PEEK_FIELDS_DEFAULT - Enum constant in enum org.apache.calcite.rel.type.StructKind
-
As
StructKind.PEEK_FIELDS
, but takes priority if another struct-typed field also has a field of the name being sought. - PEEK_FIELDS_NO_EXPAND - Enum constant in enum org.apache.calcite.rel.type.StructKind
-
As
StructKind.PEEK_FIELDS
, but fields are not expanded in "SELECT *". - per(TimeFrame) - Method in interface org.apache.calcite.rel.type.TimeFrame
-
If this time frame has units in common with another time frame, returns the number of this time frame in one of that time frame.
- PERCENT_RANK - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
PERCENT_RANK
window function. - PERCENT_RANK - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
PERCENT_RANK
window function. - PERCENT_REMAINDER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Arithmetic remainder operator, '
%
', an alternative toSqlStdOperatorTable.MOD
allowed if under certain conformance levels. - PERCENTAGE_ORIGINAL_ROWS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- PERCENTILE_CONT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
PERCENTILE_CONT
aggregate function. - PERCENTILE_CONT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
PERCENTILE_CONT
inverse distribution aggregate function. - PERCENTILE_CONT2 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
PERCENTILE_CONT
function, BigQuery's equivalent toSqlStdOperatorTable.PERCENTILE_CONT
, but uses anOVER
clause rather thanWITHIN GROUP
. - PERCENTILE_DISC - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
PERCENTILE_DISC
aggregate function. - PERCENTILE_DISC - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
PERCENTILE_DISC
inverse distribution aggregate function. - PERCENTILE_DISC_CONT - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- PERCENTILE_DISC2 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
PERCENTILE_DISC
function, BigQuery's equivalent toSqlStdOperatorTable.PERCENTILE_DISC
, but uses anOVER
clause rather thanWITHIN GROUP
. - percentileFunctionsArgumentLimit() - Method in interface org.apache.calcite.runtime.CalciteResource
- percentRemainderNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- perform(RelOptRuleCall, Filter, Join) - Method in class org.apache.calcite.rel.rules.FilterJoinRule
- perform(RelOptRuleCall, Project, Join, RelNode, Aggregate) - Method in class org.apache.calcite.rel.rules.SemiJoinRule
- perform(RelOptRuleCall, Project, RelNode) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
Rewriting logic is based on "Optimizing Queries Using Materialized Views: A Practical, Scalable Solution" by Goldstein and Larson.
- perform(CalciteServerStatement, FrameworkConfig, Frameworks.BasePrepareAction<R>) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Executes a prepare action.
- perform(CalciteServerStatement, Frameworks.PrepareAction<R>) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Deprecated.
- performUnconditionalRewrites(SqlNode, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Performs expression rewrites which are always used unconditionally.
- PERIOD - Static variable in class org.apache.calcite.sql.type.OperandTypes
- PERIOD_EQUALS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
EQUALS
operator for periods. - PERIOD_EQUALS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- PERIOD_OR_DATETIME - Static variable in class org.apache.calcite.sql.type.OperandTypes
- permAssert(boolean, String) - Static method in class org.apache.calcite.util.Util
-
Deprecated.Use
Preconditions.checkArgument(boolean)
- permutation(List<RexNode>, RelDataType) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a permutation describing where output fields come from.
- Permutation - Class in org.apache.calcite.util
-
Represents a mapping which reorders elements in an array.
- Permutation(int) - Constructor for class org.apache.calcite.util.Permutation
-
Creates a permutation of a given size.
- Permutation(int[]) - Constructor for class org.apache.calcite.util.Permutation
-
Creates a permutation from an array.
- permutationIgnoreCast(List<RexNode>, RelDataType) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a permutation describing where output fields come from.
- permutationPushDownProject(List<RexNode>, RelDataType, int, int) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a permutation describing where the Project's fields come from after the Project is pushed down.
- permute(Iterable<ImmutableBitSet>, Map<Integer, Integer>) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Permutes a collection of bit sets according to a given mapping.
- permute(Object, int[]) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Permutes an array.
- permute(List<T>, Mappings.TargetMapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Creates a view of a list, permuting according to a target mapping.
- permute(Map<Integer, Integer>) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Permutes a bit set according to a given mapping.
- permute(MutableAggregate, MutableRel, Mapping) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
- permute(RelCollation, Map<Integer, Integer>) - Static method in class org.apache.calcite.rel.RelCollations
-
Creates a copy of this collation that changes the ordinals of input fields.
- permute(RelCollation, Mappings.TargetMapping) - Static method in class org.apache.calcite.rel.RelCollations
-
Creates a copy of this collation that changes the ordinals of input fields.
- permute(RelNode, Permutation, List<String>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Creates a relational expression which permutes the output fields of a relational expression according to a permutation.
- permute(RelDataTypeFactory, RelDataType, Mapping) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Permutes a record type according to a mapping.
- permute(Mapping) - Method in class org.apache.calcite.tools.RelBuilder
- permute(Mappings.TargetMapping) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Permutes a bit set according to a given mapping.
- permutedCall() - Method in class org.apache.calcite.sql.SqlCallBinding
-
Returns a call that is equivalent except that arguments have been permuted into the logical order.
- personalityManagesRowCount() - Method in interface org.apache.calcite.runtime.CalciteResource
- personalitySupportsLabels() - Method in interface org.apache.calcite.runtime.CalciteResource
- personalitySupportsSnapshots() - Method in interface org.apache.calcite.runtime.CalciteResource
- PHOENIX - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- PhoenixSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Apache Phoenix database. - PhoenixSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.PhoenixSqlDialect
-
Creates a PhoenixSqlDialect.
- PHYSICAL - Enum constant in enum org.apache.calcite.sql.SqlExplain.Depth
- PhysicalNode - Interface in org.apache.calcite.rel
-
Physical node in a planner that is capable of doing physical trait propagation and derivation.
- physType - Variable in class org.apache.calcite.adapter.enumerable.EnumerableRel.Result
-
Describes the Java type returned by this relational expression, and the mapping between it and the fields of the logical row type.
- physType - Variable in class org.apache.calcite.adapter.spark.SparkRel.Result
- PhysType - Interface in org.apache.calcite.adapter.enumerable
-
Physical type of a row.
- PhysTypeImpl - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
PhysType
. - PI - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
PI
function. - PigAggFunction - Enum in org.apache.calcite.adapter.pig
-
Supported Pig aggregate functions and their Calcite counterparts.
- PigAggregate - Class in org.apache.calcite.adapter.pig
-
Implementation of
Aggregate
inPig calling convention
. - PigAggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.adapter.pig.PigAggregate
-
Deprecated.
- PigAggregate(RelOptCluster, RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.adapter.pig.PigAggregate
-
Creates a PigAggregate.
- PigAggregateFactory() - Constructor for class org.apache.calcite.adapter.pig.PigRelFactories.PigAggregateFactory
- PigConverter - Class in org.apache.calcite.piglet
-
Extension from PigServer to convert Pig scripts into logical relational algebra plans and SQL statements.
- PigDataType - Enum in org.apache.calcite.adapter.pig
-
Supported Pig data types and their Calcite counterparts.
- PigFilter - Class in org.apache.calcite.adapter.pig
-
Implementation of
Filter
inPig calling convention
. - PigFilter(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.calcite.adapter.pig.PigFilter
-
Creates a PigFilter.
- PigFilterFactory() - Constructor for class org.apache.calcite.adapter.pig.PigRelFactories.PigFilterFactory
- PigJoin - Class in org.apache.calcite.adapter.pig
-
Implementation of
Join
inPig calling convention
. - PigJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType) - Constructor for class org.apache.calcite.adapter.pig.PigJoin
-
Creates a PigJoin.
- PigJoinFactory() - Constructor for class org.apache.calcite.adapter.pig.PigRelFactories.PigJoinFactory
- PigProject - Class in org.apache.calcite.adapter.pig
-
Implementation of
Project
inPig calling convention
. - PigProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.adapter.pig.PigProject
-
Creates a PigProject.
- pigQuery2Rel(String) - Method in class org.apache.calcite.piglet.PigConverter
-
Parses a Pig script and converts it into relational algebra plans, optimizing the result.
- pigQuery2Rel(String, boolean, boolean, boolean) - Method in class org.apache.calcite.piglet.PigConverter
-
Parses a Pig script and converts it into relational algebra plans.
- PigRel - Interface in org.apache.calcite.adapter.pig
-
Relational expression that uses the Pig calling convention.
- PigRel.Implementor - Class in org.apache.calcite.adapter.pig
-
Callback for the implementation process that converts a tree of
PigRel
nodes into complete Pig Latin script. - PigRelBuilder - Class in org.apache.calcite.piglet
-
Extension to
RelBuilder
for Pig logical operators. - PigRelBuilder - Class in org.apache.calcite.tools
-
Extension to
RelBuilder
for Pig relational operators. - PigRelBuilder(Context, RelOptCluster, RelOptSchema) - Constructor for class org.apache.calcite.tools.PigRelBuilder
- PigRelBuilder.GroupOption - Enum in org.apache.calcite.tools
-
Option for performing group efficiently if data set is already sorted.
- PigRelBuilder.PigRelTranslationContext - Class in org.apache.calcite.piglet
-
Context constructed during Pig-to-
RelNode
translation process. - PigRelFactories - Class in org.apache.calcite.adapter.pig
-
Implementations of factories in
RelFactories
for the Pig adapter. - PigRelFactories.PigAggregateFactory - Class in org.apache.calcite.adapter.pig
-
Implementation of
RelFactories.AggregateFactory
that returns aPigAggregate
. - PigRelFactories.PigFilterFactory - Class in org.apache.calcite.adapter.pig
-
Implementation of
RelFactories.FilterFactory
that returns aPigFilter
. - PigRelFactories.PigJoinFactory - Class in org.apache.calcite.adapter.pig
-
Implementation of
RelFactories.JoinFactory
that returns aPigJoin
. - PigRelFactories.PigTableScanFactory - Class in org.apache.calcite.adapter.pig
-
Implementation of
RelFactories.TableScanFactory
that returns aPigTableScan
. - PigRelSqlUdfs - Class in org.apache.calcite.piglet
- PigRelToSqlConverter - Class in org.apache.calcite.piglet
-
An extension of
RelToSqlConverter
to convert a relation algebra tree, translated from a Pig script, into a SQL statement. - PigRelTranslationContext() - Constructor for class org.apache.calcite.piglet.PigRelBuilder.PigRelTranslationContext
- PigRules - Class in org.apache.calcite.adapter.pig
-
Various
RelOptRule
s using the Pig convention. - PigSchema - Class in org.apache.calcite.adapter.pig
-
Schema that contains one more or more Pig tables.
- PigSchema() - Constructor for class org.apache.calcite.adapter.pig.PigSchema
- PigSchemaFactory - Class in org.apache.calcite.adapter.pig
-
Factory that creates a
PigSchema
. - pigScript2Rel(String, Map<String, String>, boolean) - Method in class org.apache.calcite.piglet.PigConverter
-
Parses a Pig script and converts it into relational algebra plans.
- PigTable - Class in org.apache.calcite.adapter.pig
-
Represents a Pig relation that is created by Pig Latin
LOAD
statement. - PigTable - Class in org.apache.calcite.piglet
-
A non-queriable table that contains only row type to represent a Pig Table.
- PigTable(String, String[]) - Constructor for class org.apache.calcite.adapter.pig.PigTable
-
Creates a PigTable.
- PigTableFactory - Class in org.apache.calcite.adapter.pig
-
Factory that creates a
PigTable
. - PigTableFactory() - Constructor for class org.apache.calcite.adapter.pig.PigTableFactory
- PigTableScan - Class in org.apache.calcite.adapter.pig
-
Implementation of
TableScan
inPig calling convention
. - PigTableScan(RelOptCluster, RelTraitSet, RelOptTable) - Constructor for class org.apache.calcite.adapter.pig.PigTableScan
-
Creates a PigTableScan.
- PigTableScanFactory() - Constructor for class org.apache.calcite.adapter.pig.PigRelFactories.PigTableScanFactory
- PigToEnumerableConverter - Class in org.apache.calcite.adapter.pig
-
Relational expression representing a scan of a table in a Pig data source.
- PigToEnumerableConverter(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.adapter.pig.PigToEnumerableConverter
-
Creates a PigToEnumerableConverter.
- PigToEnumerableConverterRule - Class in org.apache.calcite.adapter.pig
-
Rule to convert a relational expression from
PigRel.CONVENTION
toEnumerableConvention
. - pigToSql(String, SqlDialect) - Method in class org.apache.calcite.piglet.PigConverter
-
Converts a Pig script to a list of SQL statements.
- PigToSqlAggregateRule - Class in org.apache.calcite.piglet
-
Planner rule that converts Pig aggregate UDF calls to built-in SQL aggregates.
- PigToSqlAggregateRule(PigToSqlAggregateRule.Config) - Constructor for class org.apache.calcite.piglet.PigToSqlAggregateRule
-
Creates a PigToSqlAggregateRule.
- PigToSqlAggregateRule.Config - Interface in org.apache.calcite.piglet
-
Rule configuration.
- PigUdfs - Class in org.apache.calcite.piglet
-
Implementation methods.
- PigUserDefinedFunction - Class in org.apache.calcite.piglet
-
Pig user-defined function.
- PigUserDefinedFunction(String, SqlReturnTypeInference, SqlOperandMetadata, Function) - Constructor for class org.apache.calcite.piglet.PigUserDefinedFunction
- PigUserDefinedFunction(String, SqlReturnTypeInference, SqlOperandMetadata, Function, FuncSpec) - Constructor for class org.apache.calcite.piglet.PigUserDefinedFunction
- pivot(RelBuilder.GroupKey, Iterable<? extends RelBuilder.AggCall>, Iterable<? extends RexNode>, Iterable<? extends Map.Entry<String, ? extends Iterable<? extends RexNode>>>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a Pivot.
- PIVOT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
PIVOT clause.
- pivotAggMalformed() - Method in interface org.apache.calcite.runtime.CalciteResource
- PivotNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for a
PIVOT
clause. - PivotNamespace(SqlValidatorImpl, SqlPivot, SqlNode) - Constructor for class org.apache.calcite.sql.validate.PivotNamespace
-
Creates a PivotNamespace.
- PivotScope - Class in org.apache.calcite.sql.validate
-
Scope for expressions in a
PIVOT
clause. - PivotScope(SqlValidatorScope, SqlPivot) - Constructor for class org.apache.calcite.sql.validate.PivotScope
-
Creates a PivotScope.
- pivotValueArityMismatch(int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- PK_FULL_SCAN - Enum constant in enum org.apache.calcite.adapter.innodb.QueryType
-
Scanning table fully with primary key.
- PK_POINT_QUERY - Enum constant in enum org.apache.calcite.adapter.innodb.QueryType
-
Primary key point query.
- PK_RANGE_QUERY - Enum constant in enum org.apache.calcite.adapter.innodb.QueryType
-
Primary key range query with lower and upper bound.
- Place(BookstoreSchema.Coordinate, String, String) - Constructor for class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Place
- PLAN_BEFORE_IMPLEMENTATION - Enum constant in enum org.apache.calcite.runtime.Hook
-
Called when a plan is about to be implemented (e.g.
- planContains(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- planHasSql(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- planner - Variable in class org.apache.calcite.plan.volcano.RuleQueue
- planner - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- Planner - Interface in org.apache.calcite.tools
-
A façade that covers Calcite's query planning process: parse SQL, validate the parse tree, convert the parse tree to a relational expression, and optimize the relational expression.
- PLANNER - Enum constant in enum org.apache.calcite.runtime.Hook
-
Called with the created planner.
- PlannerImpl - Class in org.apache.calcite.prepare
-
Implementation of
Planner
. - PlannerImpl(FrameworkConfig) - Constructor for class org.apache.calcite.prepare.PlannerImpl
-
Creates a planner.
- PlannerImpl.ViewExpanderImpl - Class in org.apache.calcite.prepare
-
Deprecated.Now
PlannerImpl
implementsRelOptTable.ViewExpander
directly. - planUpdateHasSql(String, int) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- plus() - Method in class org.apache.calcite.jdbc.CalciteSchema
- plus() - Method in class org.apache.calcite.runtime.Pattern.PatternBuilder
-
Creates a pattern that matches the patterns at the top of the stack one or more times, and pushes it onto the stack.
- plus(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
+
operator applied to int values. - plus(int, Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
+
operator applied to int values; right side may be null. - plus(Integer, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
+
operator applied to int values; left side may be null. - plus(Integer, Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
+
operator applied to nullable int values. - plus(Integer, Long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
+
operator applied to nullable int and long values. - plus(Long, Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
+
operator applied to nullable long and int values. - plus(Iterable<SqlLibrary>) - Method in class org.apache.calcite.test.MockSqlOperatorTable
-
Adds a library set.
- plus(String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIdentifier
-
Creates an identifier that consists of this identifier plus a name segment.
- plus(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
+
operator applied to BigDecimal values. - plus(RelOptCost) - Method in interface org.apache.calcite.plan.RelOptCost
-
Adds another cost to this.
- plus(RelOptCost) - Method in class org.apache.calcite.plan.RelOptCostImpl
- plus(RelTrait) - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns this trait set with a given trait added or overridden.
- plus(RelDataType, int, String, StructKind) - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.Path
-
Creates a path that consists of this path plus one additional step.
- plus(SqlParserPos) - Method in class org.apache.calcite.sql.parser.SqlParserPos
-
Combines this parser position with another to create a position that spans from the first point in the first to the last point in the other.
- PLUS - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- PLUS - Enum constant in enum org.apache.calcite.runtime.Pattern.Op
-
Pattern that matches a pattern repeated one or more times.
- PLUS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Arithmetic plus operator, "+".
- PLUS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Infix arithmetic plus operator, '
+
'. - PLUS_OPERATOR - Static variable in class org.apache.calcite.sql.type.OperandTypes
- PLUS_PREFIX - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Unary plus operator, as in "+1".
- plusAll(Collection<? extends SqlNode>) - Method in class org.apache.calcite.sql.parser.SqlParserPos
-
Combines this parser position with a list of positions.
- plusAll(RelTrait[]) - Method in class org.apache.calcite.plan.RelTraitSet
- plusAll(SqlNode[]) - Method in class org.apache.calcite.sql.parser.SqlParserPos
-
Combines this parser position with an array of positions to create a position that spans from the first point in the first to the last point in the other.
- plusAny(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
+
operator applied to Object values (at least one operand has ANY type; either may be null). - plusStar() - Method in class org.apache.calcite.sql.SqlIdentifier
-
Creates an identifier that consists of this identifier plus a wildcard star.
- PM - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- POINT - Enum constant in enum org.apache.calcite.runtime.SpatialTypeUtils.SpatialType
- pointCount - Variable in class org.apache.calcite.util.Sarg
- policy(RexNode) - Static method in class org.apache.calcite.plan.Strong
-
Returns how to deduce whether a particular
RexNode
expression is null, given whether its arguments are null. - policy(SqlKind) - Static method in class org.apache.calcite.plan.Strong
-
Deprecated.
- policy(SqlOperator) - Static method in class org.apache.calcite.plan.Strong
-
Returns how to deduce whether a particular
SqlOperator
expression is null, given whether its arguments are null. - POLYGON - Enum constant in enum org.apache.calcite.runtime.SpatialTypeUtils.SpatialType
- pool(ConnectionFactory) - Static method in class org.apache.calcite.test.ConnectionFactories
-
Creates a connection factory that uses a single pooled connection, as opposed to creating a new connection on each invocation.
- pooled() - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Returns a version that uses a single connection, as opposed to creating a new one each time a test method is invoked.
- pop(List<T>) - Static method in class org.apache.calcite.util.Stacks
-
Deprecated.Removes an element from the stack and returns it.
- pop(List<T>, T) - Static method in class org.apache.calcite.util.Stacks
-
Deprecated.Removes an element from the stack.
- pop(CalcitePrepare.Context) - Static method in class org.apache.calcite.jdbc.CalcitePrepare.Dummy
- popFunctionCall() - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Removes the topmost entry from the function call stack.
- popFunctionCall() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- populate(BitSet, Iterable<? extends Number>) - Static method in class org.apache.calcite.util.BitSets
-
Populates a
BitSet
from an iterable, such as a list of integer. - populate(BitSet, ImmutableIntList) - Static method in class org.apache.calcite.util.BitSets
-
Populates a
BitSet
from anImmutableIntList
. - populate(SqlIdentifier, SqlNode, CalcitePrepare.Context) - Static method in class org.apache.calcite.test.MockDdlExecutor
-
Populates the table called
name
by executingquery
. - populateBounds() - Method in class org.apache.calcite.sql.SqlWindow
-
Deprecated.
- populateMaterializations(CalcitePrepare.Context, RelOptCluster, Prepare.Materialization) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- POPULATION_SIZE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- pos - Variable in class org.apache.calcite.piglet.Ast.Node
- pos - Variable in class org.apache.calcite.rex.RexCall
-
In the calls which can produce runtime errors we carry the source position, so the backend can produce runtime error messages pointing to the original source position.
- pos - Variable in class org.apache.calcite.sql.parser.StringAndPos
- pos - Variable in class org.apache.calcite.sql.SqlNode
- pos() - Method in class org.apache.calcite.sql.parser.Span
-
Returns a position spanning the earliest position to the latest.
- pos(int) - Method in interface org.apache.calcite.sql.SqlSpecialOperator.TokenSequence
- POS - Static variable in class org.apache.calcite.rel.rel2sql.SqlImplementor
- position(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
POSITION(seek IN string)
function. - position(String, String, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
POSITION(seek IN string FROM integer)
function. - position(String, String, int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
POSITION(seek, string, from, occurrence)
function. - position(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
POSITION(seek IN string)
function for byte strings. - position(ByteString, ByteString, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
POSITION(seek IN string FROM integer)
function for byte strings. - position(ByteString, ByteString, int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
POSITION(seek, string, from, occurrence)
function for byte strings. - POSITION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
POSITION function.
- POSITION - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- POSITION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- POSITIVE_INTEGER_LITERAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy type must be a positive integer non-NULL literal.
- POSIX_REGEX_CASE_INSENSITIVE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
~*
operator (for case-insensitive POSIX-style regular expressions). - POSIX_REGEX_CASE_INSENSITIVE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- POSIX_REGEX_CASE_SENSITIVE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
~
operator (for POSIX-style regular expressions). - POSIX_REGEX_CASE_SENSITIVE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- POSIX_REGEX_INSENSITIVE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- POSIX_REGEX_SENSITIVE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- PosixRegexFunction() - Constructor for class org.apache.calcite.runtime.SqlFunctions.PosixRegexFunction
- posixRegexInsensitive(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.PosixRegexFunction
-
Posix regex, case-insensitive.
- posixRegexSensitive(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.PosixRegexFunction
-
Posix regex, case-sensitive.
- post - Variable in class org.apache.calcite.linq4j.tree.ForStatement
- post(boolean, String) - Static method in class org.apache.calcite.util.Util
-
Deprecated.Use
Preconditions.checkArgument(boolean)
orObjects.requireNonNull(Object)
- post(String, CharSequence, Map<String, String>, int, int) - Static method in class org.apache.calcite.runtime.HttpUtils
- post(String, CharSequence, Map<String, String>) - Static method in class org.apache.calcite.runtime.HttpUtils
- POST - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- POST_AGGREGATION_PROJECT - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- postDecrementAssign(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents the assignment of the expression followed by a subsequent decrement by 1 of the original expression.
- postDecrementAssign(Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents the assignment of the expression followed by a subsequent decrement by 1 of the original expression.
- PostDecrementAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A unary postfix decrement, such as (a--).
- postExpressionConversionHook() - Method in interface org.apache.calcite.sql2rel.InitializerExpressionFactory
-
Creates a hook function to customize the relational expression right after the column expressions are converted.
- postExpressionConversionHook() - Method in class org.apache.calcite.sql2rel.NullInitializerExpressionFactory
- postfix(Object, int) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- postfix(Object, int) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- POSTFIX - Enum constant in enum org.apache.calcite.sql.SqlSyntax
-
Postfix unary operator syntax, as in "x ++".
- POSTFIX - Enum constant in enum org.apache.calcite.util.PrecedenceClimbingParser.Type
- POSTGRESQL - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
A collection of operators that are in PostgreSQL but not in standard SQL.
- POSTGRESQL - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- POSTGRESQL - Enum constant in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
- POSTGRESQL - Static variable in class org.apache.calcite.util.format.FormatModels
-
Format model for PostgreSQL.
- POSTGRESQL_TYPE_SYSTEM - Static variable in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
-
PostgreSQL type system.
- PostgresqlDateTimeFormatter - Class in org.apache.calcite.util.format.postgresql
-
Provides an implementation of toChar that matches PostgreSQL behaviour.
- PostgresqlSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the PostgreSQL database. - PostgresqlSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
-
Creates a PostgresqlSqlDialect.
- postIncrementAssign(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents the assignment of the expression followed by a subsequent increment by 1 of the original expression.
- postIncrementAssign(Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents the assignment of the expression followed by a subsequent increment by 1 of the original expression.
- PostIncrementAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A unary postfix increment, such as (a++).
- POW - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- power(double, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
POWER
operator applied to double values. - power(double, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
- power(BigDecimal, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
- power(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
- power(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents raising a number to a power.
- power(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents raising a number to a power.
- Power - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A mathematical operation that raises a number to a power, such as (a ^ b) in Visual Basic.
- POWER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- POWER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
POWER(numeric, numeric)
function. - POWER_PG - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- POWER_PG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
POWER(numeric, numeric)
function. - powerAssign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents raising an expression to a power and assigning the result back to the expression.
- powerAssign(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents raising an expression to a power and assigning the result back to the expression.
- powerAssign(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents raising an expression to a power and assigning the result back to the expression.
- PowerAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A compound assignment operation that raises a number to a power, such as (a ^= b) in Visual Basic.
- powerOfTen(int) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Calculates a power of ten, as a long value.
- powerSet() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Computes the power set (set of all sets) of this bit set.
- powTen(int) - Static method in class org.apache.calcite.util.NumberUtil
- pPartkey - Variable in class org.apache.calcite.test.schemata.tpch.TpchSchema.Part
- PRAGMATIC_2003 - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that instructs Calcite to use SQL semantics consistent with the SQL:2003 standard, but ignoring its more inconvenient or controversial dicta.
- PRAGMATIC_2003 - Static variable in interface org.apache.calcite.sql.validate.SqlConformance
-
Deprecated.
- PRAGMATIC_99 - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that instructs Calcite to use SQL semantics consistent with the SQL:99 standard, but ignoring its more inconvenient or controversial dicta.
- PRAGMATIC_99 - Static variable in interface org.apache.calcite.sql.validate.SqlConformance
-
Deprecated.
- pre(boolean, String) - Static method in class org.apache.calcite.util.Util
-
Deprecated.Use
Preconditions.checkArgument(boolean)
orObjects.requireNonNull(Object)
- PrecedenceClimbingParser - Class in org.apache.calcite.util
-
Parser that takes a collection of tokens (atoms and operators) and groups them together according to the operators' precedence and associativity.
- PrecedenceClimbingParser.Builder - Class in org.apache.calcite.util
-
Fluent helper to build a parser containing a list of tokens.
- PrecedenceClimbingParser.Call - Class in org.apache.calcite.util
-
A token that is a call to an operator with arguments.
- PrecedenceClimbingParser.Op - Class in org.apache.calcite.util
-
An operator token.
- PrecedenceClimbingParser.Result - Class in org.apache.calcite.util
- PrecedenceClimbingParser.Special - Interface in org.apache.calcite.util
-
Callback defining the behavior of a special function.
- PrecedenceClimbingParser.SpecialOp - Class in org.apache.calcite.util
-
An token corresponding to a special operator.
- PrecedenceClimbingParser.Token - Class in org.apache.calcite.util
-
A token: either an atom, a call to an operator with arguments, or an unmatched operator.
- PrecedenceClimbingParser.Type - Enum in org.apache.calcite.util
-
Token type.
- PRECEDES - Enum constant in enum org.apache.calcite.sql.SqlKind
-
PRECEDES
operator for periods. - PRECEDES - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- preceding(RexNode) - Static method in class org.apache.calcite.rex.RexWindowBounds
- preceding(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
bound PRECEDING
window bound, for use in methods such asRelBuilder.OverCall.rowsFrom(RexWindowBound)
andRelBuilder.OverCall.rangeBetween(RexWindowBound, RexWindowBound)
. - PRECEDING - Enum constant in enum org.apache.calcite.sql.SqlKind
-
PRECEDING
qualifier of an interval end-point in a window specification. - PRECEDING_OPERATOR - Static variable in class org.apache.calcite.sql.SqlWindow
-
The PRECEDING operator used exclusively in a window specification.
- precision - Variable in class org.apache.calcite.sql.SqlAbstractDateTimeLiteral
- PRECISION_NOT_SPECIFIED - Static variable in interface org.apache.calcite.rel.type.RelDataType
- predecessorListOf(DirectedGraph<V, E>, V) - Static method in class org.apache.calcite.util.graph.Graphs
- preDecrementAssign(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that decrements the expression by 1 and assigns the result back to the expression.
- preDecrementAssign(Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that decrements the expression by 1 and assigns the result back to the expression.
- PreDecrementAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A unary prefix decrement, such as (--a).
- predicate - Variable in class org.apache.calcite.rel.hint.HintStrategy
- predicate(Predicate<? super R>) - Method in interface org.apache.calcite.plan.RelRule.OperandDetailBuilder
-
Sets the predicate of this operand.
- PREDICATE - Static variable in class org.apache.calcite.rel.rules.FilterTableScanRule
-
Deprecated.
- PREDICATE - Static variable in class org.apache.calcite.rel.rules.ProjectTableScanRule
-
Deprecated.
- PREDICATE_TEST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- Predicate1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function with one parameter returning a native
boolean
value. - Predicate2<T0,
T1> - Interface in org.apache.calcite.linq4j.function -
Function with two parameters returning a native
boolean
value. - predicateConstants(Class<C>, RexBuilder, List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Creates a map containing each (e, constant) pair that occurs within a predicate list.
- predicateConstants(Class<C>, RexBuilder, RelOptPredicateList) - Static method in class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Deprecated.
- PredicateImpl<T> - Class in org.apache.calcite.runtime
-
Deprecated.Now Calcite is Java 8 and higher, we recommend that you implement
Predicate
directly. - PredicateImpl() - Constructor for class org.apache.calcite.runtime.PredicateImpl
-
Deprecated.
- PREDICATES - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- prefer(JavaRowFormat) - Method in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
- preferArray() - Method in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
- preferCustom() - Method in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
- PreferredAlbumsTableFactory - Class in org.apache.calcite.chinook
-
Factory for the table of albums preferred by the current user.
- PreferredAlbumsTableFactory() - Constructor for class org.apache.calcite.chinook.PreferredAlbumsTableFactory
- PreferredGenresTableFactory - Class in org.apache.calcite.chinook
-
Factory for the table of genres preferred by the current user.
- PreferredGenresTableFactory() - Constructor for class org.apache.calcite.chinook.PreferredGenresTableFactory
- prefix() - Method in class org.apache.calcite.sql.validate.SqlQualified
- prefix(Object, int) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- prefix(Object, int) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- PREFIX - Enum constant in enum org.apache.calcite.sql.SqlSyntax
-
Prefix unary operator syntax, as in "- x".
- PREFIX - Enum constant in enum org.apache.calcite.util.PrecedenceClimbingParser.Type
- prefixEmps - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- prefixLength - Variable in class org.apache.calcite.sql.validate.SqlQualified
- preIncrementAssign(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that increments the expression by 1 and assigns the result back to the expression.
- preIncrementAssign(Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that increments the expression by 1 and assigns the result back to the expression.
- PreIncrementAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A unary prefix increment, such as (++a).
- preOperands(Iterable<? extends RexNode>) - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
-
Returns a copy of this AggCall with the given pre-operands.
- preOperands(RexNode...) - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
- preOrderTraverseNext(MutableRel) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- preparationAborted() - Method in interface org.apache.calcite.runtime.CalciteResource
- prepare - Variable in class org.apache.calcite.jdbc.CalcitePrepare.ParseResult
- prepare - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- prepare(Meta.ConnectionHandle, String, long) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- prepare(CalciteConnection, CalciteSchema, List<String>, String, ImmutableMap<CalciteConnectionProperty, String>) - Static method in class org.apache.calcite.schema.Schemas
-
Prepares a SQL query for execution.
- prepare(Queryable<T>) - Method in class org.apache.calcite.jdbc.CalciteStatement
- Prepare - Class in org.apache.calcite.prepare
-
Abstract base for classes that implement the process of preparing and executing SQL expressions.
- Prepare(CalcitePrepare.Context, Prepare.CatalogReader, Convention) - Constructor for class org.apache.calcite.prepare.Prepare
- Prepare.AbstractPreparingTable - Class in org.apache.calcite.prepare
-
Abstract implementation of
Prepare.PreparingTable
with an implementation forPrepare.AbstractPreparingTable.columnHasDefaultValue(org.apache.calcite.rel.type.RelDataType, int, org.apache.calcite.sql2rel.InitializerContext)
. - Prepare.CatalogReader - Interface in org.apache.calcite.prepare
-
Interface by which validator and planner can read table metadata.
- Prepare.Materialization - Class in org.apache.calcite.prepare
-
Describes that a given SQL query is materialized by a given table.
- Prepare.PreparedExplain - Class in org.apache.calcite.prepare
-
PreparedExplanation is a PreparedResult for an EXPLAIN PLAN statement.
- Prepare.PreparedResult - Interface in org.apache.calcite.prepare
- Prepare.PreparedResultImpl - Class in org.apache.calcite.prepare
-
Abstract implementation of
Prepare.PreparedResult
. - Prepare.PreparingTable - Interface in org.apache.calcite.prepare
-
Definition of a table, for the purposes of the validator and planner.
- PrepareAction() - Constructor for class org.apache.calcite.tools.Frameworks.PrepareAction
-
Deprecated.
- PrepareAction(FrameworkConfig) - Constructor for class org.apache.calcite.tools.Frameworks.PrepareAction
-
Deprecated.
- prepareAndExecute(Meta.StatementHandle, String, long, int, Meta.PrepareCallback) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- prepareAndExecute(Meta.StatementHandle, String, long, Meta.PrepareCallback) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- prepareAndExecuteBatch(Meta.StatementHandle, List<String>) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- PreparedExplain(RelDataType, RelDataType, RelRoot, SqlExplainFormat, SqlExplainLevel) - Constructor for class org.apache.calcite.prepare.Prepare.PreparedExplain
- PreparedResultImpl(RelDataType, RelDataType, List<? extends List<String>>, List<RelCollation>, RelNode, TableModify.Operation, boolean) - Constructor for class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- prepareFactory - Variable in class org.apache.calcite.jdbc.Driver
- prepareQueryable(CalcitePrepare.Context, Queryable<T>) - Method in interface org.apache.calcite.jdbc.CalcitePrepare
- prepareQueryable(CalcitePrepare.Context, Queryable<T>) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- prepareQueryable(Queryable, RelDataType) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- prepareRel(RelNode) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- prepareSql(CalcitePrepare.Context, CalcitePrepare.Query<T>, Type, long) - Method in interface org.apache.calcite.jdbc.CalcitePrepare
- prepareSql(CalcitePrepare.Context, CalcitePrepare.Query<T>, Type, long) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- prepareSql(SqlNode, Class, SqlValidator, boolean) - Method in class org.apache.calcite.prepare.Prepare
- prepareSql(SqlNode, SqlNode, Class, SqlValidator, boolean) - Method in class org.apache.calcite.prepare.Prepare
- prepareStatement(RelNode) - Method in interface org.apache.calcite.tools.RelRunner
-
Prepares a statement based on a relational expression.
- PRESERVE - Static variable in class org.apache.calcite.rel.RelCollationImpl
-
Deprecated.
- PRESERVE - Static variable in class org.apache.calcite.rel.RelCollations
-
Deprecated.
- preserveExprCondition() - Method in interface org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.Config
-
Defines when an expression should not be pushed.
- preserveExprCondition() - Method in interface org.apache.calcite.rel.rules.ProjectFilterTransposeRule.Config
-
Expressions that should be preserved in the projection.
- preserveExprCondition() - Method in interface org.apache.calcite.rel.rules.ProjectJoinTransposeRule.Config
-
Defines when an expression should not be pushed.
- preserveExprCondition() - Method in interface org.apache.calcite.rel.rules.ProjectSetOpTransposeRule.Config
-
Defines when an expression should not be pushed.
- PRESTO - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- PRESTO - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that instructs Calcite to use SQL semantics consistent with Presto.
- PrestoSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Presto database. - PrestoSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.PrestoSqlDialect
-
Creates a PrestoSqlDialect.
- PREV - Enum constant in enum org.apache.calcite.sql.SqlKind
-
PREV
operator inMATCH_RECOGNIZE
. - PREV - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
PREV
function to be used withinMATCH_RECOGNIZE
. - preValidateCall(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.SqlOperator
-
Receives notification that validation of a call to this operator is beginning.
- preventEmptyFieldList() - Method in interface org.apache.calcite.tools.RelBuilder.Config
-
Whether to ensure that relational operators always have at least one column.
- previousClearBit(int) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns the index of the nearest bit that is set to
false
that occurs on or before the specified starting index. - previousClearBit(BitSet, int) - Static method in class org.apache.calcite.util.BitSets
-
Returns the previous clear bit.
- preVisit(BinaryExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(BlockStatement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(ClassDeclaration) - Method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Creates optimizer local to the newly generated class.
- preVisit(ClassDeclaration) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(ConditionalStatement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(ConstructorDeclaration) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(DeclarationStatement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(FieldDeclaration) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(ForEachStatement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(ForStatement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(FunctionExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(GotoStatement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(IndexExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(MemberExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(MethodCallExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(MethodDeclaration) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(NewArrayExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(NewExpression) - Method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Creates optimizer local to the newly generated anonymous class.
- preVisit(NewExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(TernaryExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(ThrowStatement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(TryStatement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(TypeBinaryExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(UnaryExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- preVisit(WhileStatement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- primary(SqlParserPos, SqlIdentifier, SqlNodeList) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a PRIMARY KEY constraint.
- primary(SqlParserPos, SqlIdentifier, SqlNodeList) - Static method in class org.apache.calcite.sql.ddl.SqlKeyConstraint
-
Creates a PRIMARY KEY constraint.
- PRIMARY - Static variable in class org.apache.calcite.sql.ddl.SqlKeyConstraint
- PRIMARY_KEY - Enum constant in enum org.apache.calcite.sql.SqlKind
-
PRIMARY KEY
constraint. - primes - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- primesBoxed - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- primesCustomBoxed - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- Primitive - Enum in org.apache.calcite.linq4j.tree
-
Enumeration of Java's primitive types.
- PRIMITIVE - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive.Flavor
-
A primitive type, e.g.
- Primitive.Flavor - Enum in org.apache.calcite.linq4j.tree
-
Whether a type is primitive (e.g.
- Primitive.Sink - Interface in org.apache.calcite.linq4j.tree
-
A place to send a value.
- Primitive.Source - Interface in org.apache.calcite.linq4j.tree
-
A place from which to read a value.
- primitiveArrayWithSize(int) - Static method in class org.apache.calcite.test.Matchers
-
Returns a matcher that tests whether an object is an array (including a primitive array) with a given size.
- primitiveBoolean - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- primitiveByte - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- primitiveChar - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- primitiveClass - Variable in enum org.apache.calcite.linq4j.tree.Primitive
- primitiveDouble - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- primitiveFloat - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- primitiveInt - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- primitiveLong - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- primitiveName - Variable in enum org.apache.calcite.linq4j.tree.Primitive
- primitiveShort - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- print(int) - Static method in class org.apache.calcite.adapter.enumerable.MatchUtils
- print(int) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- print(int) - Method in interface org.apache.calcite.sql.SqlWriter
-
Prints an integer.
- print(PrintWriter, Object, int) - Static method in class org.apache.calcite.util.Util
- print(PrintWriter, Object) - Static method in class org.apache.calcite.util.Util
-
Prints an object using reflection.
- print(String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- print(String) - Method in interface org.apache.calcite.sql.SqlWriter
-
Prints a string, preceded by whitespace if necessary.
- print(String) - Method in class org.apache.calcite.util.XmlOutput
-
Sends a string directly to the output stream, without escaping any characters.
- print(StringBuilder) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Call
- print(StringBuilder) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Token
- print(PrecedenceClimbingParser.Token) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- printAsJava(PrintWriter) - Method in class org.apache.calcite.rex.RexLiteral
-
Prints the value this literal as a Java string constant.
- printer(StringBuilder, BiConsumer<StringBuilder, C>) - Static method in class org.apache.calcite.util.RangeSets
-
Creates a consumer that prints values to a
StringBuilder
. - printIterable(StringBuilder, Iterable<E>) - Static method in class org.apache.calcite.util.Util
-
Prints a collection of elements to a StringBuilder, in the same format as
AbstractCollection.toString()
. - printJavaString(Appendable, String, boolean) - Static method in class org.apache.calcite.util.Util
-
Prints a string, enclosing in double quotes (") and escaping if necessary.
- printList(StringBuilder, int, ObjIntConsumer<StringBuilder>) - Static method in class org.apache.calcite.util.Util
-
Prints a set of elements to a StringBuilder, in the same format same as
AbstractCollection.toString()
. - println(PrintWriter, Object) - Static method in class org.apache.calcite.util.Util
- println(String) - Method in class org.apache.calcite.util.Puffin.Context
- printSqlIdentifier(PrintWriter, String) - Static method in class org.apache.calcite.util.StackWriter
-
Writes an SQL identifier.
- printSqlStringLiteral(PrintWriter, String) - Static method in class org.apache.calcite.util.StackWriter
-
Writes an SQL string literal.
- printStackTrace(Throwable) - Static method in class org.apache.calcite.util.TestUtil
-
Returns string representation of the given
Throwable
. - printTo(StringBuilder, BiConsumer<StringBuilder, C>) - Method in class org.apache.calcite.util.Sarg
-
Prints this Sarg to a StringBuilder, using the given printer to deal with each embedded value.
- printUsage(String) - Static method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- printWriter(File) - Static method in class org.apache.calcite.util.Util
-
Creates a
PrintWriter
to a given file using UTF-8 character set. - printWriter(OutputStream) - Static method in class org.apache.calcite.util.Util
-
Creates a
PrintWriter
to a given output stream using UTF-8 character set. - PROCEDURE_CALL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Procedure call.
- PROCEDURE_CALL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ProcedureNamespace - Class in org.apache.calcite.sql.validate
-
Namespace whose contents are defined by the result of a call to a user-defined procedure.
- PROCESS_CURSOR_METHOD - Static variable in class org.apache.calcite.util.Smalls
- PROCESS_CURSORS_METHOD - Static variable in class org.apache.calcite.util.Smalls
- processCursor(int, Enumerable<Object[]>) - Static method in class org.apache.calcite.util.Smalls
-
Table function that adds a number to the first column of input cursor.
- processCursors(int, Enumerable<Object[]>, Enumerable<Smalls.IntString>) - Static method in class org.apache.calcite.util.Smalls
-
A function that sums the second column of first input cursor, second column of first input and the given int.
- Processes - Class in org.apache.calcite.adapter.os
-
Utilities regarding operating system processes.
- processSearchResult(String[]) - Method in interface org.apache.calcite.adapter.splunk.search.SearchResultListener
-
Handles a record from a search result.
- processSearchResult(String[]) - Method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.CountingSearchResultListener
- prod - Variable in class org.apache.calcite.util.Smalls.WideSaleSchema
- prod_id - Variable in class org.apache.calcite.test.schemata.foodmart.FoodmartSchema.SalesFact
- prodId - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- product(Iterable<? extends Iterable<T>>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Returns the cartesian product of an iterable of iterables.
- product(List<Enumerator<List<E>>>, int, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Similar to
Linq4j.product(Iterable)
but each resulting list implementsFlatLists.ComparableList
. - product(List<Enumerator<T>>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Returns an enumerator that is the cartesian product of the given enumerators.
- product(Permutation) - Method in class org.apache.calcite.util.Permutation
-
Returns the product of this Permutation with a given Permutation.
- PRODUCT_FORCE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.DECIMAL_PRODUCT_NULLABLE
but returns with nullability if any of the operands is nullable or the operation results in overflow by usingSqlTypeTransforms.FORCE_NULLABLE
. - PRODUCT_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is
ReturnTypes.DECIMAL_PRODUCT_NULLABLE
with a fallback toReturnTypes.ARG0_INTERVAL_NULLABLE
andReturnTypes.LEAST_RESTRICTIVE
. - ProductsTable - Class in org.apache.calcite.test.schemata.orderstream
-
Table representing the PRODUCTS relation.
- ProductsTable(ImmutableList<Object[]>) - Constructor for class org.apache.calcite.test.schemata.orderstream.ProductsTable
- ProductsTableFactory - Class in org.apache.calcite.test.schemata.orderstream
-
Mocks a simple relation to use for stream joining test.
- ProductsTableFactory() - Constructor for class org.apache.calcite.test.schemata.orderstream.ProductsTableFactory
- ProductsTemporalTable - Class in org.apache.calcite.test.schemata.orderstream
-
Table representing the PRODUCTS_TEMPORAL temporal table.
- ProductsTemporalTable() - Constructor for class org.apache.calcite.test.schemata.orderstream.ProductsTemporalTable
- profile(Iterable<List<Comparable>>, List<Profiler.Column>, Collection<ImmutableBitSet>) - Method in interface org.apache.calcite.profile.Profiler
-
Creates a profile of a data set.
- profile(Iterable<List<Comparable>>, List<Profiler.Column>, Collection<ImmutableBitSet>) - Method in class org.apache.calcite.profile.ProfilerImpl
- profile(Iterable<List<Comparable>>, List<Profiler.Column>, Collection<ImmutableBitSet>) - Method in class org.apache.calcite.profile.SimpleProfiler
- Profiler - Interface in org.apache.calcite.profile
-
Analyzes data sets.
- PROFILER - Static variable in class org.apache.calcite.materialize.Lattices
-
Statistics provider that uses a profiler.
- Profiler.Column - Class in org.apache.calcite.profile
-
Column.
- Profiler.Distribution - Class in org.apache.calcite.profile
-
Value distribution, including cardinality and optionally values, of a column or set of columns.
- Profiler.FunctionalDependency - Class in org.apache.calcite.profile
-
Functional dependency.
- Profiler.Profile - Class in org.apache.calcite.profile
-
The result of profiling, contains various statistics about the data in a table.
- Profiler.RowCount - Class in org.apache.calcite.profile
-
Whole data set.
- Profiler.Statistic - Interface in org.apache.calcite.profile
-
Statistic produced by the profiler.
- Profiler.Unique - Class in org.apache.calcite.profile
-
Unique key.
- ProfilerImpl - Class in org.apache.calcite.profile
-
Implementation of
Profiler
that only investigates "interesting" combinations of columns. - ProfilerImpl.Builder - Class in org.apache.calcite.profile
-
Builds a
ProfilerImpl
. - program - Variable in class org.apache.calcite.rel.core.Calc
- program - Variable in class org.apache.calcite.rel.mutable.MutableCalc
- program - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter
- Program - Interface in org.apache.calcite.tools
-
Program that transforms a relational expression into another relational expression.
- Program(SqlParserPos, List<Ast.Stmt>) - Constructor for class org.apache.calcite.piglet.Ast.Program
- PROGRAM - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- PROGRAM - Enum constant in enum org.apache.calcite.runtime.Hook
-
Called to create a Program to optimize the statement.
- programs(List<Program>) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- programs(Program...) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- Programs - Class in org.apache.calcite.tools
-
Utilities for creating
Program
s. - PROHIBITED - Enum constant in enum org.apache.calcite.plan.DeriveMode
-
Trait derivation is prohibited.
- proj4jEpsgIsMissing() - Method in interface org.apache.calcite.runtime.CalciteResource
- project() - Method in class org.apache.calcite.rel.RelRoot
-
Returns the root relational expression, creating a
LogicalProject
if necessary to remove fields that are not needed. - project(boolean) - Method in class org.apache.calcite.rel.RelRoot
-
Returns the root relational expression as a
LogicalProject
. - project(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Project
of the given list of expressions. - project(Iterable<? extends RexNode>, Iterable<? extends String>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Project
of the given list of expressions and field names. - project(Iterable<? extends RexNode>, Iterable<? extends String>, boolean) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Project
of the given list of expressions, using the given names. - project(Iterable<? extends RexNode>, Iterable<? extends String>, boolean, Iterable<CorrelationId>) - Method in class org.apache.calcite.tools.RelBuilder
-
The same with
RelBuilder.project(Iterable, Iterable, boolean)
, with additional variablesSet param. - project(List<Integer>, boolean, JavaRowFormat) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Projects a given collection of fields from this input record, optionally with indicator fields, into a particular preferred output format.
- project(List<Integer>, boolean, JavaRowFormat) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- project(List<Integer>, JavaRowFormat) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Projects a given collection of fields from this input record, into a particular preferred output format.
- project(List<Integer>, JavaRowFormat) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- project(DataContext, int[]) - Method in class org.apache.calcite.adapter.csv.CsvTranslatableTable
-
Returns an enumerable over a given projection of the fields.
- project(DataContext, int[]) - Method in class org.apache.calcite.adapter.file.CsvTranslatableTable
-
Returns an enumerable over a given projection of the fields.
- project(RelMetadataQuery, RelNode, List<? extends RexNode>) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Helper method to determine a
Project
's collation. - project(RelMetadataQuery, RelNode, List<? extends RexNode>) - Static method in class org.apache.calcite.rel.metadata.RelMdDistribution
-
Helper method to determine a
Project
's distribution. - project(RelNode, RelDataType) - Method in class org.apache.calcite.piglet.PigRelBuilder
-
Projects a specific row type out of a relation algebra operator.
- project(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Project
of the given expressions. - project(ImmutableBitSet, Set<RelDataTypeField>, RelBuilder) - Method in class org.apache.calcite.rel.core.TableScan
-
Projects a subset of the fields of the table, and also asks for "extra" fields that were not included in the table's official type.
- Project - Class in org.apache.calcite.rel.core
-
Relational expression that computes a set of 'select expressions' from its input relational expression.
- Project(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.rel.core.Project
-
Deprecated.
- Project(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, List<? extends RexNode>, RelDataType, Set<CorrelationId>) - Constructor for class org.apache.calcite.rel.core.Project
-
Creates a Project.
- Project(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.rel.core.Project
-
Deprecated.
- Project(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType, int) - Constructor for class org.apache.calcite.rel.core.Project
-
Deprecated.
- Project(RelInput) - Constructor for class org.apache.calcite.rel.core.Project
-
Creates a Project by parsing serialized output.
- PROJECT - Static variable in class org.apache.calcite.adapter.cassandra.CassandraRules
- PROJECT - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- PROJECT - Static variable in class org.apache.calcite.adapter.innodb.InnodbRules
-
Rule to convert a
LogicalProject
to aInnodbProject
. - PROJECT - Static variable in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- PROJECT - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
Project
nodes. - PROJECT - Static variable in class org.apache.calcite.rel.rules.MeasureRules
- PROJECT - Static variable in interface org.apache.calcite.rel.rules.ProjectFilterTransposeRule.Config
- PROJECT - Static variable in interface org.apache.calcite.rel.rules.PruneEmptyRules.RemoveEmptySingleRule.RemoveEmptySingleRuleConfig
- PROJECT - Static variable in interface org.apache.calcite.rel.rules.SubQueryRemoveRule.Config
- PROJECT - Static variable in interface org.apache.calcite.rel.rules.ValuesReduceRule.Config
- PROJECT_AGGREGATE - Static variable in class org.apache.calcite.rel.rules.materialize.MaterializedViewRules
- PROJECT_AGGREGATE_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- PROJECT_CALC_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that merges a
LogicalProject
and aLogicalCalc
. - PROJECT_CORRELATE_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- PROJECT_EXTRACT_RULE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
-
Rule to extract a
Project
fromAggregate
on top ofDruidQuery
based on the fields used in the aggregate. - PROJECT_FILTER - Static variable in class org.apache.calcite.rel.rules.materialize.MaterializedViewRules
- PROJECT_FILTER - Static variable in interface org.apache.calcite.rel.rules.ProjectFilterTransposeRule.Config
- PROJECT_FILTER - Static variable in interface org.apache.calcite.rel.rules.ValuesReduceRule.Config
- PROJECT_FILTER_TRANSPOSE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- PROJECT_FILTER_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- PROJECT_FILTER_TRANSPOSE_WHOLE_EXPRESSIONS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.PROJECT_FILTER_TRANSPOSE
, but pushes down project and filter expressions whole, not field references. - PROJECT_FILTER_TRANSPOSE_WHOLE_PROJECT_EXPRESSIONS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.PROJECT_FILTER_TRANSPOSE
, pushes down field references for filters, but pushes down project expressions whole. - PROJECT_FILTER_VALUES_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that merges a
Project
on top of aFilter
onto an underlyingLogicalValues
, resulting in aValues
with different columns and potentially fewer rows. - PROJECT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts a
Project
to empty if its child is empty. - PROJECT_INTERPRETER_TABLE_SCAN - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.PROJECT_TABLE_SCAN
, but with an interveningEnumerableInterpreter
. - PROJECT_JOIN - Static variable in class org.apache.calcite.rel.rules.materialize.MaterializedViewRules
- PROJECT_JOIN_JOIN_REMOVE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- PROJECT_JOIN_REMOVE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- PROJECT_JOIN_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that pushes a
LogicalProject
past aLogicalJoin
by splitting the projection into a projection on top of each child of the join. - PROJECT_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- PROJECT_MULTI_JOIN_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- PROJECT_ON_FILTER - Static variable in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- PROJECT_OVER_SUM_TO_SUM0_RULE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that converts SUM to SUM0 in OVER clauses in a project list.
- PROJECT_PREDICATE - Static variable in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- PROJECT_PREDICATE - Static variable in class org.apache.calcite.rex.RexUtil.SubQueryFinder
-
Deprecated.
- PROJECT_REDUCE_EXPRESSIONS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that reduces constants inside a
LogicalProject
. - PROJECT_REMOVE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that, given a
Project
node that merely returns its input, converts the node into its input. - PROJECT_SCAN - Static variable in class org.apache.calcite.adapter.arrow.ArrowRules
-
Rule that matches a
Project
on anArrowTableScan
and pushes down projects if possible. - PROJECT_SCAN - Static variable in class org.apache.calcite.adapter.csv.CsvRules
-
Rule that matches a
Project
on aCsvTableScan
and pushes down projects if possible. - PROJECT_SCAN - Static variable in class org.apache.calcite.adapter.file.FileRules
-
Rule that matches a
Project
on aCsvTableScan
and pushes down projects if possible. - PROJECT_SET_OP_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that pushes a
LogicalProject
past aSetOp
. - PROJECT_SORT - Static variable in class org.apache.calcite.rel.rules.MeasureRules
- PROJECT_SUB_QUERY_TO_CORRELATE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that converts sub-queries from project expressions into
Correlate
instances. - PROJECT_TABLE_SCAN - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that converts a
Project
on aTableScan
of aProjectableFilterableTable
to aBindables.BindableTableScan
. - PROJECT_TO_CALC - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that converts a
LogicalProject
to aLogicalCalc
. - PROJECT_TO_LOGICAL_PROJECT_AND_WINDOW - Static variable in class org.apache.calcite.rel.rules.CoreRules
- PROJECT_TO_SEMI_JOIN - Static variable in class org.apache.calcite.rel.rules.CoreRules
- PROJECT_VALUES_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that merges a
Project
onto an underlyingLogicalValues
, resulting in aValues
with different columns. - PROJECT_WINDOW_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that pushes a
LogicalProject
past aLogicalWindow
. - Project.Flags - Class in org.apache.calcite.rel.core
-
Deprecated.
- ProjectableFilterableTable - Interface in org.apache.calcite.schema
-
Table that can be scanned, optionally applying supplied filter expressions, and projecting a given list of columns, without creating an intermediate relational expression.
- ProjectAggregateMergeRule - Class in org.apache.calcite.rel.rules
- ProjectAggregateMergeRule(ProjectAggregateMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectAggregateMergeRule
-
Creates a ProjectAggregateMergeRule.
- ProjectAggregateMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ProjectCalcMergeRule - Class in org.apache.calcite.rel.rules
- ProjectCalcMergeRule(ProjectCalcMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectCalcMergeRule
-
Creates a ProjectCalcMergeRule.
- ProjectCalcMergeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectCalcMergeRule
-
Deprecated.
- ProjectCalcMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ProjectCorrelateTransposeRule - Class in org.apache.calcite.rel.rules
- ProjectCorrelateTransposeRule(ProjectCorrelateTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule
-
Creates a ProjectCorrelateTransposeRule.
- ProjectCorrelateTransposeRule(PushProjector.ExprCondition, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule
-
Deprecated.
- ProjectCorrelateTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ProjectCorrelateTransposeRule.RelNodesExprsHandler - Class in org.apache.calcite.rel.rules
-
Visitor for RelNodes which applies specified
RexShuttle
visitor for every node in the tree. - ProjectCorrelateTransposeRule.RexFieldAccessReplacer - Class in org.apache.calcite.rel.rules
-
Visitor for RexNodes which replaces
RexCorrelVariable
with specified. - projectExcept(Iterable<RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Project
of all original fields, except the given list of expressions. - projectExcept(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Project
of all original fields, except the given expressions. - projectFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- ProjectFilterTransposeRule - Class in org.apache.calcite.rel.rules
- ProjectFilterTransposeRule(Class<? extends Project>, Class<? extends Filter>, RelBuilderFactory, PushProjector.ExprCondition) - Constructor for class org.apache.calcite.rel.rules.ProjectFilterTransposeRule
-
Deprecated.
- ProjectFilterTransposeRule(RelOptRuleOperand, PushProjector.ExprCondition, boolean, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectFilterTransposeRule
-
Deprecated.
- ProjectFilterTransposeRule(ProjectFilterTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectFilterTransposeRule
-
Creates a ProjectFilterTransposeRule.
- ProjectFilterTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ProjectionTransformer - Class in org.apache.calcite.runtime
-
Transforms the projection of a geometry.
- ProjectionTransformer(int, int) - Constructor for class org.apache.calcite.runtime.ProjectionTransformer
-
Creates a transformer that reprojects geometries with the provided SRIDs.
- projectJoinInputs(RelNode[], List<RexNode>, List<RexNode>, int, List<Integer>, List<Integer>, List<Integer>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- ProjectJoinJoinRemoveRule - Class in org.apache.calcite.rel.rules
- ProjectJoinJoinRemoveRule(Class<? extends Project>, Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectJoinJoinRemoveRule
-
Deprecated.
- ProjectJoinJoinRemoveRule(ProjectJoinJoinRemoveRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectJoinJoinRemoveRule
-
Creates a ProjectJoinJoinRemoveRule.
- ProjectJoinJoinRemoveRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ProjectJoinRemoveRule - Class in org.apache.calcite.rel.rules
- ProjectJoinRemoveRule(Class<? extends Project>, Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectJoinRemoveRule
-
Deprecated.
- ProjectJoinRemoveRule(ProjectJoinRemoveRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectJoinRemoveRule
-
Creates a ProjectJoinRemoveRule.
- ProjectJoinRemoveRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ProjectJoinTransposeRule - Class in org.apache.calcite.rel.rules
- ProjectJoinTransposeRule(Class<? extends Project>, Class<? extends Join>, PushProjector.ExprCondition, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectJoinTransposeRule
-
Deprecated.
- ProjectJoinTransposeRule(ProjectJoinTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectJoinTransposeRule
-
Creates a ProjectJoinTransposeRule.
- ProjectJoinTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- projectMapping(RelNode, Mapping, List<String>, RelFactories.ProjectFactory) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- ProjectMeasureRule(MeasureRules.ProjectMeasureRuleConfig) - Constructor for class org.apache.calcite.rel.rules.MeasureRules.ProjectMeasureRule
-
Creates a ProjectMeasureRule.
- projectMergeRule() - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule.Config
-
Instance of rule to merge project operators.
- ProjectMergeRule - Class in org.apache.calcite.rel.rules
- ProjectMergeRule(boolean, int, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectMergeRule
-
Deprecated.
- ProjectMergeRule(boolean, RelFactories.ProjectFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectMergeRule
-
Deprecated.
- ProjectMergeRule(boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectMergeRule
-
Deprecated.
- ProjectMergeRule(ProjectMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectMergeRule
-
Creates a ProjectMergeRule.
- ProjectMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- projectMultiJoin(MultiJoin, Project) - Static method in class org.apache.calcite.plan.RelOptUtil
- ProjectMultiJoinMergeRule - Class in org.apache.calcite.rel.rules
- ProjectMultiJoinMergeRule(Class<? extends Project>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectMultiJoinMergeRule
-
Deprecated.
- ProjectMultiJoinMergeRule(ProjectMultiJoinMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectMultiJoinMergeRule
-
Creates a ProjectMultiJoinMergeRule.
- ProjectMultiJoinMergeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectMultiJoinMergeRule
-
Deprecated.
- ProjectMultiJoinMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- projectMultiset(Object...) - Static method in class org.apache.calcite.piglet.PigRelSqlUdfs
-
Implementation for BAG_PROJECTION functions.
- projectNamed(Iterable<? extends RexNode>, Iterable<? extends String>, boolean) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Project
of the given expressions and field names, and optionally optimizing. - projectNamed(Iterable<? extends RexNode>, Iterable<? extends String>, boolean, Iterable<CorrelationId>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Project
of the given expressions and field names, and optionally optimizing. - ProjectNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
Project
. - ProjectNode(Compiler, Project) - Constructor for class org.apache.calcite.interpreter.ProjectNode
- ProjectOverSumToSum0Rule - Class in org.apache.calcite.rel.rules
-
Planner rule that converts SUM to SUM0 when it is the aggregate for an OVER clause inside the project list.
- ProjectOverSumToSum0Rule(ProjectOverSumToSum0Rule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectOverSumToSum0Rule
-
Creates a ProjectOverSumToSum0Rule.
- ProjectOverSumToSum0Rule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- projectPlus(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Project
of all original fields, plus the given list of expressions. - projectPlus(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Project
of all original fields, plus the given expressions. - ProjectReduceExpressionsRule(Class<? extends Project>, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.ProjectReduceExpressionsRule
-
Deprecated.
- ProjectReduceExpressionsRule(Class<? extends Project>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.ProjectReduceExpressionsRule
-
Deprecated.
- ProjectReduceExpressionsRule(ReduceExpressionsRule.ProjectReduceExpressionsRule.ProjectReduceExpressionsRuleConfig) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.ProjectReduceExpressionsRule
-
Creates a ProjectReduceExpressionsRule.
- ProjectRemoveRule - Class in org.apache.calcite.rel.rules
-
Planner rule that, given a
Project
node that merely returns its input, converts the node into its child. - ProjectRemoveRule(ProjectRemoveRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectRemoveRule
-
Creates a ProjectRemoveRule.
- ProjectRemoveRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectRemoveRule
-
Deprecated.
- ProjectRemoveRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- projects - Variable in class org.apache.calcite.interpreter.Bindables.BindableTableScan
- projects - Variable in class org.apache.calcite.rel.mutable.MutableProject
- ProjectSetOpTransposeRule - Class in org.apache.calcite.rel.rules
- ProjectSetOpTransposeRule(ProjectSetOpTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectSetOpTransposeRule
-
Creates a ProjectSetOpTransposeRule.
- ProjectSetOpTransposeRule(PushProjector.ExprCondition, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectSetOpTransposeRule
-
Deprecated.
- ProjectSetOpTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- projectsIdentity(boolean) - Method in class org.apache.calcite.rex.RexProgram
-
Returns whether the fields on the leading edge of the project list are the input fields.
- projectsOnlyIdentity() - Method in class org.apache.calcite.rex.RexProgram
-
Returns whether this program projects precisely its input fields.
- ProjectSortMeasureRule(MeasureRules.ProjectSortMeasureRuleConfig) - Constructor for class org.apache.calcite.rel.rules.MeasureRules.ProjectSortMeasureRule
-
Creates a ProjectSortMeasureRule.
- projectsRight() - Method in enum org.apache.calcite.rel.core.JoinRelType
- ProjectTableScanRule - Class in org.apache.calcite.rel.rules
-
Planner rule that converts a
Project
on aTableScan
of aProjectableFilterableTable
to aBindables.BindableTableScan
. - ProjectTableScanRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.ProjectTableScanRule
-
Deprecated.
- ProjectTableScanRule(ProjectTableScanRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectTableScanRule
-
Creates a ProjectTableScanRule.
- ProjectTableScanRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ProjectToCalcRule - Class in org.apache.calcite.rel.rules
-
Rule to convert a
LogicalProject
to aLogicalCalc
. - ProjectToCalcRule(ProjectToCalcRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectToCalcRule
-
Creates a ProjectToCalcRule.
- ProjectToCalcRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectToCalcRule
-
Deprecated.
- ProjectToCalcRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ProjectToLogicalProjectAndWindowRule(ProjectToWindowRule.ProjectToLogicalProjectAndWindowRule.ProjectToLogicalProjectAndWindowRuleConfig) - Constructor for class org.apache.calcite.rel.rules.ProjectToWindowRule.ProjectToLogicalProjectAndWindowRule
-
Creates a ProjectToLogicalProjectAndWindowRule.
- ProjectToLogicalProjectAndWindowRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectToWindowRule.ProjectToLogicalProjectAndWindowRule
-
Deprecated.
- ProjectToSemiJoinRule(Class<Project>, Class<Join>, Class<Aggregate>, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.SemiJoinRule.ProjectToSemiJoinRule
-
Deprecated.
- ProjectToSemiJoinRule(SemiJoinRule.ProjectToSemiJoinRule.ProjectToSemiJoinRuleConfig) - Constructor for class org.apache.calcite.rel.rules.SemiJoinRule.ProjectToSemiJoinRule
-
Creates a ProjectToSemiJoinRule.
- ProjectToWindowRule - Class in org.apache.calcite.rel.rules
-
Planner rule that slices a
Project
into sections which contain windowed aggregate functions and sections which do not. - ProjectToWindowRule(ProjectToWindowRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectToWindowRule
-
Creates a ProjectToWindowRule.
- ProjectToWindowRule.CalcToWindowRule - Class in org.apache.calcite.rel.rules
-
Instance of the rule that applies to a
Calc
that contains windowed aggregates and converts it into a mixture ofLogicalWindow
andCalc
. - ProjectToWindowRule.CalcToWindowRule.CalcToWindowRuleConfig - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ProjectToWindowRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ProjectToWindowRule.ProjectToLogicalProjectAndWindowRule - Class in org.apache.calcite.rel.rules
-
Instance of the rule that can be applied to a
Project
and that produces, in turn, a mixture ofLogicalProject
andLogicalWindow
. - ProjectToWindowRule.ProjectToLogicalProjectAndWindowRule.ProjectToLogicalProjectAndWindowRuleConfig - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- projectTypes(RelDataType, List<? extends Number>) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Selects data types of the specified fields from an input row type.
- ProjectWindowTransposeRule - Class in org.apache.calcite.rel.rules
-
Planner rule that pushes a
LogicalProject
past aLogicalWindow
. - ProjectWindowTransposeRule(ProjectWindowTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.ProjectWindowTransposeRule
-
Creates a ProjectWindowTransposeRule.
- ProjectWindowTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectWindowTransposeRule
-
Deprecated.
- ProjectWindowTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- promoteToRowType(RelDataTypeFactory, RelDataType, String) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Promotes a type to a row type (does nothing if it already is one).
- propagate(RelNode, RelNode) - Method in interface org.apache.calcite.plan.RelHintsPropagator
-
Propagates the hints from a rule call's root relational expression
oriNode
to the new equivalent relational expressionequiv
. - propagateRelHints(RelNode, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Propagates the relational expression hints from root node to leaf node.
- propagateRelHints(RelNode, RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
- property(Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberExpression that represents accessing a property by using a property accessor method.
- property(Expression, Type, String) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberExpression accessing a property.
- property(Expression, String) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberExpression that represents accessing a property.
- property(Expression, String, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an IndexExpression representing the access to an indexed property.
- property(Expression, Expressions.PropertyInfo) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberExpression that represents accessing a property.
- property(Expression, Expressions.PropertyInfo, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an IndexExpression representing the access to an indexed property.
- property(Expression, Expressions.PropertyInfo, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an IndexExpression representing the access to an indexed property, using varargs.
- property(V) - Static method in enum org.apache.calcite.runtime.Hook
-
Deprecated.Use
Hook.propertyJ(V)
. - propertyJ(V) - Static method in enum org.apache.calcite.runtime.Hook
-
Returns a function that, when a hook is called, will "return" a given value.
- propertyOrField(Expression, String) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberExpression that represents accessing a property or field.
- proto(Object...) - Static method in class org.apache.calcite.tools.RelBuilder
-
Creates a
RelBuilderFactory
that uses a given set of factories. - proto(Context) - Static method in class org.apache.calcite.tools.RelBuilder
-
Creates a
RelBuilderFactory
, a partially-created RelBuilder. - proto(RelDataType) - Static method in class org.apache.calcite.rel.type.RelDataTypeImpl
-
Returns an implementation of
RelProtoDataType
that copies a given type using the given type factory. - proto(ScalarFunction) - Static method in class org.apache.calcite.schema.Schemas
-
Returns an implementation of
RelProtoDataType
that asks a given scalar function for its return type with a given type factory. - proto(Table) - Static method in class org.apache.calcite.schema.Schemas
-
Returns an implementation of
RelProtoDataType
that asks a given table for its row type with a given type factory. - proto(SqlTypeName, boolean) - Static method in class org.apache.calcite.rel.type.RelDataTypeImpl
-
Returns a
RelProtoDataType
that will create a typetypeName
. - proto(SqlTypeName, int, boolean) - Static method in class org.apache.calcite.rel.type.RelDataTypeImpl
-
Returns a
RelProtoDataType
that will create a typetypeName(precision)
. - proto(SqlTypeName, int, int, boolean) - Static method in class org.apache.calcite.rel.type.RelDataTypeImpl
-
Returns a
RelProtoDataType
that will create a typetypeName(precision, scale)
. - protocol() - Method in interface org.apache.calcite.util.Source
- protoRowType - Variable in class org.apache.calcite.adapter.csv.CsvTable
- protoRowType - Variable in class org.apache.calcite.adapter.file.CsvTable
- protoRowType - Variable in class org.apache.calcite.test.schemata.orderstream.BaseOrderStreamTable
- protoType - Variable in class org.apache.calcite.sql.type.ExplicitReturnTypeInference
- PROTOTYPE_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Specify the kinds of objects to create using a prototypical instance, and create new objects by copying this prototype.
- provideConnectionInfo() - Method in class org.apache.calcite.chinook.CalciteConnectionProvider
- provider - Variable in class org.apache.calcite.linq4j.BaseQueryable
- provider - Variable in class org.apache.calcite.materialize.DelegatingLatticeStatisticProvider
- PROXY_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Provide a surrogate or placeholder for another object to control access to it.
- ProxyingMetadataHandlerProvider - Class in org.apache.calcite.rel.metadata
-
A MetadataHandlerProvider built on a RelMetadataProvider.
- ProxyingMetadataHandlerProvider(RelMetadataProvider) - Constructor for class org.apache.calcite.rel.metadata.ProxyingMetadataHandlerProvider
-
Create a proxying handler provider.
- prune(RelNode) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- prune(RelNode) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Prunes a node from the planner.
- prune(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- PruneEmptyRule(PruneEmptyRules.PruneEmptyRule.Config) - Constructor for class org.apache.calcite.rel.rules.PruneEmptyRules.PruneEmptyRule
- PruneEmptyRules - Class in org.apache.calcite.rel.rules
-
Collection of rules which remove sections of a query plan known never to produce any rows.
- PruneEmptyRules() - Constructor for class org.apache.calcite.rel.rules.PruneEmptyRules
- PruneEmptyRules.CorrelateLeftEmptyRuleConfig - Interface in org.apache.calcite.rel.rules
-
Configuration for rule that prunes a correlate if its left input is empty.
- PruneEmptyRules.CorrelateRightEmptyRuleConfig - Interface in org.apache.calcite.rel.rules
-
Configuration for rule that prunes a correlate if its right input is empty.
- PruneEmptyRules.IntersectEmptyPruneRuleConfig - Interface in org.apache.calcite.rel.rules
-
Configuration for a rule that prunes an Intersect if any of its inputs is empty.
- PruneEmptyRules.JoinLeftEmptyRuleConfig - Interface in org.apache.calcite.rel.rules
-
Configuration for rule that prunes a join it its left input is empty.
- PruneEmptyRules.JoinRightEmptyRuleConfig - Interface in org.apache.calcite.rel.rules
-
Configuration for rule that prunes a join it its right input is empty.
- PruneEmptyRules.MinusEmptyPruneRuleConfig - Interface in org.apache.calcite.rel.rules
-
Configuration for a rule that prunes empty inputs from a Minus.
- PruneEmptyRules.PruneEmptyRule - Class in org.apache.calcite.rel.rules
-
Abstract prune empty rule that implements SubstitutionRule interface.
- PruneEmptyRules.PruneEmptyRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- PruneEmptyRules.RemoveEmptySingleRule - Class in org.apache.calcite.rel.rules
-
Rule that converts a relation into empty.
- PruneEmptyRules.RemoveEmptySingleRule.RemoveEmptySingleRuleConfig - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- PruneEmptyRules.SortFetchZeroRuleConfig - Interface in org.apache.calcite.rel.rules
-
Configuration for a rule that prunes a Sort if it has limit 0.
- PruneEmptyRules.UnionEmptyPruneRuleConfig - Interface in org.apache.calcite.rel.rules
-
Configuration for a rule that prunes empty inputs from a Minus.
- PruneEmptyRules.ZeroMaxRowsRuleConfig - Interface in org.apache.calcite.rel.rules
-
Configuration for rule that transforms an empty relational expression into an empty values.
- pruneIfEmpty - Variable in class org.apache.calcite.sql.TableCharacteristic
-
If the value is true, meaning that the DBMS can prune virtual processors from the query plan if the input table is empty.
- pruneIfEmpty() - Method in class org.apache.calcite.sql.TableCharacteristic.Builder
-
DBMS could prune virtual processors if the input table is empty.
- pruneInputOfAggregate() - Method in interface org.apache.calcite.tools.RelBuilder.Config
-
Whether
RelBuilder.aggregate(org.apache.calcite.tools.RelBuilder.GroupKey, org.apache.calcite.tools.RelBuilder.AggCall...)
should prune unused input columns; default true. - PruneSingleValueRule(SingleValuesOptimizationRules.PruneSingleValueRule.Config) - Constructor for class org.apache.calcite.rel.rules.SingleValuesOptimizationRules.PruneSingleValueRule
- ps(int, int) - Static method in class org.apache.calcite.test.schemata.tpch.TpchSchema
- PseudoField - Interface in org.apache.calcite.linq4j.tree
-
Contains the parts of the
Field
class needed for code generation, but might be implemented differently. - psPartkey - Variable in class org.apache.calcite.test.schemata.tpch.TpchSchema.PartSupp
- psSupplyCost - Variable in class org.apache.calcite.test.schemata.tpch.TpchSchema.PartSupp
- PsTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "ps" command to list processes.
- PsTableFunction.LineParser - Class in org.apache.calcite.adapter.os
-
Class for parsing, line by line, the output of the ps command for a predefined list of parameters.
- publishYear - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Book
- PUBSUB - Enum constant in enum org.apache.calcite.adapter.redis.RedisDataType
-
Redis implementation of publish and subscribe paradigm.
- Puffin - Class in org.apache.calcite.util
-
A text processor similar to Awk.
- Puffin.Builder<G,
F> - Interface in org.apache.calcite.util -
Fluent interface for constructing a Program.
- Puffin.Context<G,
F> - Class in org.apache.calcite.util -
Context for executing a Puffin program within a given file.
- Puffin.Line<G,
F> - Interface in org.apache.calcite.util -
A line in a file.
- Puffin.Program<G> - Interface in org.apache.calcite.util
-
A Puffin program.
- pulledUpPredicates - Variable in class org.apache.calcite.plan.RelOptPredicateList
-
Predicates that can be pulled up from the relational expression and its inputs.
- pullFactors(RexBuilder, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Creates an equivalent version of a node where common factors among ORs are pulled up.
- push(List<T>, T) - Static method in class org.apache.calcite.util.Stacks
-
Deprecated.Adds an element to the stack.
- push(CalcitePrepare.Context) - Static method in class org.apache.calcite.jdbc.CalcitePrepare.Dummy
- push(RelNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Adds a relational expression to be the input to the next relational expression constructed.
- push(T) - Method in class org.apache.calcite.util.TryThreadLocal
-
Assigns the value as
value
for the current thread. - pushAll(Iterable<? extends RelNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Pushes a collection of relational expressions.
- pushDownJoinConditions(Join) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- pushDownJoinConditions(Join, RelFactories.ProjectFactory) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- pushDownJoinConditions(Join, RelBuilder) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Pushes down expressions in "equal" join condition.
- pushFilterPastProject(RexNode, Project) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- pushFilterToOriginalViewPlan(RelBuilder, RelNode, RelNode, RexNode) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule
- pushFilterToOriginalViewPlan(RelBuilder, RelNode, RelNode, RexNode) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewJoinRule
- pushFilterToOriginalViewPlan(RelBuilder, RelNode, RelNode, RexNode) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
Once we create a compensation predicate, this method is responsible for pushing the resulting filter through the view nodes.
- pushFunctionCall() - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Pushes a new instance of a function call on to a function call stack.
- pushFunctionCall() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- pushJoinCondition() - Method in interface org.apache.calcite.tools.RelBuilder.Config
-
Whether to push down join conditions; default false (but
SqlToRelConverter.config()
by default sets this to true). - pushPastCalc(RexNode, Calc) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Converts an expression that is based on the output fields of a
Calc
to an equivalent expression on the Calc's input fields. - pushPastProject(List<? extends RexNode>, Project) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Converts a list of expressions that are based on the output fields of a
Project
to equivalent expressions on the Project's input fields. - pushPastProject(RexNode, Project) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Converts an expression that is based on the output fields of a
Project
to an equivalent expression on the Project's input fields. - pushPastProjectUnlessBloat(List<? extends RexNode>, Project, int) - Static method in class org.apache.calcite.plan.RelOptUtil
-
As
RelOptUtil.pushPastProject(org.apache.calcite.rex.RexNode, org.apache.calcite.rel.core.Project)
, but returns null if the resulting expressions are significantly more complex. - pushPastProjectUnlessBloat(RexNode, Project, int) - Static method in class org.apache.calcite.plan.RelOptUtil
- pushPredicateIntoCase(RexCall) - Static method in class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Pushes predicates into a CASE.
- PushProjector - Class in org.apache.calcite.rel.rules
-
PushProjector is a utility class used to perform operations used in push projection rules.
- PushProjector(Project, RexNode, RelNode, PushProjector.ExprCondition, RelBuilder) - Constructor for class org.apache.calcite.rel.rules.PushProjector
-
Creates a PushProjector object for pushing projects past a RelNode.
- PushProjector.ExprCondition - Interface in org.apache.calcite.rel.rules
-
A functor that replies true or false for a given expression.
- put(String, V) - Method in class org.apache.calcite.util.NameMap
- put(String, V) - Method in class org.apache.calcite.util.NameMultimap
-
Adds an entry to this multimap.
- put(Map<String, Object>, String, Object) - Method in class org.apache.calcite.util.JsonBuilder
-
Adds a key/value pair to a JSON object.
- put(K, V) - Method in class org.apache.calcite.util.CompositeMap
- putAll(Map<? extends K, ? extends V>) - Method in class org.apache.calcite.util.CompositeMap
- putIf(Map<String, Object>, String, Object) - Method in class org.apache.calcite.util.JsonBuilder
-
Adds a key/value pair to a JSON object if the value is not null.
- putMulti(K, V) - Method in class org.apache.calcite.runtime.SortedMultiMap
- pw - Variable in class org.apache.calcite.rel.externalize.RelWriterImpl
Q
- Q - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- qualifiedContext() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Returns a context that always qualifies identifiers.
- qualifiedTableName - Variable in class org.apache.calcite.plan.RelOptMaterialization
- QUALIFY_OPERAND - Static variable in class org.apache.calcite.sql.SqlSelect
- qualifyExpressionMustContainWindowFunction(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- qualifyUsingAlias(SqlSelect, SqlIdentifier) - Method in class org.apache.calcite.sql.validate.DelegatingScope
-
Qualifies an identifier by looking for an alias in the current select-list.
- QUANTIFY_OPERATORS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- QUARTER - Enum constant in enum org.apache.calcite.adapter.druid.Granularity.Type
- QUARTER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
QUARTER
operator. - QUARTER_VARIANTS - Static variable in class org.apache.calcite.test.SqlOperatorTest
- query - Variable in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRuleCall
- query - Variable in class org.apache.calcite.sql.ddl.SqlCreateMaterializedView
- query - Variable in class org.apache.calcite.sql.ddl.SqlCreateTable
- query - Variable in class org.apache.calcite.sql.ddl.SqlCreateView
- query - Variable in class org.apache.calcite.sql.SqlOrderBy
- query - Variable in class org.apache.calcite.sql.SqlPivot
- query - Variable in class org.apache.calcite.sql.SqlUnpivot
- query - Variable in class org.apache.calcite.sql.SqlWithItem
- query(int) - Static method in class org.apache.calcite.plan.SubstitutionVisitor.AbstractUnifyRule
-
Creates an operand that matches a relational expression in the query.
- query(TableReaderFactory) - Method in class org.apache.calcite.adapter.innodb.InnodbTable
- query(TableReaderFactory, List<Map.Entry<String, Class>>, List<Map.Entry<String, String>>, IndexCondition, Boolean) - Method in class org.apache.calcite.adapter.innodb.InnodbTable
-
Executes a query on the underlying InnoDB table.
- query(CqlSession) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable
- query(CqlSession, List<Map.Entry<String, Class>>, List<Map.Entry<String, String>>, List<String>, List<String>, Integer, Integer) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable
-
Executes a CQL query on the underlying table.
- query(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- query(List<Map.Entry<String, Class>>, List<Map.Entry<String, String>>, List<String>, List<String>, Integer, Integer) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Called via code-generation.
- query(List<Map.Entry<String, Class>>, List<Map.Entry<String, String>>, List<Map.Entry<String, String>>, List<String>, List<String>, List<String>, Long) - Method in class org.apache.calcite.adapter.geode.rel.GeodeTable.GeodeQueryable
-
Called via code-generation.
- query(List<Map.Entry<String, Class>>, List<Map.Entry<String, String>>, IndexCondition, Boolean) - Method in class org.apache.calcite.adapter.innodb.InnodbTable.InnodbQueryable
-
Called via code-generation.
- query(DataContext, ImmutableIntList, List<String>) - Method in class org.apache.calcite.adapter.arrow.ArrowTable
-
Called via code generation; see uses of
ArrowMethod.ARROW_QUERY
. - query(CalciteSchema) - Method in class org.apache.calcite.materialize.MaterializationService
-
Gathers a list of all materialized tables known within a given root schema.
- query(RelNode, RelMetadataQuery, Class<M>) - Method in interface org.apache.calcite.rel.metadata.MetadataFactory
-
Returns a metadata interface to get a particular kind of metadata from a particular relational expression.
- query(RelNode, RelMetadataQuery, Class<M>) - Method in class org.apache.calcite.rel.metadata.MetadataFactoryImpl
-
Deprecated.
- query(GemFireCache, List<Map.Entry<String, Class>>, List<Map.Entry<String, String>>, List<Map.Entry<String, String>>, List<String>, List<String>, List<String>, Long) - Method in class org.apache.calcite.adapter.geode.rel.GeodeTable
-
Executes an OQL query on the underlying table.
- QUERY - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category consisting of query node types.
- QUERY_PARTIAL - Enum constant in enum org.apache.calcite.rel.rules.materialize.MaterializedViewRule.MatchModality
- QUERY_PLAN - Enum constant in enum org.apache.calcite.runtime.Hook
-
Called with a query that has been generated to send to a back-end system.
- queryable - Variable in class org.apache.calcite.jdbc.CalcitePrepare.Query
- queryable(DataContext, Class<E>, Iterable<? extends String>) - Static method in class org.apache.calcite.schema.Schemas
-
Returns a
Queryable
, given a fully-qualified table name as an iterable. - queryable(DataContext, Class<E>, String...) - Static method in class org.apache.calcite.schema.Schemas
-
Returns a
Queryable
, given a fully-qualified table name. - queryable(DataContext, SchemaPlus, Class<E>, String) - Static method in class org.apache.calcite.schema.Schemas
-
Returns a
Queryable
, given a schema and table name. - Queryable<T> - Interface in org.apache.calcite.linq4j
-
Provides functionality to evaluate queries against a specific data source wherein the type of the data is known.
- QUERYABLE_AS_ENUMERABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- QUERYABLE_SELECT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- QUERYABLE_TABLE_AS_QUERYABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- QueryableDefaults - Class in org.apache.calcite.linq4j
-
Default implementations for methods in the
Queryable
interface. - QueryableDefaults() - Constructor for class org.apache.calcite.linq4j.QueryableDefaults
- QueryableDefaults.NonLeafReplayableQueryable<T> - Class in org.apache.calcite.linq4j
-
Non-leaf replayable queryable.
- QueryableDefaults.Replayable<T> - Interface in org.apache.calcite.linq4j
-
Replayable.
- QueryableDefaults.ReplayableQueryable<T> - Class in org.apache.calcite.linq4j
-
Replayable queryable.
- QueryableFactory<T> - Interface in org.apache.calcite.linq4j
-
Factory for building
Queryable
objects. - QueryableImpl(QueryProviderImpl, Type, Expression) - Constructor for class org.apache.calcite.linq4j.QueryProviderImpl.QueryableImpl
- QueryableRecorder<T> - Class in org.apache.calcite.linq4j
-
Implementation of
QueryableFactory
that records each event and returns an object that can replay the event when you call itsQueryableDefaults.ReplayableQueryable.replay(QueryableFactory)
method. - QueryableRecorder() - Constructor for class org.apache.calcite.linq4j.QueryableRecorder
- QueryableTable - Interface in org.apache.calcite.schema
- queryContains(Function<List, Void>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Deprecated.
- queryContains(Consumer<List>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Runs the query and applies a checker to the generated third-party queries.
- queryExecutionTimeoutReached(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- queryOperand - Variable in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRule
- queryProvider - Variable in class org.apache.calcite.schema.impl.AbstractTableQueryable
- QueryProvider - Interface in org.apache.calcite.linq4j
-
Defines methods to create and execute queries that are described by a
Queryable
object. - QueryProviderImpl - Class in org.apache.calcite.linq4j
-
Partial implementation of
QueryProvider
. - QueryProviderImpl() - Constructor for class org.apache.calcite.linq4j.QueryProviderImpl
-
Creates a QueryProviderImpl.
- QueryProviderImpl.QueryableImpl<T> - Class in org.apache.calcite.linq4j
-
Binds an expression to this query provider.
- queryRel - Variable in class org.apache.calcite.plan.RelOptMaterialization
- querySourceCoercion(SqlValidatorScope, RelDataType, RelDataType, SqlNode) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Coerces the source row expression to target type in an INSERT or UPDATE query.
- querySourceCoercion(SqlValidatorScope, RelDataType, RelDataType, SqlNode) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
- querySpec - Variable in class org.apache.calcite.adapter.druid.DruidQuery
- QuerySqlStatisticProvider - Class in org.apache.calcite.statistic
-
Implementation of
SqlStatisticProvider
that generates and executes SQL queries. - QuerySqlStatisticProvider(Consumer<String>) - Constructor for class org.apache.calcite.statistic.QuerySqlStatisticProvider
-
Creates a QuerySqlStatisticProvider.
- QueryType - Enum in org.apache.calcite.adapter.druid
-
Type of Druid query.
- QueryType - Enum in org.apache.calcite.adapter.innodb
-
Query type of a push down condition in InnoDB data source.
- QuidemConnectionFactory() - Constructor for class org.apache.calcite.test.QuidemTest.QuidemConnectionFactory
- QuidemTest - Class in org.apache.calcite.test
-
Test that runs every Quidem file as a test.
- QuidemTest() - Constructor for class org.apache.calcite.test.QuidemTest
- QuidemTest.QuidemConnectionFactory - Class in org.apache.calcite.test
-
Quidem connection factory for Calcite's built-in test schemas.
- quote(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents an expression that has a constant value of type Expression.
- Quote - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An expression that has a constant value of type Expression.
- quoteAllIdentifiers() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether to quote all identifiers, even those which would be correct according to the rules of the
SqlDialect
if quotation marks were omitted. - QUOTED_CASING - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
How identifiers are stored if they are quoted.
- QUOTED_ZERO - Static variable in class org.apache.calcite.sql.parser.SqlParserPos
-
Same as
SqlParserPos.ZERO
but always quoted. - quotedCasing - Variable in enum org.apache.calcite.config.Lex
- quotedCasing() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.QUOTED_CASING
. - quotedCasing() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- quotedCasing() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- quotedCasing() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- quoteForJava(String) - Static method in class org.apache.calcite.util.TestUtil
-
Converts a string (which may contain quotes and newlines) into a java literal.
- quoteIdentifier(String) - Method in class org.apache.calcite.sql.SqlDialect
-
Encloses an identifier in quotation marks appropriate for the current SQL dialect.
- quoteIdentifier(StringBuilder, String) - Method in class org.apache.calcite.sql.SqlDialect
-
Encloses an identifier in quotation marks appropriate for the current SQL dialect, writing the result to a
StringBuilder
. - quoteIdentifier(StringBuilder, List<String>) - Method in class org.apache.calcite.sql.SqlDialect
-
Quotes a multi-part identifier.
- quotePattern(String) - Static method in class org.apache.calcite.util.TestUtil
-
Quotes a pattern.
- quoteStringLiteral(String) - Method in class org.apache.calcite.sql.SqlDialect
-
Converts a string into a string literal.
- quoteStringLiteral(StringBuilder, String, String) - Method in class org.apache.calcite.sql.SqlDialect
-
Appends a string literal to a buffer.
- quoteStringLiteralUnicode(StringBuilder, String) - Method in class org.apache.calcite.sql.SqlDialect
-
Converts a string into a unicode string literal.
- quoteTimestampLiteral(Timestamp) - Method in class org.apache.calcite.sql.SqlDialect
-
Converts a timestamp to a SQL timestamp literal, e.g.
- QUOTIENT_FORCE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.DECIMAL_QUOTIENT_NULLABLE
but returns with nullability if any of the operands is nullable or the operation results in overflow by usingSqlTypeTransforms.FORCE_NULLABLE
. - QUOTIENT_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is
ReturnTypes.DECIMAL_QUOTIENT_NULLABLE
with a fallback toReturnTypes.ARG0_INTERVAL_NULLABLE
andReturnTypes.LEAST_RESTRICTIVE
. - quotientList(List<E>, int, int) - Static method in class org.apache.calcite.util.Util
-
Creates a list that returns every
n
th element of a list, starting at elementk
. - quoting - Variable in enum org.apache.calcite.config.Lex
- quoting() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.QUOTING
. - quoting() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- quoting() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- QUOTING - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
How identifiers are quoted.
R
- r - Variable in class org.apache.calcite.plan.RelOptUtil.Exists
- radians(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
RADIANS
operator applied to double values. - radians(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
RADIANS
operator applied to BigDecimal values. - RADIANS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- RADIANS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
RADIANS(numeric)
function. - RampFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.RampFunction
- rand() - Method in class org.apache.calcite.runtime.RandomFunction
-
Implements the
RAND()
SQL function. - RAND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- RAND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
RAND([seed])
function, which yields a random double, optionally with seed. - RAND_INTEGER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- RAND_INTEGER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
RAND_INTEGER([seed, ] bound)
function, which yields a random integer, optionally with seed. - RAND_INTEGER_SEED - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- RAND_SEED - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- randInteger(int) - Method in class org.apache.calcite.runtime.RandomFunction
-
Implements the
RAND_INTEGER(bound)
SQL function. - randIntegerSeed(int, int) - Method in class org.apache.calcite.runtime.RandomFunction
-
Implements the
RAND_INTEGER(seed, bound)
SQL function. - RANDOM - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The RANDOM() function.
- RANDOM_DISTRIBUTED - Enum constant in enum org.apache.calcite.rel.RelDistribution.Type
-
There are multiple instances of the stream, and each instance contains randomly chosen records.
- RANDOM_DISTRIBUTED - Static variable in class org.apache.calcite.rel.RelDistributions
-
The singleton random distribution.
- RandomFunction - Class in org.apache.calcite.runtime
-
Function object for
RAND
andRAND_INTEGER
, with and without seed. - RandomFunction() - Constructor for class org.apache.calcite.runtime.RandomFunction
-
Creates a RandomFunction.
- randSeed(int) - Method in class org.apache.calcite.runtime.RandomFunction
-
Implements the
RAND(seed)
SQL function. - range(int) - Static method in class org.apache.calcite.util.BitSets
-
Creates a BitSet with bits between 0 and
toIndex
set. - range(int) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Creates an ImmutableBitSet with bits between 0 and
toIndex
set. - range(int) - Static method in class org.apache.calcite.util.Util
- range(int, int) - Static method in class org.apache.calcite.util.BitSets
-
Creates a bitset with bits from
fromIndex
(inclusive) to specifiedtoIndex
(exclusive) set totrue
. - range(int, int) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Creates an ImmutableBitSet with bits from
fromIndex
(inclusive) to specifiedtoIndex
(exclusive) set totrue
. - range(int, int) - Static method in class org.apache.calcite.util.ImmutableIntList
-
Returns a list that contains the values lower to upper - 1.
- range(int, int) - Static method in class org.apache.calcite.util.Util
- range(String, boolean) - Method in class org.apache.calcite.util.NameMap
-
Returns a map containing all the entries in the map that match the given name.
- range(String, boolean) - Method in class org.apache.calcite.util.NameMultimap
-
Returns a map containing all the entries in this multimap that match the given name.
- range(String, boolean) - Method in class org.apache.calcite.util.NameSet
-
Returns an iterable over all the entries in the set that match the given name.
- range(Collection<? extends Number>) - Static method in class org.apache.calcite.rel.RelDistributions
-
Creates a range distribution.
- RANGE_DISTRIBUTED - Enum constant in enum org.apache.calcite.rel.RelDistribution.Type
-
There are multiple instances of the stream, and each instance contains records whose keys fall into a particular range.
- rangeBetween(RexWindowBound, RexWindowBound) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets a RANGE window with lower and upper bounds, equivalent to SQL
RANGE BETWEEN lower ROW AND upper
. - RangeComputeHints() - Constructor for class org.apache.calcite.runtime.SpaceFillingCurve2D.RangeComputeHints
- rangeFrom(RexWindowBound) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets a RANGE window with a lower bound, equivalent to SQL
RANGE BETWEEN lower AND CURRENT ROW
. - rangeFromJson(List<String>) - Static method in class org.apache.calcite.rel.externalize.RelJson
-
Creates a
Range
from a JSON object. - rangeSet - Variable in class org.apache.calcite.util.Sarg
- rangeSetAll() - Static method in class org.apache.calcite.util.RangeSets
-
Returns the unrestricted range set.
- rangeSetFromJson(List<List<String>>) - Static method in class org.apache.calcite.rel.externalize.RelJson
-
Converts a JSON list to a
RangeSet
. - RangeSets - Class in org.apache.calcite.util
-
Utilities for Guava
RangeSet
. - RangeSets.Consumer<V> - Interface in org.apache.calcite.util
-
Consumer of
Range
values. - RangeSets.Handler<V,
R> - Interface in org.apache.calcite.util -
Deconstructor for
Range
values. - rangeTo(RexWindowBound) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets a RANGE window with an upper bound, equivalent to SQL
RANGE BETWEEN CURRENT ROW AND upper
. - rangeUnbounded() - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets an unbounded RANGE window, equivalent to SQL
RANGE BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING
. - RANK - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
RANK
window function. - RANK - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
RANK
window function. - RANK - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy for the
NTILE
,RANK
,DENSE_RANK
, andROW_NUMBER
aggregate functions. - rankWithFrame() - Method in interface org.apache.calcite.runtime.CalciteResource
- RAW - Enum constant in enum org.apache.calcite.adapter.redis.RedisDataFormat
-
Treat redis key and value as a string format.
- RAW - Enum constant in enum org.apache.calcite.chinook.ConnectionFactory.DatabaseWrapper
- RawChinookMetaFactory() - Constructor for class org.apache.calcite.chinook.ChinookAvaticaServer.RawChinookMetaFactory
- RawEnumerable<T> - Interface in org.apache.calcite.linq4j
-
Exposes the enumerator, which supports a simple iteration over a collection, without the extension methods.
- RawQueryable<T> - Interface in org.apache.calcite.linq4j
-
Core methods that define a
Queryable
. - RDD_FLAT_MAP - Enum constant in enum org.apache.calcite.adapter.spark.SparkMethod
- reachable(Collection<V>, DirectedGraph<V, E>, V) - Static method in class org.apache.calcite.util.graph.DepthFirstIterator
-
Populates a collection with the nodes reachable from a given node.
- reachable(Set<V>, DirectedGraph<V, E>, V) - Static method in class org.apache.calcite.util.graph.BreadthFirstIterator
-
Populates a set with the nodes reachable from a given node.
- read() - Method in class org.apache.calcite.adapter.redis.RedisDataProcess
- read(String) - Method in class org.apache.calcite.rel.externalize.RelJsonReader
- READ_ACCESS - Enum constant in enum org.apache.calcite.plan.TableAccessMap.Mode
-
Deprecated.Table is accessed for read only.
- READ_ONLY - Enum constant in enum org.apache.calcite.sql.babel.postgresql.SqlBegin.TransactionMode
- READ_ONLY - Static variable in class org.apache.calcite.sql.SqlAccessType
- READ_WRITE - Enum constant in enum org.apache.calcite.sql.babel.postgresql.SqlBegin.TransactionMode
- readAllAsString(Reader) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- reader() - Method in interface org.apache.calcite.util.Source
- reader(File) - Static method in class org.apache.calcite.util.Util
-
Creates a
BufferedReader
to read a given file using UTF-8 character set. - reader(InputStream) - Static method in class org.apache.calcite.util.Util
-
Creates a
BufferedReader
to a given input stream using UTF-8 character set. - readExpression(RelOptCluster, RelJson.InputTranslator, Map<String, Object>) - Static method in class org.apache.calcite.rel.externalize.RelJson
-
Deprecated.
- readRex(RelOptCluster, String) - Static method in class org.apache.calcite.rel.externalize.RelJsonReader
-
Converts a JSON string (such as that produced by
RelJson.toJson(RexNode)
) into a Calcite expression. - readType - Variable in class org.apache.calcite.rel.core.Spool
-
How the spool consumes elements from its input.
- readType(RelDataTypeFactory, String) - Static method in class org.apache.calcite.rel.externalize.RelJsonReader
-
Converts a JSON string (such as that produced by
RelJson.toJson(Object)
) into a Calcite type. - READWRITE_ACCESS - Enum constant in enum org.apache.calcite.plan.TableAccessMap.Mode
-
Deprecated.Table is accessed for both read and write.
- REAL - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- realOrdinal(RelOptTable, int) - Static method in class org.apache.calcite.prepare.RelOptTableImpl
-
Converts the ordinal of a field into the ordinal of a stored field.
- realRowType(RelOptTable) - Static method in class org.apache.calcite.prepare.RelOptTableImpl
-
Returns the row type of a table after any
ColumnStrategy.VIRTUAL
columns have been removed. - rebuild() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Creates a Builder whose initial contents are the same as this ImmutableBitSet.
- receive() - Method in interface org.apache.calcite.interpreter.Source
-
Reads a row.
- recomputeDigest() - Method in class org.apache.calcite.rel.AbstractRelNode
- recomputeDigest() - Method in interface org.apache.calcite.rel.RelNode
-
Recomputes the digest.
- record(long) - Method in class org.apache.calcite.util.Benchmark.Statistician
- record(Type, List<Expression>) - Method in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
- record(List<Expression>) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Generates an expression that creates a record for a row, initializing its fields with the given expressions.
- record(List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- RECORD_COLLECTION - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Checker that returns whether a value is a multiset of records or an array of records.
- RECORD_TO_SCALAR - Static variable in class org.apache.calcite.sql.type.OperandTypes
- RECORD_TO_SCALAR - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns the field type of a structured type which has only one field.
- RecordEnumeratorCursor<E> - Class in org.apache.calcite.runtime
-
Implementation of
Cursor
on top of anEnumerator
that returns a record for each row. - RecordEnumeratorCursor(Enumerator<E>, Class<E>) - Constructor for class org.apache.calcite.runtime.RecordEnumeratorCursor
-
Creates a RecordEnumeratorCursor.
- recursive - Variable in class org.apache.calcite.sql.SqlWithItem
- recursiveWithMustHaveTwoChildUnionSetOp() - Method in interface org.apache.calcite.runtime.CalciteResource
- recursiveWithMustHaveUnionSetOp() - Method in interface org.apache.calcite.runtime.CalciteResource
- RedisConfig - Class in org.apache.calcite.adapter.redis
-
Set the redis config.
- RedisConfig(String, int, int, String) - Constructor for class org.apache.calcite.adapter.redis.RedisConfig
- RedisDataFormat - Enum in org.apache.calcite.adapter.redis
-
Define the data processing type of redis.
- RedisDataProcess - Class in org.apache.calcite.adapter.redis
-
The class with RedisDataProcess.
- RedisDataProcess(Jedis, RedisTableFieldInfo) - Constructor for class org.apache.calcite.adapter.redis.RedisDataProcess
- RedisDataType - Enum in org.apache.calcite.adapter.redis
-
All available data type for Redis.
- RedisJedisManager - Class in org.apache.calcite.adapter.redis
-
Manages connections to the Redis nodes.
- RedisJedisManager(String, int, int, String) - Constructor for class org.apache.calcite.adapter.redis.RedisJedisManager
- RedisSchemaFactory - Class in org.apache.calcite.adapter.redis
-
Factory that creates a
RedisSchema
. - RedisSchemaFactory() - Constructor for class org.apache.calcite.adapter.redis.RedisSchemaFactory
- RedisTable - Class in org.apache.calcite.adapter.redis
-
Table mapped onto a redis table.
- RedisTable(RedisSchema, String, RelProtoDataType, Map<String, Object>, String, RedisConfig) - Constructor for class org.apache.calcite.adapter.redis.RedisTable
- RedisTableFactory - Class in org.apache.calcite.adapter.redis
-
Implementation of
TableFactory
for Redis. - RedisTableFieldInfo - Class in org.apache.calcite.adapter.redis
-
get the redis table's field info.
- RedisTableFieldInfo() - Constructor for class org.apache.calcite.adapter.redis.RedisTableFieldInfo
- REDSHIFT - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
A collection of operators that are in Redshift but not in standard SQL or PostgreSQL.
- REDSHIFT - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- RedshiftSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Redshift database. - RedshiftSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.RedshiftSqlDialect
-
Creates a RedshiftSqlDialect.
- reduce(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Reduces this node to a simpler expression.
- reduce(RexBuilder, List<RexNode>, List<RexNode>) - Method in class org.apache.calcite.rex.RexExecutable
- reduce(RexBuilder, List<RexNode>, List<RexNode>) - Method in interface org.apache.calcite.rex.RexExecutor
-
Reduces expressions, and writes their results into
reducedValues
. - reduce(RexBuilder, List<RexNode>, List<RexNode>) - Method in class org.apache.calcite.rex.RexExecutorImpl
-
Do constant reduction using generated code.
- reduceAndCheck(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Reduces this node to a simpler expression.
- ReduceDecimalsRule - Class in org.apache.calcite.rel.rules
-
Rule that reduces decimal operations (such as casts or arithmetic) into operations involving more primitive types (such as longs and doubles).
- ReduceDecimalsRule(ReduceDecimalsRule.Config) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule
-
Creates a ReduceDecimalsRule.
- ReduceDecimalsRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule
-
Deprecated.
- ReduceDecimalsRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ReduceDecimalsRule.DecimalShuttle - Class in org.apache.calcite.rel.rules
-
A shuttle which converts decimal expressions to expressions based on longs.
- ReduceDecimalsRule.RexExpander - Class in org.apache.calcite.rel.rules
-
Rewrites a decimal expression for a specific set of SqlOperator's.
- reduceExpr(int, SqlSpecialOperator.TokenSequence) - Method in class org.apache.calcite.sql.fun.SqlBetweenOperator
- reduceExpr(int, SqlSpecialOperator.TokenSequence) - Method in class org.apache.calcite.sql.fun.SqlDotOperator
- reduceExpr(int, SqlSpecialOperator.TokenSequence) - Method in class org.apache.calcite.sql.fun.SqlItemOperator
- reduceExpr(int, SqlSpecialOperator.TokenSequence) - Method in class org.apache.calcite.sql.fun.SqlLikeOperator
- reduceExpr(int, SqlSpecialOperator.TokenSequence) - Method in class org.apache.calcite.sql.SqlSpecialOperator
-
Reduces a list of operators and arguments according to the rules of precedence and associativity.
- reduceExpressions(RelNode, List<RexNode>, RelOptPredicateList) - Static method in class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Reduces a list of expressions.
- reduceExpressions(RelNode, List<RexNode>, RelOptPredicateList, boolean) - Static method in class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Deprecated.
- reduceExpressions(RelNode, List<RexNode>, RelOptPredicateList, boolean, boolean, boolean) - Static method in class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Reduces a list of expressions.
- reduceExpressionsInternal(RelNode, RexSimplify, RexUnknownAs, List<RexNode>, RelOptPredicateList, boolean) - Static method in class org.apache.calcite.rel.rules.ReduceExpressionsRule
- ReduceExpressionsRule<C extends ReduceExpressionsRule.Config> - Class in org.apache.calcite.rel.rules
-
Collection of planner rules that apply various simplifying transformations on RexNode trees.
- ReduceExpressionsRule(C) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Creates a ReduceExpressionsRule.
- ReduceExpressionsRule.CalcReduceExpressionsRule - Class in org.apache.calcite.rel.rules
-
Rule that reduces constants inside a
Calc
. - ReduceExpressionsRule.CalcReduceExpressionsRule.CalcReduceExpressionsRuleConfig - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ReduceExpressionsRule.CaseShuttle - Class in org.apache.calcite.rel.rules
-
Shuttle that pushes predicates into a CASE.
- ReduceExpressionsRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ReduceExpressionsRule.FilterReduceExpressionsRule - Class in org.apache.calcite.rel.rules
-
Rule that reduces constants inside a
Filter
. - ReduceExpressionsRule.FilterReduceExpressionsRule.FilterReduceExpressionsRuleConfig - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ReduceExpressionsRule.JoinReduceExpressionsRule - Class in org.apache.calcite.rel.rules
-
Rule that reduces constants inside a
Join
. - ReduceExpressionsRule.JoinReduceExpressionsRule.JoinReduceExpressionsRuleConfig - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ReduceExpressionsRule.ProjectReduceExpressionsRule - Class in org.apache.calcite.rel.rules
-
Rule that reduces constants inside a
Project
. - ReduceExpressionsRule.ProjectReduceExpressionsRule.ProjectReduceExpressionsRuleConfig - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ReduceExpressionsRule.ReducibleExprLocator - Class in org.apache.calcite.rel.rules
-
Helper class used to locate expressions that either can be reduced to literals or contain redundant casts.
- ReduceExpressionsRule.RexReplacer - Class in org.apache.calcite.rel.rules
-
Replaces expressions with their reductions.
- ReduceExpressionsRule.WindowReduceExpressionsRule - Class in org.apache.calcite.rel.rules
-
Rule that reduces constants inside a
Window
. - ReduceExpressionsRule.WindowReduceExpressionsRule.WindowReduceExpressionsRuleConfig - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- reduceExtensions(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Reduces the expression to a known node type (that is not an Extension node) or just returns the expression if it is already a known type.
- ReduceResult(int, int, SqlNode) - Constructor for class org.apache.calcite.sql.SqlSpecialOperator.ReduceResult
- ref(int, RelDataType) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- REF_CURSOR - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- referenceEqual(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a reference equality comparison.
- referenceNotEqual(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a reference inequality comparison.
- referentialConstraints - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- refFile - Variable in class org.apache.calcite.test.DiffTestCase
-
Name of current .ref file.
- ReflectedPseudoField - Class in org.apache.calcite.linq4j.tree
-
Represents a PseudoField that is implemented via a Java reflection
Field
. - ReflectedPseudoField(Field) - Constructor for class org.apache.calcite.linq4j.tree.ReflectedPseudoField
- REFLECTIVE_FOODMART - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- REFLECTIVE_SCHEMA_GET_TARGET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ReflectiveCallNotNullImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
NotNullImplementor
that calls a givenMethod
. - ReflectiveCallNotNullImplementor(Method) - Constructor for class org.apache.calcite.adapter.enumerable.ReflectiveCallNotNullImplementor
-
Constructor of
ReflectiveCallNotNullImplementor
. - ReflectiveConvertletTable - Class in org.apache.calcite.sql2rel
-
Implementation of
SqlRexConvertletTable
which uses reflection to call any method of the formpublic RexNode convertXxx(ConvertletContext, SqlNode)
orpublic RexNode convertXxx(ConvertletContext, SqlOperator, SqlCall)
. - ReflectiveConvertletTable() - Constructor for class org.apache.calcite.sql2rel.ReflectiveConvertletTable
- ReflectiveFunctionBase - Class in org.apache.calcite.schema.impl
-
Implementation of a function that is based on a method.
- ReflectiveFunctionBase(Method) - Constructor for class org.apache.calcite.schema.impl.ReflectiveFunctionBase
-
Creates a ReflectiveFunctionBase.
- ReflectiveFunctionBase.ParameterListBuilder - Class in org.apache.calcite.schema.impl
-
Helps build lists of
FunctionParameter
. - ReflectiveRelMetadataProvider - Class in org.apache.calcite.rel.metadata
-
Implementation of the
RelMetadataProvider
interface that dispatches metadata methods to methods on a given object via reflection. - ReflectiveRelMetadataProvider(ConcurrentMap<Class<RelNode>, UnboundMetadata>, Class<? extends Metadata>, Multimap<Method, MetadataHandler<?>>, Class<? extends MetadataHandler<?>>) - Constructor for class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
-
Creates a ReflectiveRelMetadataProvider.
- ReflectiveSchema - Class in org.apache.calcite.adapter.java
-
Implementation of
Schema
that exposes the public fields and methods in a Java object. - ReflectiveSchema(Object) - Constructor for class org.apache.calcite.adapter.java.ReflectiveSchema
-
Creates a ReflectiveSchema.
- ReflectiveSchema.Factory - Class in org.apache.calcite.adapter.java
-
Factory that creates a schema by instantiating an object and looking at its public fields.
- ReflectiveSchemaWithoutRowCount - Class in org.apache.calcite.test
-
A ReflectiveSchema that does not return row count statistics.
- ReflectiveSchemaWithoutRowCount(Object) - Constructor for class org.apache.calcite.test.ReflectiveSchemaWithoutRowCount
-
Creates a ReflectiveSchema.
- reflectiveSource(Method, MetadataHandler) - Static method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
-
Deprecated.
- reflectiveSource(MetadataHandler<? extends M>, Class<? extends MetadataHandler<M>>) - Static method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
- reflectiveSource(MetadataHandler, Method...) - Static method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
-
Deprecated.
- ReflectiveSqlOperatorTable - Class in org.apache.calcite.sql.util
-
ReflectiveSqlOperatorTable implements the
SqlOperatorTable
interface by reflecting the public fields of a subclass. - ReflectiveSqlOperatorTable() - Constructor for class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
- ReflectiveVisitDispatcher<R extends ReflectiveVisitor,
E> - Interface in org.apache.calcite.util -
Interface for looking up methods relating to reflective visitation.
- ReflectiveVisitor - Interface in org.apache.calcite.util
-
Object which can be a target for a reflective visitation (see
ReflectUtil.invokeVisitor(ReflectiveVisitor, Object, Class, String)
. - ReflectUtil - Class in org.apache.calcite.util
-
Static utilities for Java reflection.
- ReflectUtil() - Constructor for class org.apache.calcite.util.ReflectUtil
- ReflectUtil.MethodDispatcher<T> - Interface in org.apache.calcite.util
-
Can invoke a method on an object of type E with return type T.
- refWindowWithFrame() - Method in interface org.apache.calcite.runtime.CalciteResource
- RegexFunction() - Constructor for class org.apache.calcite.runtime.SqlFunctions.RegexFunction
- REGEXP - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP(value, regexp)" function, equivalent to
SqlLibraryOperators.RLIKE
. - REGEXP_CONTAINS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_CONTAINS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_CONTAINS(value, regexp)" function.
- REGEXP_EXTRACT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_EXTRACT(value, regexp[, position[, occurrence]])" function.
- REGEXP_EXTRACT_ALL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_EXTRACT_ALL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_EXTRACT_ALL(value, regexp)" function.
- REGEXP_EXTRACT2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_EXTRACT3 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_EXTRACT4 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_INSTR - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_INSTR(value, regexp [, position[, occurrence, [occurrence_position]]])" function.
- REGEXP_INSTR2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_INSTR3 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_INSTR4 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_INSTR5 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_LIKE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_LIKE(value, regexp)" function, equivalent to
SqlLibraryOperators.RLIKE
. - REGEXP_LIKE3 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_REPLACE_2 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_REPLACE(value, regexp)" function.
- REGEXP_REPLACE_3 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_REPLACE(value, regexp, rep)" function.
- REGEXP_REPLACE_4 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_REPLACE(value, regexp, rep, pos)" function.
- REGEXP_REPLACE_5 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_REPLACE(value, regexp, rep, pos, [ occurrence | matchType ])" function.
- REGEXP_REPLACE_5_ORACLE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_REPLACE(value, regexp, rep, pos, matchType)" function.
- REGEXP_REPLACE_6 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_REPLACE(value, regexp, rep, pos, occurrence, matchType)" function.
- REGEXP_REPLACE_BIG_QUERY_3 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_REPLACE_BIG_QUERY_3 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_REPLACE(value, regexp, rep)" function.
- REGEXP_REPLACE_PG_3 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_REPLACE_PG_3 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_REPLACE(value, regexp, rep)" function.
- REGEXP_REPLACE_PG_4 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_REPLACE_PG_4 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_REPLACE(value, regexp, rep, flags)" function.
- REGEXP_REPLACE2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_REPLACE3 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_REPLACE4 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_REPLACE5_MATCHTYPE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_REPLACE5_OCCURRENCE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_REPLACE6 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REGEXP_SUBSTR - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REGEXP_SUBSTR(value, regexp[, position[, occurrence]])" function.
- regexpContains(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_CONTAINS(value, regexp)
function. - regexpExtract(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_EXTRACT(value, regexp)
function. - regexpExtract(String, String, int) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_EXTRACT(value, regexp, position)
function. - regexpExtract(String, String, int, int) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_EXTRACT(value, regexp, position, occurrence)
function. - regexpExtractAll(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_EXTRACT_ALL(value, regexp)
function. - regexpInstr(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_INSTR(value, regexp)
function. - regexpInstr(String, String, int) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_INSTR(value, regexp, position)
function. - regexpInstr(String, String, int, int) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_INSTR(value, regexp, position, occurrence)
function. - regexpInstr(String, String, int, int, int) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_INSTR(value, regexp, position, occurrence, occurrencePosition)
function. - regexpLike(String, String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_LIKE(value, regexp, flags)
function. - regexpReplace(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_REPLACE
function with 2 arguments. - regexpReplace(String, String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_REPLACE
function with 3 arguments. - regexpReplace(String, String, String, int) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_REPLACE
function with 4 arguments. - regexpReplace(String, String, String, int, int) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_REPLACE
function with 5 arguments. - regexpReplace(String, String, String, int, int, String) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_REPLACE
function with 6 arguments. - regexpReplace(String, String, String, int, String) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_REPLACE
function with 5 arguments. - regexpReplace(String, Pattern, String, int, int) - Static method in class org.apache.calcite.util.Unsafe
-
Helper for the SQL
REGEXP_REPLACE
function. - regexpReplaceNonDollarIndexed(String, String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_REPLACE
function with 3 arguments with\\
based indexing for capturing groups. - regexpReplacePg(String, String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_REPLACE
function for PostgreSQL with 3 arguments. - regexpReplacePg(String, String, String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
REGEXP_REPLACE
function for PostgreSQL with 4 arguments. - REGIONS - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeSchemaFactory
- REGIONS - Static variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchemaFactory
- register(E) - Method in interface org.apache.calcite.sql.SqlSplittableAggFunction.Registry
- register(Iterable<Class<? extends RelNode>>) - Method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
-
Deprecated.
- register(RelOptPlanner) - Method in class org.apache.calcite.adapter.cassandra.CassandraTableScan
- register(RelOptPlanner) - Method in class org.apache.calcite.adapter.csv.CsvTableScan
- register(RelOptPlanner) - Method in class org.apache.calcite.adapter.druid.DruidQuery
- register(RelOptPlanner) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTableScan
- register(RelOptPlanner) - Method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- register(RelOptPlanner) - Method in class org.apache.calcite.adapter.file.CsvTableScan
- register(RelOptPlanner) - Method in class org.apache.calcite.adapter.geode.rel.GeodeTableScan
- register(RelOptPlanner) - Method in class org.apache.calcite.adapter.innodb.InnodbTableScan
- register(RelOptPlanner) - Method in class org.apache.calcite.adapter.jdbc.JdbcConvention
- register(RelOptPlanner) - Method in class org.apache.calcite.adapter.mongodb.MongoTableScan
- register(RelOptPlanner) - Method in class org.apache.calcite.adapter.pig.PigTableScan
- register(RelOptPlanner) - Method in class org.apache.calcite.adapter.splunk.SplunkTableScan
- register(RelOptPlanner) - Method in enum org.apache.calcite.interpreter.BindableConvention
- register(RelOptPlanner) - Method in enum org.apache.calcite.interpreter.InterpretableConvention
- register(RelOptPlanner) - Method in class org.apache.calcite.plan.Convention.Impl
- register(RelOptPlanner) - Method in interface org.apache.calcite.plan.RelTrait
-
Registers a trait instance with the planner.
- register(RelOptPlanner) - Method in class org.apache.calcite.rel.AbstractRelNode
- register(RelOptPlanner) - Method in class org.apache.calcite.rel.RelCollationImpl
- register(RelOptPlanner) - Method in interface org.apache.calcite.rel.RelNode
-
Registers any special rules specific to this kind of relational expression.
- register(RelNode, RelNode) - Method in class org.apache.calcite.plan.hep.HepPlanner
- register(RelNode, RelNode) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Registers a relational expression in the expression bank.
- register(RelNode, RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- register(RelNode, RelNode) - Method in class org.apache.calcite.test.MockRelOptPlanner
- register(RelNode, JoinRelType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- register(RelNode, JoinRelType, List<RexNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Registers a relational expression.
- register(SqlOperator) - Method in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
-
Deprecated.This table is designed to be initialized from the fields of a class, and adding operators is not efficient
- registerAbstractRelationalRules() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- registerAbstractRelationalRules(RelOptPlanner) - Static method in class org.apache.calcite.plan.RelOptUtil
- registerAbstractRels(RelOptPlanner) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- registerAbstractRules(RelOptPlanner) - Static method in class org.apache.calcite.plan.RelOptUtil
- registerClass(RelNode) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- registerClass(RelNode) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Registers a class of RelNode.
- registerConverterRule(RelOptPlanner, ConverterRule) - Method in class org.apache.calcite.plan.ConventionTraitDef
- registerConverterRule(RelOptPlanner, ConverterRule) - Method in class org.apache.calcite.plan.RelTraitDef
-
Provides notification of the registration of a particular
ConverterRule
with aRelOptPlanner
. - registerCorrelVariable(String, ParameterExpression, BlockBuilder, PhysType) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- registerDefaultRules(RelOptPlanner, boolean, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
- registerEquivOp(SqlOperator) - Method in class org.apache.calcite.rex.RexSqlStandardConvertletTable
-
Creates and registers a convertlet for an operator in which the SQL and Rex representations are structurally equivalent.
- registerInput(RexNode) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Registers an expression in the list of common sub-expressions, and returns a reference to that expression.
- registerMaterializations() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- registerMetadataProviders(List<RelMetadataProvider>) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Deprecated.
- registerMetadataProviders(List<RelMetadataProvider>) - Method in class org.apache.calcite.plan.hep.HepPlanner
-
Deprecated.
- registerMetadataProviders(List<RelMetadataProvider>) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Deprecated.
- registerMetadataProviders(List<RelMetadataProvider>) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Deprecated.
- registerNamespace(SqlValidatorScope, String, SqlValidatorNamespace, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Registers a new namespace, and adds it as a child of its parent scope.
- registerOp(SqlOperator, RexSqlConvertlet) - Method in class org.apache.calcite.rex.RexSqlReflectiveConvertletTable
-
Registers a convertlet for a given operator instance.
- registerOp(SqlOperator, SqlRexConvertlet) - Method in class org.apache.calcite.sql2rel.ReflectiveConvertletTable
-
Registers a convertlet for a given operator instance.
- registerOutput(RexNode) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Converts an expression expressed in terms of the outputs of this program into an expression expressed in terms of the inputs, registers it in the list of common sub-expressions, and returns a reference to that expression.
- registerQuery(SqlValidatorScope, SqlValidatorScope, SqlNode, SqlNode, String, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Registers a query in a parent scope.
- registerRolledUpColumn(String) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- registerRules(CalcitePrepare.SparkHandler.RuleSetBuilder) - Method in class org.apache.calcite.adapter.spark.SparkHandlerImpl
- registerRules(CalcitePrepare.SparkHandler.RuleSetBuilder) - Method in interface org.apache.calcite.jdbc.CalcitePrepare.SparkHandler
- registerRules(RelOptPlanner) - Method in interface org.apache.calcite.plan.RelOptSchema
-
Registers all the rules supported by this schema.
- registerRules(RelOptPlanner) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- registerSchema(RelOptSchema) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- registerSchema(RelOptSchema) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Tells this planner that a schema exists.
- registerSchema(RelOptSchema) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- registerSchema(MockCatalogReader.MockSchema) - Method in class org.apache.calcite.test.catalog.MockCatalogReader
- registerTable(MockCatalogReader.MockTable) - Method in class org.apache.calcite.test.catalog.MockCatalogReader
- registerTablesWithRollUp(MockCatalogReader.MockSchema, Fixture) - Method in class org.apache.calcite.test.catalog.MockCatalogReader
- registerType(List<String>, RelProtoDataType) - Method in class org.apache.calcite.test.catalog.MockCatalogReader
- REGR_COUNT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
REGR_COUNT
aggregate function. - REGR_COUNT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
REGR_COUNT
aggregate function. - REGR_SXX - Enum constant in enum org.apache.calcite.sql.fun.SqlCovarAggFunction.Subtype
-
Deprecated.
- REGR_SXX - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
REGR_SXX
aggregate function. - REGR_SXX - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
REGR_SXX
aggregate function. - REGR_SYY - Enum constant in enum org.apache.calcite.sql.fun.SqlCovarAggFunction.Subtype
-
Deprecated.
- REGR_SYY - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
REGR_SYY
aggregate function. - REGR_SYY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
REGR_SYY
aggregate function. - REGULAR - Enum constant in enum org.apache.calcite.test.CalciteAssert.Config
-
Configuration that creates a connection with two in-memory data sets:
HrSchema
andFoodmartSchema
. - REGULAR_PLUS_METADATA - Enum constant in enum org.apache.calcite.test.CalciteAssert.Config
-
Configuration that includes the metadata schema.
- REINTERPRET - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The internal REINTERPRET operator (meaning a reinterpret cast).
- REINTERPRET - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
An
REINTERPRET
operator is internal to the planner. - rel - Variable in class org.apache.calcite.interpreter.UncollectNode
- rel - Variable in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- rel - Variable in class org.apache.calcite.jdbc.CalcitePrepare.Query
- rel - Variable in class org.apache.calcite.rel.mutable.MutableScan
- rel - Variable in class org.apache.calcite.rel.RelRoot
- rel - Variable in class org.apache.calcite.rex.RexSubQuery
- rel() - Method in interface org.apache.calcite.rel.metadata.Metadata
-
Returns the relational expression that this metadata is about.
- rel(int) - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Retrieves the
ordinal
th matched relational expression. - rel(SqlNode) - Method in class org.apache.calcite.prepare.PlannerImpl
- rel(SqlNode) - Method in interface org.apache.calcite.tools.Planner
-
Converts a SQL parse tree into a tree of relational expressions.
- REL_BUILDER_SIMPLIFY - Enum constant in enum org.apache.calcite.runtime.Hook
-
Returns a boolean value, whether RelBuilder should simplify expressions.
- RELATION - Enum constant in enum org.apache.calcite.sql.validate.SqlModality
- relative(Source) - Method in interface org.apache.calcite.util.Source
-
Returns a relative source, if this source is a child of a given base.
- relBuilder - Variable in class org.apache.calcite.plan.SubstitutionVisitor
-
Factory for a builder for relational expressions.
- relBuilder - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter
- relBuilder - Variable in class org.apache.calcite.sql2rel.RelDecorrelator
- RelBuilder - Class in org.apache.calcite.tools
-
Builder for relational expressions.
- RelBuilder(Context, RelOptCluster, RelOptSchema) - Constructor for class org.apache.calcite.tools.RelBuilder
- RelBuilder.AggCall - Interface in org.apache.calcite.tools
-
Information necessary to create a call to an aggregate function.
- RelBuilder.Config - Interface in org.apache.calcite.tools
-
Configuration of RelBuilder.
- RelBuilder.GroupKey - Interface in org.apache.calcite.tools
-
Information necessary to create the GROUP BY clause of an Aggregate.
- RelBuilder.OverCall - Interface in org.apache.calcite.tools
-
Call to a windowed aggregate function.
- relBuilderFactory - Variable in class org.apache.calcite.plan.RelOptRule
-
Factory for a builder for relational expressions.
- relBuilderFactory() - Method in interface org.apache.calcite.plan.RelRule.Config
-
The factory that is used to create a
RelBuilder
during rule invocations. - relBuilderFactory() - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- RelBuilderFactory - Interface in org.apache.calcite.tools
-
A partially-created RelBuilder.
- relChosen(RelOptListener.RelChosenEvent) - Method in class org.apache.calcite.plan.MulticastRelOptListener
- relChosen(RelOptListener.RelChosenEvent) - Method in interface org.apache.calcite.plan.RelOptListener
-
Notifies this listener that a relational expression has been chosen as part of the final implementation of the query plan.
- relChosen(RelOptListener.RelChosenEvent) - Method in class org.apache.calcite.plan.RuleEventLogger
- relChosen(RelOptListener.RelChosenEvent) - Method in class org.apache.calcite.plan.visualizer.RuleMatchVisualizer
- RelChosenEvent(Object, RelNode) - Constructor for class org.apache.calcite.plan.RelOptListener.RelChosenEvent
- relClass - Variable in exception class org.apache.calcite.rel.metadata.MetadataHandlerProvider.NoHandler
- RelCollation - Interface in org.apache.calcite.rel
-
Description of the physical ordering of a relational expression.
- RelCollationImpl - Class in org.apache.calcite.rel
-
Simple implementation of
RelCollation
. - RelCollationImpl(ImmutableList<RelFieldCollation>) - Constructor for class org.apache.calcite.rel.RelCollationImpl
- RelCollations - Class in org.apache.calcite.rel
-
Utilities concerning
RelCollation
andRelFieldCollation
. - RelCollationTraitDef - Class in org.apache.calcite.rel
-
Definition of the ordering trait.
- RelColumnMapping - Class in org.apache.calcite.rel.metadata
-
Mapping from an input column of a
RelNode
to one of its output columns. - RelColumnMapping(int, int, int, boolean) - Constructor for class org.apache.calcite.rel.metadata.RelColumnMapping
- RelColumnOrigin - Class in org.apache.calcite.rel.metadata
-
RelColumnOrigin is a data structure describing one of the origins of an output column produced by a relational expression.
- RelColumnOrigin(RelOptTable, int, boolean) - Constructor for class org.apache.calcite.rel.metadata.RelColumnOrigin
- RelConversionException - Exception Class in org.apache.calcite.tools
-
An Exception thrown when attempting conversion to a set of
RelNode
s. - RelConversionException(String) - Constructor for exception class org.apache.calcite.tools.RelConversionException
-
Creates a RelConversionException with the specified detail message.
- RelConversionException(String, Throwable) - Constructor for exception class org.apache.calcite.tools.RelConversionException
-
Creates a RelConversionException with the specified detail message and cause.
- RelConversionException(Throwable) - Constructor for exception class org.apache.calcite.tools.RelConversionException
-
Creates a RelConversionException with the specified cause.
- RelCrossType - Class in org.apache.calcite.rel.type
-
Type of the cartesian product of two or more sets of records.
- RelCrossType(List<RelDataType>, List<RelDataTypeField>) - Constructor for class org.apache.calcite.rel.type.RelCrossType
-
Creates a cartesian product type.
- RelDataType - Interface in org.apache.calcite.rel.type
-
RelDataType represents the type of a scalar expression or entire row returned from a relational expression.
- RelDataTypeComparability - Enum in org.apache.calcite.rel.type
-
RelDataTypeComparability is an enumeration of the categories of comparison operators which types may support.
- RelDataTypeFactory - Interface in org.apache.calcite.rel.type
-
RelDataTypeFactory is a factory for datatype descriptors.
- RelDataTypeFactory.Builder - Class in org.apache.calcite.rel.type
-
Fluid API to build a list of fields.
- RelDataTypeFactory.FieldInfo - Interface in org.apache.calcite.rel.type
-
Deprecated.
- RelDataTypeFactory.FieldInfoBuilder - Class in org.apache.calcite.rel.type
-
Deprecated.
- RelDataTypeFactoryImpl - Class in org.apache.calcite.rel.type
-
Abstract base for implementations of
RelDataTypeFactory
. - RelDataTypeFactoryImpl(RelDataTypeSystem) - Constructor for class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
-
Creates a type factory.
- RelDataTypeFactoryImpl.JavaType - Class in org.apache.calcite.rel.type
-
Type which is based upon a Java class.
- RelDataTypeFamily - Interface in org.apache.calcite.rel.type
-
RelDataTypeFamily represents a family of related types.
- RelDataTypeField - Interface in org.apache.calcite.rel.type
-
RelDataTypeField represents the definition of a field in a structured
RelDataType
. - RelDataTypeField.ToFieldIndex - Class in org.apache.calcite.rel.type
-
Deprecated.Use
RelDataTypeField::getIndex
- RelDataTypeField.ToFieldName - Class in org.apache.calcite.rel.type
-
Deprecated.Use
RelDataTypeField::getName
- RelDataTypeFieldImpl - Class in org.apache.calcite.rel.type
-
Default implementation of
RelDataTypeField
. - RelDataTypeFieldImpl(String, int, RelDataType) - Constructor for class org.apache.calcite.rel.type.RelDataTypeFieldImpl
-
Creates a RelDataTypeFieldImpl.
- RelDataTypeImpl - Class in org.apache.calcite.rel.type
-
RelDataTypeImpl is an abstract base for implementations of
RelDataType
. - RelDataTypeImpl() - Constructor for class org.apache.calcite.rel.type.RelDataTypeImpl
-
Default constructor, to allow derived classes such as
BasicSqlType
to beSerializable
. - RelDataTypeImpl(List<? extends RelDataTypeField>) - Constructor for class org.apache.calcite.rel.type.RelDataTypeImpl
-
Creates a RelDataTypeImpl.
- RelDataTypePrecedenceList - Interface in org.apache.calcite.rel.type
-
RelDataTypePrecedenceList defines a type precedence list for a particular type.
- RelDataTypeSystem - Interface in org.apache.calcite.rel.type
-
Type system.
- RelDataTypeSystemImpl - Class in org.apache.calcite.rel.type
-
Default implementation of
RelDataTypeSystem
, providing parameters from the SQL standard. - RelDataTypeSystemImpl() - Constructor for class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- RelDecorrelator - Class in org.apache.calcite.sql2rel
-
RelDecorrelator replaces all correlated expressions (corExp) in a relational expression (RelNode) tree with non-correlated expressions that are produced from joining the RelNode that produces the corExp with the RelNode that references it.
- RelDecorrelator(RelDecorrelator.CorelMap, Context, RelBuilder) - Constructor for class org.apache.calcite.sql2rel.RelDecorrelator
- RelDecorrelator.AdjustProjectForCountAggregateRule - Class in org.apache.calcite.sql2rel
-
Planner rule that adjusts projects when counts are added.
- RelDecorrelator.AdjustProjectForCountAggregateRule.AdjustProjectForCountAggregateRuleConfig - Interface in org.apache.calcite.sql2rel
-
Rule configuration.
- RelDecorrelator.Config - Interface in org.apache.calcite.sql2rel
-
Base configuration for rules that are non-static in a RelDecorrelator.
- RelDecorrelator.CorelMap - Class in org.apache.calcite.sql2rel
- RelDecorrelator.CorelMapBuilder - Class in org.apache.calcite.sql2rel
-
Builds a
RelDecorrelator.CorelMap
. - RelDecorrelator.RemoveCorrelationForScalarAggregateRule - Class in org.apache.calcite.sql2rel
-
Planner rule that removes correlations for scalar aggregates.
- RelDecorrelator.RemoveCorrelationForScalarAggregateRule.RemoveCorrelationForScalarAggregateRuleConfig - Interface in org.apache.calcite.sql2rel
-
Rule configuration.
- RelDecorrelator.RemoveCorrelationForScalarProjectRule - Class in org.apache.calcite.sql2rel
-
Planner rule that removes correlations for scalar projects.
- RelDecorrelator.RemoveCorrelationForScalarProjectRule.RemoveCorrelationForScalarProjectRuleConfig - Interface in org.apache.calcite.sql2rel
-
Rule configuration.
- RelDecorrelator.RemoveSingleAggregateRule - Class in org.apache.calcite.sql2rel
-
Rule to remove an Aggregate with SINGLE_VALUE.
- RelDecorrelator.RemoveSingleAggregateRule.RemoveSingleAggregateRuleConfig - Interface in org.apache.calcite.sql2rel
-
Rule configuration.
- RelDigest - Interface in org.apache.calcite.plan
-
The digest is the exact representation of the corresponding
RelNode
, at anytime, anywhere. - relDiscarded(RelOptListener.RelDiscardedEvent) - Method in class org.apache.calcite.plan.MulticastRelOptListener
- relDiscarded(RelOptListener.RelDiscardedEvent) - Method in interface org.apache.calcite.plan.RelOptListener
-
Notifies this listener that a relational expression is no longer of interest to the planner.
- relDiscarded(RelOptListener.RelDiscardedEvent) - Method in class org.apache.calcite.plan.RuleEventLogger
- relDiscarded(RelOptListener.RelDiscardedEvent) - Method in class org.apache.calcite.plan.visualizer.RuleMatchVisualizer
- RelDiscardedEvent(Object, RelNode) - Constructor for class org.apache.calcite.plan.RelOptListener.RelDiscardedEvent
- RelDistribution - Interface in org.apache.calcite.rel
-
Description of the physical distribution of a relational expression.
- RelDistribution.Type - Enum in org.apache.calcite.rel
-
Type of distribution.
- RelDistributions - Class in org.apache.calcite.rel
-
Utilities concerning
RelDistribution
. - RelDistributionTraitDef - Class in org.apache.calcite.rel
-
Definition of the distribution trait.
- RelDotWriter - Class in org.apache.calcite.rel.externalize
-
Utility to dump a rel node plan in dot format.
- RelDotWriter(PrintWriter, SqlExplainLevel, boolean) - Constructor for class org.apache.calcite.rel.externalize.RelDotWriter
- RelDotWriter(PrintWriter, SqlExplainLevel, boolean, RelDotWriter.WriteOption) - Constructor for class org.apache.calcite.rel.externalize.RelDotWriter
- RelDotWriter.WriteOption - Interface in org.apache.calcite.rel.externalize
-
Options for displaying the rel node plan in dot format.
- RelEnumTypes - Class in org.apache.calcite.rel.externalize
-
Registry of
Enum
classes that can be serialized to JSON. - RelEquivalenceEvent(Object, RelNode, Object, boolean) - Constructor for class org.apache.calcite.plan.RelOptListener.RelEquivalenceEvent
- relEquivalenceFound(RelOptListener.RelEquivalenceEvent) - Method in class org.apache.calcite.plan.MulticastRelOptListener
- relEquivalenceFound(RelOptListener.RelEquivalenceEvent) - Method in interface org.apache.calcite.plan.RelOptListener
-
Notifies this listener that a relational expression has been registered with a particular equivalence class after an equivalence has been either detected or asserted.
- relEquivalenceFound(RelOptListener.RelEquivalenceEvent) - Method in class org.apache.calcite.plan.RuleEventLogger
- relEquivalenceFound(RelOptListener.RelEquivalenceEvent) - Method in class org.apache.calcite.plan.visualizer.RuleMatchVisualizer
- RelEvent(Object, RelNode) - Constructor for class org.apache.calcite.plan.RelOptListener.RelEvent
- RelFactories - Class in org.apache.calcite.rel.core
-
Contains factory interface and default implementation for creating various rel nodes.
- RelFactories.AggregateFactory - Interface in org.apache.calcite.rel.core
-
Can create a
LogicalAggregate
of the appropriate type for this rule's calling convention. - RelFactories.AsofJoinFactory - Interface in org.apache.calcite.rel.core
-
Creates ASOF join of the appropriate type for a rule's calling convention.
- RelFactories.CorrelateFactory - Interface in org.apache.calcite.rel.core
-
Can create a correlate of the appropriate type for a rule's calling convention.
- RelFactories.ExchangeFactory - Interface in org.apache.calcite.rel.core
-
Can create a
Exchange
of the appropriate type for a rule's calling convention. - RelFactories.FilterFactory - Interface in org.apache.calcite.rel.core
-
Can create a
Filter
of the appropriate type for this rule's calling convention. - RelFactories.JoinFactory - Interface in org.apache.calcite.rel.core
-
Can create a join of the appropriate type for a rule's calling convention.
- RelFactories.MatchFactory - Interface in org.apache.calcite.rel.core
-
Can create a
Match
of the appropriate type for a rule's calling convention. - RelFactories.ProjectFactory - Interface in org.apache.calcite.rel.core
-
Can create a
LogicalProject
of the appropriate type for this rule's calling convention. - RelFactories.RepeatUnionFactory - Interface in org.apache.calcite.rel.core
-
Can create a
RepeatUnion
of the appropriate type for a rule's calling convention. - RelFactories.SampleFactory - Interface in org.apache.calcite.rel.core
-
Can create a
Sample
of the appropriate type for a rule's calling convention. - RelFactories.SemiJoinFactory - Interface in org.apache.calcite.rel.core
-
Deprecated.Use
RelFactories.JoinFactory
instead. - RelFactories.SetOpFactory - Interface in org.apache.calcite.rel.core
-
Can create a
SetOp
for a particular kind of set operation (UNION, EXCEPT, INTERSECT) and of the appropriate type for this rule's calling convention. - RelFactories.SnapshotFactory - Interface in org.apache.calcite.rel.core
-
Can create a
Snapshot
of the appropriate type for a rule's calling convention. - RelFactories.SnapshotFactoryImpl - Class in org.apache.calcite.rel.core
-
Implementation of
RelFactories.SnapshotFactory
that returns a vanillaLogicalSnapshot
. - RelFactories.SortExchangeFactory - Interface in org.apache.calcite.rel.core
-
Can create a
SortExchange
of the appropriate type for a rule's calling convention. - RelFactories.SortFactory - Interface in org.apache.calcite.rel.core
-
Can create a
Sort
of the appropriate type for this rule's calling convention. - RelFactories.SpoolFactory - Interface in org.apache.calcite.rel.core
-
Can create a
Spool
of the appropriate type for a rule's calling convention. - RelFactories.Struct - Class in org.apache.calcite.rel.core
-
Immutable record that contains an instance of each factory.
- RelFactories.TableFunctionScanFactory - Interface in org.apache.calcite.rel.core
-
Can create a
TableFunctionScan
of the appropriate type for a rule's calling convention. - RelFactories.TableScanFactory - Interface in org.apache.calcite.rel.core
-
Can create a
TableScan
of the appropriate type for a rule's calling convention. - RelFactories.ValuesFactory - Interface in org.apache.calcite.rel.core
-
Can create a
Values
of the appropriate type for a rule's calling convention. - RelFieldCollation - Class in org.apache.calcite.rel
-
Definition of the ordering of one field of a
RelNode
whose output is to be sorted. - RelFieldCollation(int) - Constructor for class org.apache.calcite.rel.RelFieldCollation
-
Creates an ascending field collation.
- RelFieldCollation(int, RelFieldCollation.Direction) - Constructor for class org.apache.calcite.rel.RelFieldCollation
-
Creates a field collation with unspecified null direction.
- RelFieldCollation(int, RelFieldCollation.Direction, RelFieldCollation.NullDirection) - Constructor for class org.apache.calcite.rel.RelFieldCollation
-
Creates a field collation.
- RelFieldCollation.Direction - Enum in org.apache.calcite.rel
-
Direction that a field is ordered in.
- RelFieldCollation.NullDirection - Enum in org.apache.calcite.rel
-
Ordering of nulls.
- RelFieldTrimmer - Class in org.apache.calcite.sql2rel
-
Transformer that walks over a tree of relational expressions, replacing each
RelNode
with a 'slimmed down' relational expression that projects only the columns required by its consumer. - RelFieldTrimmer(SqlValidator, RelOptCluster, RelFactories.ProjectFactory, RelFactories.FilterFactory, RelFactories.JoinFactory, RelFactories.SortFactory, RelFactories.AggregateFactory, RelFactories.SetOpFactory) - Constructor for class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Deprecated.
- RelFieldTrimmer(SqlValidator, RelBuilder) - Constructor for class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Creates a RelFieldTrimmer.
- RelFieldTrimmer.TrimResult - Class in org.apache.calcite.sql2rel
-
Result of an attempt to trim columns from a relational expression.
- RelHint - Class in org.apache.calcite.rel.hint
-
Hint attached to a relation expression.
- RelHint.Builder - Class in org.apache.calcite.rel.hint
-
Builder for
RelHint
. - RelHintsPropagator - Interface in org.apache.calcite.plan
-
Customize the propagation of the
RelHint
s from the root relational expression of a rule callRelOptRuleCall
to the new equivalent expression. - RelHomogeneousShuttle - Class in org.apache.calcite.rel
-
Visits all the relations in a homogeneous way: always redirects calls to
accept(RelNode)
. - RelHomogeneousShuttle() - Constructor for class org.apache.calcite.rel.RelHomogeneousShuttle
- RelImplementor - Interface in org.apache.calcite.plan
-
This is a marker interface for a callback used to convert a tree of
relational expressions
into a plan. - RelInput - Interface in org.apache.calcite.rel
-
Context from which a relational expression can initialize itself, reading from a serialized form of the relational expression.
- relIsValid() - Static method in class org.apache.calcite.test.Matchers
- relJson - Variable in class org.apache.calcite.rel.externalize.RelJsonWriter
- RelJson - Class in org.apache.calcite.rel.externalize
-
Utilities for converting
RelNode
into JSON format. - RelJson(JsonBuilder) - Constructor for class org.apache.calcite.rel.externalize.RelJson
-
Deprecated.Use
RelJson.create()
, followed byRelJson.withJsonBuilder(org.apache.calcite.util.JsonBuilder)
ifjsonBuilder
is not null. - RelJson.InputTranslator - Interface in org.apache.calcite.rel.externalize
-
Translates a JSON object that represents an input reference into a RexNode.
- RelJsonReader - Class in org.apache.calcite.rel.externalize
-
Reads a JSON plan and converts it back to a tree of relational expressions.
- RelJsonReader(RelOptCluster, RelOptSchema, Schema) - Constructor for class org.apache.calcite.rel.externalize.RelJsonReader
- RelJsonReader(RelOptCluster, RelOptSchema, Schema, UnaryOperator<RelJson>) - Constructor for class org.apache.calcite.rel.externalize.RelJsonReader
- RelJsonWriter - Class in org.apache.calcite.rel.externalize
-
Callback for a relational expression to dump itself as JSON.
- RelJsonWriter() - Constructor for class org.apache.calcite.rel.externalize.RelJsonWriter
-
Creates a RelJsonWriter with a private JsonBuilder.
- RelJsonWriter(JsonBuilder) - Constructor for class org.apache.calcite.rel.externalize.RelJsonWriter
-
Creates a RelJsonWriter with a given JsonBuilder.
- RelJsonWriter(JsonBuilder, UnaryOperator<RelJson>) - Constructor for class org.apache.calcite.rel.externalize.RelJsonWriter
-
Creates a RelJsonWriter.
- relList - Variable in class org.apache.calcite.rel.externalize.RelJsonWriter
- RelMdAllPredicates - Class in org.apache.calcite.rel.metadata
-
Utility to extract Predicates that are present in the (sub)plan starting at this node.
- RelMdAllPredicates() - Constructor for class org.apache.calcite.rel.metadata.RelMdAllPredicates
- RelMdCollation - Class in org.apache.calcite.rel.metadata
-
RelMdCollation supplies a default implementation of
RelMetadataQuery.collations(org.apache.calcite.rel.RelNode)
for the standard logical algebra. - RelMdColumnOrigins - Class in org.apache.calcite.rel.metadata
-
RelMdColumnOrigins supplies a default implementation of
RelMetadataQuery.getColumnOrigins(org.apache.calcite.rel.RelNode, int)
for the standard logical algebra. - RelMdColumnUniqueness - Class in org.apache.calcite.rel.metadata
-
RelMdColumnUniqueness supplies a default implementation of
RelMetadataQuery.areColumnsUnique(org.apache.calcite.rel.RelNode, org.apache.calcite.util.ImmutableBitSet)
for the standard logical algebra. - RelMdDistinctRowCount - Class in org.apache.calcite.rel.metadata
-
RelMdDistinctRowCount supplies a default implementation of
RelMetadataQuery.getDistinctRowCount(org.apache.calcite.rel.RelNode, org.apache.calcite.util.ImmutableBitSet, org.apache.calcite.rex.RexNode)
for the standard logical algebra. - RelMdDistinctRowCount() - Constructor for class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
- RelMdDistribution - Class in org.apache.calcite.rel.metadata
-
RelMdCollation supplies a default implementation of
RelMetadataQuery.distribution(org.apache.calcite.rel.RelNode)
for the standard logical algebra. - RelMdExplainVisibility - Class in org.apache.calcite.rel.metadata
-
RelMdExplainVisibility supplies a default implementation of
RelMetadataQuery.isVisibleInExplain(org.apache.calcite.rel.RelNode, org.apache.calcite.sql.SqlExplainLevel)
for the standard logical algebra. - RelMdExpressionLineage - Class in org.apache.calcite.rel.metadata
-
Default implementation of
RelMetadataQuery.getExpressionLineage(org.apache.calcite.rel.RelNode, org.apache.calcite.rex.RexNode)
for the standard logical algebra. - RelMdExpressionLineage() - Constructor for class org.apache.calcite.rel.metadata.RelMdExpressionLineage
- RelMdLowerBoundCost - Class in org.apache.calcite.rel.metadata
-
Default implementations of the
BuiltInMetadata.LowerBoundCost
metadata provider for the standard algebra. - RelMdLowerBoundCost() - Constructor for class org.apache.calcite.rel.metadata.RelMdLowerBoundCost
- RelMdMaxRowCount - Class in org.apache.calcite.rel.metadata
-
RelMdMaxRowCount supplies a default implementation of
RelMetadataQuery.getMaxRowCount(org.apache.calcite.rel.RelNode)
for the standard logical algebra. - RelMdMaxRowCount() - Constructor for class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- RelMdMeasure - Class in org.apache.calcite.rel.metadata
-
Default implementations of the
BuiltInMetadata.Measure
metadata provider for the standard logical algebra. - RelMdMeasure() - Constructor for class org.apache.calcite.rel.metadata.RelMdMeasure
- RelMdMeasure.Contexts - Class in org.apache.calcite.rel.metadata
-
Helpers for
BuiltInMetadata.Measure.Context
. - RelMdMeasure.DelegatingContext - Class in org.apache.calcite.rel.metadata
-
Implementation of Context that delegates to another Context.
- RelMdMemory - Class in org.apache.calcite.rel.metadata
-
Default implementations of the
BuiltInMetadata.Memory
metadata provider for the standard logical algebra. - RelMdMemory() - Constructor for class org.apache.calcite.rel.metadata.RelMdMemory
- RelMdMinRowCount - Class in org.apache.calcite.rel.metadata
-
RelMdMinRowCount supplies a default implementation of
RelMetadataQuery.getMinRowCount(org.apache.calcite.rel.RelNode)
for the standard logical algebra. - RelMdMinRowCount() - Constructor for class org.apache.calcite.rel.metadata.RelMdMinRowCount
- RelMdNodeTypes - Class in org.apache.calcite.rel.metadata
-
RelMdNodeTypeCount supplies a default implementation of
RelMetadataQuery.getNodeTypes(org.apache.calcite.rel.RelNode)
for the standard logical algebra. - RelMdNodeTypes() - Constructor for class org.apache.calcite.rel.metadata.RelMdNodeTypes
- RelMdParallelism - Class in org.apache.calcite.rel.metadata
-
Default implementations of the
BuiltInMetadata.Parallelism
metadata provider for the standard logical algebra. - RelMdParallelism() - Constructor for class org.apache.calcite.rel.metadata.RelMdParallelism
- RelMdPercentageOriginalRows - Class in org.apache.calcite.rel.metadata
-
RelMdPercentageOriginalRows supplies a default implementation of
RelMetadataQuery.getPercentageOriginalRows(org.apache.calcite.rel.RelNode)
for the standard logical algebra. - RelMdPopulationSize - Class in org.apache.calcite.rel.metadata
-
RelMdPopulationSize supplies a default implementation of
RelMetadataQuery.getPopulationSize(org.apache.calcite.rel.RelNode, org.apache.calcite.util.ImmutableBitSet)
for the standard logical algebra. - RelMdPredicates - Class in org.apache.calcite.rel.metadata
-
Utility to infer Predicates that are applicable above a RelNode.
- RelMdPredicates() - Constructor for class org.apache.calcite.rel.metadata.RelMdPredicates
- RelMdRowCount - Class in org.apache.calcite.rel.metadata
-
RelMdRowCount supplies a default implementation of
RelMetadataQuery.getRowCount(org.apache.calcite.rel.RelNode)
for the standard logical algebra. - RelMdRowCount() - Constructor for class org.apache.calcite.rel.metadata.RelMdRowCount
- RelMdSelectivity - Class in org.apache.calcite.rel.metadata
-
RelMdSelectivity supplies a default implementation of
RelMetadataQuery.getSelectivity(org.apache.calcite.rel.RelNode, org.apache.calcite.rex.RexNode)
for the standard logical algebra. - RelMdSelectivity() - Constructor for class org.apache.calcite.rel.metadata.RelMdSelectivity
- RelMdSize - Class in org.apache.calcite.rel.metadata
-
Default implementations of the
BuiltInMetadata.Size
metadata provider for the standard logical algebra. - RelMdSize() - Constructor for class org.apache.calcite.rel.metadata.RelMdSize
- RelMdTableReferences - Class in org.apache.calcite.rel.metadata
-
Default implementation of
RelMetadataQuery.getTableReferences(org.apache.calcite.rel.RelNode)
for the standard logical algebra. - RelMdTableReferences() - Constructor for class org.apache.calcite.rel.metadata.RelMdTableReferences
- RelMdUniqueKeys - Class in org.apache.calcite.rel.metadata
-
RelMdUniqueKeys supplies a default implementation of
RelMetadataQuery.getUniqueKeys(org.apache.calcite.rel.RelNode)
for the standard logical algebra. - RelMdUtil - Class in org.apache.calcite.rel.metadata
-
RelMdUtil provides utility methods used by the metadata provider methods.
- RelMetadataFixture - Class in org.apache.calcite.test
-
Parameters for a Metadata test.
- RelMetadataFixture.MetadataConfig - Class in org.apache.calcite.test
-
A configuration that describes how metadata should be configured.
- RelMetadataHandlerGeneratorUtil - Class in org.apache.calcite.rel.metadata.janino
-
Generates the
MetadataHandler
code. - RelMetadataHandlerGeneratorUtil.HandlerNameAndGeneratedCode - Interface in org.apache.calcite.rel.metadata.janino
-
Contains Name and code that been generated for
MetadataHandler
. - RelMetadataProvider - Interface in org.apache.calcite.rel.metadata
-
RelMetadataProvider defines an interface for obtaining metadata about relational expressions.
- RelMetadataQuery - Class in org.apache.calcite.rel.metadata
-
RelMetadataQuery provides a strongly-typed facade on top of
RelMetadataProvider
for the set of relational expression metadata queries defined as standard within Calcite. - RelMetadataQuery() - Constructor for class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Creates the instance with
JaninoRelMetadataProvider
instance fromRelMetadataQueryBase.THREAD_PROVIDERS
andRelMetadataQuery.EMPTY
as a prototype. - RelMetadataQuery(MetadataHandlerProvider) - Constructor for class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Create a RelMetadataQuery with a given
MetadataHandlerProvider
. - RelMetadataQueryBase - Class in org.apache.calcite.rel.metadata
-
Base class for the RelMetadataQuery that uses the metadata handler class generated by the Janino.
- RelMetadataQueryBase(JaninoRelMetadataProvider) - Constructor for class org.apache.calcite.rel.metadata.RelMetadataQueryBase
-
Deprecated.
- RelMetadataQueryBase(MetadataHandlerProvider) - Constructor for class org.apache.calcite.rel.metadata.RelMetadataQueryBase
- RelMultipleTrait - Interface in org.apache.calcite.plan
-
Trait for which a given relational expression can have multiple values.
- RelNode - Interface in org.apache.calcite.rel
-
A
RelNode
is a relational expression. - RelNode.Context - Interface in org.apache.calcite.rel
-
Context of a relational expression, for purposes of checking validity.
- RelNodes - Class in org.apache.calcite.rel
-
Utilities concerning relational expressions.
- RelNodesExprsHandler(RexShuttle) - Constructor for class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.RelNodesExprsHandler
- RelOptAbstractTable - Class in org.apache.calcite.plan
-
Partial implementation of
RelOptTable
. - RelOptAbstractTable(RelOptSchema, String, RelDataType) - Constructor for class org.apache.calcite.plan.RelOptAbstractTable
- RelOptCluster - Class in org.apache.calcite.plan
-
An environment for related relational expressions during the optimization of a query.
- RelOptConnection - Interface in org.apache.calcite.plan
-
The planner's view of a connection to a database.
- RelOptCost - Interface in org.apache.calcite.plan
-
RelOptCost defines an interface for optimizer cost in terms of number of rows processed, CPU cost, and I/O cost.
- RelOptCostFactory - Interface in org.apache.calcite.plan
-
Cost model for query planning.
- RelOptCostImpl - Class in org.apache.calcite.plan
-
RelOptCostImpl provides a default implementation for the
RelOptCost
interface. - RelOptCostImpl(double) - Constructor for class org.apache.calcite.plan.RelOptCostImpl
- RelOptFixture - Class in org.apache.calcite.test
-
A fixture for testing planner rules.
- RelOptLattice - Class in org.apache.calcite.plan
-
Use of a lattice by the query optimizer.
- RelOptLattice(Lattice, RelOptTable) - Constructor for class org.apache.calcite.plan.RelOptLattice
- RelOptListener - Interface in org.apache.calcite.plan
-
RelOptListener defines an interface for listening to events which occur during the optimization process.
- RelOptListener.RelChosenEvent - Class in org.apache.calcite.plan
-
Event indicating that a relational expression has been chosen.
- RelOptListener.RelDiscardedEvent - Class in org.apache.calcite.plan
-
Event indicating that a relational expression has been discarded.
- RelOptListener.RelEquivalenceEvent - Class in org.apache.calcite.plan
-
Event indicating that a relational expression has been found to be equivalent to an equivalence class.
- RelOptListener.RelEvent - Class in org.apache.calcite.plan
-
Event class for abstract event dealing with a relational expression.
- RelOptListener.RuleAttemptedEvent - Class in org.apache.calcite.plan
-
Event indicating that a planner rule has been attempted.
- RelOptListener.RuleEvent - Class in org.apache.calcite.plan
-
Event indicating that a planner rule has fired.
- RelOptListener.RuleProductionEvent - Class in org.apache.calcite.plan
-
Event indicating that a planner rule has produced a result.
- RelOptMaterialization - Class in org.apache.calcite.plan
-
Records that a particular query is materialized by a particular table.
- RelOptMaterialization(RelNode, RelNode, RelOptTable, List<String>) - Constructor for class org.apache.calcite.plan.RelOptMaterialization
-
Creates a RelOptMaterialization.
- RelOptMaterializations - Class in org.apache.calcite.plan
-
Utility methods for using materialized views and lattices for queries.
- RelOptMaterializations() - Constructor for class org.apache.calcite.plan.RelOptMaterializations
- RelOptNode - Interface in org.apache.calcite.plan
-
Node in a planner.
- RelOptPlanner - Interface in org.apache.calcite.plan
-
A
RelOptPlanner
is a query optimizer: it transforms a relational expression into a semantically equivalent relational expression, according to a given set of rules and a cost model. - RelOptPlanner.CannotPlanException - Exception Class in org.apache.calcite.plan
-
Thrown by
RelOptPlanner.findBestExp()
. - RelOptPlanner.Executor - Interface in org.apache.calcite.plan
-
Deprecated.Use
RexExecutor
- RelOptPredicateList - Class in org.apache.calcite.plan
-
Predicates that are known to hold in the output of a particular relational expression.
- RelOptQuery - Class in org.apache.calcite.plan
-
A
RelOptQuery
represents a set ofrelational expressions
which derive from the sameselect
statement. - RelOptQuery(RelOptPlanner) - Constructor for class org.apache.calcite.plan.RelOptQuery
-
Deprecated.
- RelOptRule - Class in org.apache.calcite.plan
-
A
RelOptRule
transforms an expression into another. - RelOptRule(RelOptRuleOperand) - Constructor for class org.apache.calcite.plan.RelOptRule
-
Creates a rule.
- RelOptRule(RelOptRuleOperand, String) - Constructor for class org.apache.calcite.plan.RelOptRule
-
Creates a rule with an explicit description.
- RelOptRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class org.apache.calcite.plan.RelOptRule
-
Creates a rule with an explicit description.
- RelOptRule.ConverterRelOptRuleOperand - Class in org.apache.calcite.plan
-
Operand to an instance of the converter rule.
- RelOptRuleCall - Class in org.apache.calcite.plan
-
A
RelOptRuleCall
is an invocation of aRelOptRule
with a set ofrelational expression
s as arguments. - RelOptRuleCall(RelOptPlanner, RelOptRuleOperand, RelNode[], Map<RelNode, List<RelNode>>) - Constructor for class org.apache.calcite.plan.RelOptRuleCall
- RelOptRuleCall(RelOptPlanner, RelOptRuleOperand, RelNode[], Map<RelNode, List<RelNode>>, List<RelNode>) - Constructor for class org.apache.calcite.plan.RelOptRuleCall
-
Creates a RelOptRuleCall.
- RelOptRuleOperand - Class in org.apache.calcite.plan
-
Operand that determines whether a
RelOptRule
can be applied to a particular expression. - RelOptRuleOperand(Class<R>, RelTrait, Predicate<? super R>, RelOptRuleOperandChildren) - Constructor for class org.apache.calcite.plan.RelOptRuleOperand
-
Deprecated.Use
RelOptRule.operand(Class, RelOptRuleOperandChildren)
or one of its overloaded methods. - RelOptRuleOperandChildPolicy - Enum in org.apache.calcite.plan
-
Policy by which operands will be matched by relational expressions with any number of children.
- RelOptRuleOperandChildren - Class in org.apache.calcite.plan
-
Deprecated.
- RelOptRuleOperandChildren(RelOptRuleOperandChildPolicy, List<RelOptRuleOperand>) - Constructor for class org.apache.calcite.plan.RelOptRuleOperandChildren
-
Deprecated.
- RelOptRules - Class in org.apache.calcite.plan
-
A utility class for organizing built-in rules and rule related methods.
- RelOptSamplingParameters - Class in org.apache.calcite.plan
-
RelOptSamplingParameters represents the parameters necessary to produce a sample of a relation.
- RelOptSamplingParameters(boolean, float, boolean, int) - Constructor for class org.apache.calcite.plan.RelOptSamplingParameters
-
Deprecated.
- RelOptSamplingParameters(boolean, BigDecimal, boolean, int) - Constructor for class org.apache.calcite.plan.RelOptSamplingParameters
- relOptSchema - Variable in class org.apache.calcite.tools.RelBuilder
- RelOptSchema - Interface in org.apache.calcite.plan
-
A
RelOptSchema
is a set ofRelOptTable
objects. - RelOptSchemaWithSampling - Interface in org.apache.calcite.plan
-
Extension to
RelOptSchema
with support for sample data-sets. - relOptTable() - Method in class org.apache.calcite.materialize.LatticeNode
- RelOptTable - Interface in org.apache.calcite.plan
-
Represents a relational dataset in a
RelOptSchema
. - RelOptTable.ToRelContext - Interface in org.apache.calcite.plan
-
Contains the context needed to convert a a table into a relational expression.
- RelOptTable.ViewExpander - Interface in org.apache.calcite.plan
-
Can expand a view into relational expressions.
- RelOptTableImpl - Class in org.apache.calcite.prepare
-
Implementation of
RelOptTable
. - RelOptUtil - Class in org.apache.calcite.plan
-
RelOptUtil
defines static utility methods for use in optimizingRelNode
s. - RelOptUtil() - Constructor for class org.apache.calcite.plan.RelOptUtil
- RelOptUtil.Exists - Class in org.apache.calcite.plan
- RelOptUtil.InputFinder - Class in org.apache.calcite.plan
-
Visitor which builds a bitmap of the inputs used by an expression.
- RelOptUtil.InputReferencedVisitor - Class in org.apache.calcite.plan
-
Shuttle that finds the set of inputs that are used.
- RelOptUtil.Logic - Enum in org.apache.calcite.plan
-
Policies for handling two- and three-valued boolean logic.
- RelOptUtil.RexInputConverter - Class in org.apache.calcite.plan
-
Walks an expression tree, converting the index of RexInputRefs based on some adjustment factor.
- RelOptUtil.SubQueryType - Enum in org.apache.calcite.plan
-
What kind of sub-query.
- RelOptUtil.TypeDumper - Class in org.apache.calcite.plan
-
Converts types to descriptive strings.
- RelOptUtil.VariableUsedVisitor - Class in org.apache.calcite.plan
-
Visitor that finds all variables used in an expression.
- RelProtoDataType - Interface in org.apache.calcite.rel.type
-
Can be converted into a
RelDataType
given aRelDataTypeFactory
. - RelRecordType - Class in org.apache.calcite.rel.type
-
RelRecordType represents a structured type having named fields.
- RelRecordType(List<RelDataTypeField>) - Constructor for class org.apache.calcite.rel.type.RelRecordType
-
Creates a
RecordType
. - RelRecordType(StructKind, List<RelDataTypeField>) - Constructor for class org.apache.calcite.rel.type.RelRecordType
-
Creates a
RecordType
. - RelRecordType(StructKind, List<RelDataTypeField>, boolean) - Constructor for class org.apache.calcite.rel.type.RelRecordType
-
Creates a
RecordType
. - RelReferentialConstraint - Interface in org.apache.calcite.rel
-
Interface for a referential constraint, i.e., Foreign-Key - Unique-Key relationship, between two tables.
- RelReferentialConstraintImpl - Class in org.apache.calcite.rel
-
RelOptReferentialConstraint base implementation.
- RelRoot - Class in org.apache.calcite.rel
-
Root of a tree of
RelNode
. - RelRoot(RelNode, RelDataType, SqlKind, Iterable<? extends Map.Entry<Integer, String>>, RelCollation, List<RelHint>) - Constructor for class org.apache.calcite.rel.RelRoot
-
Creates a RelRoot.
- RelRule<C extends RelRule.Config> - Class in org.apache.calcite.plan
-
Rule that is parameterized via a configuration.
- RelRule(C) - Constructor for class org.apache.calcite.plan.RelRule
-
Creates a RelRule.
- RelRule.Config - Interface in org.apache.calcite.plan
-
Rule configuration.
- RelRule.Done - Interface in org.apache.calcite.plan
-
Indicates that an operand is complete.
- RelRule.MatchHandler<R extends RelOptRule> - Interface in org.apache.calcite.plan
-
Callback interface that helps you avoid creating sub-classes of
RelRule
that differ only in implementations ofRelOptRule.onMatch(RelOptRuleCall)
method. - RelRule.OperandBuilder - Interface in org.apache.calcite.plan
-
Callback to create an operand.
- RelRule.OperandDetailBuilder<R extends RelNode> - Interface in org.apache.calcite.plan
-
Add details about an operand, such as its inputs.
- RelRule.OperandTransform - Interface in org.apache.calcite.plan
-
Function that creates an operand.
- RelRunner - Interface in org.apache.calcite.tools
-
Runs a relational expression.
- RelRunners - Class in org.apache.calcite.tools
-
Implementations of
RelRunner
. - rels - Variable in class org.apache.calcite.plan.RelOptRuleCall
- RelShuttle - Interface in org.apache.calcite.rel
-
Visitor that has methods for the common logical relational expressions.
- RelShuttleImpl - Class in org.apache.calcite.rel
-
Basic implementation of
RelShuttle
that callsRelNode.accept(RelShuttle)
on each child, andRelNode.copy(org.apache.calcite.plan.RelTraitSet, java.util.List)
if any children change. - RelShuttleImpl() - Constructor for class org.apache.calcite.rel.RelShuttleImpl
- relSinks - Variable in class org.apache.calcite.interpreter.InterpretableRel.InterpreterImplementor
- RelStructuredTypeFlattener - Class in org.apache.calcite.sql2rel
-
RelStructuredTypeFlattener removes all structured types from a tree of relational expressions.
- RelStructuredTypeFlattener(RexBuilder, RelOptTable.ToRelContext, boolean) - Constructor for class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
-
Deprecated.
- RelStructuredTypeFlattener(RelBuilder, RexBuilder, RelOptTable.ToRelContext, boolean) - Constructor for class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- RelStructuredTypeFlattener.SelfFlatteningRel - Interface in org.apache.calcite.sql2rel
-
Mix-in interface for relational expressions that know how to flatten themselves.
- RelSubset - Class in org.apache.calcite.plan.volcano
-
Subset of an equivalence class where all relational expressions have the same physical properties.
- relSupplier - Variable in class org.apache.calcite.test.RelMetadataFixture
- RelToSqlConverter - Class in org.apache.calcite.rel.rel2sql
-
Utility to convert relational expressions to SQL abstract syntax tree.
- RelToSqlConverter(SqlDialect) - Constructor for class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Creates a RelToSqlConverter.
- RelToSqlConverterUtil - Class in org.apache.calcite.util
-
Utilities used by multiple dialect for RelToSql conversion.
- RelToSqlConverterUtil() - Constructor for class org.apache.calcite.util.RelToSqlConverterUtil
- RelTrait - Interface in org.apache.calcite.plan
-
RelTrait represents the manifestation of a relational expression trait within a trait definition.
- RelTraitDef<T extends RelTrait> - Class in org.apache.calcite.plan
-
RelTraitDef represents a class of
RelTrait
s. - RelTraitDef() - Constructor for class org.apache.calcite.plan.RelTraitDef
- RelTraitPropagationVisitor - Class in org.apache.calcite.plan
-
Deprecated.As of 1.19, if you need to perform certain assertions regarding a RelNode tree and the contained traits you are encouraged to implement your own RelVisitor or
RelShuttle
directly. The reasons for deprecating this class are the following:- The contract (Javadoc and naming) and the behavior of the class are inconsistent.
- The class is no longer used by any other components of the framework.
- The class was used only for debugging purposes.
- RelTraitPropagationVisitor(RelOptPlanner, RelTraitSet) - Constructor for class org.apache.calcite.plan.RelTraitPropagationVisitor
-
Deprecated.
- RelTraitSet - Class in org.apache.calcite.plan
-
RelTraitSet represents an ordered set of
RelTrait
s. - relTransform - Variable in class org.apache.calcite.test.RelMetadataFixture
- RelType(String) - Constructor for class org.apache.calcite.rel.rules.CalcRelSplitter.RelType
- RelValidityChecker - Class in org.apache.calcite.rel
-
Visitor that checks that every
RelNode
in a tree is valid. - RelValidityChecker() - Constructor for class org.apache.calcite.rel.RelValidityChecker
- RelVisitor - Class in org.apache.calcite.rel
-
A
RelVisitor
is a Visitor role in thevisitor pattern
and visitsRelNode
objects as the role of Element. - RelVisitor() - Constructor for class org.apache.calcite.rel.RelVisitor
- RelWriter - Interface in org.apache.calcite.rel
-
Callback for an expression to dump itself to.
- RelWriterImpl - Class in org.apache.calcite.rel.externalize
-
Implementation of
RelWriter
. - RelWriterImpl(PrintWriter) - Constructor for class org.apache.calcite.rel.externalize.RelWriterImpl
- RelWriterImpl(PrintWriter, SqlExplainLevel, boolean) - Constructor for class org.apache.calcite.rel.externalize.RelWriterImpl
- RelXmlWriter - Class in org.apache.calcite.rel.externalize
-
Callback for a relational expression to dump in XML format.
- RelXmlWriter(PrintWriter, SqlExplainLevel) - Constructor for class org.apache.calcite.rel.externalize.RelXmlWriter
- remark(T) - Static method in class org.apache.calcite.util.Bug
-
Use this method to flag temporary code.
- remove() - Method in class org.apache.calcite.util.Filterator
- remove() - Method in class org.apache.calcite.util.graph.BreadthFirstIterator
- remove() - Method in class org.apache.calcite.util.graph.DepthFirstIterator
- remove() - Method in class org.apache.calcite.util.graph.TopologicalOrderIterator
- remove(int) - Method in class org.apache.calcite.util.ImmutableIntList
- remove(int) - Method in interface org.apache.calcite.runtime.PairList
- remove(int) - Method in class org.apache.calcite.sql.SqlNodeList
- remove(int) - Method in class org.apache.calcite.util.CastingList
- remove(Object) - Method in class org.apache.calcite.util.ImmutableIntList
- remove(Object) - Method in class org.apache.calcite.sql.SqlNodeList
- remove(Object) - Method in class org.apache.calcite.util.CompositeMap
- remove(Object) - Method in class org.apache.calcite.util.ImmutableNullableSet
- remove(Object) - Method in class org.apache.calcite.util.PartiallyOrderedSet
- remove(String) - Method in class org.apache.calcite.util.NameMap
- remove(String, V) - Method in class org.apache.calcite.util.NameMultimap
-
Removes all entries that have the given case-sensitive key.
- remove(Enumerable<T>, C) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Default implementation of
ExtendedEnumerable.removeAll(Collection)
. - REMOVE - Enum constant in enum org.apache.calcite.runtime.JsonFunctions.JsonModifyMode
- REMOVE_ALL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- removeAll(C) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- removeAll(C) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Removes the contents of this sequence from a collection.
- removeAll(Collection<?>) - Method in class org.apache.calcite.util.ImmutableIntList
- removeAll(Collection<?>) - Method in class org.apache.calcite.sql.SqlNodeList
- removeAll(Collection<?>) - Method in class org.apache.calcite.util.ImmutableNullableSet
- removeAll(List<RexNode>, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Removes all expressions from a list that are equivalent to a given expression.
- removeAll(ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Clears all bits in a given bit set.
- removeAllVertices(Collection<V>) - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- removeAllVertices(Collection<V>) - Method in interface org.apache.calcite.util.graph.DirectedGraph
-
Removes from this graph all vertices that are in
collection
, and the edges into and out of those vertices. - removeCast(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Removes any casts.
- removeCorrelationExpr(RexNode, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- removeCorrelationExpr(RexNode, boolean, Set<Integer>) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- removeCorrelationExpr(RexNode, boolean, RexInputRef) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- removeCorrelationViaRule(RelNode) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- removeEdge(V, V) - Method in class org.apache.calcite.util.graph.AttributedDirectedGraph
-
Removes all edges from a given vertex to another.
- removeEdge(V, V) - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- removeEdge(V, V) - Method in interface org.apache.calcite.util.graph.DirectedGraph
- RemoveEmptySingleRule(Class<R>, Predicate<R>, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.PruneEmptyRules.RemoveEmptySingleRule
-
Deprecated.
- RemoveEmptySingleRule(Class<R>, String) - Constructor for class org.apache.calcite.rel.rules.PruneEmptyRules.RemoveEmptySingleRule
-
Deprecated.
- RemoveEmptySingleRule(Class<R>, Predicate<R>, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.PruneEmptyRules.RemoveEmptySingleRule
-
Deprecated.
- removeFunction(String) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- removeFunction(String) - Method in class org.apache.calcite.jdbc.CalciteSchema
- RemoveHoleTransformer - Class in org.apache.calcite.runtime
-
Removes the holes of a geometry.
- RemoveHoleTransformer() - Constructor for class org.apache.calcite.runtime.RemoveHoleTransformer
- removeMaterialization(MaterializationKey) - Method in class org.apache.calcite.materialize.MaterializationService
- removeNullabilityCast(RelDataTypeFactory, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Removes any casts that change nullability but not type.
- removeNullabilityCast(RexNode) - Method in class org.apache.calcite.rex.RexSimplify
-
Removes any casts that change nullability but not type.
- RemovePointOperation - Class in org.apache.calcite.runtime
-
Geometry editor operation that removes a point to a geometry.
- RemovePointOperation(int) - Constructor for class org.apache.calcite.runtime.RemovePointOperation
- removeRedundantDistinct() - Method in interface org.apache.calcite.tools.RelBuilder.Config
-
Whether to remove the distinct that in aggregate if we know that the input is already unique; default false.
- RemoveRepeatedPointsTransformer - Class in org.apache.calcite.runtime
-
Removes repeated points from a geometry.
- RemoveRepeatedPointsTransformer() - Constructor for class org.apache.calcite.runtime.RemoveRepeatedPointsTransformer
- RemoveRepeatedPointsTransformer(double) - Constructor for class org.apache.calcite.runtime.RemoveRepeatedPointsTransformer
- removeRule(RelOptRule) - Method in interface org.apache.calcite.jdbc.CalcitePrepare.SparkHandler.RuleSetBuilder
- removeRule(RelOptRule) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- removeRule(RelOptRule) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Removes a rule.
- removeRule(RelOptRule) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- removeRule(RelOptRule) - Method in class org.apache.calcite.test.MockRelOptPlanner
- removeStatement(Meta.StatementHandle) - Method in interface org.apache.calcite.server.CalciteServer
- removeSubSchema(String) - Method in class org.apache.calcite.jdbc.CalciteSchema
- removeTable(String) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- removeTable(String) - Method in class org.apache.calcite.jdbc.CalciteSchema
- removeTable(String) - Method in interface org.apache.calcite.schema.SchemaPlus
-
Removes a table from this schema, used e.g.
- removeType(String) - Method in class org.apache.calcite.jdbc.CalciteSchema
- removeTypeSpecOperands(SqlCall) - Static method in class org.apache.calcite.sql.fun.SqlJsonQueryFunction
- removeTypeSpecOperands(SqlCall) - Static method in class org.apache.calcite.sql.fun.SqlJsonValueFunction
-
Returns new operand list with type specification removed.
- removeValidatedNodeType(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Removes a node from the set of validated nodes.
- removeValidatedNodeType(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- rename(String) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- rename(List<? extends String>) - Method in class org.apache.calcite.tools.RelBuilder
-
Ensures that the field names match those given.
- renameIfNecessary(RelNode, RelDataType) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- repeat(int, int) - Method in class org.apache.calcite.runtime.Pattern.PatternBuilder
- repeat(String, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL REPEAT(string, int) function.
- repeat(SqlOperandCountRange, SqlSingleOperandTypeChecker...) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a checker that passes if all of the rules pass for each operand, using a given operand count strategy.
- REPEAT - Enum constant in enum org.apache.calcite.runtime.Pattern.Op
-
Pattern that matches a pattern repeated between
minRepeat
andmaxRepeat
times. - REPEAT - Enum constant in enum org.apache.calcite.sql.type.CompositeOperandTypeChecker.Composition
- REPEAT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REPEAT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- REPEAT_UNION - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- repeatUnion(String, boolean) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
RepeatUnion
associated to aTransientTable
without a maximum number of iterations, i.e. - repeatUnion(String, boolean, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
RepeatUnion
associated to aTransientTable
of the two most recent relational expressions on the stack. - repeatUnion(Enumerable<TSource>, Enumerable<TSource>, int, boolean, EqualityComparer<TSource>, Function0<Boolean>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Repeat Union enumerable.
- RepeatUnion - Class in org.apache.calcite.rel.core
-
Relational expression that computes a repeat union (recursive union in SQL terminology).
- RepeatUnion(RelOptCluster, RelTraitSet, RelNode, RelNode, boolean, int, RelOptTable) - Constructor for class org.apache.calcite.rel.core.RepeatUnion
- repeatUnionFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- replace(int, RelTrait) - Method in class org.apache.calcite.plan.RelTraitSet
-
Replaces an existing RelTrait in the set.
- replace(String, String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
REPLACE(string, search, replacement)
function. - replace(String, String, String) - Static method in class org.apache.calcite.sql.SqlDialect.FakeUtil
-
Deprecated.Replaces every occurrence of
find
ins
withreplace
. - replace(String, String, String) - Static method in class org.apache.calcite.util.Util
-
Replaces every occurrence of
find
ins
withreplace
. - replace(List<T>) - Method in class org.apache.calcite.plan.RelTraitSet
-
Replaces the trait(s) of a given type with a list of traits of the same type.
- replace(RelTrait) - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns a trait set consisting of the current set plus a new trait.
- replace(RelTraitDef<T>, List<T>) - Method in class org.apache.calcite.plan.RelTraitSet
-
Replaces the trait(s) of a given type with a list of traits of the same type.
- replace(MutableRel, MutableRel, MutableRel) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
-
Within a relational expression
query
, replaces occurrences offind
withreplace
. - replace(RelNode, RelNode, RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Within a relational expression
query
, replaces occurrences offind
withreplace
. - REPLACE - Enum constant in enum org.apache.calcite.runtime.JsonFunctions.JsonModifyMode
- REPLACE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REPLACE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
REPLACE(string, search, replace)
function. - replaceEscapedChars(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Converts the contents of a character literal with escapes like those used in the C programming language to the corresponding Java string representation.
- replaceIf(RelTraitDef<T>, Supplier<? extends T>) - Method in class org.apache.calcite.plan.RelTraitSet
-
If a given trait is enabled, replaces it by calling the given function.
- replaceIfs(RelTraitDef<T>, Supplier<? extends List<T>>) - Method in class org.apache.calcite.plan.RelTraitSet
-
If a given multiple trait is enabled, replaces it by calling the given function.
- replaceInParent(MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableRel
-
Replaces this
MutableRel
in its parent with another node at the same position. - replaceInput(int, RelNode) - Method in class org.apache.calcite.rel.AbstractRelNode
- replaceInput(int, RelNode) - Method in class org.apache.calcite.rel.BiRel
- replaceInput(int, RelNode) - Method in class org.apache.calcite.rel.core.SetOp
- replaceInput(int, RelNode) - Method in class org.apache.calcite.rel.core.TableFunctionScan
- replaceInput(int, RelNode) - Method in interface org.apache.calcite.rel.RelNode
-
Replaces the
ordinalInParent
th input. - replaceInput(int, RelNode) - Method in class org.apache.calcite.rel.rules.MultiJoin
- replaceInput(int, RelNode) - Method in class org.apache.calcite.rel.SingleRel
- replaceInput(RelNode, int, RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a shallow copy of a relational expression with a particular input replaced.
- replacement - Variable in class org.apache.calcite.sql.advise.SqlAdvisorHint2
-
Replacement string.
- replaceNonDollarIndexedString(String) - Static method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
Preprocesses double-backslash-based indexing for capturing groups into $-based indices recognized by java regex, throws an error for invalid escapes.
- replaceRoot(RelNode) - Method in class org.apache.calcite.rel.RelVisitor
-
Replaces the root node of this traversal.
- replaceSublist(int, int, SqlNode) - Method in interface org.apache.calcite.sql.SqlSpecialOperator.TokenSequence
- replaceSublist(List<T>, int, int, T) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Replaces a range of elements in a list with a single element.
- replaceTimeUnitOperand(SqlCall, String, SqlParserPos) - Static method in class org.apache.calcite.sql.fun.SqlFloorFunction
-
Copies a
SqlCall
, replacing the time unit operand with the given literal. - replaceTimeUnits(RexBuilder, RexNode, String) - Static method in class org.apache.calcite.rel.rules.DateRangeRules
-
Replaces calls to EXTRACT, FLOOR and CEIL in an expression.
- replaceWithOriginalReferences(RexBuilder, RelNode, MaterializedViewRule.NodeLineage, RexNode) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
Given the input expression, it will replace (sub)expressions when possible using the content of the mapping.
- replay(QueryableFactory<T>) - Method in interface org.apache.calcite.linq4j.QueryableDefaults.Replayable
- replay(QueryableFactory<T>) - Method in class org.apache.calcite.linq4j.QueryableDefaults.ReplayableQueryable
- ReplayableQueryable() - Constructor for class org.apache.calcite.linq4j.QueryableDefaults.ReplayableQueryable
- REPOSITORY - Enum constant in enum org.apache.calcite.sql.validate.SqlMonikerType
- requestCancel() - Method in class org.apache.calcite.util.CancelFlag
-
Requests a cancellation.
- requireAtLeastOneArg() - Method in interface org.apache.calcite.runtime.CalciteResource
- required() - Method in enum org.apache.calcite.config.CalciteConnectionProperty
- requiredColumns - Variable in class org.apache.calcite.rel.core.Correlate
- requiredColumns - Variable in class org.apache.calcite.rel.mutable.MutableCorrelate
- requireDefaultConstructor(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- requiresAliasForFromItems() - Method in class org.apache.calcite.sql.dialect.HiveSqlDialect
- requiresAliasForFromItems() - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- requiresAliasForFromItems() - Method in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
- requiresAliasForFromItems() - Method in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- requiresAliasForFromItems() - Method in class org.apache.calcite.sql.SqlDialect
-
Whether a sub-query in the FROM clause must have an alias.
- requiresDecimalExpansion() - Method in class org.apache.calcite.sql.fun.SqlNewOperator
- requiresDecimalExpansion() - Method in class org.apache.calcite.sql.fun.SqlRowOperator
- requiresDecimalExpansion() - Method in class org.apache.calcite.sql.SqlOperator
-
Method to check if call requires expansion when it has decimal operands.
- requiresDecimalExpansion(List<RexNode>, boolean) - Static method in class org.apache.calcite.rex.RexUtil
-
Determines whether any operand of a set requires decimal expansion.
- requiresDecimalExpansion(RexNode, boolean) - Static method in class org.apache.calcite.rex.RexUtil
-
Determines whether a
RexCall
requires decimal expansion. - requiresDecimalExpansion(RexProgram, boolean) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a
RexProgram
contains expressions which require decimal expansion. - requiresGroupOrder() - Method in class org.apache.calcite.sql.SqlAggFunction
-
Returns whether this aggregate function must, may, or must not contain a
WITHIN GROUP (ORDER ...)
clause. - requiresOrder() - Method in class org.apache.calcite.sql.SqlAggFunction
- requiresOrder() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether this is a window function that requires ordering.
- requiresOver() - Method in class org.apache.calcite.sql.SqlAggFunction
- requiresOver() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether this is a window function that requires an OVER clause.
- reRegister(RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Re-register the
registered
with given root node and return the new root node. - rescaleBigDecimal(BigDecimal, int) - Static method in class org.apache.calcite.util.NumberUtil
-
Sets the scale of a BigDecimal
bd
if it is not null; always returnsbd
. - reset() - Method in class org.apache.calcite.adapter.file.CsvEnumerator
- reset() - Method in class org.apache.calcite.adapter.file.JsonEnumerator
- reset() - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleEnumerator
- reset() - Method in class org.apache.calcite.adapter.kafka.KafkaMessageEnumerator
- reset() - Method in class org.apache.calcite.adapter.os.OsQuery
- reset() - Method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.SplunkResultEnumerator
- reset() - Method in class org.apache.calcite.interpreter.Row.RowBuilder
-
Allocates a new internal array.
- reset() - Method in class org.apache.calcite.linq4j.CartesianProductEnumerator
- reset() - Method in class org.apache.calcite.linq4j.DelegatingEnumerator
- reset() - Method in interface org.apache.calcite.linq4j.Enumerator
-
Sets the enumerator to its initial position, which is before the first element in the collection.
- reset() - Method in class org.apache.calcite.linq4j.MemoryEnumerator
- reset() - Method in class org.apache.calcite.linq4j.TransformedEnumerator
- reset() - Method in class org.apache.calcite.prepare.PlannerImpl
- reset() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- reset() - Method in interface org.apache.calcite.sql.SqlWriter
-
Resets this writer so that it can format another expression.
- reset() - Method in interface org.apache.calcite.tools.Planner
-
Resets this
Planner
to be used with a new query. - resetAlias() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
In join, when the left and right nodes have been generated, update their alias with 'neededAlias' if not null.
- resetAlias(String, RelDataType) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Sets the alias of the join or correlate just created.
- resetSettings() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- resetSettings() - Method in interface org.apache.calcite.sql.SqlWriter
-
Resets all properties to their default values.
- resolve() - Method in class org.apache.calcite.sql.validate.MatchRecognizeNamespace
- resolve() - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- resolve() - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
If this namespace resolves to another namespace, returns that namespace, following links to the end of the chain.
- resolve(List<String>, SqlNameMatcher, boolean, SqlValidatorScope.Resolved) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- resolve(List<String>, SqlNameMatcher, boolean, SqlValidatorScope.Resolved) - Method in class org.apache.calcite.sql.validate.ParameterScope
- resolve(List<String>, SqlNameMatcher, boolean, SqlValidatorScope.Resolved) - Method in class org.apache.calcite.sql.validate.ListScope
- resolve(List<String>, SqlNameMatcher, boolean, SqlValidatorScope.Resolved) - Method in class org.apache.calcite.sql.validate.MatchRecognizeScope
- resolve(List<String>, SqlNameMatcher, boolean, SqlValidatorScope.Resolved) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Looks up a node with a given name.
- resolve(RelDataTypeFactory, String, Collection<CalciteSchema.FunctionEntry>, List<RelDataType>) - Static method in class org.apache.calcite.schema.Schemas
- resolve(SqlTypeName) - Method in class org.apache.calcite.sql.SqlUnknownLiteral
-
Converts this unknown literal to a literal of known type.
- resolveArgs(Object) - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Resolves the arguments of a
JsonMeasure
. - resolveColumn(Object) - Method in class org.apache.calcite.materialize.Lattice.Builder
- resolveColumn(String, SqlNode) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- resolveColumn(String, SqlNode) - Method in class org.apache.calcite.sql.validate.ListScope
- resolveColumn(String, SqlNode) - Method in class org.apache.calcite.sql.validate.MeasureScope
- resolveColumn(String, SqlNode) - Method in class org.apache.calcite.sql.validate.OrderByScope
- resolveColumn(String, SqlNode) - Method in class org.apache.calcite.sql.validate.ParameterScope
- resolveColumn(String, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlLambdaScope
- resolveColumn(String, SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Resolves a single identifier to a column, and returns the datatype of that column.
- resolveColumn(RelDataType, RelDataTypeFactory, List<String>) - Method in interface org.apache.calcite.schema.CustomColumnResolvingTable
-
Resolve a column based on the name components.
- resolveColumn(RelDataType, RelDataTypeFactory, List<String>) - Method in interface org.apache.calcite.test.catalog.MockCatalogReader.ColumnResolver
- resolveComplexMetric(String, AggregateCall) - Method in class org.apache.calcite.adapter.druid.DruidTable
-
Returns the appropriate
ComplexMetric
that is mapped from the givenalias
if it exists, and is used in the expected context with the givenAggregateCall
. - resolved - Variable in class org.apache.calcite.sql.validate.DelegatingScope
-
Computes and stores information that cannot be computed on construction, but only after sub-queries have been validated.
- ResolvedImpl() - Constructor for class org.apache.calcite.sql.validate.SqlValidatorScope.ResolvedImpl
- resolveLiteral(SqlLiteral) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Resolves a literal.
- resolveLiteral(SqlLiteral) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- resolveMeasure(String, boolean, Object) - Method in class org.apache.calcite.materialize.Lattice.Builder
- resolver - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- resolveTable(List<String>, SqlNameMatcher, SqlValidatorScope.Path, SqlValidatorScope.Resolved) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- resolveTable(List<String>, SqlNameMatcher, SqlValidatorScope.Path, SqlValidatorScope.Resolved) - Method in class org.apache.calcite.sql.validate.ParameterScope
- resolveTable(List<String>, SqlNameMatcher, SqlValidatorScope.Path, SqlValidatorScope.Resolved) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Looks up a table in this scope from its name.
- resolveWindow(SqlNode, SqlValidatorScope) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Converts a window specification or window name into a fully-resolved window specification.
- resolveWindow(SqlNode, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- resolveWindow(SqlNode, SqlValidatorScope, boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Deprecated.Use
SqlValidator.resolveWindow(SqlNode, SqlValidatorScope)
, which does not have the deprecatedpopulateBounds
parameter. - RESOURCE - Static variable in class org.apache.calcite.util.Static
-
Resources.
- RESPECT_NULLS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
RESPECT NULLS
operator. - RESPECT_NULLS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
RESPECT NULLS
operator. - restoreTo(T) - Method in class org.apache.calcite.util.TryThreadLocal
-
Sets the value back to a previous value.
- result - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- result() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- result() - Method in interface org.apache.calcite.sql.util.SqlBasicVisitor.ArgHandler
-
Returns the result of visiting all children of a call to an operator, then the call itself.
- result() - Method in class org.apache.calcite.sql.util.SqlBasicVisitor.ArgHandlerImpl
- result() - Method in class org.apache.calcite.sql.util.SqlShuttle.CallCopyingArgHandler
- result(double) - Method in class org.apache.calcite.interpreter.AggregateNode.DoubleSum
- result(int) - Method in class org.apache.calcite.interpreter.AggregateNode.IntSum
- result(int) - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter1
- result(long) - Method in class org.apache.calcite.interpreter.AggregateNode.LongSum
- result(long) - Static method in class org.apache.calcite.util.Smalls.MyStaticSumFunction
- result(long) - Method in class org.apache.calcite.util.Smalls.MySumFunction
- result(long) - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter1
- result(long) - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter2
- result(long) - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter2
- result(Boolean) - Method in class org.apache.calcite.interpreter.AggregateNode.MaxBoolean
- result(Boolean) - Method in class org.apache.calcite.interpreter.AggregateNode.MinBoolean
- result(Integer) - Method in class org.apache.calcite.util.Smalls.MySum3
- result(BigDecimal) - Method in class org.apache.calcite.interpreter.AggregateNode.BigDecimalSum
- result(List<Geometry>) - Method in class org.apache.calcite.runtime.AccumOperation
- result(List<Geometry>) - Method in class org.apache.calcite.runtime.CollectOperation
- result(List<Geometry>) - Method in class org.apache.calcite.runtime.UnionOperation
- result(PhysType, BlockStatement) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- result(MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRuleCall
- result(MutableRel, boolean) - Method in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRuleCall
- result(RelNode, Mapping) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
- result(RelNode, Mapping, RelNode) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
- result(SqlNode, Collection<SqlImplementor.Clause>, String, RelDataType, Map<String, RelDataType>) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- result(SqlNode, Collection<SqlImplementor.Clause>, String, RelDataType, Map<String, RelDataType>) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Factory method for
SqlImplementor.Result
. - result(SqlNode, Collection<SqlImplementor.Clause>, RelNode, Map<String, RelDataType>) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Creates a result based on a single relational expression.
- result(SqlNode, SqlImplementor.Result, SqlImplementor.Result) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Creates a result based on a join.
- result(T) - Method in class org.apache.calcite.interpreter.AggregateNode.NumericComparison
- Result(PhysType, BlockStatement) - Constructor for class org.apache.calcite.adapter.spark.SparkRel.Result
- Result(BlockStatement, PhysType, JavaRowFormat) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableRel.Result
- Result(ParameterExpression, ParameterExpression) - Constructor for class org.apache.calcite.adapter.enumerable.RexToLixTranslator.Result
- Result(SqlNode, Collection<SqlImplementor.Clause>, String, RelDataType, Map<String, RelDataType>) - Constructor for class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
- Result(PrecedenceClimbingParser.Token, PrecedenceClimbingParser.Token, PrecedenceClimbingParser.Token) - Constructor for class org.apache.calcite.util.PrecedenceClimbingParser.Result
- RESULT_SET_ENUMERABLE_OF - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- RESULT_SET_ENUMERABLE_OF_PREPARED - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- RESULT_SET_ENUMERABLE_SET_TIMEOUT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- RESULT_SET_GET_DATE2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- RESULT_SET_GET_TIME2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- RESULT_SET_GET_TIMESTAMP2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ResultCheckers - Class in org.apache.calcite.sql.test
-
Utilities for
SqlTester.ResultChecker
. - resultConvention - Variable in class org.apache.calcite.prepare.Prepare
-
Convention via which results should be returned by execution.
- resultMethod - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- resultSelector(Function2<TKey, TAccumulate, TResult>) - Method in class org.apache.calcite.adapter.enumerable.BasicAggregateLambdaFactory
- resultSelector(Function2<TKey, TOrigAccumulate, TResult>) - Method in interface org.apache.calcite.adapter.enumerable.AggregateLambdaFactory
- resultSelector(Function2<TKey, TOrigAccumulate, TResult>) - Method in class org.apache.calcite.adapter.enumerable.LazyAggregateLambdaFactory
- ResultSetEnumerable<T> - Class in org.apache.calcite.runtime
-
Executes a SQL statement and returns the result as an
Enumerable
. - ResultSetEnumerable.PreparedStatementEnricher - Interface in org.apache.calcite.runtime
-
Consumer for decorating a
PreparedStatement
, that is, setting its parameters. - resultTranslator() - Method in interface org.apache.calcite.adapter.enumerable.AggResultContext
-
Returns a
RexToLixTranslator
suitable to transform the result. - resultTranslator() - Method in class org.apache.calcite.adapter.enumerable.impl.AggResultContextImpl
- resultType - Variable in class org.apache.calcite.linq4j.tree.ConstructorDeclaration
- resultType - Variable in class org.apache.calcite.linq4j.tree.MethodDeclaration
- resultType - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- retainAll(Collection<?>) - Method in class org.apache.calcite.util.ImmutableIntList
- retainAll(Collection<?>) - Method in class org.apache.calcite.sql.SqlNodeList
- retainDeterministic(List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
- rethrow() - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents a rethrowing of an exception.
- rethrow(Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents a rethrowing of an exception with a given type.
- rethrow(Throwable) - Static method in class org.apache.calcite.util.TestUtil
-
Rethrows given exception keeping stacktraces clean and compact.
- rethrow(Throwable, String) - Static method in class org.apache.calcite.util.TestUtil
-
Rethrows given exception keeping stacktraces clean and compact.
- Return - Enum constant in enum org.apache.calcite.linq4j.tree.GotoExpressionKind
-
A GotoExpression that represents a return statement.
- return_(LabelTarget) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a return statement.
- return_(LabelTarget, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a return statement.
- return_(LabelTarget, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a return statement with the specified type.
- return_(LabelTarget, Expression, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a return statement with the specified type.
- RETURN_TYPE - Static variable in class org.apache.calcite.sql.type.InferTypes
-
Operand type-inference strategy where an unknown operand type is derived from the call's return type.
- RETURNING - Enum constant in enum org.apache.calcite.sql.SqlJsonValueReturning
- returnRelType() - Method in interface org.apache.calcite.adapter.enumerable.AggContext
-
Returns the return type of the aggregate as
RelDataType
. - returnRelType() - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase.AggContextImpl
- returns(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertMetaData
- returns(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returns(String, Consumer<ResultSet>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returns(Consumer<ResultSet>) - Method in class org.apache.calcite.test.CalciteAssert.AssertMetaData
- returns(Consumer<ResultSet>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returns2(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Similar to
CalciteAssert.AssertQuery.returns(java.lang.String)
, but trims a few values before comparing. - returnsCount(int) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returnsOrdered(String...) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returnsStartingWith(String...) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returnsUnordered(String...) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returnsUnordered(String...) - Static method in class org.apache.calcite.test.Matchers
-
Creates a matcher that matches if the examined result set returns the given collection of rows in some order.
- returnsValue(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returnType() - Method in interface org.apache.calcite.adapter.enumerable.AggContext
-
Returns the return type of the aggregate as
Type
. - returnType() - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase.AggContextImpl
- ReturnTypes - Class in org.apache.calcite.sql.type
-
A collection of return-type inference strategies.
- reverse() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- reverse() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- reverse() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Inverts the order of the elements in a sequence.
- reverse() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Inverts the order of the elements in a sequence.
- reverse() - Method in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Returns the reverse of this direction.
- reverse() - Method in interface org.apache.calcite.runtime.PairList
-
Reverses the contents of this PairList.
- reverse() - Method in class org.apache.calcite.sql.SqlBinaryOperator
- reverse() - Method in enum org.apache.calcite.sql.SqlKind
-
Returns the kind that corresponds to this operator but in the opposite direction.
- reverse() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns the operator that has the same effect as this operator if its arguments are reversed.
- reverse() - Method in enum org.apache.calcite.sql.validate.SqlMonotonicity
-
Returns the reverse monotonicity.
- reverse(E...) - Static method in class org.apache.calcite.linq4j.Ord
-
Iterates over an array in reverse order.
- reverse(Iterable<? extends E>) - Static method in class org.apache.calcite.linq4j.Ord
-
Iterates over a list in reverse order.
- reverse(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL REVERSE(string) function.
- reverse(List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_REVERSE function.
- reverse(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Inverts the order of the elements in a sequence.
- reverse(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Inverts the order of the elements in a sequence.
- reverse(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Inverts the order of the elements in a sequence.
- reverse(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- reverse(SqlOperator) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Deprecated.Use
SqlOperator.reverse()
, but beware that it has slightly different semantics - REVERSE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
REVERSE
function (SQL Server, MySQL). - REVERSE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- REVERSE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- REVERSE_SPARK - Enum constant in enum org.apache.calcite.sql.SqlKind
-
REVERSE
function (Spark semantics). - REVERSE_SPARK - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "REVERSE(string|array)" function.
- reverseCall(RexCall) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
-
Reverses the order of a call, while preserving semantics, if it improves readability.
- reversed() - Method in interface org.apache.calcite.runtime.PairList
-
Returns an immutable copy of this ImmutablePairList with the elements reversed.
- revise(Class<? extends RelNode>, MetadataDef<M>) - Method in class org.apache.calcite.rel.metadata.RelMetadataQueryBase
-
Deprecated.
- revise(Class<H>) - Method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- revise(Class<H>) - Method in class org.apache.calcite.rel.metadata.RelMetadataQueryBase
-
Re-generates the handler for a given kind of metadata, adding support for
class_
if it is not already present. - revise(Class<MH>) - Method in interface org.apache.calcite.rel.metadata.MetadataHandlerProvider
-
Revise the handler for a given kind of metadata.
- rewrite(RelNode) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
-
Fallback rewrite method.
- rewrite(RelNode) - Method in class org.apache.calcite.plan.RelOptLattice
-
Rewrites a relational expression to use a lattice.
- rewrite(RelNode) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteCall(SqlValidator, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlCoalesceFunction
- rewriteCall(SqlValidator, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlDatePartFunction
- rewriteCall(SqlValidator, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlNewOperator
- rewriteCall(SqlValidator, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlNullifFunction
- rewriteCall(SqlValidator, SqlCall) - Method in class org.apache.calcite.sql.SqlBasicFunction
- rewriteCall(SqlValidator, SqlCall) - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall
- rewriteCall(SqlValidator, SqlCall) - Method in class org.apache.calcite.sql.SqlOperator
-
Rewrites a call to this operator.
- rewriteCall(SqlValidator, SqlCall) - Method in class org.apache.calcite.sql.SqlProcedureCallOperator
- rewriteCall(SqlValidator, SqlCall) - Method in interface org.apache.calcite.sql.type.SqlOperandHandler
- rewriteExpression(RexBuilder, RelMetadataQuery, RelNode, RelNode, List<RexNode>, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses, boolean, RexNode) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
First, the method takes the node expressions
nodeExprs
and swaps the table and column references using the table mapping and the equivalence classes. - rewriteExpressions(RexBuilder, RelMetadataQuery, RelNode, RelNode, List<RexNode>, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses, boolean, List<RexNode>) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
First, the method takes the node expressions
nodeExprs
and swaps the table and column references using the table mapping and the equivalence classes. - rewriteGeneric(RelNode) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteMaxMin(SqlNode, RelDataType) - Static method in class org.apache.calcite.sql.dialect.SnowflakeSqlDialect
-
Helper for rewrites of MAX/MIN.
- rewriteMaxMin(SqlNode, RelDataType) - Static method in class org.apache.calcite.sql.SqlDialect
-
Helper for rewrites of MAX/MIN.
- rewriteMaxMinExpr(SqlNode, RelDataType) - Method in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
- rewriteMaxMinExpr(SqlNode, RelDataType) - Method in class org.apache.calcite.sql.dialect.RedshiftSqlDialect
- rewriteMaxMinExpr(SqlNode, RelDataType) - Method in class org.apache.calcite.sql.dialect.SnowflakeSqlDialect
- rewriteMaxMinExpr(SqlNode, RelDataType) - Method in class org.apache.calcite.sql.SqlDialect
-
Rewrites MAX(x)/MIN(x) as BOOL_OR(x)/BOOL_AND(x) for certain database variants (Postgres and Redshift, currently).
- rewriteQuery(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, RexNode, RexNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses, MaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule
- rewriteQuery(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, RexNode, RexNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses, MaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewJoinRule
- rewriteQuery(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, RexNode, RexNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses, MaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
If the view will be used in a union rewriting, this method is responsible for rewriting the query branch of the union using the given compensation predicate.
- rewriteRel(Collect) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(Sample) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(Sort) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(TableScan) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(Uncollect) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalAggregate) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalAsofJoin) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalCalc) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalCorrelate) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalExchange) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalFilter) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalIntersect) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalJoin) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalMatch) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalMinus) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalProject) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalRepeatUnion) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalSnapshot) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalSortExchange) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalTableFunctionScan) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalTableModify) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalTableSpool) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalUnion) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalValues) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalChi) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalDelta) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(RelStructuredTypeFlattener.SelfFlatteningRel) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteSingleValueExpr(SqlNode, RelDataType) - Method in class org.apache.calcite.sql.dialect.HsqldbSqlDialect
- rewriteSingleValueExpr(SqlNode, RelDataType) - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- rewriteSingleValueExpr(SqlNode, RelDataType) - Method in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
- rewriteSingleValueExpr(SqlNode, RelDataType) - Method in class org.apache.calcite.sql.SqlDialect
-
Rewrites SINGLE_VALUE into expression based on database variants E.g.
- rewritesTo(String) - Method in class org.apache.calcite.test.SqlValidatorFixture
- rewriteView(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, MaterializedViewRule.MatchModality, boolean, RelNode, Project, RelNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule
- rewriteView(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, MaterializedViewRule.MatchModality, boolean, RelNode, Project, RelNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewJoinRule
- rewriteView(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, MaterializedViewRule.MatchModality, boolean, RelNode, Project, RelNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, MaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
Rewrites the query using the given view query.
- RexAction - Interface in org.apache.calcite.rex
-
Deprecated.
- RexAnalyzer - Class in org.apache.calcite.rex
-
Analyzes an expression, figures out what are the unbound variables, assigns a variety of values to each unbound variable, and evaluates the expression.
- RexAnalyzer(RexNode, RelOptPredicateList) - Constructor for class org.apache.calcite.rex.RexAnalyzer
-
Creates a RexAnalyzer.
- rexArguments() - Method in interface org.apache.calcite.adapter.enumerable.AggAddContext
-
Returns
RexNode
representation of arguments. - rexArguments() - Method in interface org.apache.calcite.adapter.enumerable.WinAggResultContext
-
Returns
RexNode
representation of arguments. - RexBiVisitor<R,
P> - Interface in org.apache.calcite.rex -
Visitor pattern for traversing a tree of
RexNode
objects and passing a payload to each. - RexBiVisitorImpl<R,
P> - Class in org.apache.calcite.rex -
Default implementation of
RexBiVisitor
, which visits each node but does nothing while it's there. - RexBiVisitorImpl(boolean) - Constructor for class org.apache.calcite.rex.RexBiVisitorImpl
- rexBuilder - Variable in class org.apache.calcite.plan.RelOptUtil.RexInputConverter
- rexBuilder - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- rexBuilder - Variable in class org.apache.calcite.rex.RexSimplify
- rexBuilder - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- rexBuilder - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- RexBuilder - Class in org.apache.calcite.rex
-
Factory for row expressions.
- RexBuilder(RelDataTypeFactory) - Constructor for class org.apache.calcite.rex.RexBuilder
-
Creates a RexBuilder.
- rexCall - Variable in class org.apache.calcite.rel.mutable.MutableTableFunctionScan
- RexCall - Class in org.apache.calcite.rex
-
An expression formed by a call to an operator with zero or more expressions as operands.
- RexCall(RelDataType, SqlOperator, List<? extends RexNode>) - Constructor for class org.apache.calcite.rex.RexCall
- RexCall(SqlParserPos, RelDataType, SqlOperator, List<? extends RexNode>) - Constructor for class org.apache.calcite.rex.RexCall
- RexCallBinding - Class in org.apache.calcite.rex
-
RexCallBinding
implementsSqlOperatorBinding
by referring to an underlying collection ofRexNode
operands. - RexCallBinding(RelDataTypeFactory, SqlOperator, List<? extends RexNode>, List<RelCollation>) - Constructor for class org.apache.calcite.rex.RexCallBinding
- RexChecker - Class in org.apache.calcite.rex
-
Visitor which checks the validity of a
RexNode
expression. - RexChecker(List<RelDataType>, RelNode.Context, Litmus) - Constructor for class org.apache.calcite.rex.RexChecker
-
Creates a RexChecker with a given set of input fields.
- RexChecker(RelDataType, RelNode.Context, Litmus) - Constructor for class org.apache.calcite.rex.RexChecker
-
Creates a RexChecker with a given input row type.
- RexCorrelVariable - Class in org.apache.calcite.rex
-
Reference to the current row of a correlating relational expression.
- RexDigestIncludeType - Enum in org.apache.calcite.rex
-
Defines if type information should be printed for
RexLiteral
. - RexDynamicParam - Class in org.apache.calcite.rex
-
Dynamic parameter reference in a row-expression.
- RexDynamicParam(RelDataType, int) - Constructor for class org.apache.calcite.rex.RexDynamicParam
-
Creates a dynamic parameter.
- RexExecutable - Class in org.apache.calcite.rex
-
Result of compiling code generated from a
RexNode
expression. - RexExecutable(String, Object) - Constructor for class org.apache.calcite.rex.RexExecutable
- RexExecutor - Interface in org.apache.calcite.rex
-
Can reduce expressions, writing a literal for each into a list.
- RexExecutorImpl - Class in org.apache.calcite.rex
-
Evaluates a
RexNode
expression. - RexExecutorImpl(DataContext) - Constructor for class org.apache.calcite.rex.RexExecutorImpl
- RexFieldAccess - Class in org.apache.calcite.rex
-
Access to a field of a row-expression.
- RexFieldAccessReplacer(CorrelationId, RexCorrelVariable, RexBuilder, Map<Integer, Integer>) - Constructor for class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.RexFieldAccessReplacer
- RexFieldCollation - Class in org.apache.calcite.rex
-
Expression combined with sort flags (DESCENDING, NULLS LAST).
- RexFieldCollation(RexNode, Set<SqlKind>) - Constructor for class org.apache.calcite.rex.RexFieldCollation
- rexFilterArgument() - Method in interface org.apache.calcite.adapter.enumerable.AggAddContext
-
Returns
RexNode
representation of the filter, or null. - RexImplicationChecker - Class in org.apache.calcite.plan
-
Checks whether one condition logically implies another.
- RexImplicationChecker(RexBuilder, RexExecutor, RelDataType) - Constructor for class org.apache.calcite.plan.RexImplicationChecker
- RexImplicationCheckerFixtures - Interface in org.apache.calcite.test
-
Fixtures for verifying
RexImplicationChecker
. - RexImplicationCheckerFixtures.Fixture - Class in org.apache.calcite.test
-
Contains all the nourishment a test case could possibly need.
- RexImpTable - Class in org.apache.calcite.adapter.enumerable
-
Contains implementations of Rex operators as Java code.
- RexImpTable.LagImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
LAG
windowed aggregate function. - RexImpTable.LeadImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
LEAD
windowed aggregate function. - RexImpTable.NullAs - Enum in org.apache.calcite.adapter.enumerable
-
Strategy what an operator should return if one of its arguments is null.
- RexImpTable.RexCallImplementor - Interface in org.apache.calcite.adapter.enumerable
-
Null-safe implementor of
RexCall
s. - RexImpTable.UserDefinedAggReflectiveImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for user-defined aggregate functions.
- RexInputConverter(RexBuilder, List<RelDataTypeField>, int[]) - Constructor for class org.apache.calcite.plan.RelOptUtil.RexInputConverter
- RexInputConverter(RexBuilder, List<RelDataTypeField>, List<RelDataTypeField>, int[]) - Constructor for class org.apache.calcite.plan.RelOptUtil.RexInputConverter
- RexInputConverter(RexBuilder, List<RelDataTypeField>, List<RelDataTypeField>, List<RelDataTypeField>, int[]) - Constructor for class org.apache.calcite.plan.RelOptUtil.RexInputConverter
- RexInputRef - Class in org.apache.calcite.rex
-
Variable which references a field of an input relational expression.
- RexInputRef(int, RelDataType) - Constructor for class org.apache.calcite.rex.RexInputRef
-
Creates an input variable.
- RexInterpreter - Class in org.apache.calcite.rex
-
Evaluates
RexNode
expressions. - RexLambda - Class in org.apache.calcite.rex
-
Represents a lambda expression.
- RexLambdaRef - Class in org.apache.calcite.rex
-
Variable that references a field of a lambda expression.
- RexLambdaRef(int, String, RelDataType) - Constructor for class org.apache.calcite.rex.RexLambdaRef
- rexList - Variable in class org.apache.calcite.rel.core.AggregateCall
- RexLiteral - Class in org.apache.calcite.rex
-
Constant value in a row-expression.
- RexLocalRef - Class in org.apache.calcite.rex
-
Local variable.
- RexLocalRef(int, RelDataType) - Constructor for class org.apache.calcite.rex.RexLocalRef
-
Creates a local variable.
- RexMultisetUtil - Class in org.apache.calcite.rex
-
Utility class for various methods related to multisets.
- RexNode - Class in org.apache.calcite.rex
-
Row expression.
- RexNode() - Constructor for class org.apache.calcite.rex.RexNode
- RexNormalize - Class in org.apache.calcite.rex
-
Context required to normalize a row-expression.
- RexOver - Class in org.apache.calcite.rex
-
Call to an aggregate function over a window.
- RexPattern - Interface in org.apache.calcite.rex
-
Deprecated.
- RexPatternFieldRef - Class in org.apache.calcite.rex
-
Variable that references a field of an input relational expression.
- RexPatternFieldRef(String, int, RelDataType) - Constructor for class org.apache.calcite.rex.RexPatternFieldRef
- RexPermutationShuttle - Class in org.apache.calcite.rex
-
Visitor which replaces
RexLocalRef
objects after the expressions in aRexProgram
have been reordered. - RexPermutationShuttle(Permutation) - Constructor for class org.apache.calcite.rex.RexPermutationShuttle
- RexPermuteInputsShuttle - Class in org.apache.calcite.rex
-
Shuttle which applies a permutation to its input fields.
- RexPermuteInputsShuttle(Mappings.TargetMapping, RelNode...) - Constructor for class org.apache.calcite.rex.RexPermuteInputsShuttle
-
Creates a RexPermuteInputsShuttle.
- RexProgram - Class in org.apache.calcite.rex
-
A collection of expressions which read inputs, compute output expressions, and optionally use a condition to filter rows.
- RexProgram(RelDataType, List<? extends RexNode>, List<RexLocalRef>, RexLocalRef, RelDataType) - Constructor for class org.apache.calcite.rex.RexProgram
-
Creates a program.
- RexProgramBuilder - Class in org.apache.calcite.rex
-
Workspace for constructing a
RexProgram
. - RexProgramBuilder(RelDataType, RexBuilder) - Constructor for class org.apache.calcite.rex.RexProgramBuilder
-
Creates a program-builder that will not simplify.
- RexRangeRef - Class in org.apache.calcite.rex
-
Reference to a range of columns.
- RexShuttle - Class in org.apache.calcite.rex
-
Passes over a row-expression, calling a handler method for each node, appropriate to the type of the node.
- RexShuttle() - Constructor for class org.apache.calcite.rex.RexShuttle
- RexSimplify - Class in org.apache.calcite.rex
-
Context required to simplify a row-expression.
- RexSimplify(RexBuilder, boolean, RexExecutor) - Constructor for class org.apache.calcite.rex.RexSimplify
-
Deprecated.
- RexSimplify(RexBuilder, RelOptPredicateList, boolean, RexExecutor) - Constructor for class org.apache.calcite.rex.RexSimplify
-
Deprecated.
- RexSimplify(RexBuilder, RelOptPredicateList, RexExecutor) - Constructor for class org.apache.calcite.rex.RexSimplify
-
Creates a RexSimplify.
- RexSlot - Class in org.apache.calcite.rex
- RexSlot(String, int, RelDataType) - Constructor for class org.apache.calcite.rex.RexSlot
-
Creates a slot.
- RexSlot.SelfPopulatingList - Class in org.apache.calcite.rex
-
Thread-safe list that populates itself if you make a reference beyond the end of the list.
- RexSqlConvertlet - Interface in org.apache.calcite.rex
- RexSqlConvertletTable - Interface in org.apache.calcite.rex
-
Collection of
RexSqlConvertlet
s. - RexSqlReflectiveConvertletTable - Class in org.apache.calcite.rex
-
Implementation of
RexSqlConvertletTable
. - RexSqlReflectiveConvertletTable() - Constructor for class org.apache.calcite.rex.RexSqlReflectiveConvertletTable
- RexSqlStandardConvertletTable - Class in org.apache.calcite.rex
-
Standard implementation of
RexSqlConvertletTable
. - RexSqlStandardConvertletTable() - Constructor for class org.apache.calcite.rex.RexSqlStandardConvertletTable
- RexSubQuery - Class in org.apache.calcite.rex
-
Scalar expression that represents an IN, EXISTS or scalar sub-query.
- RexTableInputRef - Class in org.apache.calcite.rex
-
Variable which references a column of a table occurrence in a relational plan.
- RexTableInputRef.RelTableRef - Class in org.apache.calcite.rex
-
Identifies uniquely a table by its qualified name and its entity number (occurrence).
- RexToLixTranslator - Class in org.apache.calcite.adapter.enumerable
-
Translates
REX expressions
tolinq4j expressions
. - RexToLixTranslator.InputGetter - Interface in org.apache.calcite.adapter.enumerable
-
Translates a field of an input to an expression.
- RexToLixTranslator.InputGetterImpl - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
RexToLixTranslator.InputGetter
that callsPhysType.fieldReference(org.apache.calcite.linq4j.tree.Expression, int)
. - RexToLixTranslator.Result - Class in org.apache.calcite.adapter.enumerable
-
Result of translating a
RexNode
. - RexToSqlNodeConverter - Interface in org.apache.calcite.rex
- RexToSqlNodeConverterImpl - Class in org.apache.calcite.rex
-
Standard implementation of
RexToSqlNodeConverter
. - RexToSqlNodeConverterImpl(RexSqlConvertletTable) - Constructor for class org.apache.calcite.rex.RexToSqlNodeConverterImpl
- RexTransformer - Class in org.apache.calcite.rex
-
Takes a tree of
RexNode
objects and transforms it into another in one sense equivalent tree. - RexTransformer(RexNode, RexBuilder) - Constructor for class org.apache.calcite.rex.RexTransformer
- RexUnaryBiVisitor<R> - Class in org.apache.calcite.rex
-
Default implementation of a
RexBiVisitor
whose payload and return type are the same. - RexUnaryBiVisitor(boolean) - Constructor for class org.apache.calcite.rex.RexUnaryBiVisitor
-
Creates a RexUnaryBiVisitor.
- RexUnknownAs - Enum in org.apache.calcite.rex
-
Policy for whether a simplified expression may instead return another value.
- RexUtil - Class in org.apache.calcite.rex
-
Utility methods concerning row-expressions.
- RexUtil.ExprSimplifier - Class in org.apache.calcite.rex
-
Deprecated.
- RexUtil.FieldAccessFinder - Class in org.apache.calcite.rex
-
Visitor which builds a bitmap of the inputs used by an expression.
- RexUtil.FixNullabilityShuttle - Class in org.apache.calcite.rex
-
Shuttle that fixes up an expression to match changes in nullability of input fields.
- RexUtil.RexFinder - Class in org.apache.calcite.rex
-
Visitor that tells whether a node matching a particular description exists in a tree.
- RexUtil.SubQueryCollector - Class in org.apache.calcite.rex
-
Visitor that collects all the top level SubQueries
RexSubQuery
in a projection list of a givenProject
. - RexUtil.SubQueryFinder - Class in org.apache.calcite.rex
-
Visitor that throws
Util.FoundOne
if applied to an expression that contains aRexSubQuery
. - RexVariable - Class in org.apache.calcite.rex
-
A row-expression which references a field.
- RexVariable(String, RelDataType) - Constructor for class org.apache.calcite.rex.RexVariable
- RexVisitor<R> - Interface in org.apache.calcite.rex
-
Visitor pattern for traversing a tree of
RexNode
objects. - RexVisitorImpl<R> - Class in org.apache.calcite.rex
-
Default implementation of
RexVisitor
, which visits each node but does nothing while it's there. - RexVisitorImpl(boolean) - Constructor for class org.apache.calcite.rex.RexVisitorImpl
- RexWinAggCall(SqlAggFunction, RelDataType, List<RexNode>, int, boolean) - Constructor for class org.apache.calcite.rel.core.Window.RexWinAggCall
-
Deprecated.
- RexWinAggCall(SqlAggFunction, RelDataType, List<RexNode>, int, boolean, boolean) - Constructor for class org.apache.calcite.rel.core.Window.RexWinAggCall
-
Creates a RexWinAggCall.
- RexWindow - Class in org.apache.calcite.rex
-
Specification of the window of rows over which a
RexOver
windowed aggregate is evaluated. - RexWindowBound - Class in org.apache.calcite.rex
-
Abstracts "XX PRECEDING/FOLLOWING" and "CURRENT ROW" bounds for windowed aggregates.
- RexWindowBound() - Constructor for class org.apache.calcite.rex.RexWindowBound
- RexWindowBounds - Class in org.apache.calcite.rex
-
Helpers for
RexWindowBound
. - RexWindowExclusion - Enum in org.apache.calcite.rex
-
Representation of different kinds of exclude clause in window functions.
- right - Variable in class org.apache.calcite.rel.BiRel
- right - Variable in class org.apache.calcite.rel.mutable.MutableJoin
- right - Variable in class org.apache.calcite.util.Pair
- right(int) - Method in interface org.apache.calcite.runtime.PairList
-
Returns the right part of the
index
th pair. - right(Iterable<? extends Map.Entry<? extends L, ? extends R>>) - Static method in class org.apache.calcite.util.Pair
-
Returns an iterable over the right slice of an iterable.
- right(String, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL RIGHT(string, integer) function.
- right(List<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class org.apache.calcite.util.Pair
- right(List<IntPair>) - Static method in class org.apache.calcite.util.mapping.IntPair
-
Returns the right side of a list of pairs.
- right(ByteString, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL RIGHT(ByteString, integer) function.
- RIGHT - Enum constant in enum org.apache.calcite.linq4j.JoinType
-
Right-outer join.
- RIGHT - Enum constant in enum org.apache.calcite.rel.core.JoinRelType
-
Right-outer join.
- RIGHT - Enum constant in enum org.apache.calcite.sql.JoinType
-
Right outer join.
- RIGHT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- RIGHT - Static variable in interface org.apache.calcite.rel.rules.JoinProjectTransposeRule.Config
- RIGHT - Static variable in interface org.apache.calcite.rel.rules.JoinPushThroughJoinRule.Config
- RIGHT - Static variable in class org.apache.calcite.rel.rules.JoinPushThroughJoinRule
-
Instance of the rule that works on logical joins only, and pushes to the right.
- RIGHT - Static variable in interface org.apache.calcite.rel.rules.JoinUnionTransposeRule.Config
- RIGHT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- RIGHT - Static variable in class org.apache.calcite.util.mapping.IntPair
-
Deprecated.
- RIGHT_FIRST - Enum constant in enum org.apache.calcite.plan.DeriveMode
-
Uses the right most child's traits to decide what traits to require from the other children.
- RIGHT_OUTER - Static variable in interface org.apache.calcite.rel.rules.JoinProjectTransposeRule.Config
- RIGHT_PROJECT - Static variable in interface org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule.Config
- rightInferredPredicates - Variable in class org.apache.calcite.plan.RelOptPredicateList
-
Predicates that were inferred from the left input.
- rightKeys - Variable in class org.apache.calcite.rel.core.EquiJoin
-
Deprecated.
- rightKeys - Variable in class org.apache.calcite.rel.core.JoinInfo
- rightList() - Method in interface org.apache.calcite.runtime.PairList
-
Returns an unmodifiable list view consisting of the right entry of each pair.
- rightPrec(int, boolean) - Static method in class org.apache.calcite.sql.SqlOperator
- rightSet() - Method in class org.apache.calcite.rel.core.JoinInfo
- rightShift(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise right-shift operation.
- rightShift(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise right-shift operation.
- RightShift - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise right-shift operation, such as (a >*gt; b).
- rightShiftAssign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise right-shift assignment operation.
- rightShiftAssign(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise right-shift assignment operation.
- rightShiftAssign(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise right-shift assignment operation.
- RightShiftAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise right-shift compound assignment operation, such as (a >>= b).
- rightTrim(String, char) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Deprecated.
- rlike(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.RegexFunction
-
SQL
RLIKE
function. - RLIKE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
RLIKE
operator. - RLIKE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- RLIKE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The regex variant of the LIKE operator.
- rollback(Meta.ConnectionHandle) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- ROLLBACK - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ROLLBACK
session control statement. - rolledUpColumns - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.adapter.druid.DruidTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.adapter.kafka.KafkaStreamTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.schema.impl.AbstractTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in interface org.apache.calcite.schema.Table
-
Determines whether the given rolled up column can be used inside the given aggregate function.
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions.ExplodeTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions.GridTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.test.schemata.orderstream.BaseOrderStreamTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.test.schemata.orderstream.OrdersTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.test.schemata.orderstream.ProductsTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.test.schemata.orderstream.ProductsTemporalTable
- rolledUpNotAllowed(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- rollup(List<ImmutableBitSet>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Computes the rollup of bit sets.
- ROLLUP - Enum constant in enum org.apache.calcite.rel.core.Aggregate.Group
- ROLLUP - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The internal
ROLLUP
operator that occurs within aGROUP BY
clause. - ROLLUP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
ROLLUP
operator, occurs withinGROUP BY
clause or nested within aGROUPING SETS
. - RomanNumeralsCompiledPattern - Class in org.apache.calcite.util.format.postgresql.format.compiled
-
The date/time format compiled component for the roman numeral representation of a month.
- RomanNumeralsCompiledPattern(Set<PatternModifier>, boolean) - Constructor for class org.apache.calcite.util.format.postgresql.format.compiled.RomanNumeralsCompiledPattern
- RomanNumeralsFormatPattern - Class in org.apache.calcite.util.format.postgresql.format
-
The date/time format component for the roman numeral representation of a month.
- RomanNumeralsFormatPattern(String) - Constructor for class org.apache.calcite.util.format.postgresql.format.RomanNumeralsFormatPattern
- root - Variable in class org.apache.calcite.interpreter.Context
- root - Variable in class org.apache.calcite.jdbc.CalcitePrepare.ConvertResult
- root - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
- root - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- root() - Method in class org.apache.calcite.jdbc.CalciteSchema
- root() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- ROOT - Static variable in interface org.apache.calcite.DataContext
- rootNode - Variable in class org.apache.calcite.materialize.Lattice
- rootRel - Variable in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- rootRel - Variable in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- rootSchema - Variable in class org.apache.calcite.jdbc.CalcitePrepare.CalciteSignature
- rootSchema - Variable in class org.apache.calcite.materialize.Lattice
- rootSchema - Variable in class org.apache.calcite.prepare.CalciteCatalogReader
- rootTable() - Method in class org.apache.calcite.plan.RelOptLattice
- round(double) - Static method in class org.apache.calcite.util.NumberUtil
- round(int) - Method in class org.apache.calcite.util.TimestampString
-
Returns this value rounded to
precision
decimal digits after the point. - round(int) - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
- round(int) - Method in class org.apache.calcite.util.TimeString
- round(int) - Method in class org.apache.calcite.util.TimeWithTimeZoneString
- round(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper for rounding.
- round(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper for rounding.
- ROUND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
ROUND(numeric [, integer])
function. - ROUND_INT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ROUND_LONG - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ROUND_ROBIN_DISTRIBUTED - Enum constant in enum org.apache.calcite.rel.RelDistribution.Type
-
There are multiple instances of the stream, and records are assigned to instances in turn.
- ROUND_ROBIN_DISTRIBUTED - Static variable in class org.apache.calcite.rel.RelDistributions
-
The singleton round-robin distribution.
- ROUNDING_MODE_HALF_UP - Static variable in class org.apache.calcite.test.CustomTypeSystems
-
Type system with rounding behavior
RoundingMode.HALF_UP
. - roundingMode() - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- roundingMode() - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns the rounding behavior for numerical operations capable of discarding precision.
- roundingMode() - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- Row - Class in org.apache.calcite.interpreter
-
Row.
- ROW - Enum constant in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
-
See
Row
. - ROW - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The row-constructor function.
- ROW - Enum constant in enum org.apache.calcite.sql.TableCharacteristic.Semantics
-
Row semantics means that the result of the Window TableFunction is decided on a row-by-row basis.
- ROW - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- ROW - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ROW_AS_COPY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ROW_COPY_VALUES - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ROW_COUNT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ROW_NUMBER - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ROW_NUMBER
window function. - ROW_NUMBER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
ROW_NUMBER
window function. - ROW_VALUE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- Row.RowBuilder - Class in org.apache.calcite.interpreter
-
Utility class to build row objects.
- rowCount - Variable in class org.apache.calcite.profile.Profiler.Profile
- rowCount - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- RowCount(int) - Constructor for class org.apache.calcite.profile.Profiler.RowCount
- rowCountEstimate - Variable in class org.apache.calcite.materialize.Lattice
- rowCountEstimate - Variable in class org.apache.calcite.model.JsonLattice
-
Estimated number of rows.
- rowCountEstimate(double) - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Sets the "rowCountEstimate" attribute (default null).
- rowDataType(String) - Method in interface org.apache.calcite.adapter.kafka.KafkaRowConverter
-
Generates the row type for a given Kafka topic.
- rowDataType(String) - Method in class org.apache.calcite.adapter.kafka.KafkaRowConverterImpl
-
Generates the row schema for a given Kafka topic.
- ROWID - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- rowInFrame(Expression) - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- rowInFrame(Expression) - Method in interface org.apache.calcite.adapter.enumerable.WinAggFrameResultContext
-
Returns boolean the expression that checks if the given index is in the frame bounds.
- rowInPartition(Expression) - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- rowInPartition(Expression) - Method in interface org.apache.calcite.adapter.enumerable.WinAggFrameResultContext
-
Returns boolean the expression that checks if the given index is in the partition bounds.
- rowMustBeNonNegativeIntegral() - Method in interface org.apache.calcite.runtime.CalciteResource
- rowsBetween(RexWindowBound, RexWindowBound) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets a RANGE window with lower and upper bounds, equivalent to SQL
ROWS BETWEEN lower ROW AND upper
. - rowsFrom(RexWindowBound) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets a ROWS window with a lower bound, equivalent to SQL
ROWS BETWEEN lower AND CURRENT ROW
. - rowsTo(RexWindowBound) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets a ROWS window with an upper bound, equivalent to SQL
ROWS BETWEEN CURRENT ROW AND upper
. - rowsUnbounded() - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets an unbounded ROWS window, equivalent to SQL
ROWS BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING
. - rowTranslator() - Method in interface org.apache.calcite.adapter.enumerable.AggAddContext
-
Returns a
RexToLixTranslator
suitable to transform the arguments. - rowTranslator() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggAddContextImpl
- rowTranslator(Expression) - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- rowTranslator(Expression) - Method in interface org.apache.calcite.adapter.enumerable.WinAggFrameResultContext
-
Returns row translator for given absolute row position.
- rowType - Variable in class org.apache.calcite.jdbc.CalcitePrepare.CalciteSignature
- rowType - Variable in class org.apache.calcite.jdbc.CalcitePrepare.ParseResult
- rowType - Variable in class org.apache.calcite.plan.RelOptAbstractTable
- rowType - Variable in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- rowType - Variable in class org.apache.calcite.rel.AbstractRelNode
-
Cached type of this relational expression.
- rowType - Variable in class org.apache.calcite.rel.mutable.MutableRel
- rowType - Variable in class org.apache.calcite.sql.validate.IdentifierNamespace
-
Type of the output row, which comprises the name and type of each output column.
- rowType - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- rowType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- rowType() - Method in class org.apache.calcite.rel.core.Collect
-
Returns the row type, guaranteed not null.
- rowType() - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.Resolve
-
The row type of the found namespace, nullable if the lookup has looked into outer joins.
- rowTypeCoercion(SqlValidatorScope, SqlNode, int, RelDataType) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Widen a SqlNode ith column type to target type, mainly used for set operations like UNION, INTERSECT and EXCEPT.
- rowTypeCoercion(SqlValidatorScope, SqlNode, int, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
-
Widen a SqlNode's field type to common type, mainly used for set operations like UNION, INTERSECT and EXCEPT.
- rpad(String, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
RPAD(string, integer)
function. - rpad(String, int) - Static method in class org.apache.calcite.util.Util
-
Deprecated.Use
Spaces.padRight(String, int)
- rpad(String, int, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
RPAD(string, integer, string)
function. - rpad(ByteString, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
RPAD(binary, integer)
function. - rpad(ByteString, int, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
RPAD(binary, integer, binary)
function. - RPAD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- RPAD - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "RPAD(original_value, return_length[, pattern])" function.
- rtrim() - Method in class org.apache.calcite.util.NlsString
-
Returns a string the same as this but with spaces trimmed from the right.
- rtrim(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
RTRIM
function applied to string. - rtrim(String) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- rtrim(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper for CAST.
- RTRIM - Enum constant in enum org.apache.calcite.sql.SqlKind
-
RTRIM
function (Oracle). - RTRIM - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- RTRIM - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
Deprecated.
- RTRIM - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "RTRIM(string)" function.
- rule - Variable in class org.apache.calcite.plan.RelOptRuleCall
- rule - Variable in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRuleCall
- RULE_SET - Static variable in class org.apache.calcite.tools.Programs
- ruleAttempted(RelOptListener.RuleAttemptedEvent) - Method in class org.apache.calcite.plan.MulticastRelOptListener
- ruleAttempted(RelOptListener.RuleAttemptedEvent) - Method in interface org.apache.calcite.plan.RelOptListener
-
Notifies this listener that an optimizer rule is being applied to a particular relational expression.
- ruleAttempted(RelOptListener.RuleAttemptedEvent) - Method in class org.apache.calcite.plan.RuleEventLogger
- ruleAttempted(RelOptListener.RuleAttemptedEvent) - Method in class org.apache.calcite.plan.visualizer.RuleMatchVisualizer
- RuleAttemptedEvent(Object, RelNode, RelOptRuleCall, boolean) - Constructor for class org.apache.calcite.plan.RelOptListener.RuleAttemptedEvent
- RuleEvent(Object, RelNode, RelOptRuleCall) - Constructor for class org.apache.calcite.plan.RelOptListener.RuleEvent
- RuleEventLogger - Class in org.apache.calcite.plan
-
Listener for logging useful debugging information on certain rule events.
- RuleEventLogger() - Constructor for class org.apache.calcite.plan.RuleEventLogger
- ruleFactory() - Method in interface org.apache.calcite.rel.convert.ConverterRule.Config
- RuleMatchVisualizer - Class in org.apache.calcite.plan.visualizer
-
This is a tool to visualize the rule match process of a RelOptPlanner.
- RuleMatchVisualizer() - Constructor for class org.apache.calcite.plan.visualizer.RuleMatchVisualizer
-
Use this constructor when the result shall not be written to disk.
- RuleMatchVisualizer(String, String) - Constructor for class org.apache.calcite.plan.visualizer.RuleMatchVisualizer
-
Use this constructor to save the result on disk at the end of the planning phase.
- RuleProductionEvent(Object, RelNode, RelOptRuleCall, boolean) - Constructor for class org.apache.calcite.plan.RelOptListener.RuleProductionEvent
- ruleProductionSucceeded(RelOptListener.RuleProductionEvent) - Method in class org.apache.calcite.plan.MulticastRelOptListener
- ruleProductionSucceeded(RelOptListener.RuleProductionEvent) - Method in interface org.apache.calcite.plan.RelOptListener
-
Notifies this listener that an optimizer rule has been successfully applied to a particular relational expression, resulting in a new equivalent expression (relEquivalenceFound will also be called unless the new expression is identical to an existing one).
- ruleProductionSucceeded(RelOptListener.RuleProductionEvent) - Method in class org.apache.calcite.plan.RuleEventLogger
- ruleProductionSucceeded(RelOptListener.RuleProductionEvent) - Method in class org.apache.calcite.plan.visualizer.RuleMatchVisualizer
- RuleQueue - Class in org.apache.calcite.plan.volcano
-
A data structure that manages rule matches for RuleDriver.
- RuleQueue(VolcanoPlanner) - Constructor for class org.apache.calcite.plan.volcano.RuleQueue
- rules() - Static method in class org.apache.calcite.adapter.enumerable.EnumerableRules
- rules() - Static method in class org.apache.calcite.adapter.spark.SparkRules
- rules() - Static method in class org.apache.calcite.rel.rules.MeasureRules
-
Returns all rules.
- rules(JdbcConvention) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules
-
Creates a list of rules with the given JDBC convention instance.
- rules(JdbcConvention, RelBuilderFactory) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules
-
Creates a list of rules with the given JDBC convention instance and builder factory.
- RULES - Static variable in class org.apache.calcite.adapter.arrow.ArrowRules
- RULES - Static variable in class org.apache.calcite.adapter.cassandra.CassandraRules
- RULES - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- RULES - Static variable in class org.apache.calcite.adapter.innodb.InnodbRules
- RULES - Static variable in class org.apache.calcite.adapter.mongodb.MongoRules
- RULES - Static variable in class org.apache.calcite.interpreter.Bindables
-
All rules that convert logical relational expression to bindable.
- RULES - Static variable in class org.apache.calcite.rel.stream.StreamRules
- RuleSet - Interface in org.apache.calcite.tools
-
A set rules associated with a particular type of invocation of the
Planner
. - ruleSets(List<RuleSet>) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- ruleSets(RuleSet...) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- RuleSets - Class in org.apache.calcite.tools
-
Utilities for creating and composing rule sets.
- run() - Method in class org.apache.calcite.interpreter.AggregateNode
- run() - Method in class org.apache.calcite.interpreter.CollectNode
- run() - Method in class org.apache.calcite.interpreter.FilterNode
- run() - Method in class org.apache.calcite.interpreter.JoinNode
- run() - Method in class org.apache.calcite.interpreter.MatchNode
- run() - Method in interface org.apache.calcite.interpreter.Node
- run() - Method in class org.apache.calcite.interpreter.ProjectNode
- run() - Method in class org.apache.calcite.interpreter.SetOpNode
- run() - Method in class org.apache.calcite.interpreter.SortNode
- run() - Method in class org.apache.calcite.interpreter.TableFunctionScanNode
- run() - Method in class org.apache.calcite.interpreter.TableScanNode
- run() - Method in class org.apache.calcite.interpreter.UncollectNode
- run() - Method in class org.apache.calcite.interpreter.UnionNode
-
Deprecated.
- run() - Method in class org.apache.calcite.interpreter.ValuesNode
- run() - Method in class org.apache.calcite.interpreter.WindowNode
- run() - Method in class org.apache.calcite.util.Benchmark
- run(Object) - Method in enum org.apache.calcite.runtime.Hook
-
Runs all handlers registered for this Hook, with the given argument.
- run(RelOptPlanner, RelNode, RelTraitSet, List<RelOptMaterialization>, List<RelOptLattice>) - Method in interface org.apache.calcite.tools.Program
- run(RelNode) - Static method in class org.apache.calcite.tools.RelRunners
-
Runs a relational expression by creating a JDBC connection.
- RUNNING - Enum constant in enum org.apache.calcite.sql.SqlKind
-
FINAL
operator inMATCH_RECOGNIZE
. - RUNNING - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
RUNNING
function to be used withinMATCH_RECOGNIZE
. - runs() - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- RUNTIME - Enum constant in enum org.apache.calcite.sql.test.SqlTests.Stage
- runtimeVariables(Iterable<? extends ParameterExpression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an instance of RuntimeVariablesExpression.
- runtimeVariables(ParameterExpression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an instance of RuntimeVariablesExpression, using varargs.
- RuntimeVariables - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A list of run-time variables.
S
- s - Variable in class org.apache.calcite.util.Smalls.IntString
- safe - Variable in class org.apache.calcite.sql.fun.SqlItemOperator
- SAFE_ADD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SAFE_ADD - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "SAFE_ADD(numeric1, numeric2)" function; equivalent to the
+
operator but returns null if overflow occurs. - SAFE_CAST - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
SAFE_CAST
function, which is similar toSqlKind.CAST
but returns NULL rather than throwing an error if the conversion fails. - SAFE_CAST - Enum constant in enum org.apache.calcite.sql.test.SqlOperatorFixture.CastType
- SAFE_CAST - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "SAFE_CAST(expr AS type)" function; identical to CAST(), except that if conversion fails, it returns NULL instead of raising an error.
- SAFE_DIVIDE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SAFE_DIVIDE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "SAFE_DIVIDE(numeric1, numeric2)" function; equivalent to the
/
operator but returns null if an error occurs, such as overflow or division by zero. - SAFE_MULTIPLY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SAFE_MULTIPLY - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "SAFE_MULTIPLY(numeric1, numeric2)" function; equivalent to the
*
operator but returns null if overflow occurs. - SAFE_NEGATE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "SAFE_NEGATE(numeric)" function; negates
numeric
and returns null if overflow occurs. - SAFE_OFFSET - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "SAFE_OFFSET(index)" array subscript operator used by BigQuery.
- SAFE_ORDINAL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "SAFE_ORDINAL(index)" array subscript operator used by BigQuery.
- SAFE_SUBTRACT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SAFE_SUBTRACT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "SAFE_SUBTRACT(numeric1, numeric2)" function; equivalent to the
-
operator but returns null if overflow occurs. - safeAdd(double, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_ADD
function applied to double values. - safeAdd(double, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_ADD
function applied to double and long values. - safeAdd(double, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_ADD
function applied to double and BigDecimal values. - safeAdd(long, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_ADD
function applied to long and double values. - safeAdd(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_ADD
function applied to long values. - safeAdd(long, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_ADD
function applied to long and BigDecimal values. - safeAdd(BigDecimal, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_ADD
function applied to BigDecimal and double values. - safeAdd(BigDecimal, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_ADD
function applied to BigDecimal and long values. - safeAdd(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_ADD
function applied to BigDecimal values. - safeDivide(double, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_DIVIDE
function applied to double values. - safeDivide(double, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_DIVIDE
function applied to double and long values. - safeDivide(double, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_DIVIDE
function applied to double and BigDecimal values. - safeDivide(long, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_DIVIDE
function applied to long and double values. - safeDivide(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_MULTIPLY
function applied to long values. - safeDivide(long, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_DIVIDE
function applied to long and BigDecimal values. - safeDivide(BigDecimal, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_DIVIDE
function applied to BigDecimal and double values. - safeDivide(BigDecimal, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_DIVIDE
function applied to BigDecimal and long values. - safeDivide(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_DIVIDE
function applied to BigDecimal values. - safeMultiply(double, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_MULTIPLY
function applied to double values. - safeMultiply(double, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_MULTIPLY
function applied to double and long values. - safeMultiply(double, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_MULTIPLY
function applied to double and BigDecimal values. - safeMultiply(long, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_MULTIPLY
function applied to long and double values. - safeMultiply(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_MULTIPLY
function applied to long values. - safeMultiply(long, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_MULTIPLY
function applied to long and BigDecimal values. - safeMultiply(BigDecimal, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_MULTIPLY
function applied to BigDecimal and double values. - safeMultiply(BigDecimal, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_MULTIPLY
function applied to BigDecimal and long values. - safeMultiply(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_MULTIPLY
function applied to BigDecimal values. - safeSubtract(double, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_SUBTRACT
function applied to double values. - safeSubtract(double, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_SUBTRACT
function applied to double and long values. - safeSubtract(double, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_SUBTRACT
function applied to double and BigDecimal values. - safeSubtract(long, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_SUBTRACT
function applied to long and double values. - safeSubtract(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_SUBTRACT
function applied to long values. - safeSubtract(long, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_SUBTRACT
function applied to long and BigDecimal values. - safeSubtract(BigDecimal, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_SUBTRACT
function applied to BigDecimal and double values. - safeSubtract(BigDecimal, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_SUBTRACT
function applied to BigDecimal and long values. - safeSubtract(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SAFE_SUBTRACT
function applied to BigDecimal values. - SaffronProperties - Interface in org.apache.calcite.util
-
Deprecated.As of release 1.19, replaced by
CalciteSystemProperty
- SaffronProperties.Helper - Class in org.apache.calcite.util
-
Deprecated.Helper class.
- salary - Variable in class org.apache.calcite.test.schemata.hr.Employee
- sale0 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale1 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale10 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale100 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale101 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale102 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale103 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale104 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale105 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale106 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale107 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale108 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale109 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale11 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale110 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale111 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale112 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale113 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale114 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale115 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale116 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale117 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale118 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale119 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale12 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale120 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale121 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale122 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale123 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale124 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale125 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale126 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale127 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale128 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale129 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale13 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale130 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale131 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale132 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale133 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale134 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale135 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale136 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale137 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale138 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale139 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale14 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale140 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale141 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale142 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale143 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale144 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale145 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale146 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale147 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale148 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale149 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale15 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale150 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale151 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale152 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale153 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale154 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale155 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale156 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale157 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale158 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale159 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale16 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale160 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale161 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale162 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale163 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale164 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale165 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale166 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale167 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale168 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale169 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale17 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale170 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale171 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale172 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale173 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale174 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale175 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale176 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale177 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale178 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale179 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale18 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale180 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale181 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale182 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale183 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale184 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale185 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale186 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale187 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale188 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale189 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale19 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale190 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale191 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale192 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale193 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale194 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale195 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale196 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale197 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale198 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale199 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale2 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale20 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale21 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale22 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale23 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale24 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale25 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale26 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale27 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale28 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale29 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale3 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale30 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale31 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale32 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale33 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale34 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale35 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale36 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale37 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale38 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale39 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale4 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale40 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale41 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale42 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale43 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale44 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale45 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale46 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale47 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale48 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale49 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale5 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale50 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale51 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale52 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale53 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale54 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale55 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale56 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale57 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale58 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale59 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale6 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale60 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale61 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale62 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale63 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale64 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale65 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale66 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale67 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale68 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale69 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale7 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale70 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale71 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale72 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale73 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale74 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale75 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale76 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale77 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale78 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale79 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale8 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale80 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale81 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale82 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale83 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale84 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale85 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale86 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale87 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale88 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale89 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale9 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale90 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale91 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale92 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale93 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale94 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale95 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale96 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale97 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale98 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale99 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sales_fact_1997 - Variable in class org.apache.calcite.test.schemata.foodmart.FoodmartSchema
- SalesFact(int, int) - Constructor for class org.apache.calcite.test.schemata.foodmart.FoodmartSchema.SalesFact
- same() - Method in class org.apache.calcite.sql.parser.SqlParserFixture
- same(int, int...) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where a given list of operands must all have the same type.
- SAME_PARTITION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SAME_PARTITION
pseudo-function. - SAME_PARTITION - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
SAME_PARTITION
operator takes a number of expressions and returns whether the values of those expressions in current row are all the same as the values of those expressions in the 'anchor' row of a call toSqlInternalOperators.M2X
. - SAME_SAME - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where two operands must both be in the same type family.
- SAME_SAME_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- SAME_SAME_SAME - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where three operands must all be in the same type family.
- SAME_VARIADIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where any number of operands must all be in the same type family.
- sameNamedType(RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Tests whether two types have the same name and structure, possibly with differing modifiers.
- SameOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Parameter type-checking strategy where the type of operand I must be comparable with the type of operand I-1, for all legal values of I.
- SameOperandTypeChecker(int) - Constructor for class org.apache.calcite.sql.type.SameOperandTypeChecker
- SameOperandTypeExceptLastOperandChecker - Class in org.apache.calcite.sql.type
-
Parameter type-checking strategy where all operand types except last one must be the same.
- SameOperandTypeExceptLastOperandChecker(int, String) - Constructor for class org.apache.calcite.sql.type.SameOperandTypeExceptLastOperandChecker
- sameResultWithMaterializationsDisabled() - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- sample(boolean, BigDecimal, Integer) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Sample
. - Sample - Class in org.apache.calcite.rel.core
-
Relational expression that returns a sample of the rows from its input.
- Sample(RelOptCluster, RelNode, RelOptSamplingParameters) - Constructor for class org.apache.calcite.rel.core.Sample
- Sample(RelInput) - Constructor for class org.apache.calcite.rel.core.Sample
-
Creates a Sample by parsing serialized output.
- SAMPLE_TO_FILTER - Static variable in class org.apache.calcite.rel.rules.CoreRules
- sampleFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- sampleRate - Variable in class org.apache.calcite.plan.RelOptSamplingParameters
- sampleRate - Variable in class org.apache.calcite.sql.SqlSampleSpec.SqlTableSampleSpec
- SampleToFilterRule - Class in org.apache.calcite.rel.rules
- SampleToFilterRule(SampleToFilterRule.Config) - Constructor for class org.apache.calcite.rel.rules.SampleToFilterRule
- SampleToFilterRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- sampleValue(SqlNode) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Extracts the
SqlSampleSpec
value from a symbol literal. - sanitizeRangeSet(String) - Static method in class org.apache.calcite.test.Matchers
-
Changes all '‥' (a unicode symbol denoting a range) to '..', consistent with Guava 29+.
- sap - Variable in class org.apache.calcite.sql.parser.SqlParserFixture
- sap - Variable in class org.apache.calcite.test.SqlValidatorFixture
- Sarg<C extends Comparable<C>> - Class in org.apache.calcite.util
-
Set of values (or ranges) that are the target of a search.
- SARG - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- sargFromJson(Map<String, Object>) - Static method in class org.apache.calcite.rel.externalize.RelJson
-
Converts a JSON object to a
Sarg
. - sargRef(RexBuilder, RexNode, Sarg<C>, RelDataType, RexUnknownAs) - Static method in class org.apache.calcite.rex.RexUtil
- satisfies(RelTrait) - Method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- satisfies(RelTrait) - Method in enum org.apache.calcite.interpreter.BindableConvention
- satisfies(RelTrait) - Method in enum org.apache.calcite.interpreter.InterpretableConvention
- satisfies(RelTrait) - Method in class org.apache.calcite.plan.Convention.Impl
- satisfies(RelTrait) - Method in interface org.apache.calcite.plan.RelTrait
-
Returns whether this trait satisfies a given trait.
- satisfies(RelTrait) - Method in class org.apache.calcite.rel.RelCollationImpl
- satisfies(RelTraitSet) - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns whether this trait set satisfies another trait set.
- scalar(RelNode) - Static method in class org.apache.calcite.rex.RexSubQuery
-
Creates a scalar sub-query.
- Scalar - Interface in org.apache.calcite.interpreter
-
Compiled scalar expression.
- SCALAR - Enum constant in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
- SCALAR - Enum constant in enum org.apache.calcite.plan.RelOptUtil.SubQueryType
- SCALAR - Enum constant in enum org.apache.calcite.runtime.SqlFunctions.FlatProductInputType
- SCALAR_EXECUTE1 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SCALAR_EXECUTE2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SCALAR_OR_RECORD_COLLECTION - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Checker that returns whether a value is a collection (multiset or array) of scalar or record values.
- SCALAR_OR_RECORD_COLLECTION_OR_MAP - Static variable in class org.apache.calcite.sql.type.OperandTypes
- SCALAR_QUERY - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Scalar query; that is, a sub-query used in an expression context, and returning one row and one column.
- SCALAR_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The internal "$SCALAR_QUERY" operator returns a scalar value from a record type.
- SCALAR_TYPE - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- Scalar.Producer - Interface in org.apache.calcite.interpreter
-
Produces a
Scalar
when a query is executed. - ScalarFunction - Interface in org.apache.calcite.schema
-
Function that returns a scalar result.
- ScalarFunctionImpl - Class in org.apache.calcite.schema.impl
-
Implementation of
ScalarFunction
. - scalarQuery(Function<RelBuilder, RelNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a scalar sub-query.
- ScalarType(SqlParserPos, String) - Constructor for class org.apache.calcite.piglet.Ast.ScalarType
- scalarValueRequiredInStrictModeOfJsonValueFunc(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- SCALE_NOT_SPECIFIED - Static variable in interface org.apache.calcite.rel.type.RelDataType
- scaleDown(SqlParserPos, RexNode, int) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Scales down a decimal value, and returns the scaled value as an exact numeric.
- scaleDownDouble(SqlParserPos, RexNode, int) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Scales down a decimal value and returns the scaled value as a an double precision approximate value.
- scaleUp(SqlParserPos, RexNode, int) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Scales up a decimal value and returns the scaled value as an exact number.
- scan(Iterable<String>) - Method in class org.apache.calcite.tools.PigRelBuilder
- scan(Iterable<String>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
TableScan
of the table with a given name. - scan(String...) - Method in class org.apache.calcite.tools.PigRelBuilder
- scan(String...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
TableScan
of the table with a given name. - scan(DataContext) - Method in class org.apache.calcite.adapter.csv.CsvScannableTable
- scan(DataContext) - Method in class org.apache.calcite.adapter.csv.CsvStreamScannableTable
- scan(DataContext) - Method in class org.apache.calcite.adapter.file.JsonScannableTable
- scan(DataContext) - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleScannableTable
- scan(DataContext) - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- scan(DataContext) - Method in class org.apache.calcite.adapter.kafka.KafkaStreamTable
- scan(DataContext) - Method in class org.apache.calcite.adapter.redis.RedisTable
- scan(DataContext) - Method in class org.apache.calcite.example.maze.MazeTable
- scan(DataContext) - Method in class org.apache.calcite.piglet.PigTable
- scan(DataContext) - Method in class org.apache.calcite.schema.impl.ListTransientTable
- scan(DataContext) - Method in interface org.apache.calcite.schema.ScannableTable
-
Returns an enumerator over the rows in this Table.
- scan(DataContext) - Method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions.ExplodeTable
- scan(DataContext) - Method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions.GridTable
- scan(DataContext) - Method in class org.apache.calcite.test.schemata.orderstream.InfiniteOrdersTable
- scan(DataContext) - Method in class org.apache.calcite.test.schemata.orderstream.OrdersHistoryTable
- scan(DataContext) - Method in class org.apache.calcite.test.schemata.orderstream.OrdersTable
- scan(DataContext) - Method in class org.apache.calcite.test.schemata.orderstream.ProductsTable
- scan(DataContext) - Method in class org.apache.calcite.util.Smalls.MazeTable
- scan(DataContext, List<RexNode>) - Method in class org.apache.calcite.adapter.csv.CsvFilterableTable
- scan(DataContext, List<RexNode>) - Method in interface org.apache.calcite.schema.FilterableTable
-
Returns an enumerator over the rows in this Table.
- scan(DataContext, List<RexNode>, int[]) - Method in interface org.apache.calcite.schema.ProjectableFilterableTable
-
Returns an enumerable over the rows in this Table.
- scan(RelOptTable, String...) - Method in class org.apache.calcite.piglet.PigRelBuilder
-
Scans a table with its given schema and names.
- scan(RelDataType, String...) - Method in class org.apache.calcite.piglet.PigRelBuilder
-
Makes a table scan operator for a given row type and names.
- scan(RelDataType, List<String>) - Method in class org.apache.calcite.piglet.PigRelBuilder
-
Makes a table scan operator for a given row type and names.
- SCAN - Enum constant in enum org.apache.calcite.adapter.druid.QueryType
- SCAN - Static variable in class org.apache.calcite.rel.rules.AggregateExtractProjectRule
- scanFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- SCANNABLE - Enum constant in enum org.apache.calcite.adapter.csv.CsvTable.Flavor
- SCANNABLE - Enum constant in enum org.apache.calcite.adapter.file.CsvTable.Flavor
- SCANNABLE_TABLE_SCAN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ScannableTable - Interface in org.apache.calcite.schema
-
Table that can be scanned without creating an intermediate relational expression.
- schema - Variable in class org.apache.calcite.jdbc.CalciteSchema.Entry
- schema - Variable in class org.apache.calcite.jdbc.CalciteSchema
- schema - Variable in class org.apache.calcite.plan.RelOptAbstractTable
- schema - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- schema - Variable in class org.apache.calcite.schema.impl.AbstractTableQueryable
- schema - Variable in class org.apache.calcite.schema.impl.DelegatingSchema
- schema - Variable in class org.apache.calcite.schema.impl.ViewTableMacro
- schema - Variable in class org.apache.calcite.test.ConnectionSpec
- Schema - Interface in org.apache.calcite.schema
-
A namespace for tables and functions.
- Schema(SqlParserPos, List<Ast.FieldSchema>) - Constructor for class org.apache.calcite.piglet.Ast.Schema
- SCHEMA - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Name of initial schema.
- SCHEMA - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- SCHEMA - Enum constant in enum org.apache.calcite.sql.validate.SqlMonikerType
- SCHEMA_COLUMNS - Static variable in class org.apache.calcite.jdbc.CalciteMetaImpl
-
The columns returned by
DatabaseMetaData.getSchemas()
. - SCHEMA_FACTORY - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Schema factory.
- SCHEMA_GET_SUB_SCHEMA - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SCHEMA_GET_TABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SCHEMA_PLUS_ADD_TABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SCHEMA_PLUS_REMOVE_TABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SCHEMA_PLUS_UNWRAP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SCHEMA_TYPE - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Schema type.
- Schema.TableType - Enum in org.apache.calcite.schema
-
Table type.
- schemaExists(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- schemaFactory(Class<T>, T) - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.SCHEMA_FACTORY
, or a default schema factory if not set. - schemaFactory(Class<T>, T) - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- SchemaFactory - Interface in org.apache.calcite.schema
-
Factory for
Schema
objects. - schemaInvalidType(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- schemaName - Variable in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
-
The name of the schema that is usually created from this specification.
- schemaNotFound(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- schemaPath - Variable in class org.apache.calcite.schema.impl.ViewTableMacro
-
Typically null.
- SchemaPlus - Interface in org.apache.calcite.schema
-
Extension to the
Schema
interface. - schemas - Variable in class org.apache.calcite.model.JsonRoot
-
List of schema elements.
- schemas() - Method in interface org.apache.calcite.schema.Path
-
Returns the schemas of this path.
- Schemas - Class in org.apache.calcite.schema
-
Utility functions for schemas.
- SCHEMAS_ENUMERABLE_FILTERABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SCHEMAS_ENUMERABLE_PROJECTABLE_FILTERABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SCHEMAS_ENUMERABLE_SCANNABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SCHEMAS_QUERYABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- schemaType() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.SCHEMA_TYPE
. - schemaType() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- SchemaVersion - Interface in org.apache.calcite.schema
-
An interface to represent a version ID that can be used to create a read-consistent view of a Schema.
- scope - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.IdInfo
- scope - Variable in class org.apache.calcite.sql.validate.SqlValidatorScope.Resolve
- scope - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Collection of
RelNode
objects which correspond to a SELECT statement. - scope() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Deprecated.
- SCOPE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy where the expression is assumed to be registered as a
SqlValidatorNamespace
, and therefore the result type of the call is the type of that namespace. - scopes - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Maps
query node
objects to theSqlValidatorScope
scope created from them. - ScoreTableFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.ScoreTableFunction
- scott - Variable in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
- SCOTT - Enum constant in enum org.apache.calcite.test.CalciteAssert.Config
-
Configuration that loads the "scott/tiger" database.
- SCOTT - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- SCOTT_WITH_TEMPORAL - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- SEARCH - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SEARCH
operator. - SEARCH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Operator that tests whether its left operand is included in the range of values covered by search arguments.
- searchEscape(String) - Static method in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- searchHits() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult
- SearchResultListener - Interface in org.apache.calcite.adapter.splunk.search
-
Called each time a search returns a record.
- searchShuttle(RexBuilder, RexProgram, int) - Static method in class org.apache.calcite.rex.RexUtil
-
Creates a shuttle that expands calls to
SqlStdOperatorTable.SEARCH
. - sec(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SEC
operator applied to double values. - sec(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SEC
operator applied to BigDecimal values. - SEC - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SEC - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- sech(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SECH
operator applied to double values. - sech(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SECH
operator applied to BigDecimal values. - SECH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SECH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "COTH(value)" function; returns the hyperbolic secant of
value
. - SECOND - Enum constant in enum org.apache.calcite.adapter.druid.Granularity.Type
- SECOND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
SECOND
operator. - SECOND_THIRD_SAME - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where the second and third operands must be comparable.
- SECOND_VARIANTS - Static variable in class org.apache.calcite.test.SqlOperatorTest
- SECONDS_IN_DAY - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- SECONDS_IN_MINUTE - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- select(List<E>, List<Integer>) - Static method in class org.apache.calcite.util.Util
-
Returns a view of a list, picking the elements of a list with the given set of ordinals.
- select(Enumerable<TSource>, Function1<TSource, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Projects each element of a sequence into a new form.
- select(Enumerable<TSource>, Function2<TSource, Integer, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Projects each element of a sequence into a new form by incorporating the element's index.
- select(Function1<T, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- select(Function1<TSource, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Projects each element of a sequence into a new form.
- select(Function2<T, Integer, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- select(Function2<TSource, Integer, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Projects each element of a sequence into a new form by incorporating the element's index.
- select(Queryable<T>, FunctionExpression<Function1<T, TResult>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Projects each element of a sequence into a new form.
- select(Queryable<T>, FunctionExpression<Function1<T, TResult>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Projects each element of a sequence into a new form.
- select(Queryable<T>, FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- select(FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- select(FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Projects each element of a sequence into a new form.
- SELECT - Enum constant in enum org.apache.calcite.adapter.druid.QueryType
- SELECT - Enum constant in enum org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- SELECT - Enum constant in enum org.apache.calcite.sql.SqlAccessEnum
- SELECT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SELECT statement or sub-query.
- SELECT - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
SELECT query (or UPDATE or DELETE).
- SELECT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SELECT_LIST - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
The SELECT clause of a SELECT statement.
- SELECT_MANY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SELECT2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- selectFolding() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the line-folding policy for the SELECT clause.
- SELECTIVITY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- selectListExtraIndentFlag() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether to use a fix for SELECT list indentations.
- selectListItemsOnSeparateLines() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether each item in a SELECT list, GROUP BY list, or ORDER BY list is on its own line.
- selectMany(Enumerable<TSource>, Function1<TSource, Enumerable<TCollection>>, Function2<TSource, TCollection, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Projects each element of a sequence to an
Enumerable<TSource>
, flattens the resulting sequences into one sequence, and invokes a result selector function on each element therein. - selectMany(Enumerable<TSource>, Function1<TSource, Enumerable<TResult>>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Projects each element of a sequence to an
Enumerable<TSource>
and flattens the resulting sequences into one sequence. - selectMany(Enumerable<TSource>, Function2<TSource, Integer, Enumerable<TCollection>>, Function2<TSource, TCollection, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Projects each element of a sequence to an
Enumerable<TSource>
, flattens the resulting sequences into one sequence, and invokes a result selector function on each element therein. - selectMany(Enumerable<TSource>, Function2<TSource, Integer, Enumerable<TResult>>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Projects each element of a sequence to an
Enumerable<TSource>
, and flattens the resulting sequences into one sequence. - selectMany(Function1<T, Enumerable<TCollection>>, Function2<T, TCollection, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- selectMany(Function1<T, Enumerable<TResult>>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- selectMany(Function1<TSource, Enumerable<TCollection>>, Function2<TSource, TCollection, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Projects each element of a sequence to an
Enumerable<TSource>
, flattens the resulting sequences into one sequence, and invokes a result selector function on each element therein. - selectMany(Function1<TSource, Enumerable<TResult>>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Projects each element of a sequence to an
Enumerable<TSource>
and flattens the resulting sequences into one sequence. - selectMany(Function2<T, Integer, Enumerable<TCollection>>, Function2<T, TCollection, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- selectMany(Function2<T, Integer, Enumerable<TResult>>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- selectMany(Function2<TSource, Integer, Enumerable<TCollection>>, Function2<TSource, TCollection, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Projects each element of a sequence to an
Enumerable<TSource>
, flattens the resulting sequences into one sequence, and invokes a result selector function on each element therein. - selectMany(Function2<TSource, Integer, Enumerable<TResult>>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Projects each element of a sequence to an
Enumerable<TSource>
, and flattens the resulting sequences into one sequence. - selectMany(Queryable<T>, FunctionExpression<Function1<T, Enumerable<TResult>>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Projects each element of a sequence to an
Enumerable<T>
and combines the resulting sequences into one sequence. - selectMany(Queryable<T>, FunctionExpression<Function1<T, Enumerable<TResult>>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Projects each element of a sequence to an
Enumerable<T>
and combines the resulting sequences into one sequence. - selectMany(Queryable<T>, FunctionExpression<Function1<T, Enumerable<TResult>>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- selectMany(Queryable<T>, FunctionExpression<Function2<T, Integer, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Projects each element of a sequence to an
Enumerable<T>
that incorporates the index of the source element that produced it. - selectMany(Queryable<T>, FunctionExpression<Function2<T, Integer, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Projects each element of a sequence to an
Enumerable<T>
that incorporates the index of the source element that produced it. - selectMany(Queryable<T>, FunctionExpression<Function2<T, Integer, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- selectMany(FunctionExpression<Function1<T, Enumerable<TResult>>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- selectMany(FunctionExpression<Function1<T, Enumerable<TResult>>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Projects each element of a sequence to an
Enumerable<TSource>
and combines the resulting sequences into one sequence. - selectMany(FunctionExpression<Function2<T, Integer, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- selectMany(FunctionExpression<Function2<T, Integer, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Projects each element of a sequence to an
Enumerable<TSource>
that incorporates the index of the source element that produced it. - selectManyN(Queryable<T>, FunctionExpression<Function1<T, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Projects each element of a sequence to an
Enumerable<T>
and invokes a result selector function on each element therein. - selectManyN(Queryable<T>, FunctionExpression<Function1<T, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Projects each element of a sequence to an
Enumerable<T>
and invokes a result selector function on each element therein. - selectManyN(Queryable<T>, FunctionExpression<Function1<T, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- selectManyN(Queryable<T>, FunctionExpression<Function2<T, Integer, Enumerable<TResult>>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Projects each element of a sequence to an
Enumerable<T>
and combines the resulting sequences into one sequence. - selectManyN(Queryable<T>, FunctionExpression<Function2<T, Integer, Enumerable<TResult>>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Projects each element of a sequence to an
Enumerable<T>
and combines the resulting sequences into one sequence. - selectManyN(Queryable<T>, FunctionExpression<Function2<T, Integer, Enumerable<TResult>>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- selectManyN(FunctionExpression<Function1<T, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- selectManyN(FunctionExpression<Function1<T, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Projects each element of a sequence to an
Enumerable<TSource>
and invokes a result selector function on each element therein. - selectManyN(FunctionExpression<Function2<T, Integer, Enumerable<TResult>>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- selectManyN(FunctionExpression<Function2<T, Integer, Enumerable<TResult>>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Projects each element of a sequence to an
Enumerable<TSource>
and combines the resulting sequences into one sequence. - selectMissingFrom() - Method in interface org.apache.calcite.runtime.CalciteResource
- selectN(Queryable<T>, FunctionExpression<Function2<T, Integer, TResult>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Projects each element of a sequence into a new form by incorporating the element's index.
- selectN(Queryable<T>, FunctionExpression<Function2<T, Integer, TResult>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Projects each element of a sequence into a new form by incorporating the element's index.
- selectN(Queryable<T>, FunctionExpression<Function2<T, Integer, TResult>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- selectN(FunctionExpression<Function2<T, Integer, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- selectN(FunctionExpression<Function2<T, Integer, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Projects each element of a sequence into a new form by incorporating the element's index.
- SelectNamespace - Class in org.apache.calcite.sql.validate
-
Namespace offered by a sub-query.
- SelectNamespace(SqlValidatorImpl, SqlSelect, SqlNode) - Constructor for class org.apache.calcite.sql.validate.SelectNamespace
-
Creates a SelectNamespace.
- selector(ParameterExpression, List<Integer>, JavaRowFormat) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Generates a selector for the given fields from an expression.
- selector(ParameterExpression, List<Integer>, JavaRowFormat) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- selectorComparer(Function1<T, T2>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns an
EqualityComparer
that uses a selector function. - SelectScope - Class in org.apache.calcite.sql.validate
-
The name-resolution scope of a SELECT clause.
- selectStarRequiresFrom() - Method in interface org.apache.calcite.runtime.CalciteResource
- SelfSplitter() - Constructor for class org.apache.calcite.sql.SqlSplittableAggFunction.SelfSplitter
- semantics - Variable in class org.apache.calcite.sql.TableCharacteristic
-
Input table has either row semantics or set semantics.
- semantics() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- semantics() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Controls the behavior of operators that are part of Standard SQL but nevertheless have different behavior in different databases.
- semantics() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- semantics() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- SemanticTable - Interface in org.apache.calcite.sql.validate
-
Extension to
SqlValidatorTable
with extra, optional metadata. - SEMI - Enum constant in enum org.apache.calcite.linq4j.JoinType
-
Semi-join.
- SEMI - Enum constant in enum org.apache.calcite.rel.core.JoinRelType
-
Semi-join.
- SEMI_JOIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SEMI_JOIN_FILTER_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- SEMI_JOIN_JOIN_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- SEMI_JOIN_PROJECT_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- SEMI_JOIN_REMOVE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that removes a
semi-join
from a join tree. - SEMI_STRICT - Enum constant in enum org.apache.calcite.adapter.enumerable.NullPolicy
-
Returns null if one of the arguments is null, and possibly other times.
- semiJoin(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Join
withJoinRelType.SEMI
. - semiJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns elements of
outer
for which there is a member ofinner
with a matching key. - semiJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- semiJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, EqualityComparer<TKey>, boolean, Predicate2<TSource, TInner>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns elements of
outer
for which there is (semi-join) / is not (anti-semi-join) a member ofinner
with a matching key. - semiJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, EqualityComparer<TKey>, Predicate2<TSource, TInner>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- semiJoin(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Join
withJoinRelType.SEMI
. - SemiJoinFilterTransposeRule - Class in org.apache.calcite.rel.rules
-
Planner rule that pushes
SemiJoin
s down in a tree past aFilter
. - SemiJoinFilterTransposeRule(SemiJoinFilterTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.SemiJoinFilterTransposeRule
-
Creates a SemiJoinFilterTransposeRule.
- SemiJoinFilterTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.SemiJoinFilterTransposeRule
-
Deprecated.
- SemiJoinFilterTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- SemiJoinJoinTransposeRule - Class in org.apache.calcite.rel.rules
- SemiJoinJoinTransposeRule(SemiJoinJoinTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.SemiJoinJoinTransposeRule
-
Creates a SemiJoinJoinTransposeRule.
- SemiJoinJoinTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.SemiJoinJoinTransposeRule
-
Deprecated.
- SemiJoinJoinTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- SemiJoinProjectTransposeRule - Class in org.apache.calcite.rel.rules
- SemiJoinProjectTransposeRule(SemiJoinProjectTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.SemiJoinProjectTransposeRule
-
Creates a SemiJoinProjectTransposeRule.
- SemiJoinProjectTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- SemiJoinRemoveRule - Class in org.apache.calcite.rel.rules
-
Planner rule that removes a
semi-join
from a join tree. - SemiJoinRemoveRule(SemiJoinRemoveRule.Config) - Constructor for class org.apache.calcite.rel.rules.SemiJoinRemoveRule
-
Creates a SemiJoinRemoveRule.
- SemiJoinRemoveRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.SemiJoinRemoveRule
-
Deprecated.
- SemiJoinRemoveRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- SemiJoinRule - Class in org.apache.calcite.rel.rules
-
Planner rule that creates a
SemiJoin
from aJoin
on top of aLogicalAggregate
or on aRelNode
which is unique for join's right keys. - SemiJoinRule(SemiJoinRule.Config) - Constructor for class org.apache.calcite.rel.rules.SemiJoinRule
-
Creates a SemiJoinRule.
- SemiJoinRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- SemiJoinRule.JoinOnUniqueToSemiJoinRule - Class in org.apache.calcite.rel.rules
-
SemiJoinRule that matches a Project on top of a Join with a RelNode which is unique for Join's right keys.
- SemiJoinRule.JoinOnUniqueToSemiJoinRule.JoinOnUniqueToSemiJoinRuleConfig - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- SemiJoinRule.JoinToSemiJoinRule - Class in org.apache.calcite.rel.rules
-
SemiJoinRule that matches a Join with an empty Aggregate as its right input.
- SemiJoinRule.JoinToSemiJoinRule.JoinToSemiJoinRuleConfig - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- SemiJoinRule.ProjectToSemiJoinRule - Class in org.apache.calcite.rel.rules
-
SemiJoinRule that matches a Project on top of a Join with an Aggregate as its right child.
- SemiJoinRule.ProjectToSemiJoinRule.ProjectToSemiJoinRuleConfig - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- SemiMutableSchema - Interface in org.apache.calcite.schema
-
Schema to which materializations can be added.
- SemiStrict - Annotation Type in org.apache.calcite.linq4j.function
-
Annotation applied to a user-defined function that indicates that the function always returns null if one or more of its arguments are null but also may return null at other times.
- send(Field, Object, Primitive.Sink) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Sends a field value to a sink.
- send(Row) - Method in interface org.apache.calcite.interpreter.Sink
- send(Primitive.Source, Primitive.Sink) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Sends a value from a source to a sink.
- sep(boolean, String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- sep(String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- sep(String) - Method in interface org.apache.calcite.sql.SqlWriter
-
Writes a list separator, unless the separator is "," and this is the first occurrence in the list.
- sep(String, boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- sep(String, boolean) - Method in interface org.apache.calcite.sql.SqlWriter
-
Writes a list separator.
- SEPARATOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SEPARATOR
expression. - SEPARATOR - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
Separator expression inside GROUP_CONCAT, e.g.
- sepList(List<T>, String) - Static method in class org.apache.calcite.util.Util
-
Converts a list of a string, with a given separator between elements.
- seq() - Method in class org.apache.calcite.runtime.Pattern.PatternBuilder
-
Creates a pattern that matches the two patterns at the top of the stack in sequence, and pushes it onto the stack.
- SEQ - Enum constant in enum org.apache.calcite.runtime.Pattern.Op
-
Pattern that matches one pattern followed by another.
- sequence(String, SqlSingleOperandTypeChecker...) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates an operand checker from a sequence of single-operand checkers.
- sequence(BiFunction<SqlOperator, String, String>, SqlSingleOperandTypeChecker...) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates an operand checker from a sequence of single-operand checkers, generating the signature from the components.
- sequence(Program...) - Static method in class org.apache.calcite.tools.Programs
-
Creates a program that executes a sequence of programs.
- Sequence - Enum constant in enum org.apache.calcite.linq4j.tree.GotoExpressionKind
-
A GotoExpression that evaluates an expression and carries on.
- SEQUENCE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
Sequence table.
- SEQUENCE - Enum constant in enum org.apache.calcite.sql.type.CompositeOperandTypeChecker.Composition
- SEQUENCE_CURRENT_VALUE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SEQUENCE_NEXT_VALUE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- sequenceCurrentValue(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the
CURRENT VALUE OF sequence
operator. - sequenceEqual(Enumerable<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- sequenceEqual(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- sequenceEqual(Enumerable<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Determines whether two sequences are equal by comparing the elements by using the default equality comparer for their type.
- sequenceEqual(Enumerable<TSource>, Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Determines whether two sequences are equal by comparing the elements by using the default equality comparer for their type.
- sequenceEqual(Enumerable<TSource>, Enumerable<TSource>, EqualityComparer<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Determines whether two sequences are equal by comparing their elements by using a specified
EqualityComparer<TSource>
. - sequenceEqual(Enumerable<TSource>, EqualityComparer<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Determines whether two sequences are equal by comparing their elements by using a specified
EqualityComparer<TSource>
. - sequenceEqual(Queryable<T>, Enumerable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Determines whether two sequences are equal by using the default equality comparer to compare elements.
- sequenceEqual(Queryable<T>, Enumerable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Determines whether two sequences are equal by using the default equality comparer to compare elements.
- sequenceEqual(Queryable<T>, Enumerable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- sequenceEqual(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Determines whether two sequences are equal by using a specified
EqualityComparer<T>
to compare elements. - sequenceEqual(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Determines whether two sequences are equal by using a specified EqualityComparer to compare elements.
- sequenceEqual(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- sequenceNextValue(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the
NEXT VALUE OF sequence
operator. - SerializableCharset - Class in org.apache.calcite.util
-
Serializable wrapper around a
Charset
. - ServerDdlExecutor - Class in org.apache.calcite.server
-
Executes DDL commands.
- ServerDdlExecutor() - Constructor for class org.apache.calcite.server.ServerDdlExecutor
-
Creates a ServerDdlExecutor.
- SESSION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
SESSION
group function. - SESSION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
SESSION as a table function.
- SESSION_END - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
SESSION_END
auxiliary function of theSqlKind.SESSION
group function. - SESSION_END - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
SESSION_END
auxiliary function of theSESSION
group function. - SESSION_OLD - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
SESSION
group function. - SESSION_START - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
SESSION_START
auxiliary function of theSqlKind.SESSION
group function. - SESSION_START - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
SESSION_START
auxiliary function of theSESSION
group function. - SESSION_USER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
SESSION_USER
function. - SESSIONIZATION - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- sessionize(Enumerator<Object[]>, int, int, long) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
-
Creates enumerable implementation that applies sessionization to elements from the input enumerator based on a specified key.
- set(boolean) - Method in interface org.apache.calcite.linq4j.tree.Primitive.Sink
- set(byte) - Method in interface org.apache.calcite.linq4j.tree.Primitive.Sink
- set(char) - Method in interface org.apache.calcite.linq4j.tree.Primitive.Sink
- set(double) - Method in interface org.apache.calcite.linq4j.tree.Primitive.Sink
- set(float) - Method in interface org.apache.calcite.linq4j.tree.Primitive.Sink
- set(int) - Method in interface org.apache.calcite.linq4j.tree.Primitive.Sink
- set(int) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
- set(int) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns a bit set the same as this but with a given bit set.
- set(int, boolean) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns a bit set the same as this but with a given bit set (if b is true) or unset (if b is false).
- set(int, int) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Sets a range of bits, from
from
toto
- 1. - set(int, int) - Method in class org.apache.calcite.util.mapping.Mappings.AbstractMapping
- set(int, int) - Method in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
- set(int, int) - Method in class org.apache.calcite.util.mapping.Mappings.OverridingTargetMapping
- set(int, int) - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- set(int, int) - Method in interface org.apache.calcite.util.mapping.Mappings.TargetMapping
- set(int, int) - Method in class org.apache.calcite.util.Permutation
-
Maps source position to target position.
- set(int, int, boolean) - Method in class org.apache.calcite.util.Permutation
-
Maps source position to target position, automatically resizing if source or target is out of bounds.
- set(int, Integer) - Method in class org.apache.calcite.util.ImmutableIntList
- set(int, E) - Method in class org.apache.calcite.util.CastingList
- set(int, Object) - Method in class org.apache.calcite.interpreter.Row.RowBuilder
-
Sets the value of a particular column.
- set(int, SqlNode) - Method in class org.apache.calcite.sql.SqlNodeList
- set(int, T, U) - Method in interface org.apache.calcite.runtime.PairList
-
Sets the entry at position
index
to the pair(t, u)
. - set(long) - Method in interface org.apache.calcite.linq4j.tree.Primitive.Sink
- set(short) - Method in interface org.apache.calcite.linq4j.tree.Primitive.Sink
- set(E) - Method in class org.apache.calcite.util.Holder
-
Sets the value.
- set(Object) - Method in interface org.apache.calcite.linq4j.tree.Primitive.Sink
- set(String, String) - Method in class org.apache.calcite.test.DiffRepository
-
Sets the value of a given resource of the current test case.
- set(CalciteConnectionProperty, String) - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
-
Returns a copy of this configuration with one property changed.
- SET - Enum constant in enum org.apache.calcite.adapter.enumerable.WinAggImplementor.SeekType
-
Row position in the frame.
- SET - Enum constant in enum org.apache.calcite.adapter.redis.RedisDataType
-
Redis Sets are an unordered collection of Strings.
- SET - Enum constant in enum org.apache.calcite.runtime.JsonFunctions.JsonModifyMode
- SET - Enum constant in enum org.apache.calcite.sql.babel.TableCollectionType
-
Duplicate rows are not permitted.
- SET - Enum constant in enum org.apache.calcite.sql.TableCharacteristic.Semantics
-
Set semantics means that the outcome of the Window TableFunction depends on how the data is partitioned.
- SET_OP - Enum constant in enum org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- SET_OP - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy for a set operator (UNION, INTERSECT, EXCEPT).
- SET_OP_FACTORY - Static variable in class org.apache.calcite.adapter.jdbc.JdbcRules
- SET_OPTION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
"
ALTER scope SET option = value
" statement. - SET_QUERY - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category consisting of set-query node types.
- SET_SEMANTICS_TABLE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Input tables have either row semantics or set semantics.
- SET_SEMANTICS_TABLE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
SetSemanticsTable represents as an input table with set semantics.
- SET_VAR - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to the whole query(no specific nodes).
- setAggChildKeys(ImmutableBitSet, Aggregate, ImmutableBitSet.Builder) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Takes a bitmap representing a set of input references and extracts the ones that reference the group by columns in an aggregate.
- setAlias(SqlIdentifier) - Method in class org.apache.calcite.sql.SqlUpdate
- setAll(BitSet, Iterable<? extends Number>) - Static method in class org.apache.calcite.util.BitSets
-
Sets all bits in a given BitSet corresponding to integers from a list.
- setAll(Mapping) - Method in class org.apache.calcite.util.Permutation
- setAllowBangEqual(boolean) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Deprecated.
- setAlwaysQuoteCData(boolean) - Method in class org.apache.calcite.util.XmlOutput
-
Sets whether to always quote cdata segments (even if they don't contain special characters).
- setAlwaysUseParentheses(boolean) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setAlwaysUseParentheses(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- setAscOrder(boolean) - Method in class org.apache.calcite.adapter.innodb.InnodbRel.Implementor
- setBlock(BlockBuilder) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- setBootstrapServers(String) - Method in class org.apache.calcite.adapter.kafka.KafkaTableOptions
- setCache(boolean) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- setCache(boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema
- setCacheEnabled(boolean) - Method in interface org.apache.calcite.schema.SchemaPlus
- setCancelFlag(CancelFlag) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- setCancelFlag(CancelFlag) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Deprecated.Previously, this method installed the cancellation-checking flag for this planner, but is now deprecated. Now, you should add a
CancelFlag
to theContext
passed to the constructor. - setCaseClausesOnNewLines(boolean) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setCaseClausesOnNewLines(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- setCaseSensitive(boolean) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Deprecated.
- setCharLiteralStyles(Set<CharLiteralStyle>) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Deprecated.
- setChildRels(RelNode, List<RelNode>) - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Assigns the input relational expressions of a given relational expression, as seen by this particular call.
- setClassLoader(ClassLoader) - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- setClasspath(String) - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- setClauseStartsLine(boolean) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setClauseStartsLine(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- setCompact(boolean) - Method in class org.apache.calcite.util.XmlOutput
-
Sets or unsets the compact mode.
- setConfig(SqlParser.Config) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Deprecated.Sets configuration to a given
SqlParser.Config
. - setConformance(SqlConformance) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Deprecated.
- setConsumer(Consumer) - Method in class org.apache.calcite.adapter.kafka.KafkaTableOptions
- setConsumerParams(Map<String, String>) - Method in class org.apache.calcite.adapter.kafka.KafkaTableOptions
- setCorrelates(Function1<String, RexToLixTranslator.InputGetter>) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- setDataContext(DataContext) - Method in class org.apache.calcite.rex.RexExecutable
- setDataFormat(String) - Method in class org.apache.calcite.adapter.redis.RedisTableFieldInfo
- setDataset(String) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Notifies this Blackboard that the root just set using
SqlToRelConverter.Blackboard.setRoot(RelNode, boolean)
was derived using dataset substitution. - setDebugInfo(int) - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- setDeclName(SqlIdentifier) - Method in class org.apache.calcite.sql.SqlWindow
- setDefault(String) - Static method in class org.apache.calcite.test.ConnectionFactories
-
Returns a post-processor that sets a default schema name.
- setDefaultLocale(Locale) - Static method in class org.apache.calcite.test.Unsafe
-
Sets locale.
- setDestdir(String) - Method in class org.apache.calcite.util.javac.JaninoCompiler.JaninoCompilerArgs
- setDestdir(String) - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- setDynamicParamCountInExplain(int) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Sets the number of dynamic parameters in the current EXPLAIN PLAN statement.
- setExecutor(RexExecutor) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- setExecutor(RexExecutor) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Sets the object that can execute scalar expressions.
- setExpandedSelectList(List<SqlNode>) - Method in class org.apache.calcite.sql.validate.SelectScope
- setFactorWeights() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Sets weighting for each combination of factors, depending on which join filters reference which factors.
- setFamily(RelDataTypeFamily) - Method in class org.apache.calcite.sql.type.ObjectSqlType
- setFetch(SqlNode) - Method in class org.apache.calcite.sql.SqlSelect
- setFetch(SqlNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- setFieldNames(String[]) - Method in interface org.apache.calcite.adapter.splunk.search.SearchResultListener
- setFieldNames(String[]) - Method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.CountingSearchResultListener
- setFields(List<LinkedHashMap<String, Object>>) - Method in class org.apache.calcite.adapter.redis.RedisTableFieldInfo
- setFor(SqlOperator) - Method in class org.apache.calcite.test.SqlValidatorFixture
- setFor(SqlOperator, SqlOperatorFixture.VmName...) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Declares that this test is for a given operator.
- setFor(SqlOperator, SqlTester.VmName...) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- setFor(SqlOperator, SqlTester.VmName...) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Declares that this test is for a given operator.
- setFormatOptions(SqlFormatOptions) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- setFrom(SqlNode) - Method in class org.apache.calcite.sql.SqlSelect
- setFullClassName(String) - Method in class org.apache.calcite.util.javac.JaninoCompiler.JaninoCompilerArgs
- setFullClassName(String) - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- setGlob(boolean) - Method in class org.apache.calcite.util.XmlOutput
-
Sets whether to detect that tags are empty.
- setGroupBy(SqlNodeList) - Method in class org.apache.calcite.sql.SqlSelect
- setGroupBy(SqlNodeList) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- setHaving(SqlNode) - Method in class org.apache.calcite.sql.SqlSelect
- setHaving(SqlNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- setHints(SqlNodeList) - Method in class org.apache.calcite.sql.SqlSelect
- setHintStrategies(HintStrategyTable) - Method in class org.apache.calcite.plan.RelOptCluster
-
Sets up the hint propagation strategies to be used during rule planning.
- setIdentifierMaxLength(int) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Deprecated.
- setIdentifierTimeUnitMap(ImmutableMap<String, TimeUnit>) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Deprecated.
- setIf(int, boolean) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns a bit set the same as this but with a given bit set if condition is true.
- setIgnorePcdata(boolean) - Method in class org.apache.calcite.util.XmlOutput
-
Sets whether to ignore unquoted text, such as whitespace.
- setIncludeIntermediateCosts(boolean) - Method in class org.apache.calcite.plan.visualizer.RuleMatchVisualizer
-
Output intermediate costs, including all cost updates.
- setIncludeTransitiveEdges(boolean) - Method in class org.apache.calcite.plan.visualizer.RuleMatchVisualizer
-
Output edges from a subset to the nodes of all subsets that satisfy it.
- setIndentation(int) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setIndentation(int) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- setIndentString(String) - Method in class org.apache.calcite.util.XmlOutput
-
Sets the string to print for each level of indentation.
- setIndexCondition(IndexCondition) - Method in class org.apache.calcite.adapter.innodb.InnodbRel.Implementor
- setInput(int, MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableJoin
- setInput(int, MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableScan
- setInput(int, MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableUnion
- setInput(int, MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableRel
- setInput(int, MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableSort
- setJoinRemovalFactor(int, int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Indicates that a dimension factor's join can be removed because of a semijoin with a fact table.
- setJoinRemovalSemiJoin(int, LogicalJoin) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Indicates the semi-join that allows the join of a dimension table to be removed.
- setKeyDelimiter(String) - Method in class org.apache.calcite.adapter.redis.RedisTableFieldInfo
- setKeywordsLowercase(boolean) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setKeywordsLowerCase(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- setKind(StructKind) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- setLeft(SqlNode) - Method in class org.apache.calcite.sql.SqlJoin
- setLeftRightBitmaps(ImmutableBitSet, ImmutableBitSet.Builder, ImmutableBitSet.Builder, int) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Separates a bit-mask representing a join into masks representing the left and right inputs into the join.
- setLex(Lex) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Deprecated.
- setLimit(long) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- setLineLength(int) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setLineLength(int) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- setLocked(boolean) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Sets whether this planner is locked.
- setLowerBound(SqlNode) - Method in class org.apache.calcite.sql.SqlWindow
- setMetadataProvider(RelMetadataProvider) - Method in class org.apache.calcite.plan.RelOptCluster
-
Overrides the default metadata provider for this cluster.
- setMetadataQuerySupplier(Supplier<RelMetadataQuery>) - Method in class org.apache.calcite.plan.RelOptCluster
-
Sets up the customized
RelMetadataQuery
instance supplier that to use during rule planning. - setName(int, String) - Method in class org.apache.calcite.sql.SqlIdentifier
-
Returns an identifier that is the same as this except one modified name.
- setName(String) - Method in class org.apache.calcite.adapter.druid.DruidQuery.JsonPostAggregation
- setName(SqlIdentifier) - Method in class org.apache.calcite.sql.SqlSetOption
- setNames(List<String>, List<SqlParserPos>) - Method in class org.apache.calcite.sql.SqlIdentifier
-
Modifies the components of this identifier and their positions.
- setNeedWhitespace(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- setNeedWhitespace(boolean) - Method in interface org.apache.calcite.sql.SqlWriter
-
Sets whether whitespace is needed before the next token.
- setNewForOldRel(RelNode, RelNode) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- setNoneConventionHasInfiniteCost(boolean) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Sets whether this planner should consider rel nodes with Convention.NONE to have infinite cost or not.
- setOf(Set<String>) - Static method in class org.apache.calcite.rel.core.CorrelationId
-
Converts a set of correlation ids to a set of names.
- setOffset(SqlNode) - Method in class org.apache.calcite.sql.SqlSelect
- setOffset(SqlNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- SetOp - Class in org.apache.calcite.rel.core
-
SetOp
is an abstract base for relational set operators such as UNION, MINUS (aka EXCEPT), and INTERSECT. - SetOp(RelOptCluster, RelTraitSet, List<RelHint>, List<RelNode>, SqlKind, boolean) - Constructor for class org.apache.calcite.rel.core.SetOp
-
Creates a SetOp.
- SetOp(RelOptCluster, RelTraitSet, List<RelNode>, SqlKind, boolean) - Constructor for class org.apache.calcite.rel.core.SetOp
-
Creates a SetOp.
- SetOp(RelInput) - Constructor for class org.apache.calcite.rel.core.SetOp
-
Creates a SetOp by parsing serialized output.
- SETOP - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Set operation.
- SETOP - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
SetOp
nodes. - setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.fun.SqlCase
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlAsofJoin
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlBasicCall
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlCall
-
Changes the value of an operand.
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlDelete
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlDescribeSchema
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlDescribeTable
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlExplain
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlInsert
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlJoin
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlLambda
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlMatchRecognize
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlMerge
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlPivot
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlSelect
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlSetOption
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlSnapshot
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlUnpivot
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlUpdate
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlWindow
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlWith
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlWithItem
- setOperator(SqlOperator) - Method in class org.apache.calcite.sql.SqlBasicCall
-
Sets the operator (or function) that is being called.
- setOperators(Multimap<String, SqlOperator>) - Method in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
- setOpFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- SetopNamespace - Class in org.apache.calcite.sql.validate
-
Namespace based upon a set operation (UNION, INTERSECT, EXCEPT).
- SetopNamespace(SqlValidatorImpl, SqlCall, SqlNode) - Constructor for class org.apache.calcite.sql.validate.SetopNamespace
-
Creates a
SetopNamespace
. - SetOpNode - Class in org.apache.calcite.interpreter
- SetOpNode(Compiler, SetOp) - Constructor for class org.apache.calcite.interpreter.SetOpNode
- SetopOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Parameter type-checking strategy for a set operator (UNION, INTERSECT, EXCEPT).
- SetopOperandTypeChecker() - Constructor for class org.apache.calcite.sql.type.SetopOperandTypeChecker
- setOpToSql(SqlSetOperator, RelNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- setOrderBy(SqlNodeList) - Method in class org.apache.calcite.sql.SqlSelect
- setOrderBy(SqlNodeList) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- setOrderList(SqlNodeList) - Method in class org.apache.calcite.sql.SqlWindow
- setOriginal(SqlNode, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- setOriginalExpression(RexNode) - Method in class org.apache.calcite.plan.RelOptCluster
-
Deprecated.
- setOriginalStatement(String) - Method in exception class org.apache.calcite.runtime.CalciteContextException
-
Sets the input string to associate with the current context.
- setParent(RelOptRuleOperand) - Method in class org.apache.calcite.plan.RelOptRuleOperand
-
Sets the parent operand.
- setParserFactory(SqlParserImplFactory) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Deprecated.
- setPartitionList(SqlNodeList) - Method in class org.apache.calcite.sql.SqlWindow
- setPath(ImmutableList<ImmutableList<String>>) - Method in interface org.apache.calcite.schema.SchemaPlus
- setPatternVarRef(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- setPosition(int, int) - Method in exception class org.apache.calcite.runtime.CalciteContextException
-
Sets a textual position at which this exception was detected.
- setPosition(int, int, int, int) - Method in exception class org.apache.calcite.runtime.CalciteContextException
-
Sets a textual range at which this exception was detected.
- setQualify(SqlNode) - Method in class org.apache.calcite.sql.SqlSelect
- setQuoteAllIdentifiers(boolean) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setQuoteAllIdentifiers(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- setQuotedCasing(Casing) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Deprecated.
- setQuoting(Quoting) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Deprecated.
- setRefFileDiffMasks() - Method in class org.apache.calcite.test.DiffTestCase
-
Sets the diff masks that are common to .REF files
- setRelMetadataTimestamp(long) - Method in class org.apache.calcite.test.MockRelOptPlanner
-
Deprecated.
- setReplace(boolean) - Method in class org.apache.calcite.sql.SqlCreate
- setResultSet(Iterator<Object>) - Method in interface org.apache.calcite.server.CalciteServerStatement
- setRight(SqlNode) - Method in class org.apache.calcite.sql.SqlJoin
- setRoot(RelNode) - Method in class org.apache.calcite.plan.hep.HepPlanner
- setRoot(RelNode) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Sets the root node of this query.
- setRoot(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- setRoot(RelNode) - Method in class org.apache.calcite.test.MockRelOptPlanner
- setRoot(RelNode, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Sets a new root relational expression, as the translation process backs its way further up the tree.
- setRowConverter(KafkaRowConverter) - Method in class org.apache.calcite.adapter.kafka.KafkaTableOptions
- setRows(SqlLiteral) - Method in class org.apache.calcite.sql.SqlWindow
- setRule(RelOptRule) - Method in class org.apache.calcite.plan.RelOptRuleOperand
-
Sets the rule this operand belongs to.
- setRuleDescExclusionFilter(Pattern) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- setRuleDescExclusionFilter(Pattern) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Sets the exclusion filter to use for this planner.
- setSchema(String) - Method in interface org.apache.calcite.jdbc.CalciteConnection
- setScope(String) - Method in class org.apache.calcite.sql.SqlAlter
- setSelect(SqlNodeList) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- setSelectList(SqlNodeList) - Method in class org.apache.calcite.sql.SqlSelect
- setSelectListExtraIndentFlag(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- setSelectListItemsOnSeparateLines(boolean) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setSelectListItemsOnSeparateLines(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- setSettings(Properties) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Sets settings from a properties object.
- setSignature(Meta.Signature) - Method in interface org.apache.calcite.server.CalciteServerStatement
- setSource(String, String) - Method in class org.apache.calcite.util.javac.JaninoCompiler.JaninoCompilerArgs
- setSource(String, String) - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
-
Sets the source code (that is, the full java program, generally starting with something like "package com.foo.bar;") and the file name.
- setSource(SqlSelect) - Method in class org.apache.calcite.sql.SqlInsert
- setSourceEnumerable(Enumerable<Row>) - Method in interface org.apache.calcite.interpreter.Sink
-
Deprecated.
- setSourceSelect(SqlSelect) - Method in class org.apache.calcite.sql.SqlDelete
- setSourceSelect(SqlSelect) - Method in class org.apache.calcite.sql.SqlMerge
- setSourceSelect(SqlSelect) - Method in class org.apache.calcite.sql.SqlUpdate
- setSourceTableRef(SqlNode) - Method in class org.apache.calcite.sql.SqlMerge
- setString(String) - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
-
Sets the arguments by parsing a standard java argument string.
- setStringArray(String[]) - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
-
Sets the arguments by parsing a standard java argument string.
- setSubQueryConverter(SubQueryConverter) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Sets a new SubQueryConverter.
- setSubQueryStyle(SqlWriter.SubQueryStyle) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- setTableName(String) - Method in class org.apache.calcite.adapter.redis.RedisTableFieldInfo
- setThreadLocal() - Static method in class org.apache.calcite.materialize.MaterializationService
-
Used by tests, to ensure that they see their own service.
- setTimeout(DataContext) - Method in class org.apache.calcite.runtime.ResultSetEnumerable
- setTopDownOpt(boolean) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Enable or disable top-down optimization.
- setTopicName(String) - Method in class org.apache.calcite.adapter.kafka.KafkaTableOptions
- setType(RelDataType) - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- setType(RelDataType) - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- setType(RelDataType) - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Sets the type of this namespace.
- setUnquotedCasing(Casing) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Deprecated.
- setUp() - Method in class org.apache.calcite.test.DiffTestCase
- setUpperBound(SqlNode) - Method in class org.apache.calcite.sql.SqlWindow
- setValidatedNodeType(SqlNode, RelDataType) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Saves the type of a
SqlNode
, now that it has been validated. - setValidatedNodeType(SqlNode, RelDataType) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Saves the type of a
SqlNode
, now that it has been validated. - setValue(E) - Method in class org.apache.calcite.linq4j.Ord
- setValue(RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFieldImpl
- setValue(SqlNode) - Method in class org.apache.calcite.sql.SqlSetOption
- setValue(T2) - Method in class org.apache.calcite.util.Pair
- setValue(U) - Method in class org.apache.calcite.runtime.MapEntry
- setVerbose(boolean) - Method in class org.apache.calcite.test.DiffTestCase
-
Sets whether to give verbose message if diff fails.
- setVerbose(boolean) - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- setWhere(SqlNode) - Method in class org.apache.calcite.sql.SqlSelect
- setWhere(SqlNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- setWhereListItemsOnSeparateLines(boolean) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setWhereListItemsOnSeparateLines(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- setWindowCall(SqlCall) - Method in class org.apache.calcite.sql.SqlWindow
- setWindowDeclarationStartsLine(boolean) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setWindowDeclListNewline(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- setWindowListItemsOnSeparateLines(boolean) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setWindowNewline(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- sh - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- sha1(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SHA1(string) function.
- sha1(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SHA1(string) function for binary string.
- SHA1 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SHA1 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- sha256(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SHA256(string) function.
- sha256(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SHA256(string) function for binary string.
- SHA256 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SHA256 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- sha512(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SHA512(string) function.
- sha512(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SHA512(string) function for binary string.
- SHA512 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SHA512 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- sharedStatementPlans() - Method in interface org.apache.calcite.runtime.CalciteResource
- shift(int) - Method in class org.apache.calcite.rel.RelFieldCollation
-
Returns a copy of this RelFieldCollation with the field index shifted
offset
to the right. - shift(int) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns a bit set with every bit moved up
offset
positions. - shift(Iterable<RexNode>, int) - Static method in class org.apache.calcite.rex.RexUtil
-
Shifts every
RexInputRef
in an expression byoffset
. - shift(RelCollation, int) - Static method in class org.apache.calcite.rel.RelCollations
- shift(RexBuilder, int) - Method in class org.apache.calcite.plan.RelOptPredicateList
- shift(RexNode, int) - Static method in class org.apache.calcite.rex.RexUtil
-
Shifts every
RexInputRef
in an expression byoffset
. - shift(RexNode, int, int) - Static method in class org.apache.calcite.rex.RexUtil
- SHIFT - Enum constant in enum org.apache.calcite.sql.SqlDialect.CalendarPolicy
- SHORT - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive
- SHORT_INTERVAL_DECIMAL_CAST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SHORT_INTERVAL_DECIMAL_CAST_ROUNDING_MODE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- shortDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- shortIntervalToDecimalCast(Long, int, int, BigDecimal) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Convert a short time interval to a decimal value.
- shortIntervalToDecimalCast(Long, int, int, BigDecimal, RoundingMode) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Convert a short time interval to a decimal value.
- shortLiteral(short) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- shortName - Variable in enum org.apache.calcite.rel.RelDistribution.Type
- shortString - Variable in enum org.apache.calcite.rel.RelFieldCollation.Direction
- shortString() - Method in class org.apache.calcite.rel.RelFieldCollation
- shouldAllowIntermediateOrderBy() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- shouldAllowOverRelation() - Method in class org.apache.calcite.sql.advise.SqlAdvisorValidator
- shouldAllowOverRelation() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- shouldConvertRaggedUnionTypesToVarying() - Method in class org.apache.calcite.rel.type.DelegatingTypeSystem
- shouldConvertRaggedUnionTypesToVarying() - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Whether the least restrictive type of a number of CHAR types of different lengths should be a VARCHAR type.
- shouldConvertRaggedUnionTypesToVarying() - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- shouldConvertRaggedUnionTypesToVarying() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- shouldConvertRaggedUnionTypesToVarying() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether the least restrictive type of a number of CHAR types of different lengths should be a VARCHAR type.
- shouldConvertRaggedUnionTypesToVarying() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- shouldConvertRaggedUnionTypesToVarying() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- shouldUseDoubleMultiplication(RelDataTypeFactory, RelDataType, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Returns whether a decimal multiplication should be implemented by casting arguments to double values.
- Shuttle - Class in org.apache.calcite.linq4j.tree
-
Extension to
Visitor
that returns a mutated tree. - Shuttle() - Constructor for class org.apache.calcite.linq4j.tree.Shuttle
- shuttleReferences(RexBuilder, RexNode, Multimap<RexNode, Integer>) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
Replaces all the possible sub-expressions by input references to the input node.
- shuttleReferences(RexBuilder, RexNode, Multimap<RexNode, Integer>, RelNode, Multimap<Integer, Integer>) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
Replaces all the possible sub-expressions by input references to the input node.
- shuttleReferences(RexBuilder, RexNode, Mapping) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
Replaces all the input references by the position in the input column set.
- sign(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SIGN
operator applied to double values. - sign(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SIGN
operator applied to int values. - sign(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SIGN
operator applied to long values. - sign(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SIGN
operator applied to BigDecimal values. - SIGN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SIGN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
SIGN(numeric)
function. - signum() - Method in class org.apache.calcite.sql.SqlIntervalLiteral.IntervalValue
- signum() - Method in class org.apache.calcite.sql.SqlIntervalLiteral
- signum() - Method in class org.apache.calcite.sql.SqlLiteral
-
Deprecated.
- SILENT_CACHING_INSTANCE - Static variable in class org.apache.calcite.statistic.QuerySqlStatisticProvider
-
Instance that uses SQL to compute statistics, does not log SQL statements, and caches up to 1,024 results for up to 30 minutes.
- similar(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.SimilarFunction
-
SQL
SIMILAR
function. - similar(String, String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.SimilarEscapeFunction
-
SQL
SIMILAR
function with escape. - SIMILAR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SIMILAR
operator. - SIMILAR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SIMILAR_ESCAPE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SIMILAR_TO - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- SimilarEscapeFunction() - Constructor for class org.apache.calcite.runtime.SqlFunctions.SimilarEscapeFunction
- SimilarFunction() - Constructor for class org.apache.calcite.runtime.SqlFunctions.SimilarFunction
- SimilarlityTableFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.SimilarlityTableFunction
- simple() - Method in class org.apache.calcite.rel.externalize.RelWriterImpl
-
Converts the collected terms and values to a string.
- simple(BlockStatement) - Static method in class org.apache.calcite.linq4j.tree.Blocks
-
Converts a simple "{ return expr; }" block into "expr"; otherwise throws.
- SIMPLE - Enum constant in enum org.apache.calcite.rel.core.Aggregate.Group
- SIMPLE - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Simple list.
- SIMPLE_BINARY_OPS - Static variable in enum org.apache.calcite.sql.SqlKind
-
Simple binary operators are those operators which expects operands from the same Domain.
- simpleContext(RelOptCluster) - Static method in class org.apache.calcite.plan.ViewExpanders
-
Creates a simple
ToRelContext
that cannot expand views. - simpleContext(RelOptCluster, List<RelHint>) - Static method in class org.apache.calcite.plan.ViewExpanders
-
Creates a simple
ToRelContext
that cannot expand views. - SimpleContext(SqlDialect, IntFunction<SqlNode>) - Constructor for class org.apache.calcite.rel.rel2sql.SqlImplementor.SimpleContext
- SimpleMakeCall(SqlOperator) - Constructor for class org.apache.calcite.sql.SqlJdbcFunctionCall.SimpleMakeCall
- simpleNames(Iterable<? extends SqlNode>) - Static method in class org.apache.calcite.sql.SqlIdentifier
-
Returns the simple names in a iterable of identifiers.
- simpleNames(List<? extends SqlNode>) - Static method in class org.apache.calcite.sql.SqlIdentifier
-
Returns the simple names in a list of identifiers.
- SimpleNamespaceContext - Class in org.apache.calcite.util
-
Simple
NamespaceContext
implementation. - SimpleNamespaceContext(Map<String, String>) - Constructor for class org.apache.calcite.util.SimpleNamespaceContext
- SimpleProfiler - Class in org.apache.calcite.profile
-
Basic implementation of
Profiler
. - SimpleProfiler() - Constructor for class org.apache.calcite.profile.SimpleProfiler
- simpleSarg(RexBuilder, RexNode, Sarg<C>, RexUnknownAs) - Static method in class org.apache.calcite.rex.RexUtil
-
Expands an 'all' or 'none' sarg.
- SimpleTable() - Constructor for class org.apache.calcite.util.Smalls.SimpleTable
- SimpleTableFunction() - Constructor for class org.apache.calcite.util.Smalls.SimpleTableFunction
- SimpleTableMacro() - Constructor for class org.apache.calcite.util.Smalls.SimpleTableMacro
- simplify - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- simplify() - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns a trait set similar to this one but with all composite traits flattened.
- simplify() - Method in interface org.apache.calcite.tools.RelBuilder.Config
-
Whether to simplify expressions; default true.
- simplify(RexBuilder, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.Create a
RexSimplify
, then call itsRexSimplify.simplify(RexNode, RexUnknownAs)
method. - simplify(RexBuilder, RexNode, boolean) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.Create a
RexSimplify
, then call itsRexSimplify.simplify(RexNode, RexUnknownAs)
method. - simplify(RexNode) - Method in class org.apache.calcite.rex.RexSimplify
-
Simplifies a boolean expression.
- simplifyAnd(RexBuilder, RexCall, boolean) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- simplifyAnd(RexCall) - Method in class org.apache.calcite.rex.RexSimplify
-
Deprecated.
- simplifyAnd2(RexBuilder, List<RexNode>, List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- simplifyAnd2ForUnknownAsFalse(RexBuilder, List<RexNode>, List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- simplifyAnds(Iterable<? extends RexNode>) - Method in class org.apache.calcite.rex.RexSimplify
-
Deprecated.
- simplifyAnds(RexBuilder, Iterable<? extends RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.Use
RexSimplify.simplifyAnds(Iterable, RexUnknownAs)
. - simplifyAnds(RexBuilder, Iterable<? extends RexNode>, boolean) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- simplifyDistributionKeys(RelDistribution, Set<Integer>) - Static method in class org.apache.calcite.rel.rules.ExchangeRemoveConstantKeysRule
-
Removes constant in distribution keys.
- simplifyFilterPredicates(Iterable<? extends RexNode>) - Method in class org.apache.calcite.rex.RexSimplify
-
Combines predicates AND, optimizes, and returns null if the result is always false.
- simplifyJoin(RelNode, ImmutableList<RexNode>, JoinRelType) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Simplifies outer joins if filter above would reject nulls.
- simplifyLimit() - Method in interface org.apache.calcite.tools.RelBuilder.Config
-
Whether to simplify LIMIT 0 to an empty relation; default true.
- simplifyOr(RexBuilder, RexCall) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- simplifyOr(RexCall) - Method in class org.apache.calcite.rex.RexSimplify
-
Deprecated.
- simplifyOrs(List<RexNode>) - Method in class org.apache.calcite.rex.RexSimplify
-
Deprecated.
- simplifyOrs(RexBuilder, List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- simplifyPreservingType(RexBuilder, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.Use
RexSimplify.simplifyPreservingType(RexNode)
, which allows you to specify anRexExecutor
. - simplifyPreservingType(RexNode) - Method in class org.apache.calcite.rex.RexSimplify
-
Simplifies a boolean expression, always preserving its type and its nullability.
- simplifyPreservingType(RexNode, RexUnknownAs, boolean) - Method in class org.apache.calcite.rex.RexSimplify
- simplifySql(String) - Method in class org.apache.calcite.sql.advise.SqlSimpleParser
-
Turns a partially completed or syntactically incorrect SQL statement into a simplified, valid one that can be validated.
- simplifySql(String, int) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
-
Turns a partially completed or syntactically incorrect sql statement into a simplified, valid one that can be passed into
SqlAdvisor.getCompletionHints(String, SqlParserPos)
. - simplifySql(String, int) - Method in class org.apache.calcite.sql.advise.SqlSimpleParser
-
Turns a partially completed or syntactically incorrect sql statement into a simplified, valid one that can be passed into getCompletionHints().
- simplifyUnknownAs(RexNode, RexUnknownAs) - Method in class org.apache.calcite.rex.RexSimplify
-
As
RexSimplify.simplify(RexNode)
, but specifying how UNKNOWN values are to be treated. - simplifyUnknownAsFalse(RexNode) - Method in class org.apache.calcite.rex.RexSimplify
-
As
RexSimplify.simplify(RexNode)
, but for a boolean expression for which a result of UNKNOWN will be treated as FALSE. - simplifyValues() - Method in interface org.apache.calcite.tools.RelBuilder.Config
-
Whether to simplify
Union(Values, Values)
orUnion(Project(Values))
toValues
; default true. - sin(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SIN
operator applied to double values. - sin(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SIN
operator applied to BigDecimal values. - SIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
SIN(numeric)
function. - sind(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SIND
operator applied to double values. - sind(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SIND
operator applied to BigDecimal values. - SIND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SIND - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
SIND(numeric)
function; returns the sine ofvalue
. - single() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- single() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the only element of a sequence, and throws an exception if there is not exactly one element in the sequence.
- single(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the only element of a sequence, and throws an exception if there is not exactly one element in the sequence.
- single(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the only element of a sequence that satisfies a specified condition, and throws an exception if more than one such element exists.
- single(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- single(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the only element of a sequence that satisfies a specified condition, and throws an exception if more than one such element exists.
- single(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the only element of a sequence, and throws an exception if there is not exactly one element in the sequence.
- single(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the only element of a sequence, and throws an exception if there is not exactly one element in the sequence.
- single(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- single(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the only element of a sequence that satisfies a specified condition, and throws an exception if more than one such element exists.
- single(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the only element of a sequence that satisfies a specified condition, and throws an exception if more than one such element exists.
- single(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- single(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- single(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns the only element of a sequence that satisfies a specified condition, and throws an exception if more than one such element exists.
- SINGLE_VALUE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
SINGLE_VALUE
aggregate function. - SINGLE_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
SINGLE_VALUE
aggregate function. - SingleColumnAliasRelDataType - Class in org.apache.calcite.rel.type
-
Specific type of RelDataType that corresponds to a single column table, where column can have alias.
- SingleColumnAliasRelDataType(RelDataType, RelDataType) - Constructor for class org.apache.calcite.rel.type.SingleColumnAliasRelDataType
- singleGroupResultSelector(Function1<TAccumulate, TResult>) - Method in class org.apache.calcite.adapter.enumerable.BasicAggregateLambdaFactory
- singleGroupResultSelector(Function1<TOrigAccumulate, TResult>) - Method in interface org.apache.calcite.adapter.enumerable.AggregateLambdaFactory
- singleGroupResultSelector(Function1<TOrigAccumulate, TResult>) - Method in class org.apache.calcite.adapter.enumerable.LazyAggregateLambdaFactory
- singleOrDefault() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- singleOrDefault() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the only element of a sequence, or a default value if the sequence is empty; this method throws an exception if there is more than one element in the sequence.
- singleOrDefault() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns the only element of a sequence, or a default value if the sequence is empty; this method throws an exception if there is more than one element in the sequence.
- singleOrDefault(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the only element of a sequence, or a default value if the sequence is empty; this method throws an exception if there is more than one element in the sequence.
- singleOrDefault(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the only element of a sequence that satisfies a specified condition or a default value if no such element exists; this method throws an exception if more than one element satisfies the condition.
- singleOrDefault(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- singleOrDefault(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the only element of a sequence that satisfies a specified condition or a default value if no such element exists; this method throws an exception if more than one element satisfies the condition.
- singleOrDefault(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the only element of a sequence, or a default value if the sequence is empty; this method throws an exception if there is more than one element in the sequence.
- singleOrDefault(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the only element of a sequence, or a default value if the sequence is empty; this method throws an exception if there is more than one element in the sequence.
- singleOrDefault(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- singleOrDefault(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns the only element of a sequence that satisfies a specified condition or a default value if no such element exists; this method throws an exception if more than one element satisfies the condition.
- singleOrDefault(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns the only element of a sequence that satisfies a specified condition or a default value if no such element exists; this method throws an exception if more than one element satisfies the condition.
- singleOrDefault(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- singleOrDefault(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- singleOrDefault(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns the only element of a sequence that satisfies a specified condition or a default value if no such element exists; this method throws an exception if more than one element satisfies the condition.
- SingleRel - Class in org.apache.calcite.rel
-
Abstract base class for relational expressions with a single input.
- SingleRel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.rel.SingleRel
-
Creates a
SingleRel
. - singleton(RexBuilder, RelDataType, AggregateCall) - Method in interface org.apache.calcite.sql.SqlSingletonAggFunction
-
Generates an expression for the value of the aggregate function when applied to a single row.
- singleton(RexBuilder, RelDataType, AggregateCall) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.AbstractSumSplitter
- singleton(RexBuilder, RelDataType, AggregateCall) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.CountSplitter
-
Generates an expression for the value of the aggregate function when applied to a single row.
- singleton(RexBuilder, RelDataType, AggregateCall) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.SelfSplitter
- singleton(RexBuilder, RelDataType, AggregateCall) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.Sum0Splitter
- singleton(V) - Method in interface org.apache.calcite.util.RangeSets.Consumer
- singleton(V) - Method in interface org.apache.calcite.util.RangeSets.Handler
- SINGLETON - Enum constant in enum org.apache.calcite.rel.RelDistribution.Type
-
There is only one instance of the stream.
- SINGLETON - Static variable in class org.apache.calcite.rel.RelDistributions
-
The singleton singleton distribution.
- SINGLETON_EMPTY - Static variable in class org.apache.calcite.sql.SqlNodeList
-
A SqlNodeList that has a single element that is an empty list.
- SINGLETON_ENUMERABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SINGLETON_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Ensure a class only has one instance, and provide a global point of access to it.
- SINGLETON_STAR - Static variable in class org.apache.calcite.sql.SqlNodeList
-
A SqlNodeList that has a single element that is a star identifier.
- singletonArrayIterator(Comparator<V>, List<V>) - Static method in class org.apache.calcite.runtime.SortedMultiMap
-
Shortcut method if the partition key is empty.
- singletonEnumerable(T) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Returns an
Enumerable
that has one element. - singletonEnumerator(T) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Returns an
Enumerator
that has one element. - singletonNullEnumerator() - Static method in class org.apache.calcite.linq4j.Linq4j
-
Returns an
Enumerator
that has one null element. - SingleValuesOptimizationRules - Class in org.apache.calcite.rel.rules
-
Collection of rules which simplify joins which have one of their input as constant relations
Values
that produce a single row. - SingleValuesOptimizationRules() - Constructor for class org.apache.calcite.rel.rules.SingleValuesOptimizationRules
- SingleValuesOptimizationRules.PruneSingleValueRule - Class in org.apache.calcite.rel.rules
-
Abstract class for all the SingleValuesOptimizationRules.
- SingleValuesOptimizationRules.PruneSingleValueRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- sinh(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SINH
operator applied to double values. - sinh(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SINH
operator applied to BigDecimal values. - SINH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SINH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- sink - Variable in class org.apache.calcite.interpreter.UncollectNode
- sink(RelNode) - Method in interface org.apache.calcite.interpreter.Compiler
-
Creates a Sink for a relational expression to write into.
- sink(RelNode) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- Sink - Interface in org.apache.calcite.interpreter
-
Sink to which to send rows.
- size - Variable in enum org.apache.calcite.linq4j.tree.Primitive
-
The size of a value of this type, in bits.
- size() - Method in class org.apache.calcite.interpreter.Row.RowBuilder
- size() - Method in class org.apache.calcite.interpreter.Row
- size() - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns the size of the RelTraitSet.
- size() - Method in class org.apache.calcite.runtime.ConsList
- size() - Method in class org.apache.calcite.runtime.FlatLists.Flat1List
- size() - Method in class org.apache.calcite.runtime.FlatLists.Flat2List
- size() - Method in class org.apache.calcite.runtime.FlatLists.Flat3List
- size() - Method in class org.apache.calcite.runtime.FlatLists.Flat4List
- size() - Method in class org.apache.calcite.runtime.FlatLists.Flat5List
- size() - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- size() - Method in class org.apache.calcite.sql.SqlNodeList
- size() - Method in interface org.apache.calcite.sql.SqlSpecialOperator.TokenSequence
- size() - Method in class org.apache.calcite.tools.RelBuilder
-
Returns the size of the stack.
- size() - Method in class org.apache.calcite.util.CastingList
- size() - Method in class org.apache.calcite.util.ChunkList
- size() - Method in class org.apache.calcite.util.CompositeList
- size() - Method in class org.apache.calcite.util.CompositeMap
- size() - Method in class org.apache.calcite.util.EquivalenceSet
-
Returns the number of elements in this equivalence set.
- size() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns the number of bits of space actually in use by this
ImmutableBitSet
to represent bit values. - size() - Method in class org.apache.calcite.util.ImmutableIntList
- size() - Method in class org.apache.calcite.util.ImmutableNullableList
- size() - Method in class org.apache.calcite.util.ImmutableNullableSet
- size() - Method in class org.apache.calcite.util.IntegerIntervalSet
- size() - Method in class org.apache.calcite.util.mapping.AbstractSourceMapping
- size() - Method in class org.apache.calcite.util.mapping.AbstractTargetMapping
- size() - Method in interface org.apache.calcite.util.mapping.Mapping
-
Returns the number of elements in the mapping.
- size() - Method in interface org.apache.calcite.util.mapping.Mappings.CoreMapping
-
Returns the number of elements in the mapping.
- size() - Method in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
- size() - Method in class org.apache.calcite.util.mapping.Mappings.OverridingSourceMapping
- size() - Method in class org.apache.calcite.util.mapping.Mappings.OverridingTargetMapping
- size() - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- size() - Method in class org.apache.calcite.util.PartiallyOrderedSet
- size() - Method in class org.apache.calcite.util.Permutation
-
Returns the number of elements in this permutation.
- size() - Method in class org.apache.calcite.util.UnmodifiableArrayList
- SK_FULL_SCAN - Enum constant in enum org.apache.calcite.adapter.innodb.QueryType
-
Scanning table fully with secondary key.
- SK_POINT_QUERY - Enum constant in enum org.apache.calcite.adapter.innodb.QueryType
-
Secondary key point query.
- SK_RANGE_QUERY - Enum constant in enum org.apache.calcite.adapter.innodb.QueryType
-
Secondary key range query with lower and upper bound.
- skip(int) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- skip(int) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- skip(int) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Bypasses a specified number of elements in a sequence and then returns the remaining elements.
- skip(int) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Bypasses a specified number of elements in a sequence and then returns the remaining elements.
- skip(List<E>) - Static method in class org.apache.calcite.util.Util
-
Returns all but the first element of a list.
- skip(List<E>, int) - Static method in class org.apache.calcite.util.Util
-
Returns all but the first
n
elements of a list. - skip(Enumerable<TSource>, int) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Bypasses a specified number of elements in a sequence and then returns the remaining elements.
- skip(Queryable<T>, int) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Bypasses a specified number of elements in a sequence and then returns the remaining elements.
- skip(Queryable<T>, int) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Bypasses a specified number of elements in a sequence and then returns the remaining elements.
- skip(Queryable<T>, int) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- SKIP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SKIP_PAST_LAST_ROW - Enum constant in enum org.apache.calcite.sql.SqlMatchRecognize.AfterOption
- SKIP_TO_FIRST - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SKIP TO FIRST
qualifier of restarting point in aMATCH_RECOGNIZE
clause. - SKIP_TO_FIRST - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- SKIP_TO_LAST - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SKIP TO LAST
qualifier of restarting point in aMATCH_RECOGNIZE
clause. - SKIP_TO_LAST - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- SKIP_TO_NEXT_ROW - Enum constant in enum org.apache.calcite.sql.SqlMatchRecognize.AfterOption
- skipLast(int) - Method in class org.apache.calcite.sql.SqlIdentifier
-
Creates an identifier that consists of all but the last
n
name segments of this one. - skipLast(List<E>) - Static method in class org.apache.calcite.util.Util
-
Returns every element of a list but its last element.
- skipLast(List<E>, int) - Static method in class org.apache.calcite.util.Util
-
Returns every element of a list but its last
n
elements. - skipMatch(VolcanoRuleMatch) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Returns whether to skip a match.
- skipWhile(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Bypasses elements in a sequence as long as a specified condition is true and then returns the remaining elements.
- skipWhile(Enumerable<TSource>, Predicate2<TSource, Integer>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Bypasses elements in a sequence as long as a specified condition is true and then returns the remaining elements.
- skipWhile(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- skipWhile(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Bypasses elements in a sequence as long as a specified condition is true and then returns the remaining elements.
- skipWhile(Predicate2<T, Integer>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- skipWhile(Predicate2<TSource, Integer>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Bypasses elements in a sequence as long as a specified condition is true and then returns the remaining elements.
- skipWhile(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Bypasses elements in a sequence as long as a specified condition is true and then returns the remaining elements.
- skipWhile(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Bypasses elements in a sequence as long as a specified condition is true and then returns the remaining elements.
- skipWhile(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- skipWhile(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- skipWhile(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Bypasses elements in a sequence as long as a specified condition is true and then returns the remaining elements.
- skipWhileN(Queryable<T>, FunctionExpression<Predicate2<T, Integer>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Bypasses elements in a sequence as long as a specified condition is true and then returns the remaining elements.
- skipWhileN(Queryable<T>, FunctionExpression<Predicate2<T, Integer>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Bypasses elements in a sequence as long as a specified condition is true and then returns the remaining elements.
- skipWhileN(Queryable<T>, FunctionExpression<Predicate2<T, Integer>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- skipWhileN(FunctionExpression<Predicate2<T, Integer>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- skipWhileN(FunctionExpression<Predicate2<T, Integer>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Bypasses elements in a sequence as long as a specified condition is true and then returns the remaining elements.
- slice(List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the SLICE function.
- SLICE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SLICE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The internal "$SLICE" operator takes a multiset of records and returns a multiset of the first column of those records.
- slice0(Enumerable<E[]>) - Static method in class org.apache.calcite.runtime.Enumerables
-
Converts an enumerable over singleton arrays into the enumerable of their first elements.
- SLICE0 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- slotCount - Variable in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRule
- slots - Variable in class org.apache.calcite.plan.SubstitutionVisitor
-
Workspace while rule is being matched.
- slots - Variable in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRuleCall
- SMALLINT - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- Smalls - Class in org.apache.calcite.util
-
Holder for various classes and functions used in tests as user-defined functions and so forth.
- Smalls.AllTypesFunction - Class in org.apache.calcite.util
-
UDF class that provides user-defined functions for each data type.
- Smalls.AnotherTableMacroFunctionWithNamedParameters - Class in org.apache.calcite.util
-
User-defined table-macro function with named and optional parameters.
- Smalls.AwkwardFunction - Class in org.apache.calcite.util
-
Example of a UDF class that needs to be instantiated but cannot be.
- Smalls.CountArgs0Function - Class in org.apache.calcite.util
-
Example of a UDF that has overloaded UDFs (same name, different args).
- Smalls.CountArgs1Function - Class in org.apache.calcite.util
- Smalls.CountArgs1NullableFunction - Class in org.apache.calcite.util
- Smalls.CountArgs2Function - Class in org.apache.calcite.util
- Smalls.FibonacciTableFunction - Class in org.apache.calcite.util
-
Example of a UDF with non-default constructor.
- Smalls.IdentityTableFunction - Class in org.apache.calcite.util
-
A table function that returns its input value.
- Smalls.IntString - Class in org.apache.calcite.util
-
Class with int and String fields.
- Smalls.MazeTable - Class in org.apache.calcite.util
-
The real MazeTable may be found in example/function.
- Smalls.MultipleFunction - Class in org.apache.calcite.util
-
UDF class that has multiple methods, some overloaded.
- Smalls.MyAbcdeFunction - Class in org.apache.calcite.util
-
Example of a UDF with named parameters, some of them optional.
- Smalls.MyDeterministicPlusFunction - Class in org.apache.calcite.util
-
As
Smalls.MyPlusFunction
but declared to be deterministic. - Smalls.MyDoubleFunction - Class in org.apache.calcite.util
-
Example of a UDF with a static
eval
method. - Smalls.MyExceptionFunction - Class in org.apache.calcite.util
-
User-defined function that declares exceptions.
- Smalls.MyIncrement - Class in org.apache.calcite.util
-
User-defined function with two arguments.
- Smalls.MyLeftFunction - Class in org.apache.calcite.util
-
Example of a UDF with named parameters.
- Smalls.MyPlusFunction - Class in org.apache.calcite.util
-
Example of a UDF with a non-static
eval
method, and named parameters. - Smalls.MyPlusInitFunction - Class in org.apache.calcite.util
-
As
Smalls.MyPlusFunction
but constructor has aFunctionContext
parameter. - Smalls.MyStaticSumFunction - Class in org.apache.calcite.util
-
Example of a user-defined aggregate function (UDAF), whose methods are static.
- Smalls.MySum3 - Class in org.apache.calcite.util
-
Example of a user-defined aggregate function that implements a generic interface.
- Smalls.MySumFunction - Class in org.apache.calcite.util
-
Example of a user-defined aggregate function (UDAF).
- Smalls.MyTableFunction - Class in org.apache.calcite.util
-
A table function that returns a
QueryableTable
. - Smalls.MyThreeParamsSumFunctionWithFilter1 - Class in org.apache.calcite.util
-
Example of a user-defined aggregate function (UDAF), whose methods are static.
- Smalls.MyThreeParamsSumFunctionWithFilter2 - Class in org.apache.calcite.util
-
Example of a user-defined aggregate function (UDAF), whose methods are static.
- Smalls.MyToStringFunction - Class in org.apache.calcite.util
-
Example of a non-strict UDF.
- Smalls.MyTwoParamsSumFunctionFilter1 - Class in org.apache.calcite.util
-
Example of a user-defined aggregate function (UDAF) with two parameters.
- Smalls.MyTwoParamsSumFunctionFilter2 - Class in org.apache.calcite.util
-
Another example of a user-defined aggregate function (UDAF) with two parameters.
- Smalls.Null4Function - Class in org.apache.calcite.util
-
Example of a semi-strict UDF.
- Smalls.Null8Function - Class in org.apache.calcite.util
-
Example of a picky, semi-strict UDF.
- Smalls.SimpleTable - Class in org.apache.calcite.util
-
Table with columns (A, B).
- Smalls.SimpleTableFunction - Class in org.apache.calcite.util
-
A table function that returns a
QueryableTable
. - Smalls.SimpleTableMacro - Class in org.apache.calcite.util
-
Implementation of
TableMacro
interface withSmalls.SimpleTableMacro.apply(java.util.List<?>)
method that returnsQueryable
table. - Smalls.StaticTableMacroFunction - Class in org.apache.calcite.util
-
User-defined table-macro function whose eval method is static.
- Smalls.SumFunctionBadIAdd - Class in org.apache.calcite.util
-
User-defined function.
- Smalls.TableMacroFunction - Class in org.apache.calcite.util
-
User-defined table-macro function.
- Smalls.TableMacroFunctionWithNamedParameters - Class in org.apache.calcite.util
-
User-defined table-macro function with named and optional parameters.
- Smalls.TestStaticTableFunction - Class in org.apache.calcite.util
-
A table function that returns a
QueryableTable
via a static method. - Smalls.WideProductSale - Class in org.apache.calcite.util
-
Table with a lot of columns.
- Smalls.WideSaleSchema - Class in org.apache.calcite.util
-
Schema containing a
prod
table with a lot of columns. - snapshot(CalciteSchema, SchemaVersion) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- snapshot(CalciteSchema, SchemaVersion) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns a snapshot representation of this CalciteSchema.
- snapshot(RelMetadataQuery, RelNode) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Helper method to determine a
Snapshot
's collation. - snapshot(RelMetadataQuery, RelNode) - Static method in class org.apache.calcite.rel.metadata.RelMdDistribution
-
Helper method to determine a
Snapshot
's distribution. - snapshot(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Snapshot
of a given snapshot period. - snapshot(SchemaVersion) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- snapshot(SchemaVersion) - Method in class org.apache.calcite.schema.impl.AbstractSchema
- snapshot(SchemaVersion) - Method in class org.apache.calcite.schema.impl.DelegatingSchema
- snapshot(SchemaVersion) - Method in interface org.apache.calcite.schema.Schema
-
Returns the snapshot of this schema as of the specified time.
- Snapshot - Class in org.apache.calcite.rel.core
-
Relational expression that returns the contents of a relation expression as it was at a given time in the past.
- Snapshot(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RexNode) - Constructor for class org.apache.calcite.rel.core.Snapshot
-
Creates a Snapshot.
- Snapshot(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.calcite.rel.core.Snapshot
-
Creates a Snapshot.
- Snapshot(RelInput) - Constructor for class org.apache.calcite.rel.core.Snapshot
-
Creates a Snapshot by parsing serialized output.
- SNAPSHOT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SNAPSHOT operator.
- SNAPSHOT - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
Snapshot
nodes. - SNAPSHOT_FACTORY - Static variable in class org.apache.calcite.adapter.jdbc.JdbcRules
- snapshotFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- SnapshotFactoryImpl() - Constructor for class org.apache.calcite.rel.core.RelFactories.SnapshotFactoryImpl
- SNOWFLAKE - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
A collection of operators that are in Snowflake but not in standard SQL.
- SNOWFLAKE - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- SnowflakeSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Snowflake database. - SnowflakeSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.SnowflakeSqlDialect
-
Creates a SnowflakeSqlDialect.
- SO_CONNECT_TIMEOUT - Static variable in class org.apache.calcite.runtime.SocketFactoryImpl
-
Connect timeout in milliseconds.
- SO_KEEPALIVE - Static variable in class org.apache.calcite.runtime.SocketFactoryImpl
-
Whether keep-alives should be sent.
- SO_LINGER - Static variable in class org.apache.calcite.runtime.SocketFactoryImpl
-
Enabling lingering with 0-timeout will cause the socket to be closed forcefully upon execution of
close()
. - SO_RCVBUF - Static variable in class org.apache.calcite.runtime.SocketFactoryImpl
-
Size of receiving buffer.
- SO_REUSEADDR - Static variable in class org.apache.calcite.runtime.SocketFactoryImpl
-
Whether the address should be reused.
- SO_SNDBUF - Static variable in class org.apache.calcite.runtime.SocketFactoryImpl
-
Size of sending buffer iff needed.
- SO_TIMEOUT - Static variable in class org.apache.calcite.runtime.SocketFactoryImpl
-
Read timeout in milliseconds.
- SocketFactoryImpl - Class in org.apache.calcite.runtime
-
Extends the SocketFactory object with the main functionality being that the created sockets inherit a set of options whose values are set in the SocketFactoryImpl.
- SocketFactoryImpl() - Constructor for class org.apache.calcite.runtime.SocketFactoryImpl
- sole(List<T>) - Static method in class org.apache.calcite.rel.AbstractRelNode
- solve(int, int, int) - Static method in class org.apache.calcite.example.maze.MazeTable
-
Table function that generates a maze with a solution.
- solveOrder - Variable in class org.apache.calcite.plan.RelOptRuleOperand
- some(RelOptRuleOperand, RelOptRuleOperand...) - Static method in class org.apache.calcite.plan.RelOptRule
- some(RelNode, ImmutableList<RexNode>, SqlQuantifyOperator) - Static method in class org.apache.calcite.rex.RexSubQuery
-
Creates a SOME sub-query.
- some(RexNode, SqlOperator, Function<RelBuilder, RelNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a SOME (or ANY) predicate.
- some(SqlKind) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Returns the operator for
SOME comparisonKind
. - SOME - Enum constant in enum org.apache.calcite.plan.RelOptRuleOperandChildPolicy
-
Signifies that the operand's children must precisely match its child operands, in order.
- SOME - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SOME
quantification operator (also calledANY
). - SOME - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
SOME
aggregate function. - SOME_EQ - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- SOME_GE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- SOME_GT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- SOME_LE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- SOME_LT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
< SOME
operator (synonymous with< ANY
). - SOME_NE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- someButNotAllArgumentsAreNamed() - Method in interface org.apache.calcite.runtime.CalciteResource
- sort(int...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Sort
by field ordinals. - sort(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Sort
by expressions. - sort(Iterable<RexNode>) - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
-
Returns a copy of this AggCall that sorts its input values by
orderKeys
before aggregating, as in SQL'sWITHIN GROUP
clause. - sort(RelMetadataQuery, RelNode) - Static method in class org.apache.calcite.rel.metadata.RelMdDistribution
-
Helper method to determine a
Sort
's distribution. - sort(RelCollation) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Helper method to determine a
Sort
's collation. - sort(RelCollation) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Sort
by specifying collations. - sort(RexNode...) - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
-
Returns a copy of this AggCall that sorts its input values by
orderKeys
before aggregating, as in SQL'sWITHIN GROUP
clause. - sort(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Sort
by expressions. - Sort - Class in org.apache.calcite.rel.core
-
Relational expression that imposes a particular sort order on its input without otherwise changing its content.
- Sort(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.calcite.rel.core.Sort
-
Creates a Sort.
- Sort(RelOptCluster, RelTraitSet, RelNode, RelCollation) - Constructor for class org.apache.calcite.rel.core.Sort
-
Creates a Sort.
- Sort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.calcite.rel.core.Sort
-
Creates a Sort.
- Sort(RelInput) - Constructor for class org.apache.calcite.rel.core.Sort
-
Creates a Sort by parsing serialized output.
- SORT - Static variable in class org.apache.calcite.adapter.cassandra.CassandraRules
- SORT - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- SORT - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
Sort
nodes. - SORT - Static variable in interface org.apache.calcite.rel.rules.ExchangeRemoveConstantKeysRule.Config
- SORT - Static variable in interface org.apache.calcite.rel.rules.PruneEmptyRules.RemoveEmptySingleRule.RemoveEmptySingleRuleConfig
- SORT_ARRAY - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SORT_ARRAY
function (Spark semantics). - SORT_ARRAY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SORT_ARRAY - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "SORT_ARRAY(array)" function (Spark).
- SORT_EXCHANGE_FACTORY - Static variable in class org.apache.calcite.adapter.jdbc.JdbcRules
- SORT_EXCHANGE_REMOVE_CONSTANT_KEYS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that removes constants inside a
LogicalSortExchange
. - SORT_FACTORY - Static variable in class org.apache.calcite.adapter.jdbc.JdbcRules
- SORT_FETCH_ZERO_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts a
Sort
to empty if it hasLIMIT 0
. - SORT_FILTER - Static variable in class org.apache.calcite.adapter.innodb.InnodbRules
- SORT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts a
Sort
to empty if its child is empty. - SORT_JOIN_COPY - Static variable in class org.apache.calcite.rel.rules.CoreRules
- SORT_JOIN_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- SORT_PROJECT_TRANSPOSE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- SORT_PROJECT_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- SORT_REMOVE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that removes a
Sort
if its input is already sorted. - SORT_REMOVE_CONSTANT_KEYS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that removes keys from a
Sort
if those keys are known to be constant, or removes the entire Sort if all keys are constant. - SORT_REMOVE_REDUNDANT - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that removes redundant
Order By
orLimit
when its input RelNode's max row count is less than or equal to specified row count.All of them are represented bySort
- SORT_SCAN - Static variable in class org.apache.calcite.adapter.innodb.InnodbRules
-
Rule to convert a
Sort
to aInnodbSort
based on InnoDB table clustering index. - SORT_UNION_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- SORT_UNION_TRANSPOSE_MATCH_NULL_FETCH - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.SORT_UNION_TRANSPOSE
, but for a Union implementation that preserves the ordering of its inputs. - sortArray(Object) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Sorts an array of this primitive type.
- sortArray(Object, int, int) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Sorts a specified range of an array of this primitive type.
- sortArray(List, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the SORT_ARRAY function.
- SORTED_GROUP_BY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SORTED_MULTI_MAP_ARRAYS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SORTED_MULTI_MAP_PUT_MULTI - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SORTED_MULTI_MAP_SINGLETON - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SORTED_SET - Enum constant in enum org.apache.calcite.adapter.redis.RedisDataType
-
Redis Sorted Sets are, similarly to Redis Sets, non repeating collections of Strings.
- sortedGroupBy(Enumerable<TSource>, Function1<TSource, TKey>, Function0<TAccumulate>, Function2<TAccumulate, TSource, TAccumulate>, Function2<TKey, TAccumulate, TResult>, Comparator<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Group keys are sorted already.
- sortedGroupBy(Function1<T, TKey>, Function0<TAccumulate>, Function2<TAccumulate, T, TAccumulate>, Function2<TKey, TAccumulate, TResult>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- sortedGroupBy(Function1<TSource, TKey>, Function0<TAccumulate>, Function2<TAccumulate, TSource, TAccumulate>, Function2<TKey, TAccumulate, TResult>, Comparator<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Group keys are sorted already.
- SortedMultiMap<K,
V> - Class in org.apache.calcite.runtime -
Map that allows you to partition values into lists according to a common key, and then convert those lists into an iterator of sorted arrays.
- SortedMultiMap() - Constructor for class org.apache.calcite.runtime.SortedMultiMap
- sortExchange(RelDistribution, RelCollation) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a SortExchange by distribution and collation.
- SortExchange - Class in org.apache.calcite.rel.core
- SortExchange(RelOptCluster, RelTraitSet, RelNode, RelDistribution, RelCollation) - Constructor for class org.apache.calcite.rel.core.SortExchange
-
Creates a SortExchange.
- SortExchange(RelInput) - Constructor for class org.apache.calcite.rel.core.SortExchange
-
Creates a SortExchange by parsing serialized output.
- sortExchangeFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- sortFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- SortJoinCopyRule - Class in org.apache.calcite.rel.rules
- SortJoinCopyRule(Class<? extends Sort>, Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.SortJoinCopyRule
-
Deprecated.
- SortJoinCopyRule(SortJoinCopyRule.Config) - Constructor for class org.apache.calcite.rel.rules.SortJoinCopyRule
-
Creates a SortJoinCopyRule.
- SortJoinCopyRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- SortJoinTransposeRule - Class in org.apache.calcite.rel.rules
- SortJoinTransposeRule(Class<? extends Sort>, Class<? extends Join>) - Constructor for class org.apache.calcite.rel.rules.SortJoinTransposeRule
-
Deprecated.
- SortJoinTransposeRule(Class<? extends Sort>, Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.SortJoinTransposeRule
-
Deprecated.
- SortJoinTransposeRule(SortJoinTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.SortJoinTransposeRule
-
Creates a SortJoinTransposeRule.
- SortJoinTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- sortLimit(int, int, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Sort
by a list of expressions, with limit and offset. - sortLimit(int, int, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Sort
by expressions, with limit and offset. - sortLimit(RexNode, RexNode, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Sort
by a list of expressions, with limitNode and offsetNode. - SortMergeRule - Class in org.apache.calcite.rel.rules
-
This rule try to merge the double
Sort
,one is Limit semantics, another sort is Limit or TOPN semantics. - SortMergeRule(SortMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.SortMergeRule
- SortMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- SortNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
Sort
. - SortNode(Compiler, Sort) - Constructor for class org.apache.calcite.interpreter.SortNode
- SortProjectTransposeRule - Class in org.apache.calcite.rel.rules
- SortProjectTransposeRule(Class<? extends Sort>, Class<? extends Project>) - Constructor for class org.apache.calcite.rel.rules.SortProjectTransposeRule
-
Deprecated.
- SortProjectTransposeRule(Class<? extends Sort>, Class<? extends Project>, String) - Constructor for class org.apache.calcite.rel.rules.SortProjectTransposeRule
-
Deprecated.
- SortProjectTransposeRule(Class<? extends Sort>, Class<? extends Project>, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.SortProjectTransposeRule
-
Deprecated.
- SortProjectTransposeRule(RelOptRuleOperand) - Constructor for class org.apache.calcite.rel.rules.SortProjectTransposeRule
-
Deprecated.
- SortProjectTransposeRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.SortProjectTransposeRule
-
Deprecated.
- SortProjectTransposeRule(SortProjectTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.SortProjectTransposeRule
-
Creates a SortProjectTransposeRule.
- SortProjectTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- SortRemoveConstantKeysRule - Class in org.apache.calcite.rel.rules
-
Planner rule that removes keys from a a
Sort
if those keys are known to be constant, or removes the entire Sort if all keys are constant. - SortRemoveConstantKeysRule(SortRemoveConstantKeysRule.Config) - Constructor for class org.apache.calcite.rel.rules.SortRemoveConstantKeysRule
-
Creates a SortRemoveConstantKeysRule.
- SortRemoveConstantKeysRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- SortRemoveRedundantRule - Class in org.apache.calcite.rel.rules
-
Rule that removes redundant
ORDER BY
orLIMIT
when its input RelNode's maximum row count is less than or equal to specified row count. - SortRemoveRedundantRule(SortRemoveRedundantRule.Config) - Constructor for class org.apache.calcite.rel.rules.SortRemoveRedundantRule
- SortRemoveRedundantRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- SortRemoveRule - Class in org.apache.calcite.rel.rules
-
Planner rule that removes a
Sort
if its input is already sorted. - SortRemoveRule(SortRemoveRule.Config) - Constructor for class org.apache.calcite.rel.rules.SortRemoveRule
-
Creates a SortRemoveRule.
- SortRemoveRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.SortRemoveRule
-
Deprecated.
- SortRemoveRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- sortsAs(String) - Static method in class org.apache.calcite.test.Matchers
-
Matcher that succeeds for any collection that, when converted to strings and sorted on those strings, matches the given reference string.
- SortUnionTransposeRule - Class in org.apache.calcite.rel.rules
- SortUnionTransposeRule(Class<? extends Sort>, Class<? extends Union>, boolean, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.SortUnionTransposeRule
-
Deprecated.
- SortUnionTransposeRule(SortUnionTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.SortUnionTransposeRule
-
Creates a SortUnionTransposeRule.
- SortUnionTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- soundex(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SOUNDEX(string) function.
- SOUNDEX - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SOUNDEX - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- SOUNDEX_SPARK - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SOUNDEX
function (Spark semantics). - SOUNDEX_SPARK - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SOUNDEX_SPARK - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The variant of the SOUNDEX operator.
- soundexSpark(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SOUNDEX(string) function but return original s when not mapped.
- source - Variable in class org.apache.calcite.adapter.csv.CsvTable
- source - Variable in class org.apache.calcite.adapter.file.CsvTable
- source - Variable in class org.apache.calcite.interpreter.UncollectNode
- source - Variable in class org.apache.calcite.util.graph.DefaultEdge
- source - Variable in class org.apache.calcite.util.mapping.IntPair
- source() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHit
- source() - Method in interface org.apache.calcite.util.Puffin.Line
-
Returns the current source.
- source(List<Integer>, int) - Static method in class org.apache.calcite.util.mapping.Mappings
- source(RelNode, int) - Method in interface org.apache.calcite.interpreter.Compiler
- source(RelNode, int) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- Source - Interface in org.apache.calcite.interpreter
-
Source of rows.
- Source - Interface in org.apache.calcite.util
-
Source of data.
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdAllPredicates
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdCollation
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdDistinctRowCount
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdDistribution
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdExplainVisibility
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdLowerBoundCost
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdMaxRowCount
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdMeasure
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdMemory
-
Source for
BuiltInMetadata.Memory
. - SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdMinRowCount
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdParallelism
-
Source for
BuiltInMetadata.Parallelism
. - SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdPercentageOriginalRows
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdPopulationSize
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdPredicates
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdRowCount
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdSelectivity
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdSize
-
Source for
BuiltInMetadata.Size
. - SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdTableReferences
- SOURCE - Static variable in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- SOURCE_SORTER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- sourceExpressionList - Variable in class org.apache.calcite.rel.mutable.MutableTableModify
- sourceOrFields() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHit
- sources - Variable in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- Sources - Class in org.apache.calcite.util
-
Utilities for
Source
. - SourceSorter<TAccumulate,
TSource, TSortKey> - Class in org.apache.calcite.adapter.enumerable -
Helper that combines the sorting process and accumulating process against the aggregate execution, used with
LazyAggregateLambdaFactory
. - SourceSorter(Function2<TAccumulate, TSource, TAccumulate>, Function1<TSource, TSortKey>, Comparator<TSortKey>) - Constructor for class org.apache.calcite.adapter.enumerable.SourceSorter
- SourceStringReader - Class in org.apache.calcite.util
-
Extension to
StringReader
that allows the original string to be recovered. - SourceStringReader(String) - Constructor for class org.apache.calcite.util.SourceStringReader
-
Creates a source string reader.
- sourceTable - Variable in class org.apache.calcite.sql.ddl.SqlCreateTableLike
- space(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SPACE(int) function.
- SPACE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SPACE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- SpaceFillingCurve2D - Interface in org.apache.calcite.runtime
-
Utilities for space-filling curves.
- SpaceFillingCurve2D.AbstractRange - Class in org.apache.calcite.runtime
-
Base class for Range implementations.
- SpaceFillingCurve2D.CoveredRange - Class in org.apache.calcite.runtime
-
Range that is covered.
- SpaceFillingCurve2D.IndexRange - Interface in org.apache.calcite.runtime
-
Range.
- SpaceFillingCurve2D.IndexRangeOrdering - Class in org.apache.calcite.runtime
-
Lexicographic ordering for
SpaceFillingCurve2D.IndexRange
. - SpaceFillingCurve2D.IndexRanges - Class in org.apache.calcite.runtime
-
Utilities for
SpaceFillingCurve2D.IndexRange
. - SpaceFillingCurve2D.IndexRangeTuple - Class in org.apache.calcite.runtime
-
Data representing a range.
- SpaceFillingCurve2D.OverlappingRange - Class in org.apache.calcite.runtime
-
Range that is not contained.
- SpaceFillingCurve2D.Point - Class in org.apache.calcite.runtime
-
A 2-dimensional point.
- SpaceFillingCurve2D.RangeComputeHints - Class in org.apache.calcite.runtime
- spacer - Variable in class org.apache.calcite.rel.externalize.RelWriterImpl
- Span - Class in org.apache.calcite.sql.parser
-
Builder for
SqlParserPos
. - spark - Variable in class org.apache.calcite.interpreter.InterpretableRel.InterpreterImplementor
- spark() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.SPARK
. - spark() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- spark() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.Context
-
Returns the spark handler.
- SPARK - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Specifies whether Spark should be used as the engine for processing that cannot be pushed to the source system.
- SPARK - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
A collection of operators that are in Apache Spark but not in standard SQL.
- SPARK - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- SPARK - Enum constant in enum org.apache.calcite.test.CalciteAssert.Config
-
Configuration that loads Spark.
- SPARK_CALC_RULE - Static variable in class org.apache.calcite.adapter.spark.SparkRules
-
Rule that converts a
LogicalCalc
to aSparkRules.SparkCalc
. - SPARK_CONTEXT - Enum constant in enum org.apache.calcite.DataContext.Variable
-
The Spark engine.
- SPARK_TO_ENUMERABLE - Static variable in class org.apache.calcite.adapter.spark.SparkRules
-
Rule that converts from Spark to enumerable convention.
- SPARK_VALUES_RULE - Static variable in class org.apache.calcite.adapter.spark.SparkRules
-
Rule that implements VALUES operator in Spark convention.
- SparkCalc(RelOptCluster, RelTraitSet, RelNode, RexProgram) - Constructor for class org.apache.calcite.adapter.spark.SparkRules.SparkCalc
- SparkCalc(RelOptCluster, RelTraitSet, RelNode, RexProgram, int) - Constructor for class org.apache.calcite.adapter.spark.SparkRules.SparkCalc
-
Deprecated.
- sparkContext() - Method in class org.apache.calcite.adapter.spark.SparkHandlerImpl
- sparkContext() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.SparkHandler
- SparkHandlerImpl - Class in org.apache.calcite.adapter.spark
-
Implementation of
CalcitePrepare.SparkHandler
. - SparkMethod - Enum in org.apache.calcite.adapter.spark
-
Built-in methods in the Spark adapter.
- SparkRel - Interface in org.apache.calcite.adapter.spark
-
Relational expression that uses Spark calling convention.
- SparkRel.Implementor - Class in org.apache.calcite.adapter.spark
-
Extension to
JavaRelImplementor
that can handle Spark relational expressions. - SparkRel.Result - Class in org.apache.calcite.adapter.spark
-
Result of generating Java code to implement a Spark relational expression.
- SparkRules - Class in org.apache.calcite.adapter.spark
-
Rules for the
Spark calling convention
. - SparkRules.SparkCalc - Class in org.apache.calcite.adapter.spark
-
Implementation of
Calc
in Spark convention. - SparkRules.SparkValues - Class in org.apache.calcite.adapter.spark
-
VALUES construct implemented in Spark.
- SparkRules.SparkValuesRule - Class in org.apache.calcite.adapter.spark
-
Planner rule that implements VALUES operator in Spark convention.
- SparkRuntime - Class in org.apache.calcite.adapter.spark
-
Runtime utilities for Calcite's Spark adapter.
- SparkRuntime.CalciteFlatMapFunction<T,
R> - Class in org.apache.calcite.adapter.spark -
Combines linq4j
Function
and SparkFlatMapFunction
. - SparkSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the APACHE SPARK database. - SparkSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.SparkSqlDialect
-
Creates a SparkSqlDialect.
- SparkToEnumerableConverter - Class in org.apache.calcite.adapter.spark
-
Relational expression that converts input of
Spark convention
intoEnumerableConvention
. - SparkToEnumerableConverter(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.adapter.spark.SparkToEnumerableConverter
- SPATIAL - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
Geospatial operators.
- spatialInstance() - Static method in class org.apache.calcite.sql.util.SqlOperatorTables
-
Returns the Spatial operator table, creating it if necessary.
- SpatialRules - Class in org.apache.calcite.rel.rules
-
Collection of planner rules that convert calls to spatial functions into more efficient expressions.
- SpatialRules.FilterHilbertRule - Class in org.apache.calcite.rel.rules
-
Rule that converts ST_DWithin in a Filter condition into a predicate on a Hilbert curve.
- SpatialRules.FilterHilbertRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- SpatialTypeFunctions - Class in org.apache.calcite.runtime
-
Helper methods to implement spatial type (ST) functions in generated code.
- SpatialTypeFunctions.GridEnumerable - Class in org.apache.calcite.runtime
-
Used at run time by the
SpatialTypeFunctions.ST_MakeGrid(org.locationtech.jts.geom.Geometry, java.math.BigDecimal, java.math.BigDecimal)
andSpatialTypeFunctions.ST_MakeGridPoints(org.locationtech.jts.geom.Geometry, java.math.BigDecimal, java.math.BigDecimal)
functions. - SpatialTypeUtils - Class in org.apache.calcite.runtime
-
Utilities for spatial types.
- SpatialTypeUtils.SpatialType - Enum in org.apache.calcite.runtime
-
Geometry types, with the names and codes assigned by OGC.
- special - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.SpecialOp
- special(Object, int, int, PrecedenceClimbingParser.Special) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- special(Object, int, int, PrecedenceClimbingParser.Special) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- SPECIAL - Enum constant in enum org.apache.calcite.sql.SqlSyntax
-
Special syntax, such as that of the SQL CASE operator, "CASE x WHEN 1 THEN 2 ELSE 3 END".
- SPECIAL - Enum constant in enum org.apache.calcite.util.PrecedenceClimbingParser.Type
- SpecialIdentifier(SqlParserPos) - Constructor for class org.apache.calcite.piglet.Ast.SpecialIdentifier
- specialOperatorByName(String) - Static method in class org.apache.calcite.util.RelToSqlConverterUtil
-
Returns a
SqlSpecialOperator
with given operator name, mainly used for unparse override. - SPECIFIC_USER - Enum constant in enum org.apache.calcite.chinook.EnvironmentFairy.User
- split() - Method in class org.apache.calcite.rex.RexProgram
-
Splits this program into a list of project expressions and a list of filter expressions.
- split() - Method in class org.apache.calcite.runtime.SplitOperation
- split(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SPLIT(string)
function. - split(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SPLIT(string, string)
function. - split(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SPLIT(binary, binary)
function. - split(AggregateCall, Mappings.TargetMapping) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.AbstractSumSplitter
- split(AggregateCall, Mappings.TargetMapping) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.CountSplitter
- split(AggregateCall, Mappings.TargetMapping) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.SelfSplitter
- split(AggregateCall, Mappings.TargetMapping) - Method in interface org.apache.calcite.sql.SqlSplittableAggFunction
- split(SqlNode) - Static method in class org.apache.calcite.sql.validate.IdentifierNamespace
- SPLIT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SPLIT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "SPLIT(string [, delimiter])" function.
- SPLIT_COUNT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- splitCols(List<RexNode>, ImmutableBitSet, ImmutableBitSet.Builder, ImmutableBitSet.Builder) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Forms two bitmaps by splitting the columns in a bitmap according to whether or not the column references the child input or is an expression.
- splitCorrelatedFilterCondition(Filter, List<RexNode>, List<RexNode>, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
- splitCorrelatedFilterCondition(LogicalFilter, List<RexInputRef>, List<RexNode>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- splitCorrelatedFilterCondition(LogicalFilter, List<RexNode>, List<RexNode>, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
- splitCount() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Parallelism
-
Returns the number of distinct splits of the data.
- splitCount(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.Parallelism.splitCount()
statistic. - splitCount(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Parallelism.Handler
- splitCount(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdParallelism
-
Catch-all implementation for
BuiltInMetadata.Parallelism.splitCount()
, invoked using reflection. - splitFilter(RexSimplify, RexNode, RexNode) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
-
Maps a condition onto a target.
- splitFilters(ImmutableBitSet, RexNode, List<RexNode>, List<RexNode>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Splits a filter into two lists, depending on whether or not the filter only references its child input.
- SplitFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.SplitFunction
- splitJoinCondition(List<RelDataTypeField>, List<RelNode>, RexNode, List<List<RexNode>>, List<Integer>, List<SqlOperator>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Splits out the equi-join (and optionally, a single non-equi) components of a join condition, and returns what's left.
- splitJoinCondition(List<RelDataTypeField>, RelNode, RelNode, RexNode, List<RexNode>, List<RexNode>, List<Integer>, List<SqlOperator>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Splits out the equi-join (and optionally, a single non-equi) components of a join condition, and returns what's left.
- splitJoinCondition(RelNode, RelNode, RexNode, List<Integer>, List<Integer>, List<Boolean>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Splits out the equi-join components of a join condition, and returns what's left.
- splitJoinCondition(RelNode, RelNode, RexNode, List<Integer>, List<Integer>, List<Boolean>, List<RexNode>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
As
RelOptUtil.splitJoinCondition(RelNode, RelNode, RexNode, List, List, List)
, but writes non-equi conditions to a conjunctive list. - SplitOperation - Class in org.apache.calcite.runtime
-
Splits
geom
byblade
. - SplitOperation(Geometry, Geometry) - Constructor for class org.apache.calcite.runtime.SplitOperation
- splitPredicates(RexBuilder, RexNode) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule
-
Classifies each of the predicates in the list into one of these two categories: 1-l) column equality predicates, or 2-r) residual predicates, all the rest
- splitQuotedTableName() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- splitQuotedTableName() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to split a quoted table name.
- splitQuotedTableName() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- splitQuotedTableName() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- SPLUNK_TABLE_NAME - Static variable in class org.apache.calcite.adapter.splunk.SplunkSchema
-
The name of the one and only table.
- splunkConnection - Variable in class org.apache.calcite.adapter.splunk.SplunkSchema
- SplunkConnection - Interface in org.apache.calcite.adapter.splunk.search
-
Connection to Splunk.
- SplunkConnectionImpl - Class in org.apache.calcite.adapter.splunk.search
-
Implementation of
SplunkConnection
based on Splunk's REST API. - SplunkConnectionImpl(String, String, String) - Constructor for class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- SplunkConnectionImpl(URL, String, String) - Constructor for class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- SplunkConnectionImpl.CountingSearchResultListener - Class in org.apache.calcite.adapter.splunk.search
-
Implementation of
SearchResultListener
interface that just counts the results. - SplunkConnectionImpl.SplunkResultEnumerator - Class in org.apache.calcite.adapter.splunk.search
-
Implementation of
Enumerator
that parses results from a Splunk REST call. - SplunkDriver - Class in org.apache.calcite.adapter.splunk
-
JDBC driver for Splunk.
- SplunkDriver() - Constructor for class org.apache.calcite.adapter.splunk.SplunkDriver
- SplunkPushDownRule - Class in org.apache.calcite.adapter.splunk
-
Planner rule to push filters and projections to Splunk.
- SplunkPushDownRule(SplunkPushDownRule.Config) - Constructor for class org.apache.calcite.adapter.splunk.SplunkPushDownRule
-
Creates a SplunkPushDownRule.
- SplunkPushDownRule(RelOptRuleOperand, String) - Constructor for class org.apache.calcite.adapter.splunk.SplunkPushDownRule
-
Deprecated.
- SplunkPushDownRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class org.apache.calcite.adapter.splunk.SplunkPushDownRule
-
Deprecated.
- SplunkPushDownRule.Config - Interface in org.apache.calcite.adapter.splunk
-
Rule configuration.
- SplunkQuery<T> - Class in org.apache.calcite.adapter.splunk
-
Query against Splunk.
- SplunkQuery(SplunkConnection, String, String, String, List<String>) - Constructor for class org.apache.calcite.adapter.splunk.SplunkQuery
-
Creates a SplunkQuery.
- SplunkResultEnumerator(InputStream, List<String>) - Constructor for class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.SplunkResultEnumerator
- SplunkSchema - Class in org.apache.calcite.adapter.splunk
-
Splunk schema.
- SplunkSchema(SplunkConnection) - Constructor for class org.apache.calcite.adapter.splunk.SplunkSchema
-
Creates a SplunkSchema.
- SplunkTableScan - Class in org.apache.calcite.adapter.splunk
-
Relational expression representing a scan of Splunk.
- SplunkTableScan(RelOptCluster, RelOptTable, SplunkTable, String, String, String, List<String>) - Constructor for class org.apache.calcite.adapter.splunk.SplunkTableScan
- Spool - Class in org.apache.calcite.rel.core
-
Relational expression that iterates over its input and, in addition to returning its results, will forward them into other consumers.
- Spool(RelOptCluster, RelTraitSet, RelNode, Spool.Type, Spool.Type) - Constructor for class org.apache.calcite.rel.core.Spool
-
Creates a Spool.
- Spool.Type - Enum in org.apache.calcite.rel.core
-
Enumeration representing spool read / write type.
- spoolFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- sql - Variable in class org.apache.calcite.jdbc.CalcitePrepare.ParseResult
- sql - Variable in class org.apache.calcite.jdbc.CalcitePrepare.Query
- sql - Variable in class org.apache.calcite.model.JsonLattice
-
SQL query that defines the lattice.
- sql - Variable in class org.apache.calcite.model.JsonMaterialization
-
SQL query that defines the materialization.
- sql - Variable in class org.apache.calcite.model.JsonView
-
SQL query that is the definition of the view.
- sql - Variable in class org.apache.calcite.sql.parser.StringAndPos
- sql - Variable in enum org.apache.calcite.sql.SqlJsonConstructorNullClause
- sql - Variable in enum org.apache.calcite.sql.SqlKind
- sql() - Method in class org.apache.calcite.tools.Hoist.Variable
-
Returns SQL text of the region of the statement covered by this Variable.
- sql(String) - Method in class org.apache.calcite.sql.parser.SqlParserFixture
-
Changes the SQL.
- sql(String) - Method in class org.apache.calcite.sql.parser.SqlParserTest
- sql(String) - Method in class org.apache.calcite.test.RelOptFixture
- sql(String) - Method in class org.apache.calcite.test.SqlToRelTestBase
-
Creates a test context with a SQL query.
- sql(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
-
Creates a test context with a SQL query.
- sql(ImmutableBitSet, boolean, List<Lattice.Measure>) - Method in class org.apache.calcite.materialize.Lattice
-
Generates a SQL query to populate a tile of the lattice specified by a given set of columns and measures, optionally grouping.
- sql(ImmutableBitSet, boolean, List<Lattice.Measure>, SqlDialect) - Method in class org.apache.calcite.materialize.Lattice
-
Generates a SQL query to populate a tile of the lattice specified by a given set of columns and measures, optionally grouping and dialect.
- sql(ImmutableBitSet, List<Lattice.Measure>) - Method in class org.apache.calcite.materialize.Lattice
-
Generates a SQL query to populate a tile of the lattice specified by a given set of columns and measures.
- SQL - Static variable in class org.apache.calcite.materialize.Lattices
-
Statistics provider that uses SQL.
- SQL_ADVISOR - Enum constant in enum org.apache.calcite.DataContext.Variable
-
Advisor that suggests completion hints for SQL statements.
- SQL_BIGINT - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_BINARY - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_BOOLEAN - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_CHAR - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_DATE - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_DECIMAL - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_DOUBLE - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_FLOAT - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTEGER - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_DAY - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_DAY_TO_HOUR - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_DAY_TO_MINUTE - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_DAY_TO_SECOND - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_HOUR - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_HOUR_TO_MINUTE - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_HOUR_TO_SECOND - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_MINUTE - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_MINUTE_TO_SECOND - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_MONTH - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_SECOND - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_YEAR - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_YEAR_TO_MONTH - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_NUMERIC - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_REAL - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_SERVER - Enum constant in enum org.apache.calcite.config.Lex
-
Lexical policy similar to Microsoft SQL Server.
- SQL_SERVER_2008 - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that instructs Calcite to use SQL semantics consistent with Microsoft SQL Server version 2008.
- SQL_SMALLINT - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_TIME - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_TIME_WITH_LOCAL_TIME_ZONE - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_TIME_WITH_TIME_ZONE - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_TIMESTAMP - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_TIMESTAMP_WITH_LOCAL_TIME_ZONE - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_TIMESTAMP_WITH_TIME_ZONE - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_TINYINT - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_VARBINARY - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_VARCHAR - Enum constant in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL2003 - Static variable in interface org.apache.calcite.util.Glossary
-
The official SQL:2003 standard (ISO/IEC 9075:2003), which is broken up into numerous parts.
- SQL2REL_CONVERTER_CONFIG_BUILDER - Enum constant in enum org.apache.calcite.runtime.Hook
-
Called before SqlToRelConverter is built.
- SQL2REL_LOGGER - Static variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- SQL92 - Static variable in interface org.apache.calcite.util.Glossary
-
The official SQL-92 standard (ISO/IEC 9075:1992).
- SQL99 - Static variable in interface org.apache.calcite.util.Glossary
-
The official SQL:1999 standard (ISO/IEC 9075:1999), which is broken up into five parts.
- SqlAbstractConformance - Class in org.apache.calcite.sql.validate
-
Abstract base class for implementing
SqlConformance
. - SqlAbstractConformance() - Constructor for class org.apache.calcite.sql.validate.SqlAbstractConformance
- SqlAbstractDateTimeLiteral - Class in org.apache.calcite.sql
-
A SQL literal representing a DATE, TIME or TIMESTAMP value.
- SqlAbstractDateTimeLiteral(Object, boolean, SqlTypeName, int, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlAbstractDateTimeLiteral
-
Constructs a datetime literal.
- SqlAbstractGroupFunction - Class in org.apache.calcite.sql.fun
-
Base class for grouping functions
GROUP_ID
,GROUPING_ID
,GROUPING
. - SqlAbstractGroupFunction(String, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.fun.SqlAbstractGroupFunction
-
Creates a SqlAbstractGroupFunction.
- SqlAbstractTimeFunction - Class in org.apache.calcite.sql.fun
-
Base class for time functions such as "LOCALTIME", "LOCALTIME(n)".
- SqlAbstractTimeFunction(String, SqlTypeName) - Constructor for class org.apache.calcite.sql.fun.SqlAbstractTimeFunction
- SqlAccessEnum - Enum in org.apache.calcite.sql
-
Access type.
- SqlAccessType - Class in org.apache.calcite.sql
-
SqlAccessType is represented by a set of allowed access types.
- SqlAccessType(EnumSet<SqlAccessEnum>) - Constructor for class org.apache.calcite.sql.SqlAccessType
- SqlAdvisor - Class in org.apache.calcite.sql.advise
-
An assistant which offers hints and corrections to a partially-formed SQL statement.
- SqlAdvisor(SqlValidatorWithHints) - Constructor for class org.apache.calcite.sql.advise.SqlAdvisor
-
Deprecated.
- SqlAdvisor(SqlValidatorWithHints, SqlParser.Config) - Constructor for class org.apache.calcite.sql.advise.SqlAdvisor
-
Creates a SqlAdvisor with a validator instance and given parser configuration.
- SqlAdvisor.ValidateErrorInfo - Class in org.apache.calcite.sql.advise
-
Text and position info of a validator or parser exception.
- SqlAdvisorGetHintsFunction - Class in org.apache.calcite.sql.advise
-
Table function that returns completion hints for a given SQL statement.
- SqlAdvisorGetHintsFunction() - Constructor for class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction
- SqlAdvisorGetHintsFunction2 - Class in org.apache.calcite.sql.advise
-
Table function that returns completion hints for a given SQL statement.
- SqlAdvisorGetHintsFunction2() - Constructor for class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction2
- SqlAdvisorHint - Class in org.apache.calcite.sql.advise
-
This class is used to return values for
(String, int, String[])
. - SqlAdvisorHint(String, String[], String) - Constructor for class org.apache.calcite.sql.advise.SqlAdvisorHint
- SqlAdvisorHint(SqlMoniker) - Constructor for class org.apache.calcite.sql.advise.SqlAdvisorHint
- SqlAdvisorHint2 - Class in org.apache.calcite.sql.advise
-
This class is used to return values for
(String, int, String[])
. - SqlAdvisorHint2(String, String[], String, String) - Constructor for class org.apache.calcite.sql.advise.SqlAdvisorHint2
- SqlAdvisorHint2(SqlMoniker, String) - Constructor for class org.apache.calcite.sql.advise.SqlAdvisorHint2
- SqlAdvisorValidator - Class in org.apache.calcite.sql.advise
-
SqlAdvisorValidator
is used bySqlAdvisor
to traverse the parse tree of a SQL statement, not for validation purpose but for setting up the scopes and namespaces to facilitate retrieval of SQL statement completion hints. - SqlAdvisorValidator(SqlOperatorTable, SqlValidatorCatalogReader, RelDataTypeFactory, SqlValidator.Config) - Constructor for class org.apache.calcite.sql.advise.SqlAdvisorValidator
-
Creates a SqlAdvisor validator.
- SqlAggFunction - Class in org.apache.calcite.sql
-
Abstract base class for the definition of an aggregate function: an operator which aggregates sets of values into a result.
- SqlAggFunction(String, SqlIdentifier, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.SqlAggFunction
-
Deprecated.
- SqlAggFunction(String, SqlIdentifier, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, SqlFunctionCategory, boolean, boolean) - Constructor for class org.apache.calcite.sql.SqlAggFunction
-
Deprecated.
- SqlAggFunction(String, SqlIdentifier, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, SqlFunctionCategory, boolean, boolean, Optionality) - Constructor for class org.apache.calcite.sql.SqlAggFunction
-
Creates a built-in or user-defined SqlAggFunction or window function.
- SqlAggFunction(String, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.SqlAggFunction
-
Deprecated.
- SqlAlienSystemTypeNameSpec - Class in org.apache.calcite.sql
-
Represents a type name for an alien system.
- SqlAlienSystemTypeNameSpec(String, SqlTypeName, int, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlAlienSystemTypeNameSpec
-
Creates a
SqlAlienSystemTypeNameSpec
instance. - SqlAlienSystemTypeNameSpec(String, SqlTypeName, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlAlienSystemTypeNameSpec
-
Creates a
SqlAlienSystemTypeNameSpec
instance. - SqlAlter - Class in org.apache.calcite.sql
-
Base class for an ALTER statements parse tree nodes.
- SqlAlter(SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlAlter
- SqlAlter(SqlParserPos, String) - Constructor for class org.apache.calcite.sql.SqlAlter
- SqlAnyValueAggFunction - Class in org.apache.calcite.sql.fun
-
Definition of the
ANY_VALUE
aggregate functions, returning any one of the values which go into it. - SqlAnyValueAggFunction(SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlAnyValueAggFunction
-
Creates a SqlAnyValueAggFunction.
- SqlArrayQueryConstructor - Class in org.apache.calcite.sql.fun
-
Definition of the SQL:2003 standard ARRAY query constructor,
ARRAY (<query>)
. - SqlArrayQueryConstructor() - Constructor for class org.apache.calcite.sql.fun.SqlArrayQueryConstructor
- SqlArrayValueConstructor - Class in org.apache.calcite.sql.fun
-
Definition of the SQL:2003 standard ARRAY constructor,
ARRAY [<expr>, ...]
. - SqlArrayValueConstructor() - Constructor for class org.apache.calcite.sql.fun.SqlArrayValueConstructor
- SqlAsofJoin - Class in org.apache.calcite.sql
-
Parse tree node representing a
ASOF JOIN
clause. - SqlAsofJoin(SqlParserPos, SqlNode, SqlLiteral, SqlLiteral, SqlNode, SqlLiteral, SqlNode, SqlNode) - Constructor for class org.apache.calcite.sql.SqlAsofJoin
- SqlAsofJoin.SqlAsofJoinOperator - Class in org.apache.calcite.sql
-
Describes the syntax of the SQL ASOF JOIN operator.
- SqlAsOperator - Class in org.apache.calcite.sql
-
The
AS
operator associates an expression with an alias. - SqlAsOperator() - Constructor for class org.apache.calcite.sql.SqlAsOperator
-
Creates an AS operator.
- SqlAsOperator(String, SqlKind, int, boolean, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.SqlAsOperator
- SqlAttributeDefinition - Class in org.apache.calcite.sql.ddl
-
Parse tree for SqlAttributeDefinition, which is part of a
SqlCreateType
. - SqlAvgAggFunction - Class in org.apache.calcite.sql.fun
-
Avg
is an aggregator which returns the average of the values which go into it. - SqlAvgAggFunction(RelDataType, SqlAvgAggFunction.Subtype) - Constructor for class org.apache.calcite.sql.fun.SqlAvgAggFunction
-
Deprecated.
- SqlAvgAggFunction(SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlAvgAggFunction
-
Creates a SqlAvgAggFunction.
- SqlAvgAggFunction.Subtype - Enum in org.apache.calcite.sql.fun
-
Deprecated.
- SqlBabelCreateTable - Class in org.apache.calcite.sql.babel
-
Parse tree for
CREATE TABLE
statement, with extensions for particular SQL dialects supported by Babel. - SqlBabelCreateTable(SqlParserPos, boolean, TableCollectionType, boolean, boolean, SqlIdentifier, SqlNodeList, SqlNode) - Constructor for class org.apache.calcite.sql.babel.SqlBabelCreateTable
-
Creates a SqlBabelCreateTable.
- SqlBaseContextVariable - Class in org.apache.calcite.sql.fun
-
Base class for functions such as "USER", "CURRENT_ROLE", and "CURRENT_PATH".
- SqlBaseContextVariable(String, SqlReturnTypeInference, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.fun.SqlBaseContextVariable
-
Creates a SqlBaseContextVariable.
- SqlBasicAggFunction - Class in org.apache.calcite.sql.fun
-
Concrete implementation of
SqlAggFunction
. - SqlBasicCall - Class in org.apache.calcite.sql
-
Implementation of
SqlCall
that keeps its operands in an array. - SqlBasicCall(SqlOperator, List<? extends SqlNode>, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlBasicCall
-
Creates a SqlBasicCall.
- SqlBasicCall(SqlOperator, List<? extends SqlNode>, SqlParserPos, SqlLiteral) - Constructor for class org.apache.calcite.sql.SqlBasicCall
-
Creates a SqlBasicCall with an optional function qualifier.
- SqlBasicCall(SqlOperator, SqlNode[], SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlBasicCall
-
Deprecated.
- SqlBasicCall(SqlOperator, SqlNode[], SqlParserPos, SqlLiteral) - Constructor for class org.apache.calcite.sql.SqlBasicCall
-
Deprecated.
- SqlBasicFunction - Class in org.apache.calcite.sql
-
Concrete implementation of
SqlFunction
. - SqlBasicTypeNameSpec - Class in org.apache.calcite.sql
-
A sql type name specification of basic sql type.
- SqlBasicTypeNameSpec(SqlTypeName, int, int, String, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlBasicTypeNameSpec
-
Create a basic sql type name specification.
- SqlBasicTypeNameSpec(SqlTypeName, int, int, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlBasicTypeNameSpec
- SqlBasicTypeNameSpec(SqlTypeName, int, String, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlBasicTypeNameSpec
- SqlBasicTypeNameSpec(SqlTypeName, int, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlBasicTypeNameSpec
- SqlBasicTypeNameSpec(SqlTypeName, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlBasicTypeNameSpec
- SqlBasicVisitor<R> - Class in org.apache.calcite.sql.util
-
Basic implementation of
SqlVisitor
which does nothing at each node. - SqlBasicVisitor() - Constructor for class org.apache.calcite.sql.util.SqlBasicVisitor
- SqlBasicVisitor.ArgHandler<R> - Interface in org.apache.calcite.sql.util
-
Argument handler.
- SqlBasicVisitor.ArgHandlerImpl<R> - Class in org.apache.calcite.sql.util
-
Default implementation of
SqlBasicVisitor.ArgHandler
which merely callsSqlNode.accept(org.apache.calcite.sql.util.SqlVisitor<R>)
on each operand. - SqlBegin - Class in org.apache.calcite.sql.babel.postgresql
-
Parse tree node representing a
BEGIN
clause. - SqlBegin(SqlParserPos, SqlNodeList) - Constructor for class org.apache.calcite.sql.babel.postgresql.SqlBegin
- SqlBegin.TransactionMode - Enum in org.apache.calcite.sql.babel.postgresql
-
Transaction mode.
- SqlBetweenOperator - Class in org.apache.calcite.sql.fun
-
Defines the BETWEEN operator.
- SqlBetweenOperator(SqlBetweenOperator.Flag, boolean) - Constructor for class org.apache.calcite.sql.fun.SqlBetweenOperator
- SqlBetweenOperator.Flag - Enum in org.apache.calcite.sql.fun
-
Defines the "SYMMETRIC" and "ASYMMETRIC" keywords.
- SqlBinaryOperator - Class in org.apache.calcite.sql
-
SqlBinaryOperator
is a binary operator. - SqlBinaryOperator(String, SqlKind, int, boolean, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.SqlBinaryOperator
-
Creates a SqlBinaryOperator.
- SqlBinaryStringLiteral - Class in org.apache.calcite.sql
-
A binary (or hexadecimal) string literal.
- SqlBinaryStringLiteral(BitString, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlBinaryStringLiteral
- SqlBitOpAggFunction - Class in org.apache.calcite.sql.fun
-
Definition of the
BIT_AND
andBIT_OR
aggregate functions, returning the bitwise AND/OR of all non-null input values, or null if none. - SqlBitOpAggFunction(String, SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlBitOpAggFunction
-
Creates a SqlBitOpAggFunction from a name and SqlKind.
- SqlBitOpAggFunction(SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlBitOpAggFunction
-
Creates a SqlBitOpAggFunction from a SqlKind.
- SqlBuilder - Class in org.apache.calcite.sql.util
-
Extension to
StringBuilder
for the purposes of creating SQL queries and expressions. - SqlBuilder(SqlDialect) - Constructor for class org.apache.calcite.sql.util.SqlBuilder
-
Creates a SqlBuilder.
- SqlBuilder(SqlDialect, String) - Constructor for class org.apache.calcite.sql.util.SqlBuilder
-
Creates a SqlBuilder with a given string.
- SqlCall - Class in org.apache.calcite.sql
-
A
SqlCall
is a call to anoperator
. - SqlCall(SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlCall
- SqlCallBinding - Class in org.apache.calcite.sql
-
SqlCallBinding
implementsSqlOperatorBinding
by analyzing to the operands of aSqlCall
with aSqlValidator
. - SqlCallBinding(SqlValidator, SqlValidatorScope, SqlCall) - Constructor for class org.apache.calcite.sql.SqlCallBinding
-
Creates a call binding.
- SqlCase - Class in org.apache.calcite.sql.fun
-
A
SqlCase
is a node of a parse tree which represents a case statement. - SqlCase(SqlParserPos, SqlNode, SqlNodeList, SqlNodeList, SqlNode) - Constructor for class org.apache.calcite.sql.fun.SqlCase
-
Creates a SqlCase expression.
- SqlCaseOperator - Class in org.apache.calcite.sql.fun
-
An operator describing a
CASE
,NULLIF
orCOALESCE
expression. - SqlCastFunction - Class in org.apache.calcite.sql.fun
-
SqlCastFunction.
- SqlCastFunction() - Constructor for class org.apache.calcite.sql.fun.SqlCastFunction
- SqlCastFunction(String, SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlCastFunction
- SqlCharStringLiteral - Class in org.apache.calcite.sql
-
A character string literal.
- SqlCharStringLiteral(NlsString, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlCharStringLiteral
- SqlCheckConstraint - Class in org.apache.calcite.sql.ddl
-
Parse tree for
UNIQUE
,PRIMARY KEY
constraints. - SqlCoalesceFunction - Class in org.apache.calcite.sql.fun
-
The
COALESCE
function. - SqlCoalesceFunction() - Constructor for class org.apache.calcite.sql.fun.SqlCoalesceFunction
- SqlCollation - Class in org.apache.calcite.sql
-
A
SqlCollation
is an object representing aCollate
statement. - SqlCollation(String, SqlCollation.Coercibility) - Constructor for class org.apache.calcite.sql.SqlCollation
-
Creates a Collation by its name and its coercibility.
- SqlCollation(SqlCollation.Coercibility) - Constructor for class org.apache.calcite.sql.SqlCollation
-
Creates a SqlCollation with the default collation name and the given coercibility.
- SqlCollation(SqlCollation.Coercibility, Locale, Charset, String) - Constructor for class org.apache.calcite.sql.SqlCollation
-
Creates a Collation by its coercibility, locale, charset and strength.
- SqlCollation.Coercibility - Enum in org.apache.calcite.sql
-
A <character value expression> consisting of a column reference has the coercibility characteristic Implicit, with collating sequence as defined when the column was created.
- SqlCollectionTableOperator - Class in org.apache.calcite.sql.fun
-
SqlCollectionTableOperator is the "table function derived table" operator.
- SqlCollectionTableOperator(String, SqlModality) - Constructor for class org.apache.calcite.sql.fun.SqlCollectionTableOperator
- SqlCollectionTypeNameSpec - Class in org.apache.calcite.sql
-
A sql type name specification of collection type.
- SqlCollectionTypeNameSpec(SqlTypeNameSpec, SqlTypeName, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlCollectionTypeNameSpec
-
Creates a
SqlCollectionTypeNameSpec
. - SqlColumnDeclaration - Class in org.apache.calcite.sql.ddl
-
Parse tree for
UNIQUE
,PRIMARY KEY
constraints. - SqlColumnListConstructor - Class in org.apache.calcite.sql.fun
-
SqlColumnListConstructor defines the non-standard constructor used to pass a COLUMN_LIST parameter to a UDX.
- SqlColumnListConstructor() - Constructor for class org.apache.calcite.sql.fun.SqlColumnListConstructor
- SqlCommit - Class in org.apache.calcite.sql.babel.postgresql
-
Parse tree node representing a
COMMIT
clause. - SqlCommit(SqlParserPos, SqlLiteral) - Constructor for class org.apache.calcite.sql.babel.postgresql.SqlCommit
- sqlConformance() - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Deprecated.
- SqlConformance - Interface in org.apache.calcite.sql.validate
-
Enumeration of valid SQL compatibility modes.
- sQLConformance_MultipleActiveAutocommitStatements() - Method in interface org.apache.calcite.runtime.CalciteResource
- sQLConformance_OrderByDesc() - Method in interface org.apache.calcite.runtime.CalciteResource
- SqlConformanceEnum - Enum in org.apache.calcite.sql.validate
-
Enumeration of built-in SQL compatibility modes.
- SqlConvertFunction - Class in org.apache.calcite.sql.fun
-
The
CONVERT
function, which converts a string from one character set to another. - SqlConvertFunction(String) - Constructor for class org.apache.calcite.sql.fun.SqlConvertFunction
- SqlConvertFunction(String, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.fun.SqlConvertFunction
- SqlCountAggFunction - Class in org.apache.calcite.sql.fun
-
Definition of the SQL
COUNT
aggregation function. - SqlCountAggFunction(String) - Constructor for class org.apache.calcite.sql.fun.SqlCountAggFunction
- SqlCountAggFunction(String, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.fun.SqlCountAggFunction
- SqlCovarAggFunction - Class in org.apache.calcite.sql.fun
-
Covar
is an aggregator which returns the Covariance of the values which go into it. - SqlCovarAggFunction(RelDataType, SqlCovarAggFunction.Subtype) - Constructor for class org.apache.calcite.sql.fun.SqlCovarAggFunction
-
Deprecated.
- SqlCovarAggFunction(SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlCovarAggFunction
-
Creates a SqlCovarAggFunction.
- SqlCovarAggFunction.Subtype - Enum in org.apache.calcite.sql.fun
-
Deprecated.
- SqlCreate - Class in org.apache.calcite.sql
-
Base class for an CREATE statements parse tree nodes.
- SqlCreate(SqlParserPos, boolean) - Constructor for class org.apache.calcite.sql.SqlCreate
-
Deprecated.
- SqlCreate(SqlOperator, SqlParserPos, boolean, boolean) - Constructor for class org.apache.calcite.sql.SqlCreate
-
Creates a SqlCreate.
- SqlCreateForeignSchema - Class in org.apache.calcite.sql.ddl
-
Parse tree for
CREATE FOREIGN SCHEMA
statement. - SqlCreateFunction - Class in org.apache.calcite.sql.ddl
-
Parse tree for
CREATE FUNCTION
statement. - SqlCreateFunction(SqlParserPos, boolean, boolean, SqlIdentifier, SqlNode, SqlNodeList) - Constructor for class org.apache.calcite.sql.ddl.SqlCreateFunction
-
Creates a SqlCreateFunction.
- SqlCreateMaterializedView - Class in org.apache.calcite.sql.ddl
-
Parse tree for
CREATE MATERIALIZED VIEW
statement. - SqlCreateSchema - Class in org.apache.calcite.sql.ddl
-
Parse tree for
CREATE SCHEMA
statement. - SqlCreateTable - Class in org.apache.calcite.sql.ddl
-
Parse tree for
CREATE TABLE
statement. - SqlCreateTable(SqlParserPos, boolean, boolean, SqlIdentifier, SqlNodeList, SqlNode) - Constructor for class org.apache.calcite.sql.ddl.SqlCreateTable
-
Creates a SqlCreateTable.
- SqlCreateTableLike - Class in org.apache.calcite.sql.ddl
-
Parse tree for
CREATE TABLE LIKE
statement. - SqlCreateTableLike(SqlParserPos, boolean, boolean, SqlIdentifier, SqlIdentifier, SqlNodeList, SqlNodeList) - Constructor for class org.apache.calcite.sql.ddl.SqlCreateTableLike
- SqlCreateTableLike.LikeOption - Enum in org.apache.calcite.sql.ddl
-
The LikeOption specify which additional properties of the original table to copy.
- SqlCreateType - Class in org.apache.calcite.sql.ddl
-
Parse tree for
CREATE TYPE
statement. - SqlCreateView - Class in org.apache.calcite.sql.ddl
-
Parse tree for
CREATE VIEW
statement. - SqlCurrentDateFunction - Class in org.apache.calcite.sql.fun
-
The
CURRENT_DATE
function. - SqlCurrentDateFunction() - Constructor for class org.apache.calcite.sql.fun.SqlCurrentDateFunction
- SqlCursorConstructor - Class in org.apache.calcite.sql.fun
-
SqlCursorConstructor defines the non-standard CURSOR(<query>) constructor.
- SqlCursorConstructor() - Constructor for class org.apache.calcite.sql.fun.SqlCursorConstructor
- SqlDataTypeSpec - Class in org.apache.calcite.sql
-
Represents a SQL data type specification in a parse tree.
- SqlDataTypeSpec(SqlTypeNameSpec, TimeZone, Boolean, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlDataTypeSpec
-
Creates a type specification representing a type, with time zone, nullability and base type name specified.
- SqlDataTypeSpec(SqlTypeNameSpec, TimeZone, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlDataTypeSpec
-
Creates a type specification representing a type, with time zone specified.
- SqlDataTypeSpec(SqlTypeNameSpec, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlDataTypeSpec
-
Creates a type specification representing a type.
- sqlDate - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- SqlDateLiteral - Class in org.apache.calcite.sql
-
A SQL literal representing a DATE value, such as
DATE '2004-10-22'
. - SqlDatePartFunction - Class in org.apache.calcite.sql.fun
-
SqlDatePartFunction represents the SQL:1999 standard
YEAR
,QUARTER
,MONTH
andDAY
functions. - SqlDatePartFunction(String, TimeUnit) - Constructor for class org.apache.calcite.sql.fun.SqlDatePartFunction
- SqlDatetimePlusOperator - Class in org.apache.calcite.sql.fun
-
Operator that adds an INTERVAL to a DATETIME.
- SqlDatetimeSubtractionOperator - Class in org.apache.calcite.sql.fun
-
A special operator for the subtraction of two DATETIMEs.
- SqlDatetimeSubtractionOperator(String, SqlReturnTypeInference) - Constructor for class org.apache.calcite.sql.fun.SqlDatetimeSubtractionOperator
- SqlDdl - Class in org.apache.calcite.sql
-
Base class for CREATE, DROP and other DDL statements.
- SqlDdl(SqlOperator, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlDdl
-
Creates a SqlDdl.
- SqlDdlNodes - Class in org.apache.calcite.sql.ddl
-
Utilities concerning
SqlNode
for DDL. - SqlDdlNodes.FileType - Enum in org.apache.calcite.sql.ddl
-
File type for CREATE FUNCTION.
- SqlDelegatingConformance - Class in org.apache.calcite.sql.validate
-
Implementation of
SqlConformance
that delegates all methods to another object. - SqlDelegatingConformance(SqlConformance) - Constructor for class org.apache.calcite.sql.validate.SqlDelegatingConformance
-
Creates a SqlDelegatingConformance.
- SqlDelete - Class in org.apache.calcite.sql
-
A
SqlDelete
is a node of a parse tree which represents a DELETE statement. - SqlDelete(SqlParserPos, SqlNode, SqlNode, SqlSelect, SqlIdentifier) - Constructor for class org.apache.calcite.sql.SqlDelete
- SqlDescribeSchema - Class in org.apache.calcite.sql
-
A
SqlDescribeSchema
is a node of a parse tree that represents aDESCRIBE SCHEMA
statement. - SqlDescribeSchema(SqlParserPos, SqlIdentifier) - Constructor for class org.apache.calcite.sql.SqlDescribeSchema
-
Creates a SqlDescribeSchema.
- SqlDescribeTable - Class in org.apache.calcite.sql
-
A
SqlDescribeTable
is a node of a parse tree that represents aDESCRIBE TABLE
statement. - SqlDescribeTable(SqlParserPos, SqlIdentifier, SqlIdentifier) - Constructor for class org.apache.calcite.sql.SqlDescribeTable
-
Creates a SqlDescribeTable.
- SqlDescriptorOperator - Class in org.apache.calcite.sql
-
DESCRIPTOR appears as an argument in a function.
- SqlDescriptorOperator() - Constructor for class org.apache.calcite.sql.SqlDescriptorOperator
- SqlDialect - Class in org.apache.calcite.sql
-
SqlDialect
encapsulates the differences between dialects of SQL. - SqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.SqlDialect
-
Creates a SqlDialect.
- SqlDialect(SqlDialect.DatabaseProduct, String, String) - Constructor for class org.apache.calcite.sql.SqlDialect
-
Deprecated.
- SqlDialect(SqlDialect.DatabaseProduct, String, String, NullCollation) - Constructor for class org.apache.calcite.sql.SqlDialect
-
Deprecated.
- SqlDialect.CalendarPolicy - Enum in org.apache.calcite.sql
-
Whether this JDBC driver needs you to pass a Calendar object to methods such as
ResultSet.getTimestamp(int, java.util.Calendar)
. - SqlDialect.Context - Interface in org.apache.calcite.sql
-
Information for creating a dialect.
- SqlDialect.DatabaseProduct - Enum in org.apache.calcite.sql
-
Rough list of flavors of database.
- SqlDialect.FakeUtil - Class in org.apache.calcite.sql
-
Deprecated.
- sqlDialectFactory - Variable in class org.apache.calcite.model.JsonJdbcSchema
-
The FQN of the
SqlDialectFactory
implementation. - SqlDialectFactory - Interface in org.apache.calcite.sql
-
Creates a
SqlDialect
appropriate for a given database metadata object. - SqlDialectFactoryImpl - Class in org.apache.calcite.sql
-
The default implementation of a
SqlDialectFactory
. - SqlDialectFactoryImpl() - Constructor for class org.apache.calcite.sql.SqlDialectFactoryImpl
- SqlDialects - Class in org.apache.calcite.sql
-
Utilities related to
SqlDialect
. - SqlDiscard - Class in org.apache.calcite.sql.babel.postgresql
-
Parse tree node representing a
DISCARD
clause. - SqlDiscard(SqlParserPos, SqlIdentifier) - Constructor for class org.apache.calcite.sql.babel.postgresql.SqlDiscard
- SqlDotOperator - Class in org.apache.calcite.sql.fun
-
The dot operator
.
, used to access a field of a record. - SqlDrop - Class in org.apache.calcite.sql
-
Base class for an DROP statements parse tree nodes.
- SqlDrop(SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlDrop
-
Deprecated.
- SqlDrop(SqlOperator, SqlParserPos, boolean) - Constructor for class org.apache.calcite.sql.SqlDrop
-
Creates a SqlDrop.
- SqlDropFunction - Class in org.apache.calcite.sql.ddl
-
Parse tree for
DROP FUNCTION
statement. - SqlDropFunction(SqlParserPos, boolean, SqlIdentifier) - Constructor for class org.apache.calcite.sql.ddl.SqlDropFunction
-
Creates a SqlDropFunction.
- SqlDropMaterializedView - Class in org.apache.calcite.sql.ddl
-
Parse tree for
DROP MATERIALIZED VIEW
statement. - SqlDropObject - Class in org.apache.calcite.sql.ddl
-
Base class for parse trees of
DROP TABLE
,DROP VIEW
,DROP MATERIALIZED VIEW
andDROP TYPE
statements. - SqlDropSchema - Class in org.apache.calcite.sql.ddl
-
Parse tree for
DROP SCHEMA
statement. - SqlDropTable - Class in org.apache.calcite.sql.ddl
-
Parse tree for
DROP TABLE
statement. - SqlDropType - Class in org.apache.calcite.sql.ddl
-
Parse tree for
DROP TYPE
statement. - SqlDropView - Class in org.apache.calcite.sql.ddl
-
Parse tree for
DROP VIEW
statement. - SqlDynamicParam - Class in org.apache.calcite.sql
-
A
SqlDynamicParam
represents a dynamic parameter marker in an SQL statement. - SqlDynamicParam(int, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlDynamicParam
- SqlExplain - Class in org.apache.calcite.sql
-
A
SqlExplain
is a node of a parse tree which represents an EXPLAIN PLAN statement. - SqlExplain(SqlParserPos, SqlNode, SqlLiteral, SqlLiteral, SqlLiteral, int) - Constructor for class org.apache.calcite.sql.SqlExplain
- SqlExplain.Depth - Enum in org.apache.calcite.sql
-
The level of abstraction with which to display the plan.
- SqlExplainFormat - Enum in org.apache.calcite.sql
-
Output format for
EXPLAIN PLAN
statement. - SqlExplainLevel - Enum in org.apache.calcite.sql
-
SqlExplainLevel defines detail levels for EXPLAIN PLAN.
- SqlExtractFunction - Class in org.apache.calcite.sql.fun
-
The SQL
EXTRACT
operator. - SqlExtractFunction(String, boolean) - Constructor for class org.apache.calcite.sql.fun.SqlExtractFunction
- sQLFeature_E051_01() - Method in interface org.apache.calcite.runtime.CalciteResource
- sQLFeature_E071_03() - Method in interface org.apache.calcite.runtime.CalciteResource
- sQLFeature_E101_03() - Method in interface org.apache.calcite.runtime.CalciteResource
- sQLFeature_E151() - Method in interface org.apache.calcite.runtime.CalciteResource
- sQLFeature_F302() - Method in interface org.apache.calcite.runtime.CalciteResource
- sQLFeature_F312() - Method in interface org.apache.calcite.runtime.CalciteResource
- sQLFeature_S271() - Method in interface org.apache.calcite.runtime.CalciteResource
- sQLFeature_T613() - Method in interface org.apache.calcite.runtime.CalciteResource
- sQLFeatureExt_T613_Substitution() - Method in interface org.apache.calcite.runtime.CalciteResource
- SqlFilterOperator - Class in org.apache.calcite.sql
-
An operator that applies a filter before rows are included in an aggregate function.
- SqlFilterOperator() - Constructor for class org.apache.calcite.sql.SqlFilterOperator
- SqlFirstLastValueAggFunction - Class in org.apache.calcite.sql.fun
-
FIRST_VALUE
andLAST_VALUE
aggregate functions return the first or the last value in a list of values that are input to the function. - SqlFirstLastValueAggFunction(boolean) - Constructor for class org.apache.calcite.sql.fun.SqlFirstLastValueAggFunction
-
Deprecated.
- SqlFirstLastValueAggFunction(SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlFirstLastValueAggFunction
- SqlFloorFunction - Class in org.apache.calcite.sql.fun
-
Definition of the "FLOOR" and "CEIL" built-in SQL functions.
- SqlFloorFunction(SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlFloorFunction
- SqlFormatOptions - Class in org.apache.calcite.sql.pretty
-
Data structure to hold options for
SqlPrettyWriter.setFormatOptions(SqlFormatOptions)
. - SqlFormatOptions() - Constructor for class org.apache.calcite.sql.pretty.SqlFormatOptions
-
Constructs a set of default SQL format options.
- SqlFormatOptions(boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, int, int) - Constructor for class org.apache.calcite.sql.pretty.SqlFormatOptions
-
Constructs a complete set of SQL format options.
- SqlFunction - Class in org.apache.calcite.sql
-
A
SqlFunction
is a type of operator which has conventional function-call syntax. - SqlFunction(String, SqlIdentifier, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, List<RelDataType>, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.SqlFunction
-
Deprecated.
- SqlFunction(String, SqlIdentifier, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.SqlFunction
-
Internal constructor.
- SqlFunction(String, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.SqlFunction
-
Creates a new SqlFunction for a call to a built-in function.
- SqlFunction(SqlIdentifier, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, List<RelDataType>, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.SqlFunction
-
Creates a placeholder SqlFunction for an invocation of a function with a possibly qualified name.
- SqlFunctionalOperator - Class in org.apache.calcite.sql
-
SqlFunctionalOperator is a base class for special operators which use functional syntax.
- SqlFunctionalOperator(String, SqlKind, int, boolean, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.SqlFunctionalOperator
- SqlFunctionCategory - Enum in org.apache.calcite.sql
-
Enumeration of the categories of SQL-invoked routines.
- SqlFunctions - Class in org.apache.calcite.runtime
-
Helper methods to implement SQL functions in generated code.
- SqlFunctions.DateFormatFunction - Class in org.apache.calcite.runtime
-
State for
FORMAT_DATE
,FORMAT_TIMESTAMP
,FORMAT_DATETIME
,FORMAT_TIME
,TO_CHAR
functions. - SqlFunctions.DateFormatFunctionPg - Class in org.apache.calcite.runtime
-
State for
FORMAT_DATE
,FORMAT_TIMESTAMP
,FORMAT_DATETIME
,FORMAT_TIME
,TO_CHAR
functions. - SqlFunctions.DateParseFunction - Class in org.apache.calcite.runtime
-
State for
PARSE_DATE
,PARSE_TIMESTAMP
,PARSE_DATETIME
,PARSE_TIME
functions. - SqlFunctions.FlatProductInputType - Enum in org.apache.calcite.runtime
-
Type of argument passed into
SqlFunctions.flatProduct(int[], boolean, org.apache.calcite.runtime.SqlFunctions.FlatProductInputType[])
. - SqlFunctions.JsonScope - Enum in org.apache.calcite.runtime
-
Specifies scope to search for
#containsSubstr
. - SqlFunctions.LikeFunction - Class in org.apache.calcite.runtime
-
State for
LIKE
,ILIKE
. - SqlFunctions.ParseUrlFunction - Class in org.apache.calcite.runtime
-
State for
PARSE_URL
. - SqlFunctions.PosixRegexFunction - Class in org.apache.calcite.runtime
-
State for posix regex function.
- SqlFunctions.RegexFunction - Class in org.apache.calcite.runtime
-
State for
REGEXP_CONTAINS
,REGEXP_EXTRACT
,REGEXP_EXTRACT_ALL
,REGEXP_INSTR
,REGEXP_REPLACE
,RLIKE
. - SqlFunctions.SimilarEscapeFunction - Class in org.apache.calcite.runtime
-
State for
SIMILAR
function with escape. - SqlFunctions.SimilarFunction - Class in org.apache.calcite.runtime
-
State for
SIMILAR
function. - SqlGroupedWindowFunction - Class in org.apache.calcite.sql
-
SQL function that computes keys by which rows can be partitioned and aggregated.
- SqlGroupedWindowFunction(String, SqlKind, SqlGroupedWindowFunction, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.SqlGroupedWindowFunction
-
Deprecated.
- SqlGroupedWindowFunction(String, SqlKind, SqlGroupedWindowFunction, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.SqlGroupedWindowFunction
-
Creates a SqlGroupedWindowFunction.
- SqlGroupedWindowFunction(SqlKind, SqlGroupedWindowFunction, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.SqlGroupedWindowFunction
-
Deprecated.
- SqlHint - Class in org.apache.calcite.sql
-
A
SqlHint
is a node of a parse tree which represents a sql hint expression. - SqlHint(SqlParserPos, SqlIdentifier, SqlNodeList, SqlHint.HintOptionFormat) - Constructor for class org.apache.calcite.sql.SqlHint
- SqlHint.HintOptionFormat - Enum in org.apache.calcite.sql
-
Enumeration that represents hint option format.
- SqlHistogramAggFunction - Class in org.apache.calcite.sql.fun
-
HISTOGRAM
is the base operator that supports the Histogram MIN/MAX aggregate functions. - SqlHistogramAggFunction(RelDataType) - Constructor for class org.apache.calcite.sql.fun.SqlHistogramAggFunction
- SqlHopTableFunction - Class in org.apache.calcite.sql
-
SqlHopTableFunction implements an operator for hopping.
- SqlHopTableFunction() - Constructor for class org.apache.calcite.sql.SqlHopTableFunction
- SqlIdentifier - Class in org.apache.calcite.sql
-
A
SqlIdentifier
is an identifier, possibly compound. - SqlIdentifier(String, SqlCollation, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlIdentifier
-
Creates a simple identifier, for example
foo
, with a collation. - SqlIdentifier(String, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlIdentifier
-
Creates a simple identifier, for example
foo
. - SqlIdentifier(List<String>, SqlCollation, SqlParserPos, List<SqlParserPos>) - Constructor for class org.apache.calcite.sql.SqlIdentifier
-
Creates a compound identifier, for example
foo.bar
. - SqlIdentifier(List<String>, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlIdentifier
- SqlIdentifierFinder() - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.SqlIdentifierFinder
- SqlIdentifierMoniker - Class in org.apache.calcite.sql.validate
-
An implementation of
SqlMoniker
that encapsulates the normalized name information of aSqlIdentifier
. - SqlIdentifierMoniker(SqlIdentifier) - Constructor for class org.apache.calcite.sql.validate.SqlIdentifierMoniker
-
Creates an SqlIdentifierMoniker.
- SqlImplementor - Class in org.apache.calcite.rel.rel2sql
-
State for generating a SQL statement.
- SqlImplementor(SqlDialect) - Constructor for class org.apache.calcite.rel.rel2sql.SqlImplementor
- SqlImplementor.AliasContext - Class in org.apache.calcite.rel.rel2sql
-
Implementation of Context that precedes field references with their "table alias" based on the current sub-query's FROM clause.
- SqlImplementor.BaseContext - Class in org.apache.calcite.rel.rel2sql
-
Implementation of
SqlImplementor.Context
that has an enclosingSqlImplementor
and can therefore do non-trivial expressions. - SqlImplementor.Builder - Class in org.apache.calcite.rel.rel2sql
-
Builder.
- SqlImplementor.Clause - Enum in org.apache.calcite.rel.rel2sql
-
Clauses in a SQL query.
- SqlImplementor.Context - Class in org.apache.calcite.rel.rel2sql
- SqlImplementor.MatchRecognizeContext - Class in org.apache.calcite.rel.rel2sql
-
Context for translating MATCH_RECOGNIZE clause.
- SqlImplementor.Result - Class in org.apache.calcite.rel.rel2sql
-
Result of implementing a node.
- SqlImplementor.SimpleContext - Class in org.apache.calcite.rel.rel2sql
-
Simple implementation of
SqlImplementor.Context
that cannot handle sub-queries or correlations. - SqlInfixOperator - Class in org.apache.calcite.sql
-
A generalization of a binary operator to involve several (two or more) arguments, and keywords between each pair of arguments.
- SqlInfixOperator(String[], SqlKind, int, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.SqlInfixOperator
- SqlInOperator - Class in org.apache.calcite.sql.fun
-
Definition of the SQL
IN
operator, which tests for a value's membership in a sub-query or a list of values. - SqlInOperator(String, SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlInOperator
- SqlInsert - Class in org.apache.calcite.sql
-
A
SqlInsert
is a node of a parse tree which represents an INSERT statement. - SqlInsert(SqlParserPos, SqlNodeList, SqlNode, SqlNode, SqlNodeList) - Constructor for class org.apache.calcite.sql.SqlInsert
- SqlInsertKeyword - Enum in org.apache.calcite.sql
-
Defines the keywords that can occur immediately after the "INSERT" keyword.
- SqlInternalOperator - Class in org.apache.calcite.sql
-
Generic operator for nodes with internal syntax.
- SqlInternalOperator(String, SqlKind) - Constructor for class org.apache.calcite.sql.SqlInternalOperator
- SqlInternalOperator(String, SqlKind, int) - Constructor for class org.apache.calcite.sql.SqlInternalOperator
- SqlInternalOperator(String, SqlKind, int, boolean, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.SqlInternalOperator
- SqlInternalOperators - Class in org.apache.calcite.sql.fun
-
Contains internal operators.
- SqlIntervalLiteral - Class in org.apache.calcite.sql
-
A SQL literal representing a time interval.
- SqlIntervalLiteral(int, String, SqlIntervalQualifier, SqlTypeName, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlIntervalLiteral
- SqlIntervalLiteral.IntervalValue - Class in org.apache.calcite.sql
-
A Interval value.
- SqlIntervalOperator - Class in org.apache.calcite.sql.fun
-
Interval expression.
- SqlIntervalQualifier - Class in org.apache.calcite.sql
-
Represents an INTERVAL qualifier.
- SqlIntervalQualifier(String, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlIntervalQualifier
-
Creates a qualifier based on a time frame name.
- SqlIntervalQualifier(TimeUnit, int, TimeUnit, int, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlIntervalQualifier
- SqlIntervalQualifier(TimeUnit, TimeUnit, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlIntervalQualifier
- SqlItemOperator - Class in org.apache.calcite.sql.fun
-
The item operator
[ ... ]
, used to access a given element of an array, map or struct. - SqlItemOperator(String, SqlSingleOperandTypeChecker, int, boolean) - Constructor for class org.apache.calcite.sql.fun.SqlItemOperator
- SqlJdbcDataTypeName - Enum in org.apache.calcite.sql
-
Defines the name of the types which can occur as a type argument in a JDBC
{fn CONVERT(value, type)}
function. - SqlJdbcFunctionCall - Class in org.apache.calcite.sql
-
A
SqlJdbcFunctionCall
is a node of a parse tree which represents a JDBC function call. - SqlJdbcFunctionCall(String) - Constructor for class org.apache.calcite.sql.SqlJdbcFunctionCall
- SqlJdbcFunctionCall.SimpleMakeCall - Class in org.apache.calcite.sql
-
Converter that calls a built-in function with the same arguments.
- SqlJoin - Class in org.apache.calcite.sql
-
Parse tree node representing a
JOIN
clause. - SqlJoin(SqlParserPos, SqlNode, SqlLiteral, SqlLiteral, SqlNode, SqlLiteral, SqlNode) - Constructor for class org.apache.calcite.sql.SqlJoin
- SqlJoin.SqlJoinOperator - Class in org.apache.calcite.sql
-
Describes the syntax of the SQL
JOIN
operator. - SqlJsonArrayAggAggFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_OBJECTAGG
aggregate function. - SqlJsonArrayAggAggFunction(SqlKind, SqlJsonConstructorNullClause) - Constructor for class org.apache.calcite.sql.fun.SqlJsonArrayAggAggFunction
- SqlJsonArrayFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_ARRAY
function. - SqlJsonArrayFunction() - Constructor for class org.apache.calcite.sql.fun.SqlJsonArrayFunction
- SqlJsonConstructorNullClause - Enum in org.apache.calcite.sql
-
Indicating how JSON constructors handle null.
- SqlJsonDepthFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_DEPTH
function. - SqlJsonDepthFunction() - Constructor for class org.apache.calcite.sql.fun.SqlJsonDepthFunction
- SqlJsonEmptyOrError - Enum in org.apache.calcite.sql
-
Flag to indicate if the json value is missing or an error is thrown where EmptyOrErrorBehavior is invoked.
- SqlJsonEncoding - Enum in org.apache.calcite.sql
-
Supported json encodings that could be passed to a
JsonValueExpression
. - SqlJsonExistsErrorBehavior - Enum in org.apache.calcite.sql
-
Categorizing Json exists error behaviors.
- SqlJsonExistsFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_EXISTS
function. - SqlJsonExistsFunction() - Constructor for class org.apache.calcite.sql.fun.SqlJsonExistsFunction
- SqlJsonKeysFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_KEYS
function. - SqlJsonKeysFunction() - Constructor for class org.apache.calcite.sql.fun.SqlJsonKeysFunction
- SqlJsonLengthFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_LENGTH
function. - SqlJsonLengthFunction() - Constructor for class org.apache.calcite.sql.fun.SqlJsonLengthFunction
- SqlJsonModifyFunction - Class in org.apache.calcite.sql.fun
-
Definition of the
JSON_INSERT
,JSON_REPLACE
andJSON_SET
JSON Modify functions. - SqlJsonModifyFunction(String) - Constructor for class org.apache.calcite.sql.fun.SqlJsonModifyFunction
- SqlJsonObjectAggAggFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_OBJECTAGG
aggregate function. - SqlJsonObjectAggAggFunction(SqlKind, SqlJsonConstructorNullClause) - Constructor for class org.apache.calcite.sql.fun.SqlJsonObjectAggAggFunction
-
Creates a SqlJsonObjectAggAggFunction.
- SqlJsonObjectFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_OBJECT
function. - SqlJsonObjectFunction() - Constructor for class org.apache.calcite.sql.fun.SqlJsonObjectFunction
- SqlJsonPrettyFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_TYPE
function. - SqlJsonPrettyFunction() - Constructor for class org.apache.calcite.sql.fun.SqlJsonPrettyFunction
- SqlJsonQueryEmptyOrErrorBehavior - Enum in org.apache.calcite.sql
-
Categorizing Json query empty or error behaviors.
- SqlJsonQueryFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_QUERY
function. - SqlJsonQueryFunction() - Constructor for class org.apache.calcite.sql.fun.SqlJsonQueryFunction
- SqlJsonQueryWrapperBehavior - Enum in org.apache.calcite.sql
-
How json query function handle array result.
- SqlJsonRemoveFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_REMOVE
function. - SqlJsonRemoveFunction() - Constructor for class org.apache.calcite.sql.fun.SqlJsonRemoveFunction
- SqlJsonStorageSizeFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_STORAGE_SIZE
function. - SqlJsonStorageSizeFunction() - Constructor for class org.apache.calcite.sql.fun.SqlJsonStorageSizeFunction
- SqlJsonTypeFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_TYPE
function. - SqlJsonTypeFunction() - Constructor for class org.apache.calcite.sql.fun.SqlJsonTypeFunction
- SqlJsonValueEmptyOrErrorBehavior - Enum in org.apache.calcite.sql
-
Categorizing Json value empty or error behaviors.
- SqlJsonValueExpressionOperator - Class in org.apache.calcite.sql.fun
-
The JSON value expression operator that indicates that the value expression should be parsed as JSON.
- SqlJsonValueExpressionOperator() - Constructor for class org.apache.calcite.sql.fun.SqlJsonValueExpressionOperator
- SqlJsonValueFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_VALUE
function. - SqlJsonValueFunction(String) - Constructor for class org.apache.calcite.sql.fun.SqlJsonValueFunction
- SqlJsonValueReturning - Enum in org.apache.calcite.sql
-
Flag to indicate the explicit return type of JSON_VALUE.
- SqlKeyConstraint - Class in org.apache.calcite.sql.ddl
-
Parse tree for
UNIQUE
,PRIMARY KEY
constraints. - SqlKind - Enum in org.apache.calcite.sql
-
Enumerates the possible types of
SqlNode
. - SqlLambda - Class in org.apache.calcite.sql
-
A
SqlLambda
is a node of a parse tree which represents a lambda expression. - SqlLambda(SqlParserPos, SqlNodeList, SqlNode) - Constructor for class org.apache.calcite.sql.SqlLambda
- SqlLambdaScope - Class in org.apache.calcite.sql.validate
-
Scope for a
LAMBDA EXPRESSION
. - SqlLambdaScope(SqlValidatorScope, SqlLambda) - Constructor for class org.apache.calcite.sql.validate.SqlLambdaScope
- SqlLateralOperator - Class in org.apache.calcite.sql
-
An operator describing a LATERAL specification.
- SqlLateralOperator(SqlKind) - Constructor for class org.apache.calcite.sql.SqlLateralOperator
- SqlLeadLagAggFunction - Class in org.apache.calcite.sql.fun
-
LEAD
andLAG
aggregate functions return the value of given expression evaluated at given offset. - SqlLeadLagAggFunction(boolean) - Constructor for class org.apache.calcite.sql.fun.SqlLeadLagAggFunction
-
Deprecated.
- SqlLeadLagAggFunction(SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlLeadLagAggFunction
- SqlLibrary - Enum in org.apache.calcite.sql.fun
-
A library is a collection of SQL functions and operators.
- SqlLibraryOperators - Class in org.apache.calcite.sql.fun
-
Defines functions and operators that are not part of standard SQL but belong to one or more other dialects of SQL.
- SqlLibraryOperatorTableFactory - Class in org.apache.calcite.sql.fun
-
Factory that creates operator tables that consist of functions and operators for particular named libraries.
- SqlLikeOperator - Class in org.apache.calcite.sql.fun
-
An operator describing the
LIKE
andSIMILAR
operators. - SqlLiteral - Class in org.apache.calcite.sql
-
A
SqlLiteral
is a constant. - SqlLiteral(Object, SqlTypeName, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlLiteral
-
Creates a
SqlLiteral
. - SqlLiteral.SqlSymbol - Interface in org.apache.calcite.sql
-
Deprecated.
- SqlLiteralAggFunction - Class in org.apache.calcite.sql.fun
-
The
LITERAL_AGG
aggregate function. - SqlLiteralChainOperator - Class in org.apache.calcite.sql.fun
-
Internal operator, by which the parser represents a continued string literal.
- SqlMapQueryConstructor - Class in org.apache.calcite.sql.fun
-
Definition of the MAP query constructor,
MAP (<query>)
. - SqlMapQueryConstructor() - Constructor for class org.apache.calcite.sql.fun.SqlMapQueryConstructor
- SqlMapTypeNameSpec - Class in org.apache.calcite.sql
-
Parse SQL MAP type, i.e.
- SqlMapTypeNameSpec(SqlDataTypeSpec, SqlDataTypeSpec, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlMapTypeNameSpec
-
Creates a
SqlMapTypeNameSpec
. - SqlMapValueConstructor - Class in org.apache.calcite.sql.fun
-
Definition of the MAP constructor,
MAP [<key>, <value>, ...]
. - SqlMapValueConstructor() - Constructor for class org.apache.calcite.sql.fun.SqlMapValueConstructor
- SqlMatchFunction - Class in org.apache.calcite.sql
-
Base class for all functions used in MATCH_RECOGNIZE.
- SqlMatchFunction(String, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.SqlMatchFunction
- SqlMatchRecognize - Class in org.apache.calcite.sql
-
SqlNode for MATCH_RECOGNIZE clause.
- SqlMatchRecognize(SqlParserPos, SqlNode, SqlNode, SqlLiteral, SqlLiteral, SqlNodeList, SqlNodeList, SqlNode, SqlNodeList, SqlLiteral, SqlNodeList, SqlNodeList, SqlLiteral) - Constructor for class org.apache.calcite.sql.SqlMatchRecognize
-
Creates a SqlMatchRecognize.
- SqlMatchRecognize.AfterOption - Enum in org.apache.calcite.sql
-
Options for
AFTER MATCH
clause. - SqlMatchRecognize.RowsPerMatchOption - Enum in org.apache.calcite.sql
-
Options for
ROWS PER MATCH
. - SqlMatchRecognize.SqlMatchRecognizeOperator - Class in org.apache.calcite.sql
-
An operator describing a MATCH_RECOGNIZE specification.
- SqlMeasureOperator - Class in org.apache.calcite.sql
-
The
MEASURE
wraps an expression in theSELECT
clause and tags it as a measure. - SqlMeasureOperator() - Constructor for class org.apache.calcite.sql.SqlMeasureOperator
-
Creates a MEASURE operator.
- SqlMerge - Class in org.apache.calcite.sql
-
A
SqlMerge
is a node of a parse tree which represents a MERGE statement. - SqlMerge(SqlParserPos, SqlNode, SqlNode, SqlNode, SqlUpdate, SqlInsert, SqlSelect, SqlIdentifier) - Constructor for class org.apache.calcite.sql.SqlMerge
- SqlMinMaxAggFunction - Class in org.apache.calcite.sql.fun
-
Definition of the
MIN
andMAX
aggregate functions, returning the returns the smallest/largest of the values which go into it. - SqlMinMaxAggFunction(String, SqlKind, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
-
Creates a SqlMinMaxAggFunction.
- SqlMinMaxAggFunction(List<RelDataType>, boolean, int) - Constructor for class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
-
Deprecated.
- SqlMinMaxAggFunction(SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
-
Creates a SqlMinMaxAggFunction.
- SqlModality - Enum in org.apache.calcite.sql.validate
-
Relational or streaming.
- SqlMoniker - Interface in org.apache.calcite.sql.validate
-
An interface of an object identifier that represents a SqlIdentifier.
- SqlMonikerImpl - Class in org.apache.calcite.sql.validate
-
A generic implementation of
SqlMoniker
. - SqlMonikerImpl(String, SqlMonikerType) - Constructor for class org.apache.calcite.sql.validate.SqlMonikerImpl
-
Creates a moniker with a single name.
- SqlMonikerImpl(List<String>, SqlMonikerType) - Constructor for class org.apache.calcite.sql.validate.SqlMonikerImpl
-
Creates a moniker with an array of names.
- SqlMonikerType - Enum in org.apache.calcite.sql.validate
-
An enumeration of moniker types.
- SqlMonotonicBinaryOperator - Class in org.apache.calcite.sql.fun
-
Base class for binary operators such as addition, subtraction, and multiplication which are monotonic for the patterns
m op c
andc op m
where m is any monotonic expression and c is a constant. - SqlMonotonicBinaryOperator(String, SqlKind, int, boolean, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.fun.SqlMonotonicBinaryOperator
- SqlMonotonicity - Enum in org.apache.calcite.sql.validate
-
Enumeration of types of monotonicity.
- SqlMonotonicUnaryFunction - Class in org.apache.calcite.sql.fun
-
Base class for unary operators such as FLOOR/CEIL which are monotonic for monotonic inputs.
- SqlMonotonicUnaryFunction(String, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.fun.SqlMonotonicUnaryFunction
- SqlMultisetMemberOfOperator - Class in org.apache.calcite.sql.fun
-
Multiset MEMBER OF.
- SqlMultisetMemberOfOperator() - Constructor for class org.apache.calcite.sql.fun.SqlMultisetMemberOfOperator
- SqlMultisetQueryConstructor - Class in org.apache.calcite.sql.fun
-
Definition of the SQL:2003 standard MULTISET query constructor,
MULTISET (<query>)
. - SqlMultisetQueryConstructor() - Constructor for class org.apache.calcite.sql.fun.SqlMultisetQueryConstructor
- SqlMultisetQueryConstructor(String, SqlKind, SqlTypeTransform) - Constructor for class org.apache.calcite.sql.fun.SqlMultisetQueryConstructor
- SqlMultisetSetOperator - Class in org.apache.calcite.sql.fun
-
An operator which performs set operations on multisets, such as "MULTISET UNION ALL".
- SqlMultisetSetOperator(String, int, boolean) - Constructor for class org.apache.calcite.sql.fun.SqlMultisetSetOperator
- SqlMultisetValueConstructor - Class in org.apache.calcite.sql.fun
-
Definition of the SQL:2003 standard MULTISET constructor,
MULTISET [<expr>, ...]
. - SqlMultisetValueConstructor() - Constructor for class org.apache.calcite.sql.fun.SqlMultisetValueConstructor
- SqlMultisetValueConstructor(String, SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlMultisetValueConstructor
- SqlMultisetValueConstructor(String, SqlKind, SqlOperandTypeInference) - Constructor for class org.apache.calcite.sql.fun.SqlMultisetValueConstructor
- SqlNameMatcher - Interface in org.apache.calcite.sql.validate
-
Checks whether two names are the same according to a case-sensitivity policy.
- SqlNameMatchers - Class in org.apache.calcite.sql.validate
-
Helpers for
SqlNameMatcher
. - SqlNewOperator - Class in org.apache.calcite.sql.fun
-
SqlNewOperator represents an SQL
new specification
such asNEW UDT(1, 2)
. - SqlNewOperator() - Constructor for class org.apache.calcite.sql.fun.SqlNewOperator
- sqlNode - Variable in class org.apache.calcite.jdbc.CalcitePrepare.ParseResult
- SqlNode - Class in org.apache.calcite.sql
-
A
SqlNode
is a SQL parse tree. - SqlNodeList - Class in org.apache.calcite.sql
-
A
SqlNodeList
is a list ofSqlNode
s. - SqlNodeList(Collection<? extends SqlNode>, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlNodeList
-
Creates a
SqlNodeList
containing the nodes inlist
. - SqlNodeList(SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlNodeList
-
Creates a SqlNodeList that is initially empty.
- SqlNodeToRexConverter - Interface in org.apache.calcite.sql2rel
- SqlNodeToRexConverterImpl - Class in org.apache.calcite.sql2rel
-
Standard implementation of
SqlNodeToRexConverter
. - SqlNonNullableAccessors - Class in org.apache.calcite.sql.validate
-
This class provides non-nullable accessors for common getters.
- SqlNthValueAggFunction - Class in org.apache.calcite.sql.fun
-
NTH_VALUE
windowed aggregate function returns the value of an expression evaluated at then
th row of the window frame. - SqlNthValueAggFunction(SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlNthValueAggFunction
- SqlNtileAggFunction - Class in org.apache.calcite.sql.fun
-
NTILE
aggregate function return the value of given expression evaluated at given offset. - SqlNtileAggFunction() - Constructor for class org.apache.calcite.sql.fun.SqlNtileAggFunction
- SqlNullifFunction - Class in org.apache.calcite.sql.fun
-
The
NULLIF
function. - SqlNullifFunction() - Constructor for class org.apache.calcite.sql.fun.SqlNullifFunction
- SqlNullSemantics - Enum in org.apache.calcite.sql
-
SqlNullSemantics defines the possible comparison rules for values which might be null.
- SqlNullTreatmentOperator - Class in org.apache.calcite.sql
-
An operator that decides how to handle null input (
RESPECT NULLS
andIGNORE NULLS
). - SqlNullTreatmentOperator(SqlKind) - Constructor for class org.apache.calcite.sql.SqlNullTreatmentOperator
- SqlNumericLiteral - Class in org.apache.calcite.sql
-
A numeric SQL literal.
- SqlNumericLiteral(BigDecimal, Integer, Integer, boolean, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlNumericLiteral
- SqlOperandCountRange - Interface in org.apache.calcite.sql
-
A class that describes how many operands an operator can take.
- SqlOperandCountRanges - Class in org.apache.calcite.sql.type
-
Helpers for
SqlOperandCountRange
. - SqlOperandCountRanges() - Constructor for class org.apache.calcite.sql.type.SqlOperandCountRanges
- SqlOperandHandler - Interface in org.apache.calcite.sql.type
-
Strategy interface to process operands of an operator call.
- SqlOperandMetadata - Interface in org.apache.calcite.sql.type
-
Extension to
SqlOperandTypeChecker
that also provides names and types of particular operands. - SqlOperandTypeChecker - Interface in org.apache.calcite.sql.type
-
Strategy interface to check for allowed operand types of an operator call.
- SqlOperandTypeChecker.Consistency - Enum in org.apache.calcite.sql.type
-
Strategy used to make arguments consistent.
- SqlOperandTypeInference - Interface in org.apache.calcite.sql.type
-
Strategy to infer unknown types of the operands of an operator call.
- SqlOperator - Class in org.apache.calcite.sql
-
A
SqlOperator
is a type of node in a SQL parse tree (it is NOT a node in a SQL parse tree). - SqlOperator(String, SqlKind, int, boolean, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.SqlOperator
-
Creates an operator specifying left/right associativity.
- SqlOperator(String, SqlKind, int, int, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.SqlOperator
-
Creates an operator.
- SqlOperatorBinding - Class in org.apache.calcite.sql
-
SqlOperatorBinding
represents the binding of anSqlOperator
to actual operands, along with any additional information required to validate those operands if needed. - SqlOperatorBinding(RelDataTypeFactory, SqlOperator) - Constructor for class org.apache.calcite.sql.SqlOperatorBinding
-
Creates a SqlOperatorBinding.
- SqlOperatorFixture - Interface in org.apache.calcite.sql.test
-
A fixture for testing the SQL operators.
- SqlOperatorFixture.CastType - Enum in org.apache.calcite.sql.test
-
Types for cast.
- SqlOperatorFixture.VmName - Enum in org.apache.calcite.sql.test
-
Name of a virtual machine that can potentially implement an operator.
- SqlOperatorTable - Interface in org.apache.calcite.sql
-
SqlOperatorTable defines a directory interface for enumerating and looking up SQL operators and functions.
- SqlOperatorTables - Class in org.apache.calcite.sql.util
-
Utilities for
SqlOperatorTable
s. - SqlOperatorTest - Class in org.apache.calcite.test
-
Contains unit tests for all operators.
- SqlOperatorTest() - Constructor for class org.apache.calcite.test.SqlOperatorTest
- SqlOperatorTest.TesterImpl - Class in org.apache.calcite.test
-
Implementation of
SqlTester
based on a JDBC connection. - SqlOrderBy - Class in org.apache.calcite.sql
-
Parse tree node that represents an
ORDER BY
on a query other than aSELECT
(e.g. - SqlOrderBy(SqlParserPos, SqlNode, SqlNodeList, SqlNode, SqlNode) - Constructor for class org.apache.calcite.sql.SqlOrderBy
- SqlOverlapsOperator - Class in org.apache.calcite.sql.fun
-
SqlOverlapsOperator represents the SQL:1999 standard
OVERLAPS
function. - SqlOverlayFunction - Class in org.apache.calcite.sql.fun
-
The
OVERLAY
function. - SqlOverlayFunction() - Constructor for class org.apache.calcite.sql.fun.SqlOverlayFunction
- SqlOverOperator - Class in org.apache.calcite.sql
-
An operator describing a window function specification.
- SqlOverOperator() - Constructor for class org.apache.calcite.sql.SqlOverOperator
- SqlParseException - Exception Class in org.apache.calcite.sql.parser
-
SqlParseException defines a checked exception corresponding to
SqlParser
. - SqlParseException(String, SqlParserPos, int[][], String[], Throwable) - Constructor for exception class org.apache.calcite.sql.parser.SqlParseException
-
Creates a SqlParseException.
- sqlParser(Reader, UnaryOperator<SqlParser.Config>) - Static method in class org.apache.calcite.sql.parser.SqlParserTest
- SqlParser - Class in org.apache.calcite.sql.parser
-
A
SqlParser
parses a SQL statement. - SqlParser.Config - Interface in org.apache.calcite.sql.parser
-
Interface to define the configuration for a SQL parser.
- SqlParser.ConfigBuilder - Class in org.apache.calcite.sql.parser
-
Deprecated.
- SqlParserFixture - Class in org.apache.calcite.sql.parser
-
Helper class for building fluent parser tests such as
sql("values 1").ok();
. - SqlParserImplFactory - Interface in org.apache.calcite.sql.parser
-
Factory for
SqlAbstractParserImpl
objects. - SqlParserPos - Class in org.apache.calcite.sql.parser
-
SqlParserPos represents the position of a parsed token within SQL statement text.
- SqlParserPos(int, int) - Constructor for class org.apache.calcite.sql.parser.SqlParserPos
-
Creates a new parser position.
- SqlParserPos(int, int, int, int) - Constructor for class org.apache.calcite.sql.parser.SqlParserPos
-
Creates a new parser range.
- SqlParserTest - Class in org.apache.calcite.sql.parser
-
A
SqlParserTest
is a unit-test forthe SQL parser
. - SqlParserTest() - Constructor for class org.apache.calcite.sql.parser.SqlParserTest
- SqlParserTest.Tester - Interface in org.apache.calcite.sql.parser
-
Callback to control how test actions are performed.
- SqlParserTest.TesterImpl - Class in org.apache.calcite.sql.parser
-
Default implementation of
SqlParserTest.Tester
. - SqlParserTest.UnparsingTesterImpl - Class in org.apache.calcite.sql.parser
-
Implementation of
SqlParserTest.Tester
which makes sure that the results of unparsing a query are consistent with the original query. - SqlParserUtil - Class in org.apache.calcite.sql.parser
-
Utility methods relating to parsing SQL.
- SqlParserUtil.MalformedUnicodeEscape - Exception Class in org.apache.calcite.sql.parser
-
Thrown by
SqlParserUtil.replaceEscapedChars(String)
. - SqlParserUtil.ParsedCollation - Class in org.apache.calcite.sql.parser
-
The components of a collation definition, per the SQL standard.
- SqlParserUtil.ToTreeListItem - Class in org.apache.calcite.sql.parser
-
Class that holds a
SqlOperator
and aSqlParserPos
. - SqlPivot - Class in org.apache.calcite.sql
-
Parse tree node that represents a PIVOT applied to a table reference (or sub-query).
- SqlPivot(SqlParserPos, SqlNode, SqlNodeList, SqlNodeList, SqlNodeList) - Constructor for class org.apache.calcite.sql.SqlPivot
- SqlPositionFunction - Class in org.apache.calcite.sql.fun
-
The
POSITION
function. - SqlPositionFunction(String) - Constructor for class org.apache.calcite.sql.fun.SqlPositionFunction
- SqlPosixRegexOperator - Class in org.apache.calcite.sql.fun
-
An operator describing the
~
operator. - SqlPostfixOperator - Class in org.apache.calcite.sql
-
A postfix unary operator.
- SqlPostfixOperator(String, SqlKind, int, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.SqlPostfixOperator
- SqlPrefixOperator - Class in org.apache.calcite.sql
-
A unary operator.
- SqlPrefixOperator(String, SqlKind, int, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.SqlPrefixOperator
- SqlPrettyWriter - Class in org.apache.calcite.sql.pretty
-
Pretty printer for SQL statements.
- SqlPrettyWriter() - Constructor for class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Creates a writer with the default configuration.
- SqlPrettyWriter(SqlDialect) - Constructor for class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- SqlPrettyWriter(SqlDialect, boolean) - Constructor for class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- SqlPrettyWriter(SqlDialect, boolean, PrintWriter) - Constructor for class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- SqlPrettyWriter(SqlDialect, SqlWriterConfig) - Constructor for class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Deprecated.
- SqlPrettyWriter(SqlDialect, SqlWriterConfig, StringBuilder) - Constructor for class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Creates a writer with the given configuration and dialect, and a given print writer (or a private print writer if it is null).
- SqlPrettyWriter(SqlWriterConfig) - Constructor for class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Creates a writer with the given configuration, and a private builder.
- SqlPrettyWriter(SqlWriterConfig, StringBuilder) - Constructor for class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Creates a writer with the given configuration and a given buffer to write to.
- SqlPrettyWriter.FrameImpl - Class in org.apache.calcite.sql.pretty
-
Implementation of
SqlWriter.Frame
. - SqlProcedureCallOperator - Class in org.apache.calcite.sql
-
SqlProcedureCallOperator represents the CALL statement.
- SqlProcedureCallOperator() - Constructor for class org.apache.calcite.sql.SqlProcedureCallOperator
- SqlQualified - Class in org.apache.calcite.sql.validate
-
Fully-qualified identifier.
- SqlQuantifyOperator - Class in org.apache.calcite.sql.fun
-
Definition of the SQL
ALL
andSOME
operators. - SqlRandIntegerFunction - Class in org.apache.calcite.sql.fun
-
The
RAND_INTEGER
function. - SqlRandIntegerFunction() - Constructor for class org.apache.calcite.sql.fun.SqlRandIntegerFunction
- SqlRankFunction - Class in org.apache.calcite.sql
-
Operator which aggregates sets of values into a result.
- SqlRankFunction(boolean, SqlKind) - Constructor for class org.apache.calcite.sql.SqlRankFunction
-
Deprecated.
- SqlRankFunction(SqlKind, SqlReturnTypeInference, boolean) - Constructor for class org.apache.calcite.sql.SqlRankFunction
- SqlRegrCountAggFunction - Class in org.apache.calcite.sql.fun
-
Definition of the SQL
REGR_COUNT
aggregation function. - SqlRegrCountAggFunction(SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlRegrCountAggFunction
- SqlReturnTypeInference - Interface in org.apache.calcite.sql.type
-
Strategy interface to infer the type of an operator call from the type of the operands.
- SqlReturnTypeInferenceChain - Class in org.apache.calcite.sql.type
-
Strategy to infer the type of an operator call from the type of the operands by using a series of
SqlReturnTypeInference
rules in a given order. - SqlRexContext - Interface in org.apache.calcite.sql2rel
-
Contains the context necessary for a
SqlRexConvertlet
to convert aSqlNode
expression into aRexNode
. - SqlRexConvertlet - Interface in org.apache.calcite.sql2rel
- SqlRexConvertletTable - Interface in org.apache.calcite.sql2rel
-
Collection of
SqlRexConvertlet
s. - SqlRollback - Class in org.apache.calcite.sql.babel.postgresql
-
Parse tree node representing a
ROLLBACK
clause. - SqlRollback(SqlParserPos, SqlLiteral) - Constructor for class org.apache.calcite.sql.babel.postgresql.SqlRollback
- SqlRowOperator - Class in org.apache.calcite.sql.fun
-
SqlRowOperator represents the special ROW constructor.
- SqlRowOperator(String) - Constructor for class org.apache.calcite.sql.fun.SqlRowOperator
- SqlRowTypeNameSpec - Class in org.apache.calcite.sql
-
A sql type name specification of row type.
- SqlRowTypeNameSpec(SqlParserPos, List<SqlIdentifier>, List<SqlDataTypeSpec>) - Constructor for class org.apache.calcite.sql.SqlRowTypeNameSpec
-
Creates a row type specification.
- sqls - Variable in class org.apache.calcite.jdbc.CalciteSchema.TableEntry
- SqlSampleSpec - Class in org.apache.calcite.sql
-
Specification of a SQL sample.
- SqlSampleSpec() - Constructor for class org.apache.calcite.sql.SqlSampleSpec
- SqlSampleSpec.SqlSubstitutionSampleSpec - Class in org.apache.calcite.sql
-
Sample specification that orders substitution.
- SqlSampleSpec.SqlTableSampleSpec - Class in org.apache.calcite.sql
-
Sample specification.
- SqlScopedShuttle - Class in org.apache.calcite.sql.validate
-
Refinement to
SqlShuttle
which maintains a stack of scopes. - SqlScopedShuttle(SqlValidatorScope) - Constructor for class org.apache.calcite.sql.validate.SqlScopedShuttle
- SqlSelect - Class in org.apache.calcite.sql
-
A
SqlSelect
is a node of a parse tree which represents a select statement. - SqlSelect(SqlParserPos, SqlNodeList, SqlNodeList, SqlNode, SqlNode, SqlNodeList, SqlNode, SqlNodeList, SqlNodeList, SqlNode, SqlNode, SqlNodeList) - Constructor for class org.apache.calcite.sql.SqlSelect
-
Deprecated.
- SqlSelect(SqlParserPos, SqlNodeList, SqlNodeList, SqlNode, SqlNode, SqlNodeList, SqlNode, SqlNodeList, SqlNode, SqlNodeList, SqlNode, SqlNode, SqlNodeList) - Constructor for class org.apache.calcite.sql.SqlSelect
- SqlSelectKeyword - Enum in org.apache.calcite.sql
-
Defines the keywords which can occur immediately after the "SELECT" keyword.
- SqlSelectOperator - Class in org.apache.calcite.sql
-
An operator describing a query.
- SqlSequenceValueOperator - Class in org.apache.calcite.sql.fun
-
Operator that returns the current or next value of a sequence.
- SqlSessionTableFunction - Class in org.apache.calcite.sql
-
SqlSessionTableFunction implements an operator for per-key sessionization.
- SqlSessionTableFunction() - Constructor for class org.apache.calcite.sql.SqlSessionTableFunction
- SqlSetOperator - Class in org.apache.calcite.sql
-
SqlSetOperator represents a relational set theory operator (UNION, INTERSECT, MINUS).
- SqlSetOperator(String, SqlKind, int, boolean) - Constructor for class org.apache.calcite.sql.SqlSetOperator
- SqlSetOperator(String, SqlKind, int, boolean, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.SqlSetOperator
- SqlSetOption - Class in org.apache.calcite.sql
-
SQL parse tree node to represent
SET
andRESET
statements, optionally preceded byALTER SYSTEM
orALTER SESSION
. - SqlSetOption(SqlParserPos, String, SqlIdentifier, SqlNode) - Constructor for class org.apache.calcite.sql.SqlSetOption
-
Creates a node.
- SqlSetSemanticsTableOperator - Class in org.apache.calcite.sql
-
SetSemanticsTable appears as an parameter in a table function.
- SqlSetSemanticsTableOperator() - Constructor for class org.apache.calcite.sql.SqlSetSemanticsTableOperator
- SqlShell - Class in org.apache.calcite.adapter.os
-
Command that executes its arguments as a SQL query against Calcite's OS adapter.
- SqlShow - Class in org.apache.calcite.sql.babel.postgresql
-
Parse tree node representing a
SHOW
clause. - SqlShow(SqlParserPos, SqlIdentifier) - Constructor for class org.apache.calcite.sql.babel.postgresql.SqlShow
- SqlShuttle - Class in org.apache.calcite.sql.util
-
Basic implementation of
SqlVisitor
which returns each leaf node unchanged. - SqlShuttle() - Constructor for class org.apache.calcite.sql.util.SqlShuttle
- SqlShuttle.CallCopyingArgHandler - Class in org.apache.calcite.sql.util
-
Implementation of
SqlBasicVisitor.ArgHandler
that deep-copiesSqlCall
s and their operands. - SqlSimpleParser - Class in org.apache.calcite.sql.advise
-
A simple parser that takes an incomplete and turn it into a syntactically correct statement.
- SqlSimpleParser(String) - Constructor for class org.apache.calcite.sql.advise.SqlSimpleParser
-
Deprecated.
- SqlSimpleParser(String, SqlParser.Config) - Constructor for class org.apache.calcite.sql.advise.SqlSimpleParser
-
Creates a SqlSimpleParser.
- SqlSimpleParser.IdToken - Class in org.apache.calcite.sql.advise
-
Token representing an identifier.
- SqlSimpleParser.Token - Class in org.apache.calcite.sql.advise
-
Token.
- SqlSimpleParser.Tokenizer - Class in org.apache.calcite.sql.advise
-
Tokenizer.
- SqlSingleOperandTypeChecker - Interface in org.apache.calcite.sql.type
-
SqlSingleOperandTypeChecker is an extension of
SqlOperandTypeChecker
for implementations which are capable of checking the type of a single operand in isolation. - SqlSingletonAggFunction - Interface in org.apache.calcite.sql
-
Aggregate function that knows how to convert itself to a scalar value when applied to a single row.
- SqlSingleValueAggFunction - Class in org.apache.calcite.sql.fun
-
SINGLE_VALUE
aggregate function returns the input value if there is only one value in the input; Otherwise it triggers a run-time error. - SqlSingleValueAggFunction(RelDataType) - Constructor for class org.apache.calcite.sql.fun.SqlSingleValueAggFunction
- SqlSnapshot - Class in org.apache.calcite.sql
-
Parse tree node for "
FOR SYSTEM_TIME AS OF
" temporal clause. - SqlSnapshot(SqlParserPos, SqlNode, SqlNode) - Constructor for class org.apache.calcite.sql.SqlSnapshot
-
Creates a SqlSnapshot.
- SqlSnapshot.SqlSnapshotOperator - Class in org.apache.calcite.sql
-
An operator describing a FOR SYSTEM_TIME specification.
- SqlSpatialTypeFunctions - Class in org.apache.calcite.sql.fun
-
Utilities for spatial type functions.
- SqlSpatialTypeFunctions.ExplodeTable - Class in org.apache.calcite.sql.fun
-
Returns the geometries of a geometry.
- SqlSpatialTypeFunctions.GridTable - Class in org.apache.calcite.sql.fun
-
Returns the points or rectangles in a grid that covers a given geometry.
- SqlSpatialTypeOperatorTable - Class in org.apache.calcite.sql
-
Implementation of
SqlSpatialTypeOperatorTable
containing the spatial operators and functions. - SqlSpatialTypeOperatorTable() - Constructor for class org.apache.calcite.sql.SqlSpatialTypeOperatorTable
- SqlSpecialOperator - Class in org.apache.calcite.sql
-
Generic operator for nodes with special syntax.
- SqlSpecialOperator(String, SqlKind) - Constructor for class org.apache.calcite.sql.SqlSpecialOperator
- SqlSpecialOperator(String, SqlKind, int) - Constructor for class org.apache.calcite.sql.SqlSpecialOperator
- SqlSpecialOperator(String, SqlKind, int, boolean, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker) - Constructor for class org.apache.calcite.sql.SqlSpecialOperator
- SqlSpecialOperator.ReduceResult - Class in org.apache.calcite.sql
- SqlSpecialOperator.TokenSequence - Interface in org.apache.calcite.sql
-
List of tokens: the input to a parser.
- SqlSplittableAggFunction - Interface in org.apache.calcite.sql
-
Aggregate function that can be split into partial aggregates.
- SqlSplittableAggFunction.AbstractSumSplitter - Class in org.apache.calcite.sql
-
Common splitting strategy for
SUM
andSUM0
functions. - SqlSplittableAggFunction.CountSplitter - Class in org.apache.calcite.sql
-
Splitting strategy for
COUNT
. - SqlSplittableAggFunction.Registry<E> - Interface in org.apache.calcite.sql
-
Collection in which one can register an element.
- SqlSplittableAggFunction.SelfSplitter - Class in org.apache.calcite.sql
-
Aggregate function that splits into two applications of itself.
- SqlSplittableAggFunction.Sum0Splitter - Class in org.apache.calcite.sql
-
Splitting strategy for
SUM0
function. - SqlSplittableAggFunction.SumSplitter - Class in org.apache.calcite.sql
-
Splitting strategy for
SUM
function. - SqlStateCodes - Enum in org.apache.calcite.sql
-
Deprecated.Use
org.apache.calcite.avatica.SqlState
- SqlStaticAggFunction - Interface in org.apache.calcite.sql
-
Aggregate function whose value may be a constant expression, based on only the contents of the GROUP BY clause.
- SqlStatisticProvider - Interface in org.apache.calcite.materialize
-
Estimates row counts for tables and columns, and whether combinations of columns form primary/unique and foreign keys.
- SqlStdOperatorTable - Class in org.apache.calcite.sql.fun
-
Implementation of
SqlOperatorTable
containing the standard operators and functions. - SqlStdOperatorTable() - Constructor for class org.apache.calcite.sql.fun.SqlStdOperatorTable
- SQLSTREAM - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- SqlString - Class in org.apache.calcite.sql.util
-
String that represents a kocher SQL statement, expression, or fragment.
- SqlString(SqlDialect, String) - Constructor for class org.apache.calcite.sql.util.SqlString
-
Creates a SqlString.
- SqlString(SqlDialect, String, ImmutableList<Integer>) - Constructor for class org.apache.calcite.sql.util.SqlString
-
Creates a SqlString.
- SqlStringContextVariable - Class in org.apache.calcite.sql.fun
-
Base class for string functions such as "USER", "CURRENT_ROLE", and "CURRENT_PATH".
- SqlStringContextVariable(String) - Constructor for class org.apache.calcite.sql.fun.SqlStringContextVariable
- SqlSubstringFunction - Class in org.apache.calcite.sql.fun
-
Definition of the "SUBSTRING" builtin SQL function.
- SqlSumAggFunction - Class in org.apache.calcite.sql.fun
-
Sum
is an aggregator which returns the sum of the values which go into it. - SqlSumAggFunction(RelDataType) - Constructor for class org.apache.calcite.sql.fun.SqlSumAggFunction
- SqlSumEmptyIsZeroAggFunction - Class in org.apache.calcite.sql.fun
-
Sum0
is an aggregator which returns the sum of the values which go into it likeSum
. - SqlSumEmptyIsZeroAggFunction() - Constructor for class org.apache.calcite.sql.fun.SqlSumEmptyIsZeroAggFunction
- SqlSyntax - Enum in org.apache.calcite.sql
-
Enumeration of possible syntactic types of
operators
. - SqlTableFunction - Interface in org.apache.calcite.sql
-
A function that returns a table.
- SqlTableRef - Class in org.apache.calcite.sql
-
A
SqlTableRef
is a node of a parse tree which represents a table reference. - SqlTableRef(SqlParserPos, SqlIdentifier, SqlNodeList) - Constructor for class org.apache.calcite.sql.SqlTableRef
- SqlTester - Interface in org.apache.calcite.sql.test
-
Callback for testing SQL queries and expressions.
- SqlTester.ParameterChecker - Interface in org.apache.calcite.sql.test
-
Parameter checker.
- SqlTester.ResultChecker - Interface in org.apache.calcite.sql.test
-
Result checker.
- SqlTester.TypeChecker - Interface in org.apache.calcite.sql.test
-
Type checker.
- SqlTester.ValidatedNodeConsumer - Interface in org.apache.calcite.sql.test
-
Action that is called after validation.
- SqlTester.ValidatedNodeFunction<R> - Interface in org.apache.calcite.sql.test
-
A function to apply to the result of validation.
- SqlTester.VmName - Enum in org.apache.calcite.sql.test
-
Name of a virtual machine that can potentially implement an operator.
- SqlTestFactory - Class in org.apache.calcite.sql.test
-
As
SqlTestFactory
but has no state, and therefore configuration is passed to each method. - SqlTestFactory(SqlTestFactory.CatalogReaderFactory, SqlTestFactory.TypeFactoryFactory, SqlTestFactory.PlannerFactory, Context, UnaryOperator<RelOptCluster>, SqlTestFactory.ValidatorFactory, ConnectionFactory, SqlParser.Config, SqlValidator.Config, SqlToRelConverter.Config, SqlOperatorTable, UnaryOperator<RelDataTypeSystem>) - Constructor for class org.apache.calcite.sql.test.SqlTestFactory
- SqlTestFactory.CatalogReaderFactory - Interface in org.apache.calcite.sql.test
-
Creates a
SqlValidatorCatalogReader
for tests. - SqlTestFactory.PlannerFactory - Interface in org.apache.calcite.sql.test
-
Creates a
RelOptPlanner
for tests. - SqlTestFactory.TypeFactoryFactory - Interface in org.apache.calcite.sql.test
-
Creates a
RelDataTypeFactory
for tests. - SqlTestFactory.ValidatorFactory - Interface in org.apache.calcite.sql.test
-
Creates
SqlValidator
for tests. - SqlTests - Class in org.apache.calcite.sql.test
-
Utility methods.
- SqlTests() - Constructor for class org.apache.calcite.sql.test.SqlTests
- SqlTests.Stage - Enum in org.apache.calcite.sql.test
-
Stage of query processing.
- SqlTests.StringTypeChecker - Class in org.apache.calcite.sql.test
-
Type checker which compares types to a specified string.
- SqlThrowOperator - Class in org.apache.calcite.sql.fun
-
An internal operator that throws an exception.
- SqlThrowOperator() - Constructor for class org.apache.calcite.sql.fun.SqlThrowOperator
- sqlTime - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- SqlTimeLiteral - Class in org.apache.calcite.sql
-
A SQL literal representing a TIME value, for example
TIME '14:33:44.567'
. - SqlTimeoutException - Exception Class in org.apache.calcite.jdbc
-
Indicates that an operation timed out.
- sqlTimestamp - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- SqlTimestampAddFunction - Class in org.apache.calcite.sql.fun
-
The
TIMESTAMPADD
function, which adds an interval to a datetime (TIMESTAMP, TIME or DATE). - SqlTimestampLiteral - Class in org.apache.calcite.sql
-
A SQL literal representing a TIMESTAMP value, for example
TIMESTAMP '1969-07-21 03:15'
. - SqlTimestampTzLiteral - Class in org.apache.calcite.sql
-
A SQL literal representing a TIMESTAMP WITH TIME ZONE value, for example
TIMESTAMP '1969-07-21 03:15 GMT+00:00'
. - SqlTimeTzLiteral - Class in org.apache.calcite.sql
-
A SQL literal representing a TIME WITH TIME ZONE value, for example
TIME WITH TIME ZONE '14:33:44.567 GMT+08'
. - sqlToRelConfig - Variable in class org.apache.calcite.sql.test.SqlTestFactory
- SqlToRelConverter - Class in org.apache.calcite.sql2rel
- SqlToRelConverter(RelOptTable.ViewExpander, SqlValidator, Prepare.CatalogReader, RelOptCluster, SqlRexConvertletTable, SqlToRelConverter.Config) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter
- SqlToRelConverter(RelOptTable.ViewExpander, SqlValidator, Prepare.CatalogReader, RelOptCluster, SqlRexConvertletTable) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter
-
Deprecated.
- SqlToRelConverter(RelOptTable.ViewExpander, SqlValidator, Prepare.CatalogReader, RelOptPlanner, RexBuilder, SqlRexConvertletTable) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter
-
Deprecated.
- SqlToRelConverter.Blackboard - Class in org.apache.calcite.sql2rel
-
Workspace for translating an individual SELECT statement (or sub-SELECT).
- SqlToRelConverter.Config - Interface in org.apache.calcite.sql2rel
-
Interface to define the configuration for a SqlToRelConverter.
- SqlToRelConverter.SqlIdentifierFinder - Class in org.apache.calcite.sql2rel
-
Visitor that looks for an SqlIdentifier inside a tree of
SqlNode
objects and returnBoolean.TRUE
when it finds one. - sqlToRelConverterConfig(SqlToRelConverter.Config) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- SqlToRelFixture - Class in org.apache.calcite.test
-
Parameters for a SQL-to-RelNode test.
- SqlToRelTestBase - Class in org.apache.calcite.test
-
SqlToRelTestBase is an abstract base for tests which involve conversion from SQL to relational algebra.
- SqlToRelTestBase() - Constructor for class org.apache.calcite.test.SqlToRelTestBase
- SqlToRelTestBase.CustomCorrelate - Class in org.apache.calcite.test
-
Custom implementation of Correlate for testing.
- SqlTranslate3Function - Class in org.apache.calcite.sql.fun
-
Definition of the "TRANSLATE" built-in SQL function that takes 3 arguments.
- SqlTranslateFunction - Class in org.apache.calcite.sql.fun
-
Common base for the
TRANSLATE(USING)
andCONVERT(USING)
function, which is different fromSqlLibraryOperators.TRANSLATE3
andSqlLibraryOperators.MSSQL_CONVERT
. - SqlTranslateFunction(String) - Constructor for class org.apache.calcite.sql.fun.SqlTranslateFunction
- SqlTrimFunction - Class in org.apache.calcite.sql.fun
-
Definition of the "TRIM" builtin SQL function.
- SqlTrimFunction(String, SqlKind, SqlReturnTypeInference, SqlSingleOperandTypeChecker) - Constructor for class org.apache.calcite.sql.fun.SqlTrimFunction
- SqlTrimFunction.Flag - Enum in org.apache.calcite.sql.fun
-
Defines the enumerated values "LEADING", "TRAILING", "BOTH".
- SqlTruncate - Class in org.apache.calcite.sql
-
Base class for an TRUNCATE statements parse tree nodes.
- SqlTruncate(SqlOperator, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlTruncate
-
Creates a SqlTruncate.
- SqlTruncateTable - Class in org.apache.calcite.sql.ddl
-
Parse tree for
TRUNCATE TABLE
statement. - SqlTruncateTable(SqlParserPos, SqlIdentifier, boolean) - Constructor for class org.apache.calcite.sql.ddl.SqlTruncateTable
-
Creates a SqlTruncateTable.
- SqlTumbleTableFunction - Class in org.apache.calcite.sql
-
SqlTumbleTableFunction implements an operator for tumbling.
- SqlTumbleTableFunction() - Constructor for class org.apache.calcite.sql.SqlTumbleTableFunction
- sqlType - Variable in enum org.apache.calcite.adapter.druid.DruidType
-
The corresponding SQL type.
- SqlTypeAssignmentRule - Class in org.apache.calcite.sql.type
-
Rules that determine whether a type is assignable from another type.
- SqlTypeCoercionRule - Class in org.apache.calcite.sql.type
-
Rules that determine whether a type is castable from another type.
- SqlTypeConstructorFunction - Class in org.apache.calcite.sql
-
Type Constructor function.
- SqlTypeConstructorFunction(SqlIdentifier, RelDataType) - Constructor for class org.apache.calcite.sql.SqlTypeConstructorFunction
-
Creates a constructor function for types.
- SqlTypeExplicitPrecedenceList - Class in org.apache.calcite.sql.type
-
SqlTypeExplicitPrecedenceList implements the
RelDataTypePrecedenceList
interface via an explicit list ofSqlTypeName
entries. - SqlTypeExplicitPrecedenceList(Iterable<SqlTypeName>) - Constructor for class org.apache.calcite.sql.type.SqlTypeExplicitPrecedenceList
- SqlTypeFactoryImpl - Class in org.apache.calcite.sql.type
-
SqlTypeFactoryImpl provides a default implementation of
RelDataTypeFactory
which supports SQL types. - SqlTypeFactoryImpl(RelDataTypeSystem) - Constructor for class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- SqlTypeFamily - Enum in org.apache.calcite.sql.type
-
SqlTypeFamily provides SQL type categorization.
- SqlTypeMappingRule - Interface in org.apache.calcite.sql.type
-
Interface that defines rules within type mappings.
- SqlTypeMappingRules - Class in org.apache.calcite.sql.type
-
This class defines some utilities to build type mapping matrix which would then use to construct the
SqlTypeMappingRule
rules. - SqlTypeMappingRules() - Constructor for class org.apache.calcite.sql.type.SqlTypeMappingRules
- SqlTypeMappingRules.Builder - Class in org.apache.calcite.sql.type
-
Keeps state while building the type mappings.
- SqlTypeName - Enum in org.apache.calcite.sql.type
-
Enumeration of the type names which can be used to construct a SQL type.
- SqlTypeName.Limit - Enum in org.apache.calcite.sql.type
-
Limit.
- SqlTypeNameSpec - Class in org.apache.calcite.sql
-
A
SqlTypeNameSpec
is a type name specification that allows user to customize sql node unparsing and data type deriving. - SqlTypeNameSpec(SqlIdentifier, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlTypeNameSpec
-
Creates a
SqlTypeNameSpec
. - SqlTypeTransform - Interface in org.apache.calcite.sql.type
-
Strategy to transform one type to another.
- SqlTypeTransformCascade - Class in org.apache.calcite.sql.type
-
Strategy to infer the type of an operator call from the type of the operands by using one
SqlReturnTypeInference
rule and a combination ofSqlTypeTransform
s. - SqlTypeTransformCascade(SqlReturnTypeInference, SqlTypeTransform...) - Constructor for class org.apache.calcite.sql.type.SqlTypeTransformCascade
-
Creates a SqlTypeTransformCascade from a rule and an array of one or more transforms.
- SqlTypeTransforms - Class in org.apache.calcite.sql.type
-
SqlTypeTransforms defines a number of reusable instances of
SqlTypeTransform
. - SqlTypeTransforms() - Constructor for class org.apache.calcite.sql.type.SqlTypeTransforms
- SqlTypeUtil - Class in org.apache.calcite.sql.type
-
Contains utility methods used during SQL validation or type derivation.
- SqlTypeUtil() - Constructor for class org.apache.calcite.sql.type.SqlTypeUtil
- SqlUnknownLiteral - Class in org.apache.calcite.sql
-
Literal whose type is not yet known.
- SqlUnnestOperator - Class in org.apache.calcite.sql
-
The
UNNEST
operator. - SqlUnnestOperator(boolean) - Constructor for class org.apache.calcite.sql.SqlUnnestOperator
- SqlUnpivot - Class in org.apache.calcite.sql
-
Parse tree node that represents UNPIVOT applied to a table reference (or sub-query).
- SqlUnpivot(SqlParserPos, SqlNode, boolean, SqlNodeList, SqlNodeList, SqlNodeList) - Constructor for class org.apache.calcite.sql.SqlUnpivot
- SqlUnresolvedFunction - Class in org.apache.calcite.sql
-
Placeholder for an unresolved function.
- SqlUnresolvedFunction(SqlIdentifier, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, List<RelDataType>, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.SqlUnresolvedFunction
-
Creates a placeholder SqlUnresolvedFunction for an invocation of a function with a possibly qualified name.
- SqlUpdate - Class in org.apache.calcite.sql
-
A
SqlUpdate
is a node of a parse tree which represents an UPDATE statement. - SqlUpdate(SqlParserPos, SqlNode, SqlNodeList, SqlNodeList, SqlNode, SqlSelect, SqlIdentifier) - Constructor for class org.apache.calcite.sql.SqlUpdate
- SqlUserDefinedAggFunction - Class in org.apache.calcite.sql.validate
-
User-defined aggregate function.
- SqlUserDefinedAggFunction(SqlIdentifier, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandMetadata, AggregateFunction, boolean, boolean, Optionality) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
-
Creates a SqlUserDefinedAggFunction.
- SqlUserDefinedAggFunction(SqlIdentifier, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, AggregateFunction, boolean, boolean, Optionality, RelDataTypeFactory) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
-
Deprecated.
- SqlUserDefinedFunction - Class in org.apache.calcite.sql.validate
-
User-defined scalar function.
- SqlUserDefinedFunction(SqlIdentifier, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandMetadata, Function) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedFunction
-
Creates a
SqlUserDefinedFunction
. - SqlUserDefinedFunction(SqlIdentifier, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandMetadata, Function, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedFunction
-
Constructor used internally and by derived classes.
- SqlUserDefinedFunction(SqlIdentifier, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, List<RelDataType>, Function) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedFunction
-
Deprecated.
- SqlUserDefinedTableFunction - Class in org.apache.calcite.sql.validate
-
User-defined table function.
- SqlUserDefinedTableFunction(SqlIdentifier, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandMetadata, TableFunction) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedTableFunction
-
Creates a user-defined table function.
- SqlUserDefinedTableFunction(SqlIdentifier, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, List<RelDataType>, TableFunction) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedTableFunction
-
Deprecated.
- SqlUserDefinedTableMacro - Class in org.apache.calcite.sql.validate
-
User-defined table macro.
- SqlUserDefinedTableMacro(SqlIdentifier, SqlKind, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandMetadata, TableMacro) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedTableMacro
-
Creates a user-defined table macro.
- SqlUserDefinedTableMacro(SqlIdentifier, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, List<RelDataType>, TableMacro) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedTableMacro
-
Deprecated.
- SqlUserDefinedTypeNameSpec - Class in org.apache.calcite.sql
-
A sql type name specification of user defined type.
- SqlUserDefinedTypeNameSpec(String, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlUserDefinedTypeNameSpec
- SqlUserDefinedTypeNameSpec(SqlIdentifier, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlUserDefinedTypeNameSpec
-
Create a SqlUserDefinedTypeNameSpec instance.
- SqlUtil - Class in org.apache.calcite.sql
-
Contains utility functions related to SQL parsing, all static.
- SqlUtil() - Constructor for class org.apache.calcite.sql.SqlUtil
- SqlUtil.DatabaseMetaDataInvocationHandler - Class in org.apache.calcite.sql
-
Handles particular
DatabaseMetaData
methods; invocations of other methods will fall through to the base class,BarfingInvocationHandler
, which will throw an error. - SqlValidator - Interface in org.apache.calcite.sql.validate
-
Validates the parse tree of a SQL statement, and provides semantic information about the parse tree.
- SqlValidator.Config - Interface in org.apache.calcite.sql.validate
-
Interface to define the configuration for a SqlValidator.
- SqlValidatorCatalogReader - Interface in org.apache.calcite.sql.validate
-
Supplies catalog information for
SqlValidator
. - sqlValidatorConfig(SqlValidator.Config) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- SqlValidatorException - Exception Class in org.apache.calcite.sql.validate
-
Exception thrown while validating a SQL statement.
- SqlValidatorException(String, Throwable) - Constructor for exception class org.apache.calcite.sql.validate.SqlValidatorException
-
Creates a new SqlValidatorException object.
- SqlValidatorFixture - Class in org.apache.calcite.test
-
A fixture for testing the SQL validator.
- SqlValidatorFixture(SqlTester, SqlTestFactory, StringAndPos, boolean, boolean) - Constructor for class org.apache.calcite.test.SqlValidatorFixture
-
Creates a SqlValidatorFixture.
- SqlValidatorImpl - Class in org.apache.calcite.sql.validate
-
Default implementation of
SqlValidator
. - SqlValidatorImpl(SqlOperatorTable, SqlValidatorCatalogReader, RelDataTypeFactory, SqlValidator.Config) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Creates a validator.
- SqlValidatorImpl.DmlNamespace - Class in org.apache.calcite.sql.validate
-
Common base class for DML statement namespaces.
- SqlValidatorImpl.FunctionParamInfo - Class in org.apache.calcite.sql.validate
-
Utility object used to maintain information about the parameters in a function call.
- SqlValidatorImpl.IdInfo - Class in org.apache.calcite.sql.validate
-
Information about an identifier in a particular scope.
- SqlValidatorImpl.Status - Enum in org.apache.calcite.sql.validate
-
Validation status.
- SqlValidatorNamespace - Interface in org.apache.calcite.sql.validate
-
A namespace describes the relation returned by a section of a SQL query.
- SqlValidatorScope - Interface in org.apache.calcite.sql.validate
-
Name-resolution scope.
- SqlValidatorScope.EmptyPath - Class in org.apache.calcite.sql.validate
-
A path that has no steps.
- SqlValidatorScope.Path - Class in org.apache.calcite.sql.validate
-
A sequence of steps by which an identifier was resolved.
- SqlValidatorScope.Resolve - Class in org.apache.calcite.sql.validate
-
A match found when looking up a name.
- SqlValidatorScope.Resolved - Interface in org.apache.calcite.sql.validate
- SqlValidatorScope.ResolvedImpl - Class in org.apache.calcite.sql.validate
-
Default implementation of
SqlValidatorScope.Resolved
. - SqlValidatorScope.Step - Class in org.apache.calcite.sql.validate
-
A step in resolving an identifier.
- SqlValidatorTable - Interface in org.apache.calcite.sql.validate
-
Supplies a
SqlValidator
with the metadata for a table. - SqlValidatorTestCase - Class in org.apache.calcite.test
-
An abstract base class for implementing tests against
SqlValidator
. - SqlValidatorTestCase() - Constructor for class org.apache.calcite.test.SqlValidatorTestCase
-
Creates a test case.
- SqlValidatorTester - Class in org.apache.calcite.sql.test
-
Implementation of
SqlTester
that can parse and validate SQL, and convert it to relational algebra. - SqlValidatorTester() - Constructor for class org.apache.calcite.sql.test.SqlValidatorTester
- SqlValidatorUtil - Class in org.apache.calcite.sql.validate
-
Utility methods related to validation.
- SqlValidatorUtil.DeepCopier - Class in org.apache.calcite.sql.validate
-
Deprecated.
- SqlValidatorUtil.FlatAggregate - Class in org.apache.calcite.sql.validate
-
Flattens any FILTER, WITHIN DISTINCT, WITHIN GROUP surrounding a call to an aggregate function.
- SqlValidatorUtil.Suggester - Interface in org.apache.calcite.sql.validate
-
Suggests candidates for unique names, given the number of attempts so far and the number of expressions in the project list.
- SqlValidatorWithHints - Interface in org.apache.calcite.sql.validate
-
Extends
SqlValidator
to allow discovery of useful data such as fully qualified names of SQL objects, alternative valid SQL objects that can be used in the SQL statement (dubbed as hints). - SqlValuesOperator - Class in org.apache.calcite.sql
-
The
VALUES
operator. - SqlValuesOperator() - Constructor for class org.apache.calcite.sql.SqlValuesOperator
- SqlVisitor<R> - Interface in org.apache.calcite.sql.util
-
Visitor class, follows the
visitor pattern
. - SqlWindow - Class in org.apache.calcite.sql
-
SQL window specification.
- SqlWindow(SqlParserPos, SqlIdentifier, SqlIdentifier, SqlNodeList, SqlNodeList, SqlLiteral, SqlNode, SqlNode, SqlLiteral) - Constructor for class org.apache.calcite.sql.SqlWindow
-
Creates a window.
- SqlWindow(SqlParserPos, SqlIdentifier, SqlIdentifier, SqlNodeList, SqlNodeList, SqlLiteral, SqlNode, SqlNode, SqlLiteral, SqlLiteral) - Constructor for class org.apache.calcite.sql.SqlWindow
-
Creates a window.
- SqlWindowTableFunction - Class in org.apache.calcite.sql
-
Base class for a table-valued function that computes windows.
- SqlWindowTableFunction(String, SqlOperandMetadata) - Constructor for class org.apache.calcite.sql.SqlWindowTableFunction
-
Creates a window table function with a given name.
- SqlWindowTableFunction.AbstractOperandMetadata - Class in org.apache.calcite.sql
-
Partial implementation of operand type checker.
- SqlWith - Class in org.apache.calcite.sql
-
The WITH clause of a query.
- SqlWith(SqlParserPos, SqlNodeList, SqlNode) - Constructor for class org.apache.calcite.sql.SqlWith
- SqlWithinDistinctOperator - Class in org.apache.calcite.sql
-
An operator that applies a distinct operation before rows are included in an aggregate function.
- SqlWithinDistinctOperator() - Constructor for class org.apache.calcite.sql.SqlWithinDistinctOperator
- SqlWithinGroupOperator - Class in org.apache.calcite.sql
-
An operator that applies a sort operation before rows are included in an aggregate function.
- SqlWithinGroupOperator() - Constructor for class org.apache.calcite.sql.SqlWithinGroupOperator
- SqlWithinGroupOperator.PercentileDiscCallBinding - Class in org.apache.calcite.sql
-
Used for PERCENTILE_DISC return type inference.
- SqlWithItem - Class in org.apache.calcite.sql
-
An item in a WITH clause of a query.
- SqlWithItem(SqlParserPos, SqlIdentifier, SqlNodeList, SqlNode) - Constructor for class org.apache.calcite.sql.SqlWithItem
-
Deprecated.
- SqlWithItem(SqlParserPos, SqlIdentifier, SqlNodeList, SqlNode, SqlLiteral) - Constructor for class org.apache.calcite.sql.SqlWithItem
- SqlWithItemTableRef - Class in org.apache.calcite.sql.validate
-
A
SqlWithItemTableRef
is a node created during validation for recursive queries which represents a table reference in aWITH RECURSIVE
clause. - SqlWithItemTableRef(SqlParserPos, SqlWithItem) - Constructor for class org.apache.calcite.sql.validate.SqlWithItemTableRef
- SqlWriter - Interface in org.apache.calcite.sql
-
A
SqlWriter
is the target to construct a SQL statement from a parse tree. - SqlWriter.Frame - Interface in org.apache.calcite.sql
-
A Frame is a piece of generated text which shares a common indentation level.
- SqlWriter.FrameType - Interface in org.apache.calcite.sql
-
Frame type.
- SqlWriter.FrameTypeEnum - Enum in org.apache.calcite.sql
-
Enumerates the types of frame.
- SqlWriter.SubQueryStyle - Enum in org.apache.calcite.sql
-
Style of formatting sub-queries.
- SqlWriterConfig - Interface in org.apache.calcite.sql
-
Configuration for
SqlWriter
andSqlPrettyWriter
. - SqlWriterConfig.LineFolding - Enum in org.apache.calcite.sql
-
Policy for how to do deal with long lines.
- SQLXML - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- SQRT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
SQRT(numeric)
function. - squelchConnection(Connection) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- squelchJar(JarFile) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- squelchReader(Reader) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- squelchStmt(Statement) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- squelchStream(InputStream) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- squelchStream(OutputStream) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- squelchWriter(Writer) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- sround(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ROUND
operator applied to double values. - sround(double, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ROUND
operator applied to double values. - sround(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ROUND
operator applied to int values. - sround(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ROUND
operator applied to int values. - sround(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ROUND
operator applied to long values. - sround(long, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ROUND
operator applied to long values. - sround(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ROUND
operator applied to BigDecimal values. - sround(BigDecimal, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ROUND
operator applied to BigDecimal values. - SROUND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SS - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- SSSSS - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- ST_AddPoint(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Adds
point
tolinestring
at the end. - ST_AddPoint(Geometry, Geometry, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Adds
point
tolinestring
at a givenindex
. - ST_AddZ(Geometry, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Adds
zToAdd
to the z-coordinate of thegeom
. - ST_Area(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the area of the
geom
. - ST_AsBinary(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_AsEWKB(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_AsEWKT(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_AsGeoJSON(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_AsGML(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_AsText(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_AsWKB(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_AsWKT(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_Boundary(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the boundary of
geom
. - ST_BoundingCircle(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the minimum bounding circle of
geom
. - ST_Buffer(Geometry, double) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes a buffer around
geom
. - ST_Buffer(Geometry, double, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes a buffer around
geom
. - ST_Buffer(Geometry, double, int, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes a buffer around
geom
. - ST_Buffer(Geometry, double, String) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes a buffer around
geom
. - ST_Centroid(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the centroid of
geom
. - ST_ClosestCoordinate(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the coordinate(s) of
geom
closest topoint
. - ST_ClosestPoint(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the point of
geom1
closest togeom2
. - ST_ConstrainedDelaunay(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes a constrained Delaunay triangulation based on points in
geom
. - ST_ConstrainedDelaunay(Geometry, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes a constrained Delaunay triangulation based on points in
geom
. - ST_Contains(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether
geom1
containsgeom2
. - ST_CONTAINS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ST_Contains
function that tests whether one geometry contains another. - ST_ContainsProperly(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether
geom1
containsgeom2
but does not intersect its boundary. - ST_ConvexHull(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes the smallest convex POLYGON that contains all the points of geom.
- ST_CoordDim(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the dimension of the coordinates of
geom
. - ST_CoveredBy(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether no point in
geom1
is outsidegeom2
. - ST_Covers(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether no point in
geom2
is outsidegeom1
. - ST_Crosses(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether
geom1
crossesgeom2
. - ST_Delaunay(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes a Delaunay triangulation based on points in
geom
. - ST_Delaunay(Geometry, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes a Delaunay triangulation based on points in
geom
. - ST_Densify(Geometry, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Densifies a
geom
by inserting extra vertices along the line segments. - ST_Difference(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes the difference between geom1 and geom2.
- ST_Dimension(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the dimension of
geom
. - ST_Disjoint(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether
geom1
andgeom2
are disjoint. - ST_Distance(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the distance between
geom1
andgeom2
. - ST_DWithin(Geometry, Geometry, double) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether
geom1
andgeom2
are withindistance
of each other. - ST_DWITHIN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ST_DWithin
geo-spatial function. - ST_EndPoint(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the first point of
geom
. - ST_Envelope(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the minimum bounding box of
geom
(which may be a GEOMETRYCOLLECTION). - ST_EnvelopesIntersect(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether the envelope of
geom1
intersects the envelope ofgeom2
. - ST_Equals(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether
geom1
equalsgeom2
. - ST_Expand(Geometry, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Expands
geom
's envelope. - ST_Expand(Geometry, BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Expands
geom
's envelope. - ST_Explode(Geometry) - Static method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions
-
Explodes the
geom
into multiple geometries. - ST_Extent(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the minimum bounding box that encloses geom as a Geometry.
- ST_ExteriorRing(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the exterior ring of
geom
, or null ifgeom
is not a polygon. - ST_FlipCoordinates(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Flips the X and Y coordinates of the
geom
. - ST_Force2D(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_Force3D(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_FurthestCoordinate(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the coordinate(s) of
geom
furthest frompoint
. - ST_GEOM_FROM_EWKT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ST_GeometryN(Geometry, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the nth geometry of a geometry collection.
- ST_GeometryType(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the type of
geom
. - ST_GeometryTypeCode(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the OGC SFS type code of
geom
. - ST_GeomFromEWKB(ByteString) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_GeomFromEWKT(String) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_GeomFromGeoJSON(String) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_GeomFromGML(String) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_GeomFromGML(String, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_GeomFromText(String) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_GeomFromText(String, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_GeomFromWKB(ByteString) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_GeomFromWKB(ByteString, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_GeomFromWKT(String) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_GeomFromWKT(String, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_Holes(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the holes in the
geom
(which may be a GEOMETRYCOLLECTION). - ST_InteriorRing(Geometry, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the nth interior ring of
geom
, or null ifgeom
is not a polygon. - ST_Intersection(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes the intersection between geom1 and geom2.
- ST_Intersects(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether
geom1
intersectsgeom2
. - ST_Is3D(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether
geom
has at least one z-coordinate. - ST_IsClosed(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether
geom
is a closed LINESTRING or MULTILINESTRING. - ST_IsEmpty(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns true if geom is empty.
- ST_IsRectangle(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns true if geom is rectangle.
- ST_IsRing(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether
geom
is a closed and simple linestring or multi-linestring. - ST_IsSimple(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns true if geom is simple.
- ST_IsValid(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns true if geom is valid.
- ST_Length(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the length of the
geom
. - ST_LineFromText(String) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_LineFromText(String, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_LineFromWKB(ByteString) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_LineFromWKB(ByteString, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_LineMerge(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Merges a collection of linear components to form a line-string of maximal length.
- ST_LocateAlong(Geometry, BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns a MULTIPOINT containing points along the line segments of
geom
atsegmentLengthFraction
andoffsetDistance
. - ST_LongestLine(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the 2-dimensional longest line-string between the points of
geom1
andgeom2
. - ST_MAKE_LINE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ST_MakeLine
function that makes a line. - ST_MakeEllipse(Geometry, BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Makes an ellipse.
- ST_MakeEnvelope(BigDecimal, BigDecimal, BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Creates a rectangular Polygon.
- ST_MakeEnvelope(BigDecimal, BigDecimal, BigDecimal, BigDecimal, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Creates a rectangular Polygon.
- ST_MakeGrid(Geometry, BigDecimal, BigDecimal) - Static method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions
-
Calculates a regular grid of polygons based on
geom
. - ST_MakeGridPoints(Geometry, BigDecimal, BigDecimal) - Static method in class org.apache.calcite.sql.fun.SqlSpatialTypeFunctions
-
Calculates a regular grid of points based on
geom
. - ST_MakeLine(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Creates a line-string from the given POINTs (or MULTIPOINTs).
- ST_MakeLine(Geometry, Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_MakeLine(Geometry, Geometry, Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_MakeLine(Geometry, Geometry, Geometry, Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_MakeLine(Geometry, Geometry, Geometry, Geometry, Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_MakePoint(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_MakePoint(BigDecimal, BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_MakePolygon(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Makes a polygon.
- ST_MakePolygon(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Makes a polygon.
- ST_MakePolygon(Geometry, Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Makes a polygon.
- ST_MakePolygon(Geometry, Geometry, Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Makes a polygon.
- ST_MakePolygon(Geometry, Geometry, Geometry, Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Makes a polygon.
- ST_MakePolygon(Geometry, Geometry, Geometry, Geometry, Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Makes a polygon.
- ST_MakePolygon(Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Makes a polygon.
- ST_MakePolygon(Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Makes a polygon.
- ST_MakePolygon(Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Makes a polygon.
- ST_MakePolygon(Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Makes a polygon.
- ST_MakePolygon(Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Makes a polygon.
- ST_MakeValid(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Makes a valid geometry of a given invalid geometry.
- ST_MaxDistance(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes the maximum distance between
geom1
andgeom2
. - ST_MinimumDiameter(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the minimum diameter of
geom
. - ST_MinimumRectangle(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the minimum rectangle enclosing
geom
. - ST_MLineFromText(String) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_MLineFromText(String, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_MPointFromText(String) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_MPointFromText(String, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_MPolyFromText(String) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_MPolyFromText(String, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_Normalize(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Converts the
geom
to normal form. - ST_NPoints(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the number of points in
geom
. - ST_NumGeometries(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the number of geometries in
geom
(1 if it is not a GEOMETRYCOLLECTION). - ST_NumInteriorRing(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the number of interior rings of
geom
. - ST_NumInteriorRings(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the number of interior rings of
geom
. - ST_NumPoints(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the number of points in
geom
. - ST_OctagonalEnvelope(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the octagonal envelope of
geom
. - ST_OffsetCurve(Geometry, double, String) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes an offset line for
linestring
. - ST_OrderingEquals(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether
geom1
equalsgeom2
and their coordinates and component Geometries are listed in the same order. - ST_Overlaps(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns
geom1
overlapsgeom2
. - ST_Perimeter(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the length of the perimeter of *polygon* (which may be a MULTIPOLYGON).
- ST_Point(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Constructs a 2D point from coordinates.
- ST_Point(BigDecimal, BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Constructs a 3D point from coordinates.
- ST_POINT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ST_Point
function. - ST_POINT3 - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ST_Point
function that makes a 3D point. - ST_PointFromText(String) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_PointFromText(String, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_PointFromWKB(ByteString) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_PointFromWKB(ByteString, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_PointN(Geometry, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the nth point of a
geom
. - ST_PointOnSurface(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns an interior or boundary point of
geom
. - ST_PolyFromText(String) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_PolyFromText(String, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_PolyFromWKB(ByteString) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_PolyFromWKB(ByteString, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
- ST_Polygonize(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Creates a multipolygon from the geometry.
- ST_PrecisionReducer(Geometry, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Reduces the geometry's precision to n decimal places.
- ST_ProjectPoint(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Projects
point
onto alineString
(which may be a MULTILINESTRING). - ST_ReducePrecision(Geometry, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Reduces the precision of a
geom
to the providedgridSize
. - ST_Relate(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the DE-9IM intersection matrix for geom1 and geom2.
- ST_Relate(Geometry, Geometry, String) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns true if geom1 and geom2 are related by the intersection matrix specified by iMatrix.
- ST_RemoveHoles(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Removes the holes of the
geom
. - ST_RemovePoint(Geometry, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Remove
point
at givenindex
inlinestring
. - ST_RemoveRepeatedPoints(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Removes duplicated coordinates from the
geom
. - ST_RemoveRepeatedPoints(Geometry, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Removes duplicated coordinates from the
geom
. - ST_Reverse(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Reverses the order of the coordinates of the
geom
. - ST_Rotate(Geometry, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Rotates geom counter-clockwise by angle (in radians) about the point origin.
- ST_Rotate(Geometry, BigDecimal, BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Rotates geom counter-clockwise by angle (in radians) about the point origin.
- ST_Rotate(Geometry, BigDecimal, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Rotates geom counter-clockwise by angle (in radians) about the point origin.
- ST_Scale(Geometry, BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Scales geom Geometry by multiplying the ordinates by the indicated scale factors.
- ST_SetSRID(Geometry, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns a copy of
geom
with a new SRID. - ST_Simplify(Geometry, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Simplifies geom a geometry using the Douglas-Peuker algorithm.
- ST_SimplifyPreserveTopology(Geometry, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Simplifies a geometry and preserves its topology.
- ST_Snap(Geometry, Geometry, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Snaps geom1 and geom2 together with the given snapTolerance.
- ST_Split(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Splits
geom
byblade
. - ST_SRID(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns SRID value or 0 if input Geometry does not have one.
- ST_StartPoint(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the first point of
geom
. - ST_SymDifference(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes the symmetric difference between geom1 and geom2.
- ST_ToMultiLine(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Converts the a
geom
into a MULTILINESTRING. - ST_ToMultiPoint(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Converts the coordinates of a
geom
into a MULTIPOINT. - ST_ToMultiSegments(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Converts a
geom
into a set of distinct segments stored in a MULTILINESTRING. - ST_Touches(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether
geom1
touchesgeom2
. - ST_Transform(Geometry, int) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Transforms
geom
from one coordinate reference system (CRS) to the CRS specified bysrid
. - ST_Translate(Geometry, BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Translates geom by the vector (x, y).
- ST_UnaryUnion(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes the union of the geometries in
geomCollection
. - ST_UnaryUnion(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Computes the union of
geom1
andgeom2
. - ST_Within(Geometry, Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns whether
geom1
is withingeom2
. - ST_X(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Return the X coordinate of the point, or NULL if not available.
- ST_XMax(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the X maxima of a 2D or 3D bounding box or a geometry.
- ST_XMin(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the X minima of a 2D or 3D bounding box or a geometry.
- ST_Y(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the y-value of the first coordinate of
geom
. - ST_YMax(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the Y maxima of a 2D or 3D bounding box or a geometry.
- ST_YMin(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the Y minima of a 2D or 3D bounding box or a geometry.
- ST_Z(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the z-value of the first coordinate of
geom
. - ST_ZMax(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the maximum z-value of
geom
. - ST_ZMin(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeFunctions
-
Returns the minimum z-value of
geom
. - stack - Variable in class org.apache.calcite.rel.RelShuttleImpl
- Stacks - Class in org.apache.calcite.util
-
Deprecated.
- StackWriter - Class in org.apache.calcite.util
-
A helper class for generating formatted text.
- StackWriter(Writer, String) - Constructor for class org.apache.calcite.util.StackWriter
-
Creates a new StackWriter on top of an existing Writer, with the specified string to be used for each level of indentation.
- standard() - Static method in class org.apache.calcite.test.MockSqlOperatorTable
-
Returns the operator table that contains only the standard operators.
- standard() - Static method in class org.apache.calcite.tools.Programs
-
Returns the standard program used by Prepare.
- standard(RelMetadataProvider) - Static method in class org.apache.calcite.tools.Programs
-
Returns the standard program with user metadata provider.
- standard(RelMetadataProvider, boolean) - Static method in class org.apache.calcite.tools.Programs
-
Returns the standard program with user metadata provider and enableFieldTrimming config.
- STANDARD - Enum constant in enum org.apache.calcite.config.CharLiteralStyle
-
Standard character literal.
- STANDARD - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
The standard operators.
- STANDARD_STREAMS - Enum constant in enum org.apache.calcite.runtime.Hook
-
Called to get stdin, stdout, stderr.
- StandardConvertletTable - Class in org.apache.calcite.sql2rel
-
Standard implementation of
SqlRexConvertletTable
. - star() - Method in class org.apache.calcite.runtime.Pattern.PatternBuilder
-
Creates a pattern that matches the patterns at the top of the stack zero or more times, and pushes it onto the stack.
- star(List<String>, SqlParserPos, List<SqlParserPos>) - Static method in class org.apache.calcite.sql.SqlIdentifier
-
Creates an identifier that ends in a wildcard star.
- star(SqlParserPos) - Static method in class org.apache.calcite.sql.SqlIdentifier
-
Creates an identifier that is a singleton wildcard star.
- STAR - Enum constant in enum org.apache.calcite.runtime.Pattern.Op
-
Pattern that matches a pattern repeated zero or more times.
- STAR - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
A structure, similar to a view, that is the basis for auto-generated materializations.
- STAR - Static variable in class org.apache.calcite.sql.SqlIdentifier
-
An identifier for star, "*".
- starRelOptTable - Variable in class org.apache.calcite.plan.RelOptLattice
- starRelOptTable - Variable in class org.apache.calcite.plan.RelOptMaterialization
- starRequiresRecordType() - Method in interface org.apache.calcite.runtime.CalciteResource
- STARROCKS - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- StarRocksSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the StarRocks database. - StarRocksSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.StarRocksSqlDialect
-
Creates a StarRocksSqlDialect.
- start - Variable in class org.apache.calcite.tools.Hoist.Variable
-
Zero-based position within the SQL text of start of node.
- START - Enum constant in enum org.apache.calcite.adapter.enumerable.WinAggImplementor.SeekType
-
Start of window.
- starTable - Variable in class org.apache.calcite.plan.RelOptMaterialization
- StarTable - Class in org.apache.calcite.schema.impl
-
Virtual table that is composed of two or more tables joined together.
- StarTable.StarTableScan - Class in org.apache.calcite.schema.impl
-
Relational expression that scans a
StarTable
. - StarTableScan(RelOptCluster, RelOptTable) - Constructor for class org.apache.calcite.schema.impl.StarTable.StarTableScan
- startFunCall(String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- startFunCall(String) - Method in interface org.apache.calcite.sql.SqlWriter
-
Starts a list which is a call to a function.
- startIndex() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResetContextImpl
- startIndex() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- startIndex() - Method in interface org.apache.calcite.adapter.enumerable.WinAggFrameContext
-
Returns the index of the very first row in partition.
- startList(String, String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- startList(String, String) - Method in interface org.apache.calcite.sql.SqlWriter
-
Starts a list.
- startList(SqlWriter.FrameTypeEnum) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- startList(SqlWriter.FrameTypeEnum) - Method in interface org.apache.calcite.sql.SqlWriter
-
Starts a list with no opening string.
- startList(SqlWriter.FrameType, String, String, String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Starts a list.
- startList(SqlWriter.FrameType, String, String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- startList(SqlWriter.FrameType, String, String) - Method in interface org.apache.calcite.sql.SqlWriter
-
Starts a list.
- startOrdinal - Variable in class org.apache.calcite.sql.SqlSpecialOperator.ReduceResult
- STARTS_WITH - Enum constant in enum org.apache.calcite.sql.SqlKind
-
STARTS_WITH
function. - STARTS_WITH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- STARTS_WITH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "STARTS_WITH(value1, value2)" function (BigQuery, PostgreSQL).
- startsAt(SqlParserPos) - Method in class org.apache.calcite.sql.parser.SqlParserPos
- startsWith(String) - Method in interface org.apache.calcite.util.Puffin.Line
-
Returns whether the current line starts with
prefix
. - startsWith(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
STARTS_WITH(string, string)
function. - startsWith(List<E>, List<E>) - Static method in class org.apache.calcite.util.Util
-
Returns whether one list is a prefix of another.
- startsWith(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
STARTS_WITH(binary, binary)
function. - STARTSWITH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "STARTSWITH(value1, value2)" function (Snowflake).
- startWithCalcite() - Method in class org.apache.calcite.chinook.ChinookAvaticaServer
- startWithRaw() - Method in class org.apache.calcite.chinook.ChinookAvaticaServer
- stash(T, Class<? super T>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
-
Stashes a value for the executor.
- state - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- state() - Method in class org.apache.calcite.util.Puffin.Context
- state() - Method in interface org.apache.calcite.util.Puffin.Line
-
Returns the state of the current file.
- STATE_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Allow an object to alter its behavior when its internal state changes.
- StatefulFunction() - Constructor for class org.apache.calcite.runtime.JsonFunctions.StatefulFunction
- statement(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a statement that executes an expression.
- Statement - Class in org.apache.calcite.linq4j.tree
-
Statement.
- Statement(ExpressionType, Type) - Constructor for class org.apache.calcite.linq4j.tree.Statement
- statements - Variable in class org.apache.calcite.linq4j.tree.BlockStatement
- states(boolean) - Static method in class org.apache.calcite.test.schemata.countries.StatesTableFunction
- StatesTableFunction - Class in org.apache.calcite.test.schemata.countries
-
A table function that returns states and their boundaries; also national parks.
- Static - Class in org.apache.calcite.util
-
Definitions of objects to be statically imported.
- StaticTableMacroFunction() - Constructor for class org.apache.calcite.util.Smalls.StaticTableMacroFunction
- Statistic - Interface in org.apache.calcite.schema
-
Statistics about a
Table
. - Statistician(String) - Constructor for class org.apache.calcite.util.Benchmark.Statistician
- statisticProvider - Variable in class org.apache.calcite.materialize.Lattice
- statisticProvider - Variable in class org.apache.calcite.model.JsonLattice
-
Name of a class that provides estimates of the number of distinct values in each column.
- statisticProvider(String) - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Sets the "statisticProvider" attribute.
- statisticProvider(SqlStatisticProvider) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- statistics() - Method in class org.apache.calcite.profile.Profiler.Profile
- Statistics - Class in org.apache.calcite.schema
-
Utility functions regarding
Statistic
. - STDDEV - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
STDDEV
aggregate function. - STDDEV_POP - Enum constant in enum org.apache.calcite.sql.fun.SqlAvgAggFunction.Subtype
-
Deprecated.
- STDDEV_POP - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
STDDEV_POP
aggregate function. - STDDEV_POP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
STDDEV_POP
aggregate function. - STDDEV_SAMP - Enum constant in enum org.apache.calcite.sql.fun.SqlAvgAggFunction.Subtype
-
Deprecated.
- STDDEV_SAMP - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
STDDEV_SAMP
aggregate function. - STDDEV_SAMP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
STDDEV_SAMP
aggregate function. - STDERR - Enum constant in enum org.apache.calcite.DataContext.Variable
-
Writer to the standard error (stderr).
- STDIN - Enum constant in enum org.apache.calcite.DataContext.Variable
-
Reader on the standard input (stdin).
- StdinTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that reads stdin and returns one row per line.
- STDOUT - Enum constant in enum org.apache.calcite.DataContext.Variable
-
Writer to the standard output (stdout).
- steelwheels - Variable in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
- STEELWHEELS - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- STEP - Enum constant in enum org.apache.calcite.sql.SqlWriterConfig.LineFolding
-
As
SqlWriterConfig.LineFolding.WIDE
but start a new line ifSqlWriterConfig.clauseEndsLine()
. - stepCount() - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.Path
-
Number of steps in this path.
- stepCount() - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.Step
- steps() - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.Path
-
Returns the steps in this path.
- Stmt(SqlParserPos, Ast.Op) - Constructor for class org.apache.calcite.piglet.Ast.Stmt
- stmtList - Variable in class org.apache.calcite.piglet.Ast.Program
- stop() - Method in class org.apache.calcite.chinook.ChinookAvaticaServer
- STORED - Enum constant in enum org.apache.calcite.schema.ColumnStrategy
-
Column is computed and stored.
- str - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- str(Object, Object) - Static method in class org.apache.calcite.util.Smalls
- STR_METHOD - Static variable in class org.apache.calcite.util.Smalls
- STR_TO_MAP - Enum constant in enum org.apache.calcite.sql.SqlKind
-
STR_TO_MAP
function (Spark semantics). - STR_TO_MAP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- STR_TO_MAP - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "STR_TO_MAP(string[, stringDelimiter[, keyValueDelimiter]])" function.
- strategy - Variable in class org.apache.calcite.sql.ddl.SqlColumnDeclaration
- STRATEGY_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Define a family of algorithms, encapsulate each one, and make them interchangeable.
- strcmp(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL STRCMP(String,String) function.
- STRCMP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- STRCMP - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- stream - Variable in class org.apache.calcite.model.JsonStream
-
Whether the table allows streaming.
- stream - Variable in class org.apache.calcite.model.JsonTable
-
Information about whether the table can be streamed, and if so, whether the history of the table is also available.
- stream - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- stream() - Method in class org.apache.calcite.adapter.csv.CsvStreamScannableTable
- stream() - Method in class org.apache.calcite.adapter.kafka.KafkaStreamTable
- stream() - Method in interface org.apache.calcite.schema.StreamableTable
-
Returns an enumerator over the rows in this Table.
- stream() - Method in class org.apache.calcite.test.schemata.orderstream.InfiniteOrdersTable
- stream() - Method in class org.apache.calcite.test.schemata.orderstream.OrdersTable
- STREAM - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
Stream.
- STREAM - Enum constant in enum org.apache.calcite.sql.SqlSelectKeyword
- STREAM - Enum constant in enum org.apache.calcite.sql.validate.SqlModality
- StreamableTable - Interface in org.apache.calcite.schema
-
Table that can be converted to a stream.
- streamMustGroupByMonotonic() - Method in interface org.apache.calcite.runtime.CalciteResource
- streamMustOrderByMonotonic() - Method in interface org.apache.calcite.runtime.CalciteResource
- StreamRules - Class in org.apache.calcite.rel.stream
-
Rules and relational operators for streaming relational expressions.
- StreamRules.DeltaAggregateTransposeRule - Class in org.apache.calcite.rel.stream
- StreamRules.DeltaAggregateTransposeRule.DeltaAggregateTransposeRuleConfig - Interface in org.apache.calcite.rel.stream
-
Rule configuration.
- StreamRules.DeltaFilterTransposeRule - Class in org.apache.calcite.rel.stream
- StreamRules.DeltaFilterTransposeRule.DeltaFilterTransposeRuleConfig - Interface in org.apache.calcite.rel.stream
-
Rule configuration.
- StreamRules.DeltaJoinTransposeRule - Class in org.apache.calcite.rel.stream
- StreamRules.DeltaJoinTransposeRule.DeltaJoinTransposeRuleConfig - Interface in org.apache.calcite.rel.stream
-
Rule configuration.
- StreamRules.DeltaProjectTransposeRule - Class in org.apache.calcite.rel.stream
- StreamRules.DeltaProjectTransposeRule.DeltaProjectTransposeRuleConfig - Interface in org.apache.calcite.rel.stream
-
Rule configuration.
- StreamRules.DeltaSortTransposeRule - Class in org.apache.calcite.rel.stream
- StreamRules.DeltaSortTransposeRule.DeltaSortTransposeRuleConfig - Interface in org.apache.calcite.rel.stream
-
Rule configuration.
- StreamRules.DeltaTableScanRule - Class in org.apache.calcite.rel.stream
- StreamRules.DeltaTableScanRule.DeltaTableScanRuleConfig - Interface in org.apache.calcite.rel.stream
-
Rule configuration.
- StreamRules.DeltaTableScanToEmptyRule - Class in org.apache.calcite.rel.stream
-
Planner rule that converts
Delta
over aTableScan
of a table other thanStreamableTable
to an emptyValues
. - StreamRules.DeltaTableScanToEmptyRule.DeltaTableScanToEmptyRuleConfig - Interface in org.apache.calcite.rel.stream
-
Rule configuration.
- StreamRules.DeltaUnionTransposeRule - Class in org.apache.calcite.rel.stream
- StreamRules.DeltaUnionTransposeRule.DeltaUnionTransposeRuleConfig - Interface in org.apache.calcite.rel.stream
-
Rule configuration.
- streamSetOpInconsistentInputs() - Method in interface org.apache.calcite.runtime.CalciteResource
- strength - Variable in class org.apache.calcite.sql.SqlCollation
- Strict - Annotation Type in org.apache.calcite.linq4j.function
-
Annotation applied to a user-defined function that indicates that the function returns null if and only if one or more of its arguments are null.
- STRICT - Enum constant in enum org.apache.calcite.adapter.enumerable.NullPolicy
-
Returns null if and only if one of the arguments are null.
- STRICT - Enum constant in enum org.apache.calcite.runtime.JsonFunctions.PathMode
- STRICT - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to follow the SQL standard strictly.
- STRICT_2003 - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that instructs Calcite to use SQL semantics strictly consistent with the SQL:2003 standard.
- STRICT_2003 - Static variable in interface org.apache.calcite.sql.validate.SqlConformance
-
Deprecated.
- STRICT_92 - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that instructs Calcite to use SQL semantics strictly consistent with the SQL:92 standard.
- STRICT_92 - Static variable in interface org.apache.calcite.sql.validate.SqlConformance
-
Deprecated.
- STRICT_99 - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that instructs Calcite to use SQL semantics strictly consistent with the SQL:99 standard.
- STRICT_99 - Static variable in interface org.apache.calcite.sql.validate.SqlConformance
-
Deprecated.
- StrictAggImplementor - Class in org.apache.calcite.adapter.enumerable
-
The base implementation of strict aggregate function.
- StrictAggImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- strictEnd - Variable in class org.apache.calcite.rel.core.Match
- strictEnd - Variable in class org.apache.calcite.rel.mutable.MutableMatch
- STRICTLY_ASCENDING - Enum constant in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Strictly ascending direction: A value is always followed by a greater value.
- STRICTLY_DECREASING - Enum constant in enum org.apache.calcite.sql.validate.SqlMonotonicity
- STRICTLY_DESCENDING - Enum constant in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Strictly descending direction: A value is always followed by a lesser value.
- STRICTLY_INCREASING - Enum constant in enum org.apache.calcite.sql.validate.SqlMonotonicity
- strictPathModeRequiresNonEmptyValue() - Method in interface org.apache.calcite.runtime.CalciteResource
- strictStart - Variable in class org.apache.calcite.rel.core.Match
- strictStart - Variable in class org.apache.calcite.rel.mutable.MutableMatch
- strictTypeName(RelDataType) - Static method in class org.apache.calcite.rex.RexLiteral
-
Returns the strict literal type for a given type.
- StrictWinAggImplementor - Class in org.apache.calcite.adapter.enumerable
-
The base implementation of strict window aggregate function.
- StrictWinAggImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- string - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- string - Variable in class org.apache.calcite.util.Version
- STRING - Enum constant in enum org.apache.calcite.adapter.druid.DruidType
- STRING - Enum constant in enum org.apache.calcite.adapter.redis.RedisDataType
-
Strings are the most basic kind of Redis value.
- STRING - Enum constant in enum org.apache.calcite.sql.SqlFunctionCategory
- STRING - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING - Static variable in interface org.apache.calcite.util.JdbcType
- STRING_AGG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
STRING_AGG
aggregate function. - STRING_AGG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "STRING_AGG(value [, separator ] [ ORDER BY ...])" aggregate function, BigQuery and PostgreSQL's equivalent of
SqlStdOperatorTable.LISTAGG
. - STRING_ARRAY_CHARACTER_OPTIONAL_CHARACTER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_CONCAT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- STRING_CONCAT_WITH_NULL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- STRING_EQUIVALENCE - Static variable in class org.apache.calcite.rel.mutable.MutableRel
-
Equivalence that compares objects by their
Object.toString()
method. - STRING_FIRST_OBJECT_REPEAT - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy that the first argument is of string type, and the remaining arguments can be any type.
- STRING_FIRST_STRING_ARRAY_REPEAT - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy that the first argument is of string type, and the remaining arguments can be of string or array of string type.
- STRING_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_INTEGER_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_INTEGER_OPTIONAL_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_NULLABLE - Static variable in interface org.apache.calcite.util.JdbcType
- STRING_NUMERIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_NUMERIC_NUMERIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_NUMERIC_OPTIONAL_STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_OPTIONAL_STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_OPTIONAL_STRING_OPTIONAL_STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_SAME_SAME - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where two operands must both be in the same string type family.
- STRING_SAME_SAME_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where two operands must both be in the same string type family and last type is INTEGER.
- STRING_SAME_SAME_OR_ARRAY_SAME_SAME - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_SAME_SAME_SAME - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where three operands must all be in the same string type family.
- STRING_STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_STRING_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_STRING_INTEGER_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_STRING_OPTIONAL_INTEGER_OPTIONAL_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_STRING_OPTIONAL_INTEGER_OPTIONAL_INTEGER_OPTIONAL_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_STRING_OPTIONAL_STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_STRING_STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_STRING_STRING_STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_TO_BINARY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- STRING_TO_BOOLEAN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- STRING_TO_DATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- STRING_TO_QUERY - Enum constant in enum org.apache.calcite.runtime.Hook
-
Converts a SQL string to a
CalcitePrepare.Query
object. - STRING_TO_TIME - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- STRING_TO_TIME_WITH_LOCAL_TIME_ZONE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- STRING_TO_TIMESTAMP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- STRING_TO_TIMESTAMP_WITH_LOCAL_TIME_ZONE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- STRING_TO_UPPER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- STRING_TRUNC_MESSAGE - Static variable in interface org.apache.calcite.sql.test.SqlOperatorFixture
- STRING_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- STRING_UNION_METHOD - Static variable in class org.apache.calcite.util.Smalls
- StringAndPos - Class in org.apache.calcite.sql.parser
-
Contains a string, the offset of a token within the string, and a parser position containing the beginning and end line number.
- StringConcatFunction - Class in org.apache.calcite.chinook
-
Example query for checking query projections.
- StringConcatFunction() - Constructor for class org.apache.calcite.chinook.StringConcatFunction
- stringDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- stringFragsOnSameLine() - Method in interface org.apache.calcite.runtime.CalciteResource
- stringLiteral(String) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- strings(List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Transforms a list of expressions to the list of digests.
- stringTag(String, String) - Method in class org.apache.calcite.util.XmlOutput
-
Writes a String tag; a tag containing nothing but a CDATA section.
- stringToBinary(String, Charset) - Static method in class org.apache.calcite.runtime.SqlFunctions
- stringToDatePartTimeUnit(String) - Static method in class org.apache.calcite.sql.SqlIntervalQualifier
- stringToList(String) - Static method in class org.apache.calcite.util.Util
- StringTypeChecker(String) - Constructor for class org.apache.calcite.sql.test.SqlTests.StringTypeChecker
- stringUnion(Queryable<T>, Queryable<T>) - Static method in class org.apache.calcite.util.Smalls
- StringUtils - Class in org.apache.calcite.adapter.splunk.util
-
Utility methods for encoding and decoding strings for Splunk REST calls.
- stringValue(RexNode) - Static method in class org.apache.calcite.rex.RexLiteral
- stringValue(SqlNode) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Deprecated.
- strip(String, String, String, String, Casing) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Converts a quoted identifier, unquoted identifier, or quoted string to a string of its contents.
- strip(List<PartiallyOrderedSet.Node<E>>) - Static method in class org.apache.calcite.util.PartiallyOrderedSet
-
Returns a list, backed by a list of
PartiallyOrderedSet.Node
s, that strips away the node and returns the element inside. - strip(Project) - Static method in class org.apache.calcite.rel.rules.ProjectRemoveRule
-
Returns the child of a project if the project is trivial, otherwise the project itself.
- strip(MutableProject) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- stripAs(SqlNode) - Static method in class org.apache.calcite.sql.SqlUtil
-
If a node is "AS", returns the underlying expression; otherwise returns the node.
- stripDoubleQuotes(String) - Static method in class org.apache.calcite.util.Util
-
Converts double-quoted Java strings to their contents.
- stripGenerics(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- stripListAs(SqlNodeList) - Static method in class org.apache.calcite.sql.SqlUtil
-
Modifies a list of nodes, removing AS from each if present.
- stripOrderBy(SqlCall) - Static method in class org.apache.calcite.sql.type.ReturnTypes
- stripOrderBy(SqlOperatorBinding) - Static method in class org.apache.calcite.sql.type.ReturnTypes
-
Converts a binding of
FOO(x, y ORDER BY z)
orFOO(x, y ORDER BY z SEPARATOR s)
to a binding ofFOO(x, y)
. - stripped() - Method in class org.apache.calcite.plan.hep.HepRelVertex
- stripped() - Method in class org.apache.calcite.plan.volcano.RelSubset
- stripped() - Method in interface org.apache.calcite.rel.RelNode
-
Returns this node without any wrapper added by the planner.
- stripQuotes(String, String, String, String, Casing) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Unquotes a quoted string, using different quotes for beginning and end.
- stripRow(SqlNode) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Converts "ROW (1, 2)" to "(1, 2)" and "3" to "(3)".
- stripSeparator(SqlCall) - Static method in class org.apache.calcite.sql.type.ReturnTypes
- stripTrivialAliases(SqlNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
- Strong - Class in org.apache.calcite.plan
-
Utilities for strong predicates.
- Strong() - Constructor for class org.apache.calcite.plan.Strong
- Strong.Policy - Enum in org.apache.calcite.plan
-
How whether an operator's operands are null affects whether a call to that operator evaluates to null.
- STRPOS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "STRPOS(string, substring)" function.
- strToMap(String, String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the STR_TO_MAP function.
- STRUCT_ACCESS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- STRUCT_ACCESS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The internal
$STRUCT_ACCESS
operator is used to access a field of a record. - structAccess(Object, int, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Implements the
.
(field access) operator on an object whose type is not known until runtime. - StructKind - Enum in org.apache.calcite.rel.type
-
Describes a policy for resolving fields in record types.
- STRUCTURED - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- struncate(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TRUNCATE
operator applied to double values. - struncate(double, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- struncate(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TRUNCATE
operator applied to int values. - struncate(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- struncate(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TRUNCATE
operator applied to long values. - struncate(long, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- struncate(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TRUNCATE
operator applied to BigDecimal values. - struncate(BigDecimal, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- STRUNCATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- strView(String) - Static method in class org.apache.calcite.util.Smalls
- SUB - Enum constant in enum org.apache.calcite.runtime.Hook
-
Called by the planner after substituting a materialization.
- SUB_QUERY - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Sub-query list.
- SUB_QUERY_PROGRAM - Static variable in class org.apache.calcite.tools.Programs
-
Program that expands sub-queries.
- subClasses(Class<? extends RelNode>) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Returns sub-classes of relational expression.
- subList(int, int) - Method in class org.apache.calcite.util.ImmutableIntList
- subList(int, int) - Method in interface org.apache.calcite.runtime.ImmutablePairList
- subList(int, int) - Method in interface org.apache.calcite.runtime.PairList
- subList(int, int) - Method in class org.apache.calcite.sql.SqlNodeList
- SUBMULTISET_OF - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SUBMULTISET_OF - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Submultiset.
- submultisetOf(Collection, Collection) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the SUBMULTISET OF function.
- subordinateid - Variable in class org.apache.calcite.test.schemata.hr.HierarchySchema.Hierarchy
- subquery(RelMetadataProvider) - Static method in class org.apache.calcite.tools.Programs
-
Deprecated.
- subQuery(RelMetadataProvider) - Static method in class org.apache.calcite.tools.Programs
- SubQueryConverter - Interface in org.apache.calcite.sql2rel
-
SubQueryConverter provides the interface for classes that convert sub-queries into equivalent expressions.
- SubQueryRemoveRule - Class in org.apache.calcite.rel.rules
-
Transform that converts IN, EXISTS and scalar sub-queries into joins.
- SubQueryRemoveRule(SubQueryRemoveRule.Config) - Constructor for class org.apache.calcite.rel.rules.SubQueryRemoveRule
-
Creates a SubQueryRemoveRule.
- SubQueryRemoveRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- subQueryStyle() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the sub-query style.
- subSchema(CalciteSchema, Iterable<String>) - Static method in class org.apache.calcite.schema.Schemas
-
Returns a sub-schema of a given schema obtained by following a sequence of names.
- subSchemaExpression(SchemaPlus, String, Class) - Static method in class org.apache.calcite.schema.Schemas
-
Returns the expression for a sub-schema.
- subSchemaMap - Variable in class org.apache.calcite.jdbc.CalciteSchema
- subSelect() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
- subsets - Variable in class org.apache.calcite.rel.core.Match
- subsets - Variable in class org.apache.calcite.rel.mutable.MutableMatch
- substitute(Function<Hoist.Variable, String>) - Method in class org.apache.calcite.tools.Hoist.Hoisted
-
Returns the SQL string with variables replaced according to the given substitution function.
- substitute(RexCall, int, RexNode) - Static method in class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Converts op(arg0, ..., argOrdinal, ..., argN) to op(arg0,..., node, ..., argN).
- substitutionMatches(Consumer<RelNode>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- SubstitutionRule - Interface in org.apache.calcite.rel.rules
-
A rule that implements this interface indicates that the new RelNode is typically better than the old one.
- SubstitutionVisitor - Class in org.apache.calcite.plan
-
Substitutes part of a tree of relational expressions with another tree.
- SubstitutionVisitor(RelNode, RelNode) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor
-
Creates a SubstitutionVisitor with the default rule set.
- SubstitutionVisitor(RelNode, RelNode, ImmutableList<SubstitutionVisitor.UnifyRule>) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor
-
Creates a SubstitutionVisitor with the default logical builder.
- SubstitutionVisitor(RelNode, RelNode, ImmutableList<SubstitutionVisitor.UnifyRule>, RelBuilderFactory) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor
- SubstitutionVisitor.AbstractUnifyRule - Class in org.apache.calcite.plan
-
Abstract base class for implementing
SubstitutionVisitor.UnifyRule
. - SubstitutionVisitor.MatchFailed - Exception Class in org.apache.calcite.plan
-
Exception thrown to exit a matcher.
- SubstitutionVisitor.Operand - Class in org.apache.calcite.plan
-
Operand to a
SubstitutionVisitor.UnifyRule
. - SubstitutionVisitor.UnifyResult - Class in org.apache.calcite.plan
-
Result of an application of a
SubstitutionVisitor.UnifyRule
indicating that the rule successfully matchedquery
againsttarget
and generated aresult
that is equivalent toquery
and containstarget
. - SubstitutionVisitor.UnifyRule - Class in org.apache.calcite.plan
-
Rule that attempts to match a query relational expression against a target relational expression.
- SubstitutionVisitor.UnifyRuleCall - Class in org.apache.calcite.plan
-
Arguments to an application of a
SubstitutionVisitor.UnifyRule
. - SUBSTR - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
Deprecated.
- SUBSTR_BIG_QUERY - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SUBSTR
function (BigQuery semantics). - SUBSTR_BIG_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
BigQuery's "SUBSTR(string, position [, substringLength ])" function.
- SUBSTR_MYSQL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SUBSTR
function (MySQL semantics). - SUBSTR_MYSQL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
MySQL's "SUBSTR(string, position [, substringLength ])" function.
- SUBSTR_ORACLE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SUBSTR
function (Oracle semantics). - SUBSTR_ORACLE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
Oracle's "SUBSTR(string, position [, substringLength ])" function.
- SUBSTR_POSTGRESQL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SUBSTR
function (PostgreSQL semantics). - SUBSTR_POSTGRESQL - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
PostgreSQL's "SUBSTR(string, position [, substringLength ])" function.
- substring(String, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SUBSTRING(string FROM ...) function.
- substring(String, int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SUBSTRING(string FROM ...
- substring(String, int, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- substring(String, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- substring(String, long, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- substring(String, long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- substring(ByteString, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SUBSTRING(binary FROM ...) function for binary.
- substring(ByteString, int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SUBSTRING(binary FROM ...
- SUBSTRING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SUBSTRING - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The character substring function:
SUBSTRING(string FROM start [FOR length])
. - SUBSTRING_INDEX - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SUBSTRING_INDEX
function (Spark semantics). - SUBSTRING_INDEX - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SUBSTRING_INDEX - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "SUBSTRING_INDEX(string, delimiter, count)" function.
- substringIndex(String, String, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the SUBSTRING_INDEX function.
- SubstringOperatorConversion - Class in org.apache.calcite.adapter.druid
-
Converts Calcite SUBSTRING call to Druid Expression when possible.
- SubstringOperatorConversion() - Constructor for class org.apache.calcite.adapter.druid.SubstringOperatorConversion
- subTestIntervalDayNegative() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalDayPositive() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToHourNegative() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToHourPositive() - Method in class org.apache.calcite.test.IntervalTest
- subTestIntervalDayToMinuteNegative() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToMinutePositive() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToSecondNegative() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToSecondPositive() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalHourNegative() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalHourPositive() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalHourToMinuteNegative() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalHourToMinutePositive() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalHourToSecondNegative() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalHourToSecondPositive() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalMinuteNegative() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalMinutePositive() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalMinuteToSecondNegative() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalMinuteToSecondPositive() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalMonthNegative() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalMonthPositive() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalPlural() - Method in class org.apache.calcite.test.IntervalTest
- subTestIntervalQuarterPositive() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalSecondNegative() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalSecondPositive() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalWeekPositive() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalYearNegative() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalYearPositive() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalYearToMonthNegative() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestIntervalYearToMonthPositive() - Method in class org.apache.calcite.test.IntervalTest
-
Runs tests for INTERVAL...
- subTestMisc() - Method in class org.apache.calcite.test.IntervalTest
- subtract(Double, Double) - Static method in class org.apache.calcite.util.NumberUtil
-
Returns the difference of two numbers, or null if either is null.
- subtract(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic subtraction operation that does not have overflow checking.
- subtract(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic subtraction operation that does not have overflow checking.
- Subtract - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A subtraction operation, such as (a - b), without overflow checking, for numeric operands.
- SUBTRACT_MONTHS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- subtractAssign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a subtraction assignment operation that does not have overflow checking.
- subtractAssign(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a subtraction assignment operation that does not have overflow checking.
- subtractAssign(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a subtraction assignment operation that does not have overflow checking.
- SubtractAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A subtraction compound assignment operation, such as (a -= b), without overflow checking, for numeric operands.
- subtractAssignChecked(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a subtraction assignment operation that has overflow checking.
- subtractAssignChecked(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a subtraction assignment operation that has overflow checking.
- subtractAssignChecked(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a subtraction assignment operation that has overflow checking.
- SubtractAssignChecked - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A subtraction compound assignment operation, such as (a -= b), that has overflow checking, for numeric operands.
- subtractChecked(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic subtraction operation that has overflow checking.
- subtractChecked(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic subtraction operation that has overflow checking.
- SubtractChecked - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An arithmetic subtraction operation, such as (a - b), that has overflow checking, for numeric operands.
- succeed() - Method in interface org.apache.calcite.util.Litmus
-
Called when test succeeds.
- SUCCEEDS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
SUCCEEDS
operator for periods. - SUCCEEDS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- suffix() - Method in class org.apache.calcite.sql.validate.SqlQualified
- sum(boolean, String, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
SUM
aggregate function, optionally distinct and with an alias. - sum(Iterable<SqlParserPos>) - Static method in class org.apache.calcite.sql.parser.SqlParserPos
-
Returns a position spanning the earliest position to the latest.
- sum(List<? extends SqlNode>) - Static method in class org.apache.calcite.sql.parser.SqlParserPos
-
Combines the parser positions of a list of nodes to create a position which spans from the beginning of the first to the end of the last.
- sum(Enumerable<TSource>, BigDecimalFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the sum of the sequence of Decimal values that are obtained by invoking a transform function on each element of the input sequence.
- sum(Enumerable<TSource>, DoubleFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the sum of the sequence of Double values that are obtained by invoking a transform function on each element of the input sequence.
- sum(Enumerable<TSource>, FloatFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the sum of the sequence of Float values that are obtained by invoking a transform function on each element of the input sequence.
- sum(Enumerable<TSource>, IntegerFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the sum of the sequence of int values that are obtained by invoking a transform function on each element of the input sequence.
- sum(Enumerable<TSource>, LongFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the sum of the sequence of long values that are obtained by invoking a transform function on each element of the input sequence.
- sum(Enumerable<TSource>, NullableBigDecimalFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the sum of the sequence of nullable Decimal values that are obtained by invoking a transform function on each element of the input sequence.
- sum(Enumerable<TSource>, NullableDoubleFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the sum of the sequence of nullable Double values that are obtained by invoking a transform function on each element of the input sequence.
- sum(Enumerable<TSource>, NullableFloatFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the sum of the sequence of nullable Float values that are obtained by invoking a transform function on each element of the input sequence.
- sum(Enumerable<TSource>, NullableIntegerFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the sum of the sequence of nullable int values that are obtained by invoking a transform function on each element of the input sequence.
- sum(Enumerable<TSource>, NullableLongFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the sum of the sequence of nullable long values that are obtained by invoking a transform function on each element of the input sequence.
- sum(BigDecimalFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- sum(BigDecimalFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the sum of the sequence of Decimal values that are obtained by invoking a transform function on each element of the input sequence.
- sum(DoubleFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- sum(DoubleFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the sum of the sequence of Double values that are obtained by invoking a transform function on each element of the input sequence.
- sum(FloatFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- sum(FloatFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the sum of the sequence of Float values that are obtained by invoking a transform function on each element of the input sequence.
- sum(IntegerFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- sum(IntegerFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the sum of the sequence of int values that are obtained by invoking a transform function on each element of the input sequence.
- sum(LongFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- sum(LongFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the sum of the sequence of long values that are obtained by invoking a transform function on each element of the input sequence.
- sum(NullableBigDecimalFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- sum(NullableBigDecimalFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the sum of the sequence of nullable Decimal values that are obtained by invoking a transform function on each element of the input sequence.
- sum(NullableDoubleFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- sum(NullableDoubleFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the sum of the sequence of nullable Double values that are obtained by invoking a transform function on each element of the input sequence.
- sum(NullableFloatFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- sum(NullableFloatFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the sum of the sequence of nullable Float values that are obtained by invoking a transform function on each element of the input sequence.
- sum(NullableIntegerFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- sum(NullableIntegerFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the sum of the sequence of nullable int values that are obtained by invoking a transform function on each element of the input sequence.
- sum(NullableLongFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- sum(NullableLongFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the sum of the sequence of nullable long values that are obtained by invoking a transform function on each element of the input sequence.
- sum(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
SUM
aggregate function. - sum(SqlParserPos, boolean, String, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
SUM
aggregate function, optionally distinct and with an alias. - sum(SqlParserPos, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
SUM
aggregate function. - sum(SqlNode[]) - Static method in class org.apache.calcite.sql.parser.SqlParserPos
-
Combines the parser positions of an array of nodes to create a position which spans from the beginning of the first to the end of the last.
- SUM - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
SUM
aggregate function. - SUM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
SUM
aggregate function. - SUM_FORCE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.DECIMAL_SUM_NULLABLE
but returns with nullability if any of the operands is nullable or the operation results in overflow by usingSqlTypeTransforms.FORCE_NULLABLE
. - SUM0 - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
SUM0
aggregate function. - SUM0 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
SUM0
aggregate function. - Sum0Splitter() - Constructor for class org.apache.calcite.sql.SqlSplittableAggFunction.Sum0Splitter
- sumBigDecimal(Queryable<T>, FunctionExpression<BigDecimalFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the sum of the sequence of Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- sumBigDecimal(Queryable<T>, FunctionExpression<BigDecimalFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the sum of the sequence of Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- sumBigDecimal(Queryable<T>, FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- sumBigDecimal(FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- sumBigDecimal(FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the sum of the sequence of Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- sumDouble(Queryable<T>, FunctionExpression<DoubleFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the sum of the sequence of Double values that is obtained by invoking a projection function on each element of the input sequence.
- sumDouble(Queryable<T>, FunctionExpression<DoubleFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the sum of the sequence of Double values that is obtained by invoking a projection function on each element of the input sequence.
- sumDouble(Queryable<T>, FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- sumDouble(FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- sumDouble(FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the sum of the sequence of Double values that is obtained by invoking a projection function on each element of the input sequence.
- sumFloat(Queryable<T>, FunctionExpression<FloatFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the sum of the sequence of Float values that is obtained by invoking a projection function on each element of the input sequence.
- sumFloat(Queryable<T>, FunctionExpression<FloatFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the sum of the sequence of Float values that is obtained by invoking a projection function on each element of the input sequence.
- sumFloat(Queryable<T>, FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- sumFloat(FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- sumFloat(FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the sum of the sequence of Float values that is obtained by invoking a projection function on each element of the input sequence.
- SumFunctionBadIAdd() - Constructor for class org.apache.calcite.util.Smalls.SumFunctionBadIAdd
- sumInteger(Queryable<T>, FunctionExpression<IntegerFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the sum of the sequence of int values that is obtained by invoking a projection function on each element of the input sequence.
- sumInteger(Queryable<T>, FunctionExpression<IntegerFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the sum of the sequence of int values that is obtained by invoking a projection function on each element of the input sequence.
- sumInteger(Queryable<T>, FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- sumInteger(FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- sumInteger(FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the sum of the sequence of int values that is obtained by invoking a projection function on each element of the input sequence.
- sumLong(Queryable<T>, FunctionExpression<LongFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the sum of the sequence of long values that is obtained by invoking a projection function on each element of the input sequence.
- sumLong(Queryable<T>, FunctionExpression<LongFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the sum of the sequence of long values that is obtained by invoking a projection function on each element of the input sequence.
- sumLong(Queryable<T>, FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- sumLong(FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- sumLong(FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the sum of the sequence of long values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableBigDecimal(Queryable<T>, FunctionExpression<NullableBigDecimalFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the sum of the sequence of nullable Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableBigDecimal(Queryable<T>, FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the sum of the sequence of nullable Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableBigDecimal(Queryable<T>, FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- sumNullableBigDecimal(FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- sumNullableBigDecimal(FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the sum of the sequence of nullable Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableDouble(Queryable<T>, FunctionExpression<NullableDoubleFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the sum of the sequence of nullable Double values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableDouble(Queryable<T>, FunctionExpression<NullableDoubleFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the sum of the sequence of nullable Double values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableDouble(Queryable<T>, FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- sumNullableDouble(FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- sumNullableDouble(FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the sum of the sequence of nullable Double values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableFloat(Queryable<T>, FunctionExpression<NullableFloatFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the sum of the sequence of nullable Float values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableFloat(Queryable<T>, FunctionExpression<NullableFloatFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the sum of the sequence of nullable Float values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableFloat(Queryable<T>, FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- sumNullableFloat(FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- sumNullableFloat(FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the sum of the sequence of nullable Float values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableInteger(Queryable<T>, FunctionExpression<NullableIntegerFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the sum of the sequence of nullable int values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableInteger(Queryable<T>, FunctionExpression<NullableIntegerFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the sum of the sequence of nullable int values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableInteger(Queryable<T>, FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- sumNullableInteger(FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- sumNullableInteger(FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the sum of the sequence of nullable int values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableLong(Queryable<T>, FunctionExpression<NullableLongFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the sum of the sequence of nullable long values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableLong(Queryable<T>, FunctionExpression<NullableLongFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the sum of the sequence of nullable long values that is obtained by invoking a projection function on each element of the input sequence.
- sumNullableLong(Queryable<T>, FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- sumNullableLong(FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- sumNullableLong(FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the sum of the sequence of nullable long values that is obtained by invoking a projection function on each element of the input sequence.
- SumSplitter() - Constructor for class org.apache.calcite.sql.SqlSplittableAggFunction.SumSplitter
- supportBooleanCaseWhen() - Method in class org.apache.calcite.sql.dialect.OracleSqlDialect
- supportBooleanCaseWhen() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether this dialect supports case when return boolean type.
- SUPPORTED_DATE_TIME_ROLLUP_UNITS - Static variable in class org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule
- SUPPORTED_SQL_KIND - Static variable in class org.apache.calcite.rex.RexInterpreter
- supportsAggregateFunction(SqlKind) - Method in class org.apache.calcite.sql.dialect.ExasolSqlDialect
- supportsAggregateFunction(SqlKind) - Method in class org.apache.calcite.sql.dialect.FireboltSqlDialect
- supportsAggregateFunction(SqlKind) - Method in class org.apache.calcite.sql.dialect.JethroDataSqlDialect
- supportsAggregateFunction(SqlKind) - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- supportsAggregateFunction(SqlKind) - Method in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- supportsAggregateFunction(SqlKind) - Method in class org.apache.calcite.sql.dialect.SparkSqlDialect
- supportsAggregateFunction(SqlKind) - Method in class org.apache.calcite.sql.SqlDialect
- supportsAggregateFunctionFilter() - Method in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
- supportsAggregateFunctionFilter() - Method in class org.apache.calcite.sql.dialect.ExasolSqlDialect
- supportsAggregateFunctionFilter() - Method in class org.apache.calcite.sql.dialect.FireboltSqlDialect
- supportsAggregateFunctionFilter() - Method in class org.apache.calcite.sql.dialect.HsqldbSqlDialect
- supportsAggregateFunctionFilter() - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- supportsAggregateFunctionFilter() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether this dialect supports the use of FILTER clauses for aggregate functions.
- supportsAliasedValues() - Method in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
- supportsAliasedValues() - Method in class org.apache.calcite.sql.dialect.ClickHouseSqlDialect
- supportsAliasedValues() - Method in class org.apache.calcite.sql.dialect.HiveSqlDialect
- supportsAliasedValues() - Method in class org.apache.calcite.sql.dialect.InformixSqlDialect
- supportsAliasedValues() - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- supportsAliasedValues() - Method in class org.apache.calcite.sql.dialect.OracleSqlDialect
- supportsAliasedValues() - Method in class org.apache.calcite.sql.dialect.RedshiftSqlDialect
- supportsAliasedValues() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether the dialect supports VALUES in a sub-query with and an "AS t(column, ...)" values to define column names.
- supportsApproxCountDistinct() - Method in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
- supportsApproxCountDistinct() - Method in class org.apache.calcite.sql.dialect.HiveSqlDialect
- supportsApproxCountDistinct() - Method in class org.apache.calcite.sql.dialect.OracleSqlDialect
- supportsApproxCountDistinct() - Method in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- supportsApproxCountDistinct() - Method in class org.apache.calcite.sql.dialect.SnowflakeSqlDialect
- supportsApproxCountDistinct() - Method in class org.apache.calcite.sql.dialect.SparkSqlDialect
- supportsApproxCountDistinct() - Method in class org.apache.calcite.sql.dialect.StarRocksSqlDialect
- supportsApproxCountDistinct() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether this dialect supports APPROX_COUNT_DISTINCT functions.
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.ClickHouseSqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.Db2SqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.ExasolSqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.FireboltSqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.H2SqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.HiveSqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.HsqldbSqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.JethroDataSqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.OracleSqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.PhoenixSqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.RedshiftSqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.SparkSqlDialect
- supportsCharSet() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether the dialect supports character set names as part of a data type, for instance
VARCHAR(30) CHARACTER SET `ISO-8859-1`
. - supportsCondition() - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.RelType
- supportsDataType(RelDataType) - Method in class org.apache.calcite.sql.dialect.OracleSqlDialect
- supportsDataType(RelDataType) - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether this dialect supports a given type.
- supportsFunction(SqlOperator, RelDataType, List<RelDataType>) - Method in class org.apache.calcite.sql.dialect.FireboltSqlDialect
- supportsFunction(SqlOperator, RelDataType, List<RelDataType>) - Method in class org.apache.calcite.sql.dialect.JethroDataSqlDialect
- supportsFunction(SqlOperator, RelDataType, List<RelDataType>) - Method in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
- supportsFunction(SqlOperator, RelDataType, List<RelDataType>) - Method in class org.apache.calcite.sql.dialect.VerticaSqlDialect
- supportsFunction(SqlOperator, RelDataType, List<RelDataType>) - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether this dialect supports a given function or operator.
- supportsGroupByLiteral() - Method in class org.apache.calcite.sql.dialect.InformixSqlDialect
- supportsGroupByLiteral() - Method in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
- supportsGroupByLiteral() - Method in class org.apache.calcite.sql.dialect.RedshiftSqlDialect
- supportsGroupByLiteral() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether the dialect supports GROUP BY literals.
- supportsGroupByWithCube() - Method in class org.apache.calcite.sql.dialect.HiveSqlDialect
- supportsGroupByWithCube() - Method in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- supportsGroupByWithCube() - Method in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- supportsGroupByWithCube() - Method in class org.apache.calcite.sql.dialect.SparkSqlDialect
- supportsGroupByWithCube() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether this dialect supports "WITH CUBE" in "GROUP BY" clause.
- supportsGroupByWithRollup() - Method in class org.apache.calcite.sql.dialect.HiveSqlDialect
- supportsGroupByWithRollup() - Method in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- supportsGroupByWithRollup() - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- supportsGroupByWithRollup() - Method in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- supportsGroupByWithRollup() - Method in class org.apache.calcite.sql.dialect.SparkSqlDialect
- supportsGroupByWithRollup() - Method in class org.apache.calcite.sql.dialect.StarRocksSqlDialect
- supportsGroupByWithRollup() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether this dialect supports "WITH ROLLUP" in the "GROUP BY" clause.
- supportsImplicitTypeCoercion(RexCall) - Method in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
- supportsImplicitTypeCoercion(RexCall) - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether the dialect supports implicit type coercion.
- supportsJoinType(JoinRelType) - Method in class org.apache.calcite.sql.dialect.H2SqlDialect
- supportsJoinType(JoinRelType) - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- supportsJoinType(JoinRelType) - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether this dialect support the specified type of join.
- supportsModality(SqlModality) - Method in class org.apache.calcite.prepare.RelOptTableImpl
- supportsModality(SqlModality) - Method in class org.apache.calcite.sql.validate.MatchRecognizeNamespace
- supportsModality(SqlModality) - Method in class org.apache.calcite.sql.validate.AliasNamespace
- supportsModality(SqlModality) - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- supportsModality(SqlModality) - Method in class org.apache.calcite.sql.validate.SelectNamespace
- supportsModality(SqlModality) - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns whether this namespace is capable of giving results of the desired modality.
- supportsModality(SqlModality) - Method in interface org.apache.calcite.sql.validate.SqlValidatorTable
- supportsModality(SqlModality) - Method in class org.apache.calcite.sql.validate.TableConstructorNamespace
- supportsModality(SqlModality) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- supportsNestedAggregations() - Method in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
- supportsNestedAggregations() - Method in class org.apache.calcite.sql.dialect.ClickHouseSqlDialect
- supportsNestedAggregations() - Method in class org.apache.calcite.sql.dialect.ExasolSqlDialect
- supportsNestedAggregations() - Method in class org.apache.calcite.sql.dialect.HiveSqlDialect
- supportsNestedAggregations() - Method in class org.apache.calcite.sql.dialect.JethroDataSqlDialect
- supportsNestedAggregations() - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- supportsNestedAggregations() - Method in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
- supportsNestedAggregations() - Method in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- supportsNestedAggregations() - Method in class org.apache.calcite.sql.dialect.SparkSqlDialect
- supportsNestedAggregations() - Method in class org.apache.calcite.sql.dialect.VerticaSqlDialect
- supportsNestedAggregations() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether the dialect supports nested aggregations, for instance
SELECT SUM(SUM(1))
. - supportsOffsetFetch() - Method in class org.apache.calcite.sql.dialect.JethroDataSqlDialect
- supportsOffsetFetch() - Method in class org.apache.calcite.sql.SqlDialect
-
Deprecated.This method is no longer used. To change how the dialect unparses offset/fetch, override the
SqlDialect.unparseOffsetFetch(org.apache.calcite.sql.SqlWriter, org.apache.calcite.sql.SqlNode, org.apache.calcite.sql.SqlNode)
method. - supportsSetSource() - Method in class org.apache.calcite.util.javac.JaninoCompiler.JaninoCompilerArgs
- supportsSetSource() - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
-
Returns whether
JavaCompilerArgs.setSource(java.lang.String, java.lang.String)
will work. - supportsTimestampPrecision() - Method in class org.apache.calcite.sql.dialect.ExasolSqlDialect
- supportsTimestampPrecision() - Method in class org.apache.calcite.sql.dialect.HiveSqlDialect
- supportsTimestampPrecision() - Method in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- supportsTimestampPrecision() - Method in class org.apache.calcite.sql.dialect.SparkSqlDialect
- supportsTimestampPrecision() - Method in class org.apache.calcite.sql.dialect.StarRocksSqlDialect
- supportsTimestampPrecision() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether this dialect supports TIMESTAMP with precision.
- supportsWindowFunctions() - Method in class org.apache.calcite.sql.dialect.AccessSqlDialect
- supportsWindowFunctions() - Method in class org.apache.calcite.sql.dialect.ClickHouseSqlDialect
- supportsWindowFunctions() - Method in class org.apache.calcite.sql.dialect.H2SqlDialect
- supportsWindowFunctions() - Method in class org.apache.calcite.sql.dialect.HsqldbSqlDialect
- supportsWindowFunctions() - Method in class org.apache.calcite.sql.dialect.InfobrightSqlDialect
- supportsWindowFunctions() - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether this dialect supports window functions (OVER clause).
- SURJECTION - Enum constant in enum org.apache.calcite.util.mapping.MappingType
- surprise(double, double) - Static method in class org.apache.calcite.profile.SimpleProfiler
-
Returns a measure of how much an actual value differs from expected.
- swallow(Throwable, Logger) - Static method in class org.apache.calcite.util.Util
-
Records that an exception has been caught but will not be re-thrown.
- swap() - Method in enum org.apache.calcite.rel.core.JoinRelType
-
Swaps left to right, and vice versa.
- swap(Join) - Static method in class org.apache.calcite.rel.rules.JoinCommuteRule
-
Deprecated.
- swap(Join, boolean) - Static method in class org.apache.calcite.rel.rules.JoinCommuteRule
-
Deprecated.
- swap(Join, boolean, RelBuilder) - Static method in class org.apache.calcite.rel.rules.JoinCommuteRule
-
Returns a relational expression with the inputs switched round.
- SWAP - Static variable in class org.apache.calcite.util.mapping.IntPair
-
Deprecated.
- swapColumnReferences(RexBuilder, RexNode, Map<RexTableInputRef, Set<RexTableInputRef>>) - Static method in class org.apache.calcite.rex.RexUtil
-
Given an expression, it will swap its column references
RexTableInputRef
using the contents in the map (in particular, the first element of the set in the map value). - swapColumnTableReferences(RexBuilder, RexNode, Map<RexTableInputRef, ? extends Set<RexTableInputRef>>, Map<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>) - Static method in class org.apache.calcite.rex.RexUtil
-
Given an expression, it will swap the column references
RexTableInputRef
using the contents in the first map (in particular, the first element of the set in the map value), and then it will swap the table references contained in itsRexTableInputRef
using the contents in the second map. - swapTableColumnReferences(RexBuilder, RexNode, Map<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, Map<RexTableInputRef, Set<RexTableInputRef>>) - Static method in class org.apache.calcite.rex.RexUtil
-
Given an expression, it will swap the table references contained in its
RexTableInputRef
using the contents in the first map, and then it will swap the column referencesRexTableInputRef
using the contents in the second map (in particular, the first element of the set in the map value). - swapTableReferences(RexBuilder, RexNode, Map<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>) - Static method in class org.apache.calcite.rex.RexUtil
-
Given an expression, it will swap the table references contained in its
RexTableInputRef
using the contents in the map. - Switch - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A switch operation, such as switch in C# or Select Case in Visual Basic.
- switch_(Type, Expression, Expression, Method, Iterable<? extends SwitchCase>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a SwitchExpression that represents a switch statement that has a default case.
- switch_(Type, Expression, Expression, Method, SwitchCase...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a SwitchExpression that represents a switch statement that has a default case, using varargs.
- switch_(Expression, Expression, Method, Iterable<? extends SwitchCase>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a SwitchExpression that represents a switch statement that has a default case.
- switch_(Expression, Expression, Method, SwitchCase...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a SwitchExpression that represents a switch statement that has a default case, using varargs.
- switch_(Expression, Expression, SwitchCase...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a SwitchExpression that represents a switch statement that has a default case.
- switch_(Expression, SwitchCase...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a SwitchExpression that represents a switch statement without a default case.
- switchCase(Expression, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a SwitchCase for use in a SwitchExpression.
- switchCase(Expression, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a SwitchCase for use in a SwitchExpression, with varargs.
- SwitchCase - Class in org.apache.calcite.linq4j.tree
-
Represents one case of a
SwitchStatement
. - SwitchCase() - Constructor for class org.apache.calcite.linq4j.tree.SwitchCase
- SwitchStatement - Class in org.apache.calcite.linq4j.tree
-
Represents a control expression that handles multiple selections by passing control to
SwitchCase
. - SwitchStatement(ExpressionType) - Constructor for class org.apache.calcite.linq4j.tree.SwitchStatement
- SYBASE - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- SybaseSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Sybase database. - SybaseSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.SybaseSqlDialect
-
Creates a SybaseSqlDialect.
- symbol(String) - Method in class org.apache.calcite.runtime.Pattern.PatternBuilder
-
Creates a pattern that matches symbol, and pushes it onto the stack.
- symbol(SqlParserPos) - Method in enum org.apache.calcite.sql.SqlMatchRecognize.RowsPerMatchOption
- symbol(SqlParserPos) - Method in interface org.apache.calcite.sql.Symbolizable
-
Creates a parse-tree node representing an occurrence of this keyword at a particular position in the parsed text.
- SYMBOL - Enum constant in enum org.apache.calcite.runtime.Pattern.Op
-
A leaf pattern, consisting of a single symbol.
- SYMBOL - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- symbolDocument(String) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an instance of SymbolDocumentInfo.
- symbolDocument(String, UUID) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an instance of SymbolDocumentInfo.
- symbolDocument(String, UUID, UUID) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an instance of SymbolDocumentInfo.
- symbolDocument(String, UUID, UUID, UUID) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an instance of SymbolDocumentInfo.
- Symbolizable - Interface in org.apache.calcite.sql
-
Sub-class should be a Enum and can convert to a
SqlLiteral
. - symbolValue(Class<E>) - Method in class org.apache.calcite.sql.SqlLiteral
-
Returns the value as a symbol.
- symbolValue_() - Method in class org.apache.calcite.sql.SqlLiteral
-
Deprecated.
- SYMMETRIC - Enum constant in enum org.apache.calcite.sql.fun.SqlBetweenOperator.Flag
- SYMMETRIC_BETWEEN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- SYMMETRIC_NOT_BETWEEN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- SYMMETRICAL - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of operators that do not depend on the argument order.
- SYMMETRICAL_SAME_ARG_TYPE - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of operators that do not depend on the argument order if argument types are equal.
- syncResults(Meta.StatementHandle, QueryState, long) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- SYNONYM - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
A synonym.
- SYSTEM - Enum constant in enum org.apache.calcite.sql.SqlFunctionCategory
- SYSTEM_INDEX - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
System index.
- SYSTEM_INFO - Enum constant in enum org.apache.calcite.adapter.os.OsQueryType
- SYSTEM_TABLE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
A table maintained by the system.
- SYSTEM_TOAST_INDEX - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
System TOAST index.
- SYSTEM_TOAST_TABLE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
System TOAST table.
- SYSTEM_USER - Enum constant in enum org.apache.calcite.DataContext.Variable
-
The system user.
- SYSTEM_USER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- SYSTEM_USER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
SYSTEM_USER
function. - SYSTEM_VIEW - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
System view.
- systemExit(int) - Static method in class org.apache.calcite.util.Unsafe
-
Calls
System.exit(int)
. - SystemInfoTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "system_info".
- systemUser(DataContext) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SYSTEM_USER
function.
T
- t - Variable in class org.apache.calcite.materialize.LatticeTable
- t - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- table - Variable in class org.apache.calcite.jdbc.CalcitePrepare.AnalyzeViewResult
-
Not null if and only if the view is modifiable.
- table - Variable in class org.apache.calcite.materialize.Lattice.BaseColumn
-
Alias of the table reference that the column belongs to.
- table - Variable in class org.apache.calcite.materialize.LatticeNode
- table - Variable in class org.apache.calcite.model.JsonMaterialization
- table - Variable in class org.apache.calcite.rel.core.TableModify
-
The table definition.
- table - Variable in class org.apache.calcite.rel.core.TableScan
-
The table definition.
- table - Variable in class org.apache.calcite.rel.core.TableSpool
- table - Variable in class org.apache.calcite.rel.mutable.MutableTableModify
- table - Variable in class org.apache.calcite.schema.impl.AbstractTableQueryable
- table - Variable in class org.apache.calcite.sql.validate.DelegatingSqlValidatorTable
- table() - Method in interface org.apache.calcite.sql.validate.SqlValidatorTable
-
Returns the table.
- table(DataContext, String...) - Static method in class org.apache.calcite.schema.Schemas
-
Returns an
Enumerable
over object arrays, given a fully-qualified table name which leads to aScannableTable
. - table(RelOptTable) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Helper method to determine a
TableScan
's collation. - table(RelOptTable) - Static method in class org.apache.calcite.rel.metadata.RelMdDistribution
-
Helper method to determine a
TableScan
's distribution. - Table - Interface in org.apache.calcite.schema
-
Table.
- TABLE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
A regular table.
- TABLE - Enum constant in enum org.apache.calcite.sql.validate.SqlMonikerType
- TABLE_COLUMNS - Static variable in class org.apache.calcite.jdbc.CalciteMetaImpl
-
The columns returned by
DatabaseMetaData.getTables(java.lang.String, java.lang.String, java.lang.String, java.lang.String[])
. - TABLE_FUNCTION_SCAN - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
TableFunctionScan
nodes. - TABLE_INPUT_REF - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Reference to an input field, with a qualified name and an identifier.
- TABLE_MAP - Static variable in class org.apache.calcite.adapter.splunk.SplunkSchema
- TABLE_REF - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Table reference.
- TABLE_REFERENCES - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TABLE_SCAN - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
TableScan
nodes. - TABLE_SCAN_FACTORY - Static variable in class org.apache.calcite.adapter.jdbc.JdbcRules
- TABLE_TYPE_COLUMNS - Static variable in class org.apache.calcite.jdbc.CalciteMetaImpl
-
The columns returned by
DatabaseMetaData.getTableTypes()
. - TableAccessMap - Class in org.apache.calcite.plan
-
Deprecated.As of 1.30.0, if you need to know how tables in a plan are accessed you are encouraged to implement your own logic (using a RelNode visitor or other). The class is not used anywhere in the project and remains untested thus it is deprecated.
- TableAccessMap() - Constructor for class org.apache.calcite.plan.TableAccessMap
-
Deprecated.Constructs a permanently empty TableAccessMap.
- TableAccessMap(List<String>, TableAccessMap.Mode) - Constructor for class org.apache.calcite.plan.TableAccessMap
-
Deprecated.Constructs a TableAccessMap for a single table.
- TableAccessMap(RelNode) - Constructor for class org.apache.calcite.plan.TableAccessMap
-
Deprecated.Constructs a TableAccessMap for all tables accessed by a RelNode and its descendants.
- TableAccessMap.Mode - Enum in org.apache.calcite.plan
-
Deprecated.Access mode.
- tableCardinality(RelOptTable) - Method in interface org.apache.calcite.materialize.SqlStatisticProvider
-
Returns an estimate of the number of rows in
table
. - tableCardinality(RelOptTable) - Method in class org.apache.calcite.statistic.CachingSqlStatisticProvider
- tableCardinality(RelOptTable) - Method in enum org.apache.calcite.statistic.MapSqlStatisticProvider
- tableCardinality(RelOptTable) - Method in class org.apache.calcite.statistic.QuerySqlStatisticProvider
- tableCharacteristic(int) - Method in interface org.apache.calcite.sql.SqlTableFunction
-
Returns the table parameter characteristics for
ordinal
th parameter to this table function. - tableCharacteristic(int) - Method in class org.apache.calcite.test.MockSqlOperatorTable.InvalidTableFunction
- tableCharacteristic(int) - Method in class org.apache.calcite.test.MockSqlOperatorTable.ScoreTableFunction
- tableCharacteristic(int) - Method in class org.apache.calcite.test.MockSqlOperatorTable.SimilarlityTableFunction
- tableCharacteristic(int) - Method in class org.apache.calcite.test.MockSqlOperatorTable.TopNTableFunction
- TableCharacteristic - Class in org.apache.calcite.sql
-
A table-valued input parameter of a table function is classified by three characteristics.
- TableCharacteristic.Builder - Class in org.apache.calcite.sql
-
Builder for
TableCharacteristic
. - TableCharacteristic.Semantics - Enum in org.apache.calcite.sql
-
Input table has either row semantics or set semantics.
- TableCollectionType - Enum in org.apache.calcite.sql.babel
-
Enumerates the collection type of a table:
MULTISET
allows duplicates andSET
does not. - TableConstructorNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for a table constructor
VALUES (expr, expr, ...)
. - tableEntry(String, Table) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Creates a TableEntryImpl with no SQLs.
- TableEntry(CalciteSchema, String, ImmutableList<String>) - Constructor for class org.apache.calcite.jdbc.CalciteSchema.TableEntry
- TableEntryImpl(CalciteSchema, String, Table, ImmutableList<String>) - Constructor for class org.apache.calcite.jdbc.CalciteSchema.TableEntryImpl
-
Creates a TableEntryImpl.
- tableExists(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- tableExpression(SchemaPlus, Type, String, Class) - Static method in class org.apache.calcite.schema.Schemas
-
Returns the expression to access a table within a schema.
- TableExpressionFactory - Interface in org.apache.calcite.linq4j.tree
-
Factory for creating table expressions that may be used in generated code for accessing table data.
- TableFactory<T extends Table> - Interface in org.apache.calcite.schema
-
Factory for
Table
objects. - TableFunction - Interface in org.apache.calcite.schema
-
Function that returns a table during execution time.
- TableFunctionCallImplementor - Interface in org.apache.calcite.adapter.enumerable
-
Implements a table-valued function call.
- TableFunctionImpl - Class in org.apache.calcite.schema.impl
-
Implementation of
TableFunction
based on a method. - TableFunctionReturnTypeInference - Class in org.apache.calcite.sql.type
-
TableFunctionReturnTypeInference implements rules for deriving table function output row types by expanding references to cursor parameters.
- TableFunctionReturnTypeInference(RelProtoDataType, List<String>, boolean) - Constructor for class org.apache.calcite.sql.type.TableFunctionReturnTypeInference
- TableFunctionScan - Class in org.apache.calcite.rel.core
-
Relational expression that calls a table-valued function.
- TableFunctionScan(RelOptCluster, RelTraitSet, List<RelHint>, List<RelNode>, RexNode, Type, RelDataType, Set<RelColumnMapping>) - Constructor for class org.apache.calcite.rel.core.TableFunctionScan
-
Creates a
TableFunctionScan
. - TableFunctionScan(RelOptCluster, RelTraitSet, List<RelNode>, RexNode, Type, RelDataType, Set<RelColumnMapping>) - Constructor for class org.apache.calcite.rel.core.TableFunctionScan
-
Creates a
TableFunctionScan
. - TableFunctionScan(RelInput) - Constructor for class org.apache.calcite.rel.core.TableFunctionScan
-
Creates a TableFunctionScan by parsing serialized output.
- tableFunctionScanContext(List<SqlNode>) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- tableFunctionScanFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- TableFunctionScanNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
TableFunctionScan
. - tableList - Variable in class org.apache.calcite.sql.util.ChainedSqlOperatorTable
- TableMacro - Interface in org.apache.calcite.schema
-
Function that returns a
Table
. - TableMacroFunction() - Constructor for class org.apache.calcite.util.Smalls.TableMacroFunction
- TableMacroFunctionWithNamedParameters() - Constructor for class org.apache.calcite.util.Smalls.TableMacroFunctionWithNamedParameters
- TableMacroImpl - Class in org.apache.calcite.schema.impl
-
Implementation of
TableMacro
based on a method. - tableMap - Variable in class org.apache.calcite.adapter.pig.PigSchema
- tableMap - Variable in class org.apache.calcite.jdbc.CalciteSchema
-
Tables explicitly defined in this schema.
- TableModify - Class in org.apache.calcite.rel.core
-
Relational expression that modifies a table.
- TableModify(RelOptCluster, RelTraitSet, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean) - Constructor for class org.apache.calcite.rel.core.TableModify
-
Creates a
TableModify
. - TableModify(RelInput) - Constructor for class org.apache.calcite.rel.core.TableModify
-
Creates a TableModify by parsing serialized output.
- TableModify.Operation - Enum in org.apache.calcite.rel.core
-
Enumeration of supported modification operations.
- tableModOp - Variable in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- tableName - Variable in class org.apache.calcite.schema.impl.AbstractTableQueryable
- tableName() - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
-
Returns the table name, qualified with catalog and schema name if applicable, as a parse tree node (
SqlIdentifier
). - tableNameNotFound(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- tableNameNotFoundDidYouMean(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- tableNotFound(String) - Method in interface org.apache.calcite.runtime.CalciteResource
-
Same message as
CalciteResource.tableNameNotFound(String)
but a different kind of exception, so it can be used inRelBuilder
. - tablePath - Variable in class org.apache.calcite.jdbc.CalcitePrepare.AnalyzeViewResult
- tableRel - Variable in class org.apache.calcite.plan.RelOptMaterialization
- tables - Variable in class org.apache.calcite.model.JsonMapSchema
-
Tables in this schema.
- tables - Variable in class org.apache.calcite.schema.impl.StarTable
- tables() - Method in class org.apache.calcite.materialize.Lattice
-
Returns the set of tables in this lattice.
- TABLES - Enum constant in enum org.apache.calcite.model.ModelHandler.ExtraOperand
-
Tables defined in this schema.
- TABLESAMPLE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
TABLESAMPLE relational operator.
- TABLESAMPLE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
TABLESAMPLE
operator. - TableScan - Class in org.apache.calcite.rel.core
-
Relational operator that returns the contents of a table.
- TableScan(RelOptCluster, RelTraitSet, List<RelHint>, RelOptTable) - Constructor for class org.apache.calcite.rel.core.TableScan
- TableScan(RelOptCluster, RelTraitSet, RelOptTable) - Constructor for class org.apache.calcite.rel.core.TableScan
-
Deprecated.
- TableScan(RelInput) - Constructor for class org.apache.calcite.rel.core.TableScan
-
Creates a TableScan by parsing serialized output.
- TableScanNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
TableScan
. - TableScanRule - Class in org.apache.calcite.rel.rules
-
Deprecated.
org.apache.calcite.rel.core.RelFactories.TableScanFactoryImpl
has calledRelOptTable.toRel(RelOptTable.ToRelContext)
. - TableScanRule(RelRule.Config) - Constructor for class org.apache.calcite.rel.rules.TableScanRule
-
Deprecated.Creates a TableScanRule.
- TableScanRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.TableScanRule
-
Deprecated.
- TableScanRule.Config - Interface in org.apache.calcite.rel.rules
-
Deprecated.Rule configuration.
- TableSpool - Class in org.apache.calcite.rel.core
-
Spool that writes into a table.
- TableSpool(RelOptCluster, RelTraitSet, RelNode, Spool.Type, Spool.Type, RelOptTable) - Constructor for class org.apache.calcite.rel.core.TableSpool
- tag - Variable in class org.apache.calcite.sql.SqlUnknownLiteral
- take(int) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- take(int) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- take(int) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns a specified number of contiguous elements from the start of a sequence.
- take(int) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns a specified number of contiguous elements from the start of a sequence.
- take(Enumerable<TSource>, int) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns a specified number of contiguous elements from the start of a sequence.
- take(Enumerable<TSource>, long) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns a specified number of contiguous elements from the start of a sequence.
- take(Queryable<T>, int) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns a specified number of contiguous elements from the start of a sequence.
- take(Queryable<T>, int) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns a specified number of contiguous elements from the start of a sequence.
- take(Queryable<T>, int) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- TAKE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- takeWhile(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns elements from a sequence as long as a specified condition is true.
- takeWhile(Enumerable<TSource>, Predicate2<TSource, Integer>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns elements from a sequence as long as a specified condition is true.
- takeWhile(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- takeWhile(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns elements from a sequence as long as a specified condition is true.
- takeWhile(Predicate2<T, Integer>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- takeWhile(Predicate2<TSource, Integer>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns elements from a sequence as long as a specified condition is true.
- takeWhile(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns elements from a sequence as long as a specified condition is true.
- takeWhile(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns elements from a sequence as long as a specified condition is true.
- takeWhile(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- takeWhile(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- takeWhile(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns elements from a sequence as long as a specified condition is true.
- takeWhileLong(Enumerable<TSource>, Predicate2<TSource, Long>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns elements from a sequence as long as a specified condition is true.
- takeWhileN(Queryable<T>, FunctionExpression<Predicate2<T, Integer>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Returns elements from a sequence as long as a specified condition is true.
- takeWhileN(Queryable<T>, FunctionExpression<Predicate2<T, Integer>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Returns elements from a sequence as long as a specified condition is true.
- takeWhileN(Queryable<T>, FunctionExpression<Predicate2<T, Integer>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- takeWhileN(FunctionExpression<Predicate2<T, Integer>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- takeWhileN(FunctionExpression<Predicate2<T, Integer>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Returns elements from a sequence as long as a specified condition is true.
- TALL - Enum constant in enum org.apache.calcite.sql.SqlWriterConfig.LineFolding
-
Wrap always.
- tan(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TAN
operator applied to double values. - tan(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TAN
operator applied to BigDecimal values. - TAN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TAN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
TAN(numeric)
function. - tand(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TAND
operator applied to double values. - tand(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TAND
operator applied to BigDecimal values. - TAND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TAND - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
TAND(numeric)
function; returns the tangent ofvalue
. - tanh(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TANH
operator applied to double values. - tanh(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TANH
operator applied to BigDecimal values. - TANH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TANH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- target - Variable in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRuleCall
- target - Variable in class org.apache.calcite.util.graph.DefaultEdge
- target - Variable in class org.apache.calcite.util.mapping.IntPair
- target(int) - Static method in class org.apache.calcite.plan.SubstitutionVisitor.AbstractUnifyRule
-
Creates an operand that matches a relational expression in the target.
- target(Iterable<IntPair>, int, int) - Static method in class org.apache.calcite.util.mapping.Mappings
- target(IntFunction<? extends Integer>, int, int) - Static method in class org.apache.calcite.util.mapping.Mappings
- target(List<Integer>, int) - Static method in class org.apache.calcite.util.mapping.Mappings
- target(Map<Integer, Integer>, int, int) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Converts a
Map
of integers to aMappings.TargetMapping
. - targetExpression - Variable in class org.apache.calcite.linq4j.tree.MethodCallExpression
- targetOperand - Variable in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRule
- targets - Variable in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- TCP_NODELAY - Static variable in class org.apache.calcite.runtime.SocketFactoryImpl
-
Whether to not buffer send(s).
- tearDown() - Method in class org.apache.calcite.test.DiffTestCase
- Template - Class in org.apache.calcite.util
-
String template.
- TEMPLATE_METHOD_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Define the skeleton of an algorithm in an operation, deferring some steps to subclasses.
- TEMPORAL_TABLE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
A temporal table.
- TemporalTable - Interface in org.apache.calcite.schema
-
Table that is temporal.
- TEMPORARY_INDEX - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
Temporary index.
- TEMPORARY_SEQUENCE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
Temporary sequence.
- TEMPORARY_TABLE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
Temporary table.
- TEMPORARY_VIEW - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
Temporary view.
- TEN - Enum constant in enum org.apache.calcite.util.mapping.MappingType
- TENTHS_OF_MS - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- TENTHS_OF_SECOND - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- TERADATA - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- TeradataSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Teradata database. - TeradataSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.TeradataSqlDialect
-
Creates a TeradataSqlDialect.
- TernaryExpression - Class in org.apache.calcite.linq4j.tree
-
Represents an expression that has a ternary operator.
- test(T) - Method in class org.apache.calcite.runtime.PredicateImpl
-
Deprecated.Overrides
java.util.function.Predicate#test
in JDK8 and higher. - test(String) - Method in class org.apache.calcite.test.QuidemTest
- test(TableScan) - Static method in class org.apache.calcite.rel.rules.FilterTableScanRule
- test(TableScan) - Static method in class org.apache.calcite.rel.rules.ProjectTableScanRule
- test(RexNode) - Method in interface org.apache.calcite.rel.rules.PushProjector.ExprCondition
-
Evaluates a condition for a given expression.
- TEST_ARROW - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to run Arrow tests.
- TEST_CASSANDRA - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to run Cassandra tests.
- TEST_DATASET_PATH - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Path to the dataset file that should used for integration tests.
- TEST_DB - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Which database to use for tests that require a JDBC data source.
- TEST_DRUID - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to run Druid tests.
- TEST_FOODMART_QUERY_IDS - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
A list of ids designating the queries (from query.json in new.hydromatic:foodmart-queries:0.4.1) that should be run as part of FoodmartTest.
- TEST_INNODB - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to run InnoDB tests.
- TEST_MONGODB - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to run MongoDB tests.
- TEST_REDIS - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to run Redis tests.
- TEST_SPLUNK - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to run Splunk tests.
- TEST_UNICODE_SQL_ESCAPED_LITERAL - Static variable in class org.apache.calcite.util.ConversionUtil
-
A constant string which can be used wherever a SQL literal containing Unicode escape characters is needed in a test.
- TEST_UNICODE_STRING - Static variable in class org.apache.calcite.util.ConversionUtil
-
A constant string which can be used wherever a Java string containing Unicode characters is needed in a test.
- TEST_WITH_DOCKER_CONTAINER - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to use Docker containers in tests.
- testAll() - Method in class org.apache.calcite.test.IntervalTest
-
Runs all tests.
- testCaseExpression() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCast() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testConstantCast() - Method in class org.apache.calcite.test.SqlOperatorTest
- tester - Variable in class org.apache.calcite.sql.parser.SqlParserFixture
- tester - Variable in class org.apache.calcite.test.RelMetadataFixture
- tester - Variable in class org.apache.calcite.test.SqlValidatorFixture
- TESTER - Static variable in class org.apache.calcite.test.SqlOperatorTest
- TESTER - Static variable in class org.apache.calcite.test.SqlToRelFixture
- TesterImpl() - Constructor for class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- TesterImpl() - Constructor for class org.apache.calcite.test.SqlOperatorTest.TesterImpl
- testHoist() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Tests
Hoist
. - testIssue6322() - Method in class org.apache.calcite.test.SqlOperatorTest
-
Test cases for [CALCITE-6322] Casts to DECIMAL types are ignored.
- testJsonInsert() - Method in class org.apache.calcite.test.SqlOperatorTest
- testJsonReplace() - Method in class org.apache.calcite.test.SqlOperatorTest
- testJsonSet() - Method in class org.apache.calcite.test.SqlOperatorTest
- testLambdaExpression() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Tests
SqlLambda
. - testMetadata() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testOverflow() - Method in class org.apache.calcite.test.SqlOperatorTest
- TestStaticTableFunction() - Constructor for class org.apache.calcite.util.Smalls.TestStaticTableFunction
- testTimeUnitCodes() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Tests that EXTRACT, FLOOR, CEIL, DATE_TRUNC functions accept abbreviations for time units (such as "Y" for "YEAR") when configured via
SqlParser.Config.timeUnitCodes()
. - TestUtil - Class in org.apache.calcite.util
-
Static utilities for JUnit tests.
- TestUtil() - Constructor for class org.apache.calcite.util.TestUtil
- testVarbinaryCast() - Method in class org.apache.calcite.test.SqlOperatorTest
-
Test case for Cast to VARBINARY causes an assertion failure.
- testVarbitArithmetic() - Method in class org.apache.calcite.test.SqlOperatorTest
- TEXT - Enum constant in enum org.apache.calcite.sql.SqlExplainFormat
-
Indicates that the plan should be output as a piece of indented text.
- TH_LOWER - Enum constant in enum org.apache.calcite.util.format.postgresql.PatternModifier
- TH_UPPER - Enum constant in enum org.apache.calcite.util.format.postgresql.PatternModifier
- that() - Static method in class org.apache.calcite.test.CalciteAssert
-
Creates an instance of
CalciteAssert
with the empty configuration. - that(CalciteAssert.Config) - Static method in class org.apache.calcite.test.CalciteAssert
-
Creates an instance of
CalciteAssert
with a given configuration. - thenBy(Function1<T, TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- thenBy(Function1<T, TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedOrderedEnumerable
-
Performs a subsequent ordering of the elements in a sequence in ascending order according to a key.
- thenBy(Function1<T, TKey>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- thenBy(Function1<T, TKey>, Comparator<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedOrderedEnumerable
-
Performs a subsequent ordering of the elements in a sequence in ascending order according to a key, using a specified comparator.
- thenBy(OrderedEnumerable<TSource>, Function1<TSource, TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Performs a subsequent ordering of the elements in a sequence in ascending order according to a key.
- thenBy(OrderedEnumerable<TSource>, Function1<TSource, TKey>, Comparator<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Performs a subsequent ordering of the elements in a sequence in ascending order according to a key, using a specified comparator.
- thenBy(OrderedQueryable<T>, FunctionExpression<Function1<T, TKey>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Performs a subsequent ordering of the elements in a sequence in ascending order according to a key.
- thenBy(OrderedQueryable<T>, FunctionExpression<Function1<T, TKey>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
- thenBy(OrderedQueryable<T>, FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- thenBy(OrderedQueryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Performs a subsequent ordering of the elements in a sequence in ascending order according to a key, using a specified comparator.
- thenBy(OrderedQueryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
- thenBy(OrderedQueryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- thenBy(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- thenBy(FunctionExpression<Function1<T, TKey>>) - Method in interface org.apache.calcite.linq4j.ExtendedOrderedQueryable
-
Performs a subsequent ordering of the elements in a sequence in ascending order according to a key.
- thenBy(FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- thenBy(FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedOrderedQueryable
-
Performs a subsequent ordering of the elements in a sequence in ascending order according to a key, using a specified comparator.
- thenByDescending(Function1<T, TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- thenByDescending(Function1<T, TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedOrderedEnumerable
-
Performs a subsequent ordering of the elements in a sequence in descending order according to a key.
- thenByDescending(Function1<T, TKey>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- thenByDescending(Function1<T, TKey>, Comparator<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedOrderedEnumerable
-
Performs a subsequent ordering of the elements in a sequence in descending order according to a key, using a specified comparator.
- thenByDescending(OrderedEnumerable<TSource>, Function1<TSource, TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Performs a subsequent ordering of the elements in a sequence in descending order according to a key.
- thenByDescending(OrderedEnumerable<TSource>, Function1<TSource, TKey>, Comparator<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Performs a subsequent ordering of the elements in a sequence in descending order according to a key, using a specified comparator.
- thenByDescending(OrderedQueryable<T>, FunctionExpression<Function1<T, TKey>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Performs a subsequent ordering of the elements in a sequence in descending order according to a key.
- thenByDescending(OrderedQueryable<T>, FunctionExpression<Function1<T, TKey>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
- thenByDescending(OrderedQueryable<T>, FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- thenByDescending(OrderedQueryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Performs a subsequent ordering of the elements in a sequence in dscending order according to a key, using a specified comparator.
- thenByDescending(OrderedQueryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
- thenByDescending(OrderedQueryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- thenByDescending(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- thenByDescending(FunctionExpression<Function1<T, TKey>>) - Method in interface org.apache.calcite.linq4j.ExtendedOrderedQueryable
-
Performs a subsequent ordering of the elements in a sequence in descending order according to a key.
- thenByDescending(FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- thenByDescending(FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedOrderedQueryable
-
Performs a subsequent ordering of the elements in a sequence in descending order according to a key, using a specified comparator.
- THETA_SKETCH - Enum constant in enum org.apache.calcite.adapter.druid.DruidType
- THOUSANDTHS_OF_MS - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- THOUSANDTHS_OF_SECOND - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- THREAD_CALL_COUNT - Static variable in class org.apache.calcite.test.catalog.CountingFactory
- THREAD_CONTEXT_STACK - Static variable in interface org.apache.calcite.jdbc.CalcitePrepare
- THREAD_DIGEST - Static variable in class org.apache.calcite.util.Smalls.MyPlusInitFunction
- THREAD_EXPAND - Static variable in class org.apache.calcite.prepare.Prepare
-
Temporary, until [CALCITE-1045] Decorrelate sub-queries in Project and Join is fixed.
- THREAD_INSUBQUERY_THRESHOLD - Static variable in class org.apache.calcite.prepare.Prepare
- THREAD_LOCAL - Static variable in interface org.apache.calcite.prepare.Prepare.CatalogReader
- THREAD_METADATA - Static variable in class org.apache.calcite.adapter.jdbc.JdbcSchema
- THREAD_PROVIDERS - Static variable in class org.apache.calcite.rel.metadata.RelMetadataQueryBase
- THREAD_PROVIDERS - Static variable in class org.apache.calcite.sql.type.SqlTypeCoercionRule
- THREAD_TRIM - Static variable in class org.apache.calcite.prepare.Prepare
- THREAD_TYPE_SYSTEM - Static variable in class org.apache.calcite.test.SqlOperatorTest.TesterImpl
-
Assign a type system object to this thread-local, pass the name of the field as the
CalciteConnectionProperty.TYPE_SYSTEM
property, and any connection you make in the same thread will use your type system. - Throw - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An operation that throws an exception, such as throw new Exception().
- THROW - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- THROW - Static variable in interface org.apache.calcite.util.Litmus
-
Implementation of
Litmus
that throws anAssertionError
on failure. - throw_(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a statement that represents the throwing of an exception.
- THROW_UNLESS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- THROW_UNLESS - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
"$THROW_UNLESS(condition, message)" throws an error with the given message if condition is not TRUE, otherwise returns TRUE.
- throwAsRuntime(String, Throwable) - Static method in class org.apache.calcite.util.Util
-
This method rethrows input throwable as is (if its unchecked) with an extra message or wraps it with
RuntimeException
and throws. - throwAsRuntime(Throwable) - Static method in class org.apache.calcite.util.Util
-
This method rethrows input throwable as is (if its unchecked) or wraps it with
RuntimeException
and throws. - throwIfNotUnique() - Method in interface org.apache.calcite.rel.rules.AggregateExpandWithinDistinctRule.Config
-
Whether the code generated by the rule should throw if the arguments are not functionally dependent.
- throwIfUnchecked(Throwable) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- throws_(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- throws_(String) - Method in class org.apache.calcite.test.SqlToRelFixture
- ThrowStatement - Class in org.apache.calcite.linq4j.tree
-
Represents a
throw
statement. - ThrowStatement(Expression) - Constructor for class org.apache.calcite.linq4j.tree.ThrowStatement
- throwUnless(boolean, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Internal THROW_UNLESS(condition, message) function.
- Tile(ImmutableList<Lattice.Measure>, ImmutableList<Lattice.Column>) - Constructor for class org.apache.calcite.materialize.Lattice.Tile
- TileBuilder() - Constructor for class org.apache.calcite.materialize.Lattice.TileBuilder
- TileKey - Class in org.apache.calcite.materialize
-
Definition of a particular combination of dimensions and measures of a lattice that is the basis of a materialization.
- TileKey(Lattice, ImmutableBitSet, ImmutableList<Lattice.Measure>) - Constructor for class org.apache.calcite.materialize.TileKey
-
Creates a TileKey.
- tiles - Variable in class org.apache.calcite.materialize.Lattice
- tiles - Variable in class org.apache.calcite.model.JsonLattice
-
List of materialized aggregates to create up front.
- tiles() - Method in class org.apache.calcite.materialize.TileSuggester
- TileSuggester - Class in org.apache.calcite.materialize
-
Algorithm that suggests a set of initial tiles (materialized aggregate views) for a given lattice.
- TileSuggester(Lattice) - Constructor for class org.apache.calcite.materialize.TileSuggester
- time(int, int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TIME(<hour>, <minute>, <second>)
function. - time(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TIME(<timestamp>)
andTIME(<timestampLtz>)
functions. - time(long, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TIME(<timestampLtz>, <timeZone>)
function. - TIME - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- TIME - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- TIME - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIME - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TIME" function.
- TIME - Static variable in class org.apache.calcite.sql.type.OperandTypes
- TIME - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is TIME(0).
- TIME_ADD - Enum constant in enum org.apache.calcite.sql.SqlKind
-
TIME_ADD
function (BigQuery). - TIME_ADD - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TIME_ADD(time, interval)" function (BigQuery); adds interval expression to the specified time expression.
- TIME_DIFF - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TIME_DIFF(time, time, timeUnit)" function (BigQuery); returns the number of timeUnit between the two time expressions.
- TIME_FRAME_SET - Enum constant in enum org.apache.calcite.DataContext.Variable
-
Set of built-in and custom time frames for use in functions such as
FLOOR
andEXTRACT
. - TIME_FRAME_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
-
The possible types of a time frame argument to a function such as
TIMESTAMP_DIFF
. - TIME_INTERVAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
- TIME_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is nullable TIME(0).
- TIME_PATTERN - Static variable in class org.apache.calcite.test.SqlOperatorTest
-
Regular expression for a SQL TIME(0/1) value.
- TIME_STRING_TO_TIME_WITH_LOCAL_TIME_ZONE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIME_SUB - Enum constant in enum org.apache.calcite.sql.SqlKind
-
TIME_SUB
function (BigQuery). - TIME_SUB - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TIME_SUB(time, interval)" function (BigQuery); subtracts an interval from a time, independent of any time zone.
- TIME_TO_INT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIME_TO_INT_OPTIONAL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIME_TRUNC - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TIME_TRUNC(time, timeUnit)" function (BigQuery); truncates a TIME value to the beginning of a timeUnit.
- TIME_TZ - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- TIME_WITH_LOCAL_TIME_ZONE - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- TIME_WITH_LOCAL_TIME_ZONE_TO_STRING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIME_WITH_LOCAL_TIME_ZONE_TO_TIME - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIME_WITH_LOCAL_TIME_ZONE_TO_TIMESTAMP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIME_WITH_LOCAL_TIME_ZONE_TO_TIMESTAMP_WITH_LOCAL_TIME_ZONE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIME_WITH_TIMEZONE - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- TIME_ZONE - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Returns the time zone from the connect string, for example 'gmt-3'.
- TIME_ZONE - Enum constant in enum org.apache.calcite.DataContext.Variable
-
Time zone in which the current statement is executing.
- TIME_ZONE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIME_ZONE_GET_OFFSET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- timeDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- TIMEDATE - Enum constant in enum org.apache.calcite.sql.SqlFunctionCategory
- TimeExtractionFunction - Class in org.apache.calcite.adapter.druid
-
Implementation of Druid time format extraction function.
- TimeExtractionFunction(String, Granularity, String, String) - Constructor for class org.apache.calcite.adapter.druid.TimeExtractionFunction
- TimeFrame - Interface in org.apache.calcite.rel.type
-
Time frame.
- timeFrameName - Variable in class org.apache.calcite.sql.SqlIntervalQualifier
- TimeFrames - Class in org.apache.calcite.rel.type
-
Utilities for
TimeFrame
. - timeFrameSet - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- TimeFrameSet - Class in org.apache.calcite.rel.type
-
Set of
TimeFrame
definitions. - TimeFrameSet.Builder - Interface in org.apache.calcite.rel.type
-
Builds a collection of time frames.
- timeFun(Time) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- timeInterval() - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a checker for TIME intervals (HOUR, SECOND, etc.)
- timeLiteral(TimeString) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- TIMEOUT - Enum constant in enum org.apache.calcite.DataContext.Variable
-
Query timeout in milliseconds.
- TIMES - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Arithmetic multiplication operator, "*".
- TIMESERIES - Enum constant in enum org.apache.calcite.adapter.druid.QueryType
- timestamp(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TIMESTAMP(<date>)
function. - timestamp(int, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TIMESTAMP(<date>, <timeZone>)
function. - timestamp(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TIMESTAMP(<timestamp>)
function; returns a TIMESTAMP WITH LOCAL TIME ZONE. - timestamp(long, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TIMESTAMP(<timestamp>, <timeZone>)
function; returns a TIMESTAMP WITH LOCAL TIME ZONE. - timestamp(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TIMESTAMP(<string>)
function. - timestamp(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TIMESTAMP(<string>, <timeZone>)
function. - TIMESTAMP - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- TIMESTAMP - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- TIMESTAMP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TIMESTAMP" function returns a Calcite
TIMESTAMP WITH LOCAL TIME ZONE
(which BigQuery calls aTIMESTAMP
). - TIMESTAMP - Static variable in class org.apache.calcite.sql.type.OperandTypes
- TIMESTAMP - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is TIMESTAMP.
- TIMESTAMP_ADD - Enum constant in enum org.apache.calcite.sql.SqlKind
-
TIMESTAMP_ADD
function (ODBC, SQL Server, MySQL). - TIMESTAMP_ADD - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
TIMESTAMPADD
function. - TIMESTAMP_ADD2 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TIMESTAMP_ADD(timestamp, interval)" function (BigQuery), the two-argument variant of the built-in
TIMESTAMPADD
function, which has three arguments. - TIMESTAMP_DIFF - Enum constant in enum org.apache.calcite.sql.SqlKind
-
TIMESTAMP_DIFF
function (ODBC, SQL Server, MySQL). - TIMESTAMP_DIFF - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
TIMESTAMPDIFF
function. - TIMESTAMP_DIFF3 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TIMESTAMP_DIFF(timestamp, timestamp, timeUnit)" function (BigQuery); returns the number of timeUnit between the two timestamp expressions.
- TIMESTAMP_INTERVAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
- TIMESTAMP_LTZ - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Type-checker that matches "TIMESTAMP WITH LOCAL TIME ZONE" but not other members of the "TIMESTAMP" family (e.g.
- TIMESTAMP_LTZ - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is TIMESTAMP WITH LOCAL TIME ZONE.
- TIMESTAMP_LTZ_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is nullable TIMESTAMP WITH LOCAL TIME ZONE.
- TIMESTAMP_MICROS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_MICROS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TIMESTAMP_MICROS(bigint)" function; returns a TIMESTAMP value a given number of micro-seconds after 1970-01-01 00:00:00.
- TIMESTAMP_MILLIS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_MILLIS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TIMESTAMP_MILLIS(bigint)" function; returns a TIMESTAMP value a given number of milliseconds after 1970-01-01 00:00:00.
- TIMESTAMP_NTZ - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Type-checker that matches "TIMESTAMP" but not other members of the "TIMESTAMP" family (e.g.
- TIMESTAMP_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is nullable TIMESTAMP.
- TIMESTAMP_PATTERN - Static variable in class org.apache.calcite.test.SqlOperatorTest
-
Regular expression for a SQL TIMESTAMP(0/1) value.
- TIMESTAMP_SECONDS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_SECONDS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TIMESTAMP_SECONDS(bigint)" function; returns a TIMESTAMP value a given number of seconds after 1970-01-01 00:00:00.
- TIMESTAMP_STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- TIMESTAMP_STRING_TO_TIMESTAMP_WITH_LOCAL_TIME_ZONE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_SUB - Enum constant in enum org.apache.calcite.sql.SqlKind
-
TIMESTAMP_SUB
function (BigQuery). - TIMESTAMP_SUB - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TIMESTAMP_SUB(timestamp, interval)" function (BigQuery); subtracts an interval from a timestamp, independent of any time zone.
- TIMESTAMP_TO_DATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_TO_LONG - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_TO_LONG_OFFSET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_TO_LONG_OPTIONAL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_TO_LONG_OPTIONAL_OFFSET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_TRUNC - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TIMESTAMP_TRUNC(timestamp, timeUnit[, timeZone])" function (BigQuery); truncates a
TIMESTAMP WITH LOCAL TIME ZONE
value to the beginning of a timeUnit. - TIMESTAMP_TZ - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- TIMESTAMP_TZ - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is TIMESTAMP WITH TIME ZONE.
- TIMESTAMP_TZ_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is nullable TIMESTAMP WITH TIME ZONE.
- TIMESTAMP_WITH_LOCAL_TIME_ZONE - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- TIMESTAMP_WITH_LOCAL_TIME_ZONE_TO_DATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_WITH_LOCAL_TIME_ZONE_TO_STRING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_WITH_LOCAL_TIME_ZONE_TO_TIME - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_WITH_LOCAL_TIME_ZONE_TO_TIME_WITH_LOCAL_TIME_ZONE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_WITH_LOCAL_TIME_ZONE_TO_TIMESTAMP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_WITH_TIMEZONE - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- timestampDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- timestampEpoch() - Method in interface org.apache.calcite.rel.type.TimeFrame
-
Returns a timestamp where this time frame is at the start of a cycle.
- timestampFun(Timestamp) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- timestampInterval() - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a checker for TIMESTAMP intervals (YEAR, WEEK, ISOWEEK, WEEK_WEDNESDAY, HOUR, SECOND, etc.)
- timestampLiteral(TimestampString) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- timestampLocalTzLiteral(TimestampString) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- timestampMicros(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- timestampMillis(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- timestampSeconds(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- TimestampString - Class in org.apache.calcite.util
-
Timestamp literal.
- TimestampString(int, int, int, int, int, int) - Constructor for class org.apache.calcite.util.TimestampString
-
Creates a TimestampString for year, month, day, hour, minute, second, millisecond values.
- TimestampString(String) - Constructor for class org.apache.calcite.util.TimestampString
-
Creates a TimeString.
- timestampToDate(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a timestamp (milliseconds since epoch) to a date (days since epoch).
- timestampToTime(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a timestamp (milliseconds since epoch) to a time (milliseconds since midnight).
- timestampWithLocalTimeZoneToDate(long, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
- timestampWithLocalTimeZoneToString(long, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
- timestampWithLocalTimeZoneToTime(long, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
- timestampWithLocalTimeZoneToTimestamp(long, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
- timestampWithLocalTimeZoneToTimeWithLocalTimeZone(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- TimestampWithTimeZoneString - Class in org.apache.calcite.util
-
Timestamp with time-zone literal.
- TimestampWithTimeZoneString(int, int, int, int, int, int, String) - Constructor for class org.apache.calcite.util.TimestampWithTimeZoneString
-
Creates a TimestampWithTimeZoneString for year, month, day, hour, minute, second, millisecond values in the given time-zone.
- TimestampWithTimeZoneString(String) - Constructor for class org.apache.calcite.util.TimestampWithTimeZoneString
-
Creates a TimestampWithTimeZoneString.
- TimestampWithTimeZoneString(TimestampString, TimeZone) - Constructor for class org.apache.calcite.util.TimestampWithTimeZoneString
-
Creates a TimestampWithTimeZoneString.
- TimeString - Class in org.apache.calcite.util
-
Time literal.
- TimeString(int, int, int) - Constructor for class org.apache.calcite.util.TimeString
-
Creates a TimeString for hour, minute, second and millisecond values.
- TimeString(String) - Constructor for class org.apache.calcite.util.TimeString
-
Creates a TimeString.
- timeUnitCodes() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
-
Deprecated.This property is deprecated, and has no effect. All non-standard time units are now parsed as identifiers, and resolved in the validator. You can define custom time frames using
RelDataTypeSystem.deriveTimeFrameSet(TimeFrameSet)
. To alias a time frame, useTimeFrameSet.Builder.addAlias(String, String)
. - timeUnitRange - Variable in class org.apache.calcite.sql.SqlIntervalQualifier
- timeWithLocalTimeZoneToString(int, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
- timeWithLocalTimeZoneToTime(int, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
- timeWithLocalTimeZoneToTimestamp(String, int, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
- timeWithLocalTimeZoneToTimestampWithLocalTimeZone(String, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- TimeWithTimeZoneString - Class in org.apache.calcite.util
-
Time with time-zone literal.
- TimeWithTimeZoneString(int, int, int, String) - Constructor for class org.apache.calcite.util.TimeWithTimeZoneString
-
Creates a TimeWithTimeZoneString for hour, minute, second and millisecond values in the given time-zone.
- TimeWithTimeZoneString(String) - Constructor for class org.apache.calcite.util.TimeWithTimeZoneString
-
Creates a TimeWithTimeZoneString.
- TimeWithTimeZoneString(TimeString, TimeZone) - Constructor for class org.apache.calcite.util.TimeWithTimeZoneString
-
Creates a TimeWithTimeZoneString.
- timeZone() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.TIME_ZONE
. - timeZone() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- timeZone(DataContext) - Static method in class org.apache.calcite.runtime.SqlFunctions
- TIMEZONE - Static variable in enum org.apache.calcite.config.CalciteConnectionProperty
-
Deprecated.
- TIMEZONE_HOURS - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- TIMEZONE_MINUTES - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- TimeZoneCompiledPattern - Class in org.apache.calcite.util.format.postgresql.format.compiled
-
The date/time format compiled component for the 3 letter timezone code (such as UTC).
- TimeZoneCompiledPattern(Set<PatternModifier>, boolean) - Constructor for class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneCompiledPattern
- TimeZoneFormatPattern - Class in org.apache.calcite.util.format.postgresql.format
-
The date/time format component for the 3 letter timezone code (such as UTC).
- TimeZoneFormatPattern(String) - Constructor for class org.apache.calcite.util.format.postgresql.format.TimeZoneFormatPattern
- TimeZoneHoursCompiledPattern - Class in org.apache.calcite.util.format.postgresql.format.compiled
-
The date/time format compiled component for the hours of the timezone offset.
- TimeZoneHoursCompiledPattern(Set<PatternModifier>) - Constructor for class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneHoursCompiledPattern
- TimeZoneHoursFormatPattern - Class in org.apache.calcite.util.format.postgresql.format
-
The date/time format component for the hours of the timezone offset.
- TimeZoneHoursFormatPattern() - Constructor for class org.apache.calcite.util.format.postgresql.format.TimeZoneHoursFormatPattern
- TimeZoneMinutesCompiledPattern - Class in org.apache.calcite.util.format.postgresql.format.compiled
-
The date/time format compiled component for the minutes of the timezone offset.
- TimeZoneMinutesCompiledPattern(Set<PatternModifier>) - Constructor for class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneMinutesCompiledPattern
- TimeZoneMinutesFormatPattern - Class in org.apache.calcite.util.format.postgresql.format
-
The date/time format component for the minutes of the timezone offset.
- TimeZoneMinutesFormatPattern() - Constructor for class org.apache.calcite.util.format.postgresql.format.TimeZoneMinutesFormatPattern
- TimeZoneOffsetCompiledPattern - Class in org.apache.calcite.util.format.postgresql.format.compiled
-
The date/time format compiled component for the hours and minutes of the timezone offset.
- TimeZoneOffsetCompiledPattern(Set<PatternModifier>) - Constructor for class org.apache.calcite.util.format.postgresql.format.compiled.TimeZoneOffsetCompiledPattern
- TimeZoneOffsetFormatPattern - Class in org.apache.calcite.util.format.postgresql.format
-
The date/time format component for the hours and minutes of the timezone offset.
- TimeZoneOffsetFormatPattern() - Constructor for class org.apache.calcite.util.format.postgresql.format.TimeZoneOffsetFormatPattern
- timingTracer - Variable in class org.apache.calcite.prepare.Prepare
- TINYINT - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- TINYINT - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is a TINYINT.
- TINYINT_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is a TINYINT with nulls allowed if any of the operands allow nulls.
- title - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Book
- TM - Enum constant in enum org.apache.calcite.util.format.postgresql.PatternModifier
- TO_ARRAY - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns an ARRAY type.
- TO_ARRAY - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy that wraps a given type in an array.
- TO_ARRAY_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is nullable
ARRAY
. - TO_ARRAY_NULLABLE - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy that wraps a given type in an array, but nullable if any of element of a calls operands is nullable.
- TO_ARRAY_QUERY - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy that wraps a given type in an array or wraps a field of the given type in an array if the given type is struct with one field.
- TO_BASE32 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TO_BASE32 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- TO_BASE64 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TO_BASE64 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- TO_BINDABLE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
-
Rule that converts any enumerable relational expression to bindable.
- TO_CHAR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TO_CHAR - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TO_CHAR(timestamp, format)" function; converts
timestamp
to string according to the givenformat
. - TO_CHAR_PG - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TO_CHAR_PG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TO_CHAR(timestamp, format)" function; converts
timestamp
to string according to the givenformat
. - TO_CODE_POINTS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TO_CODE_POINTS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TO_CODE_POINTS(string or binary)" function (BigQuery); Converts a
string
orbinary
value to an array of integers that represent code points or extended ASCII character values. - TO_COLLECTION_ELEMENT - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns the element type of an ARRAY or MULTISET.
- TO_COLLECTION_ELEMENT_FORCE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- TO_COLLECTION_ELEMENT_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- TO_COLLECTION_ELEMENT_TYPE - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy where a derived type must be a multiset or array type and the returned type is element type.
- TO_DATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TO_DATE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TO_DATE(string1, string2)" function; casts string1 to a DATE using the format specified in string2.
- TO_DATE_PG - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TO_DATE_PG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TO_DATE(string1, string2)" function for PostgreSQL; casts string1 to a DATE using the format specified in string2.
- TO_ENUMERABLE - Static variable in class org.apache.calcite.adapter.arrow.ArrowRules
- TO_ENUMERABLE - Static variable in class org.apache.calcite.adapter.cassandra.CassandraRules
-
Rule to convert a relational expression from
CassandraRel.CONVENTION
toEnumerableConvention
. - TO_ENUMERABLE - Static variable in class org.apache.calcite.adapter.innodb.InnodbRules
-
Rule to convert a relational expression from
InnodbRel.CONVENTION
toEnumerableConvention
. - TO_HEX - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TO_HEX - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TO_HEX(binary)" function; converts
binary
into a hexadecimal varchar. - TO_INTERPRETER - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- TO_MAP - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns a MAP type.
- TO_MAP - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy that converts a two-field record type to a MAP type.
- TO_MAP_ENTRIES - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns a ARRAY type.
- TO_MAP_ENTRIES_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- TO_MAP_KEYS - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns a ARRAY type.
- TO_MAP_KEYS - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy that converts a MAP type to a ARRAY type.
- TO_MAP_KEYS_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- TO_MAP_QUERY - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy that converts a two-field record type to a MAP query type.
- TO_MAP_VALUES - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns a ARRAY type.
- TO_MAP_VALUES - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy that converts a MAP type to a ARRAY type.
- TO_MAP_VALUES_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- TO_MEASURE - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform that transforms
T
toMEASURE<T>
for some type T. - TO_MULTISET - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns a MULTISET type.
- TO_MULTISET - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy that wraps a given type in a multiset.
- TO_MULTISET_QUERY - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy that wraps a given type in a multiset or wraps a field of the given type in a multiset if the given type is struct with one field.
- TO_NOT_NULLABLE - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy where a derived type is transformed into the same type but not nullable.
- TO_NULLABLE - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy where a derived type is transformed into the same type but nullable if any of a calls operands is nullable.
- TO_NULLABLE_ALL - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy where a derived type is transformed into the same type, but nullable if and only if all of a call's operands are nullable.
- TO_ROW - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns a ROW type.
- TO_ROW - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy that converts a MAP type to a two-field record type.
- TO_TIMESTAMP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TO_TIMESTAMP - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TO_TIMESTAMP(string1, string2)" function; casts string1 to a TIMESTAMP using the format specified in string2.
- TO_TIMESTAMP_PG - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TO_TIMESTAMP_PG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TO_TIMESTAMP(string1, string2)" function for PostgreSQL; casts string1 to a TIMESTAMP using the format specified in string2.
- TO_VARYING - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Type-inference strategy whereby the result type of a call is VARYING the type given.
- toArray() - Method in class org.apache.calcite.runtime.ConsList
- toArray() - Method in class org.apache.calcite.runtime.FlatLists.Flat1List
- toArray() - Method in class org.apache.calcite.runtime.FlatLists.Flat2List
- toArray() - Method in class org.apache.calcite.runtime.FlatLists.Flat3List
- toArray() - Method in class org.apache.calcite.runtime.FlatLists.Flat4List
- toArray() - Method in class org.apache.calcite.runtime.FlatLists.Flat5List
- toArray() - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- toArray() - Method in class org.apache.calcite.sql.SqlNodeList
- toArray() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Converts this bit set to an array.
- toArray() - Method in class org.apache.calcite.util.ImmutableIntList
- toArray(BitSet) - Static method in class org.apache.calcite.util.BitSets
-
Converts a BitSet to an array.
- toArray(Collection) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Converts a collection of boxed primitives into an array of primitives.
- toArray(List<Integer>) - Static method in class org.apache.calcite.util.IntList
-
Deprecated.Use
Ints.toArray(java.util.Collection)
- toArray(T[]) - Method in class org.apache.calcite.runtime.ConsList
- toArray(T[]) - Method in class org.apache.calcite.sql.SqlNodeList
- toArray(T[]) - Method in class org.apache.calcite.util.ImmutableIntList
- toArray(T2[]) - Method in class org.apache.calcite.runtime.FlatLists.Flat1List
- toArray(T2[]) - Method in class org.apache.calcite.runtime.FlatLists.Flat2List
- toArray(T2[]) - Method in class org.apache.calcite.runtime.FlatLists.Flat3List
- toArray(T2[]) - Method in class org.apache.calcite.runtime.FlatLists.Flat4List
- toArray(T2[]) - Method in class org.apache.calcite.runtime.FlatLists.Flat5List
- toArray(T2[]) - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- toArray2(Collection<Number>) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Converts a collection of
Number
to a primitive array. - toAutomaton() - Method in class org.apache.calcite.runtime.Pattern.AbstractPattern
- toAutomaton() - Method in interface org.apache.calcite.runtime.Pattern
- toBase32(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL TO_BASE32(string) function.
- toBase32(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL TO_BASE32(string) function for binary string.
- toBase64(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL TO_BASE64(string) function.
- toBase64(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL TO_BASE64(string) function for binary string.
- toBigDecimal(Number) - Static method in class org.apache.calcite.util.NumberUtil
-
Converts a number to a BigDecimal with the same value; returns null if and only if the number is null.
- toBigDecimal(Number) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toBigDecimal(Number, int) - Static method in class org.apache.calcite.util.NumberUtil
- toBigDecimal(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toBigDecimal(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toBindable(Map<String, Object>, CalcitePrepare.SparkHandler, EnumerableRel, EnumerableRel.Prefer) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableInterpretable
- toBitSet() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns a
BitSet
that has the same contents as thisImmutableBitSet
. - toBitString() - Method in class org.apache.calcite.util.BitString
-
Returns this bit string as a bit string, such as "10110".
- toBlock() - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Returns a block consisting of the current list of statements.
- toBlock(Node) - Static method in class org.apache.calcite.linq4j.tree.Blocks
- toBoolean() - Method in enum org.apache.calcite.rex.RexUnknownAs
- toBoolean(String) - Static method in class org.apache.calcite.util.ConversionUtil
-
Converts a string into a BOOLEAN.
- toBoolean(Number) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toBoolean(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toBoolean(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
CAST(VARCHAR AS BOOLEAN).
- toByte(Number) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toByte(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toByteArrayFromBitString(String, int) - Static method in class org.apache.calcite.util.BitString
-
Converts a bit string to an array of bytes.
- toByteArrayFromString(String, int) - Static method in class org.apache.calcite.util.ConversionUtil
-
Converts a string into a byte array.
- toCalendar() - Method in class org.apache.calcite.util.DateString
- toCalendar() - Method in class org.apache.calcite.util.TimestampString
- toCalendar() - Method in class org.apache.calcite.util.TimeString
- toCalendar(TimeZone) - Method in class org.apache.calcite.util.TimestampString
- toCase(String, Casing) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Converts an identifier to a particular casing.
- toChar(long, String) - Method in class org.apache.calcite.runtime.SqlFunctions.DateFormatFunction
- toChar(long, String) - Method in class org.apache.calcite.runtime.SqlFunctions.DateFormatFunctionPg
- toChar(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toCharBoxed(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toClass(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- toClassArray(Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Types
- toCnf(RexBuilder, int, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Similar to
RexUtil.toCnf(RexBuilder, RexNode)
; however, it lets you specify a threshold in the number of nodes that can be created out of the conversion. - toCnf(RexBuilder, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Converts an expression to conjunctive normal form (CNF).
- toCodePoints(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL TO_CODE_POINTS(string) function.
- toCodePoints(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL TO_CODE_POINTS(string) function for binary string.
- toCollation(List<Map<String, Object>>) - Method in class org.apache.calcite.rel.externalize.RelJson
- toDate(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.DateFormatFunction
- toDate(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.DateFormatFunctionPg
- toDateFun(int) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
-
Overloaded, in a challenging way, with
Smalls.AllTypesFunction.toDateFun(Long)
. - toDateFun(Long) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- toDistribution(Map<String, Object>) - Method in class org.apache.calcite.rel.externalize.RelJson
- toDnf(RexBuilder, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Converts an expression to disjunctive normal form (DNF).
- todo() - Static method in class org.apache.calcite.linq4j.Extensions
- TODO - Static variable in class org.apache.calcite.test.SqlOperatorTest
- TODO_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Use this to flag temporary code.
- toDot() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- toDouble(Double) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- toDouble(Float) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- toDouble(Number) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toDouble(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toDouble(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toDouble(BigDecimal) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
-
For overloaded user-defined functions that have
double
andBigDecimal
arguments will go wrong. - toDruidColumn(RexNode, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Converts a
RexNode
to a Druid column. - toDruidExpression(RexNode, RelDataType, DruidQuery) - Method in class org.apache.calcite.adapter.druid.BinaryOperatorConversion
- toDruidExpression(RexNode, RelDataType, DruidQuery) - Method in class org.apache.calcite.adapter.druid.CeilOperatorConversion
- toDruidExpression(RexNode, RelDataType, DruidQuery) - Method in class org.apache.calcite.adapter.druid.DirectOperatorConversion
- toDruidExpression(RexNode, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
-
Translates a Calcite
RexNode
to a Druid expression, if possible; returns null if not possible. - toDruidExpression(RexNode, RelDataType, DruidQuery) - Method in class org.apache.calcite.adapter.druid.DruidSqlCastConverter
- toDruidExpression(RexNode, RelDataType, DruidQuery) - Method in interface org.apache.calcite.adapter.druid.DruidSqlOperatorConverter
-
Translate rexNode to valid Druid expression.
- toDruidExpression(RexNode, RelDataType, DruidQuery) - Method in class org.apache.calcite.adapter.druid.ExtractOperatorConversion
- toDruidExpression(RexNode, RelDataType, DruidQuery) - Method in class org.apache.calcite.adapter.druid.FloorOperatorConversion
- toDruidExpression(RexNode, RelDataType, DruidQuery) - Method in class org.apache.calcite.adapter.druid.NaryOperatorConverter
- toDruidExpression(RexNode, RelDataType, DruidQuery) - Method in class org.apache.calcite.adapter.druid.SubstringOperatorConversion
- toDruidExpression(RexNode, RelDataType, DruidQuery) - Method in class org.apache.calcite.adapter.druid.UnaryPrefixOperatorConversion
- toDruidExpression(RexNode, RelDataType, DruidQuery) - Method in class org.apache.calcite.adapter.druid.UnarySuffixOperatorConversion
- toDruidExpressions(DruidQuery, RelDataType, List<RexNode>) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
-
Translate a list of Calcite
RexNode
to Druid expressions. - toDruidGranularity(TimeUnitRange) - Static method in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
-
Translates a Calcite
TimeUnitRange
to a DruidGranularity
. - toExternal(List<RelDataType>, TimeZone) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
-
Returns a function that converts an array of internal values to a list of external values.
- toExternal(RelDataType, TimeZone) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
-
Returns a function that converts an internal value to an external value.
- toFieldCollation(Map<String, Object>) - Method in class org.apache.calcite.rel.externalize.RelJson
- ToFieldIndex() - Constructor for class org.apache.calcite.rel.type.RelDataTypeField.ToFieldIndex
-
Deprecated.
- ToFieldName() - Constructor for class org.apache.calcite.rel.type.RelDataTypeField.ToFieldName
-
Deprecated.
- toFloat(Number) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toFloat(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toFloat(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toFormattedString() - Method in class org.apache.calcite.sql.SqlAbstractDateTimeLiteral
-
Returns e.g.
- toFormattedString() - Method in class org.apache.calcite.sql.SqlDateLiteral
-
Returns e.g.
- toFormattedString() - Method in class org.apache.calcite.sql.SqlTimeLiteral
-
Returns e.g.
- toFormattedString() - Method in class org.apache.calcite.sql.SqlTimestampLiteral
-
Returns e.g.
- toFormattedString() - Method in class org.apache.calcite.sql.SqlTimestampTzLiteral
- toFormattedString() - Method in class org.apache.calcite.sql.SqlTimeTzLiteral
-
Returns e.g.
- toFunctionBlock(Node) - Static method in class org.apache.calcite.linq4j.tree.Blocks
- toHex(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL TO_HEX(binary) function.
- toHexString() - Method in class org.apache.calcite.util.BitString
-
Converts this bit string to a hex string, such as "7AB".
- toIdentifier() - Method in class org.apache.calcite.sql.validate.SqlIdentifierMoniker
- toIdentifier() - Method in interface org.apache.calcite.sql.validate.SqlMoniker
-
Creates a
SqlIdentifier
containing the fully-qualified name. - toIdentifier() - Method in class org.apache.calcite.sql.validate.SqlMonikerImpl
- toImmutableBitSet() - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Creates a Collector.
- toImmutableList() - Static method in class org.apache.calcite.util.Util
-
Deprecated.Use
ImmutableList.toImmutableList()
- toImmutableMap() - Method in interface org.apache.calcite.runtime.PairList
-
Creates an
ImmutableMap
whose entries are the pairs in this list. - toIndex(double, double) - Method in class org.apache.calcite.runtime.HilbertCurve2D
- toIndex(double, double) - Method in interface org.apache.calcite.runtime.SpaceFillingCurve2D
- toInt(Number) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toInt(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toInt(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toInt(Date) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a SQL DATE value from the Java type (
Date
) to the internal representation type (number of days since January 1st, 1970 asint
) in the local time zone. - toInt(Date, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a SQL DATE value from the Java type (
Date
) to the internal representation type (number of days since January 1st, 1970 asint
). - toInt(Time) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a SQL TIME value from the Java type (
Time
) to the internal representation type (number of milliseconds since January 1st, 1970 asint
) in the local time zone. - toIntArray() - Method in class org.apache.calcite.util.ImmutableIntList
-
Returns an array of
int
s with the same contents as this list. - toIntArray() - Method in class org.apache.calcite.util.IntList
-
Deprecated.
- toIntegerList() - Method in class org.apache.calcite.util.ImmutableIntList
-
Returns a List of
Integer
. - toInterval(List<Range<Long>>) - Static method in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
- toIntOptional(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toIntOptional(Date) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toIntOptional(Date, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toIntOptional(Time) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toISOPeriodFormat(Granularity.Type) - Static method in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
-
Converts a granularity to ISO period format.
- toIter(BitSet) - Static method in class org.apache.calcite.util.BitSets
-
Returns an iterable over the bits in a bitmap that are set to '1'.
- toIter(ImmutableBitSet) - Static method in class org.apache.calcite.util.BitSets
- toJavaId(String, int) - Static method in class org.apache.calcite.util.Util
-
Converts an arbitrary string into a string suitable for use as a Java identifier.
- toJavaString(String) - Static method in class org.apache.calcite.util.TestUtil
-
Converts a string (which may contain quotes and newlines) into a java literal.
- toJson(Range<C>) - Method in class org.apache.calcite.rel.externalize.RelJson
-
Serializes a
Range
that can be deserialized usingRelJson.rangeFromJson(List)
. - toJson(RangeSet<C>) - Method in class org.apache.calcite.rel.externalize.RelJson
- toJson(Object) - Method in class org.apache.calcite.rel.externalize.RelJson
- toJson(AggregateCall) - Method in class org.apache.calcite.rel.externalize.RelJson
- toJson(RelCollationImpl) - Method in class org.apache.calcite.rel.externalize.RelJson
- toJson(RexNode) - Method in class org.apache.calcite.rel.externalize.RelJson
- toJson(Sarg<C>) - Method in class org.apache.calcite.rel.externalize.RelJson
- toJsonString(Object) - Method in class org.apache.calcite.util.JsonBuilder
-
Serializes an object consisting of maps, lists and atoms into a JSON string.
- tokenize(String, String) - Static method in class org.apache.calcite.util.Util
-
Converts a string into tokens.
- Tokenizer(String, String) - Constructor for class org.apache.calcite.sql.advise.SqlSimpleParser.Tokenizer
-
Deprecated.
- Tokenizer(String, String, Quoting) - Constructor for class org.apache.calcite.sql.advise.SqlSimpleParser.Tokenizer
- toLeafJoinForm(RelNode) - Static method in class org.apache.calcite.plan.RelOptMaterialization
-
Converts a relational expression to a form where
LogicalJoin
s are as close to leaves as possible. - toLinux(String) - Static method in class org.apache.calcite.util.Util
- toList() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- toList() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Creates a
List<TSource>
from anEnumerable<TSource>
. - toList() - Method in class org.apache.calcite.runtime.ConsList
- toList() - Method in class org.apache.calcite.runtime.FlatLists.AbstractFlatList
- toList() - Static method in class org.apache.calcite.sql.SqlNode
-
Returns a
Collector
that accumulates the input elements into aSqlNodeList
, with zero position. - toList() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Converts this bit set to a list.
- toList(BitSet) - Static method in class org.apache.calcite.util.BitSets
-
Converts a bitset to a list.
- toList(Iterator<T>) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- toList(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Creates a
List<TSource>
from anEnumerable<TSource>
. - toList(SqlParserPos) - Static method in class org.apache.calcite.sql.SqlNode
-
Returns a
Collector
that accumulates the input elements into aSqlNodeList
. - ToLogicalConverter - Class in org.apache.calcite.rel.logical
-
Shuttle to convert any rel plan to a plan with all logical nodes.
- ToLogicalConverter(RelBuilder) - Constructor for class org.apache.calcite.rel.logical.ToLogicalConverter
- toLong(Number) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toLong(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toLong(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toLong(Date) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
-
Overloaded functions with DATE, TIMESTAMP and TIME arguments.
- toLong(Time) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- toLong(Timestamp) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a SQL TIMESTAMP value from the Java type (
Timestamp
) to the internal representation type (number of milliseconds since January 1st, 1970 aslong
). - toLong(Timestamp) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- toLong(Timestamp, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a SQL TIMESTAMP value from the Java type (
Timestamp
) to the internal representation type (number of milliseconds since January 1st, 1970 aslong
). - toLong(Date) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a SQL TIMESTAMP value from the Java type (
Date
) to the internal representation type (number of milliseconds since January 1st, 1970 aslong
). - toLongArray() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Converts this bit set to an array of little-endian words.
- toLongOptional(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toLongOptional(Timestamp) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toLongOptional(Timestamp, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toLookup(Enumerable<TSource>, Function1<TSource, TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Creates a Lookup<TKey, TElement> from an Enumerable<TSource> according to a specified key selector function.
- toLookup(Enumerable<TSource>, Function1<TSource, TKey>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Creates a
Lookup<TKey, TElement>
from anEnumerable<TSource>
according to a specified key selector function and key comparer. - toLookup(Enumerable<TSource>, Function1<TSource, TKey>, Function1<TSource, TElement>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Creates a
Lookup<TKey, TElement>
from anEnumerable<TSource>
according to specified key selector and element selector functions. - toLookup(Enumerable<TSource>, Function1<TSource, TKey>, Function1<TSource, TElement>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Creates a
Lookup<TKey, TElement>
from anEnumerable<TSource>
according to a specified key selector function, a comparer and an element selector function. - toLookup(Function1<T, TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- toLookup(Function1<T, TKey>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- toLookup(Function1<T, TKey>, Function1<T, TElement>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- toLookup(Function1<T, TKey>, Function1<T, TElement>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- toLookup(Function1<TSource, TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Creates a
Lookup<TKey, TElement>
from anEnumerable<TSource>
according to a specified key selector function. - toLookup(Function1<TSource, TKey>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Creates a
Lookup<TKey, TElement>
from anEnumerable<TSource>
according to a specified key selector function and key comparer. - toLookup(Function1<TSource, TKey>, Function1<TSource, TElement>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Creates a
Lookup<TKey, TElement>
from anEnumerable<TSource>
according to specified key selector and element selector functions. - toLookup(Function1<TSource, TKey>, Function1<TSource, TElement>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Creates a
Lookup<TKey, TElement>
from anEnumerable<TSource>
according to a specified key selector function, a comparer and an element selector function. - toMap(Iterable<? extends Pair<? extends K, ? extends V>>) - Static method in class org.apache.calcite.util.Pair
-
Converts a collection of Pairs into a Map.
- toMap(Properties) - Static method in class org.apache.calcite.util.Util
-
Converts a
Properties
object to a
.Map
<String, String> - toMap(Enumerable<TSource>, Function1<TSource, TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Creates a Map<TKey, TValue> from an Enumerable<TSource> according to a specified key selector function.
- toMap(Enumerable<TSource>, Function1<TSource, TKey>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Creates a
Map<TKey, TValue>
from anEnumerable<TSource>
according to a specified key selector function and key comparer. - toMap(Enumerable<TSource>, Function1<TSource, TKey>, Function1<TSource, TElement>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Creates a
Map<TKey, TValue>
from anEnumerable<TSource>
according to specified key selector and element selector functions. - toMap(Enumerable<TSource>, Function1<TSource, TKey>, Function1<TSource, TElement>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Creates a
Map<TKey, TValue>
from anEnumerable<TSource>
according to a specified key selector function, a comparer, and an element selector function. - toMap(Function1<T, TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- toMap(Function1<T, TKey>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- toMap(Function1<T, TKey>, Function1<T, TElement>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- toMap(Function1<T, TKey>, Function1<T, TElement>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- toMap(Function1<TSource, TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Creates a
Map<TKey, TValue>
from anEnumerable<TSource>
according to a specified key selector function. - toMap(Function1<TSource, TKey>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Creates a
Map<TKey, TValue>
from anEnumerable<TSource>
according to a specified key selector function and key comparer. - toMap(Function1<TSource, TKey>, Function1<TSource, TElement>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Creates a
Map<TKey, TValue>
from anEnumerable<TSource>
according to specified key selector and element selector functions. - toMap(Function1<TSource, TKey>, Function1<TSource, TElement>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Creates a
Map<TKey, TValue>
from anEnumerable<TSource>
according to a specified key selector function, a comparer, and an element selector function. - toMap(JsonBuilder) - Method in class org.apache.calcite.profile.Profiler.Distribution
- toMap(JsonBuilder) - Method in class org.apache.calcite.profile.Profiler.FunctionalDependency
- toMap(JsonBuilder) - Method in class org.apache.calcite.profile.Profiler.RowCount
- toMap(JsonBuilder) - Method in interface org.apache.calcite.profile.Profiler.Statistic
- toMap(JsonBuilder) - Method in class org.apache.calcite.profile.Profiler.Unique
- toMeasures(List<AggregateCall>) - Method in class org.apache.calcite.materialize.Lattice
- toModificationRel(RelOptCluster, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean) - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- toModificationRel(RelOptCluster, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean) - Method in class org.apache.calcite.schema.impl.ListTransientTable
- toModificationRel(RelOptCluster, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean) - Method in interface org.apache.calcite.schema.ModifiableTable
-
Creates a relational expression that modifies this table.
- toModificationRel(RelOptCluster, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean) - Method in class org.apache.calcite.test.AbstractModifiableTable
- toMutable(RelNode) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- toNodeArray(List<SqlNode>) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- toNodeArray(SqlNodeList) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- toNodeList(SqlNode[]) - Static method in class org.apache.calcite.sql.SqlUtil
-
Converts a SqlNode array to a SqlNodeList.
- took() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult
- tooLong(String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- TooManyElementsException() - Constructor for exception class org.apache.calcite.util.mapping.Mappings.TooManyElementsException
- TOP_DOWN - Enum constant in enum org.apache.calcite.plan.hep.HepMatchOrder
-
Match from root down.
- TOP_LEVEL - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of all SQL statement types.
- TOP_N - Enum constant in enum org.apache.calcite.adapter.druid.QueryType
- toPattern(StringBuilder) - Method in interface org.apache.calcite.util.format.FormatElement
-
Adds the appropriate
SimpleDateFormat
pattern for the element to provided StringBuilder. - toPattern(StringBuilder) - Method in enum org.apache.calcite.util.format.FormatElementEnum
- TOPDOWN_OPT - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether to enable top-down optimization in Volcano planner.
- TOPDOWN_OPT - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether to enable top-down optimization.
- topDownOpt() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.TOPDOWN_OPT
. - topDownOpt() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- topN(SqlNode, SqlNode) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- topN(SqlNode, SqlNode) - Method in interface org.apache.calcite.sql.SqlWriter
-
Prints the TOP(n) clause.
- TopNTableFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.TopNTableFunction
- toPoint(long) - Method in class org.apache.calcite.runtime.HilbertCurve2D
- toPoint(long) - Method in interface org.apache.calcite.runtime.SpaceFillingCurve2D
- TopologicalOrderIterator<V,
E extends DefaultEdge> - Class in org.apache.calcite.util.graph -
Iterates over the edges of a graph in topological order.
- TopologicalOrderIterator(DirectedGraph<V, E>) - Constructor for class org.apache.calcite.util.graph.TopologicalOrderIterator
- toPosix(TimeZone, boolean) - Static method in class org.apache.calcite.util.Util
-
Converts a Java timezone to POSIX format, so that the boost C++ library can instantiate timezone objects.
- toPredicate(Function2<T1, T2, Boolean>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Converts a 2-parameter function to a predicate.
- toPredicate2(Predicate1<T1>) - Static method in class org.apache.calcite.linq4j.function.Functions
- topSplit(RexBuilder, SqlSplittableAggFunction.Registry<RexNode>, int, RelDataType, AggregateCall, int, int) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.AbstractSumSplitter
- topSplit(RexBuilder, SqlSplittableAggFunction.Registry<RexNode>, int, RelDataType, AggregateCall, int, int) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.CountSplitter
- topSplit(RexBuilder, SqlSplittableAggFunction.Registry<RexNode>, int, RelDataType, AggregateCall, int, int) - Method in class org.apache.calcite.sql.SqlSplittableAggFunction.SelfSplitter
- topSplit(RexBuilder, SqlSplittableAggFunction.Registry<RexNode>, int, RelDataType, AggregateCall, int, int) - Method in interface org.apache.calcite.sql.SqlSplittableAggFunction
-
Generates an aggregate call to merge sub-totals.
- toQueryGranularity(DimensionSpec) - Static method in class org.apache.calcite.adapter.druid.ExtractionDimensionSpec
-
Returns a valid
Granularity
of floor extract, or null when not possible. - toRanges(double, double, double, double, SpaceFillingCurve2D.RangeComputeHints) - Method in class org.apache.calcite.runtime.HilbertCurve2D
- toRanges(double, double, double, double, SpaceFillingCurve2D.RangeComputeHints) - Method in interface org.apache.calcite.runtime.SpaceFillingCurve2D
- toRel() - Method in class org.apache.calcite.test.RelMetadataFixture
-
Creates a
RelNode
from this fixture's supplier (seeRelMetadataFixture.withSql(String)
andRelMetadataFixture.withRelFn(Function)
). - toRel() - Method in class org.apache.calcite.test.RelOptFixture
- toRel() - Method in class org.apache.calcite.test.SqlToRelFixture
- toRel(RelOptTable.ToRelContext) - Method in class org.apache.calcite.plan.RelOptAbstractTable
- toRel(RelOptTable.ToRelContext) - Method in interface org.apache.calcite.plan.RelOptTable
-
Converts this table into a
relational expression
. - toRel(RelOptTable.ToRelContext) - Method in class org.apache.calcite.prepare.RelOptTableImpl
- toRel(RelOptTable.ToRelContext) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockRelViewTable
- toRel(RelOptTable.ToRelContext) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- toRel(RelOptTable.ToRelContext) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.adapter.arrow.ArrowTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.adapter.csv.CsvTranslatableTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.adapter.druid.DruidTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.adapter.file.CsvTranslatableTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.adapter.geode.rel.GeodeTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.adapter.innodb.InnodbTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.adapter.mongodb.MongoTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.adapter.pig.PigTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.schema.impl.MaterializedViewTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.schema.impl.StarTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.schema.impl.ViewTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in interface org.apache.calcite.schema.TranslatableTable
-
Converts this table into a
relational expression
. - toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockDynamicTable
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.util.Smalls.SimpleTable
- toRel(RelOptTable, List<RelHint>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- toRelContext(RelOptTable.ViewExpander, RelOptCluster) - Static method in class org.apache.calcite.plan.ViewExpanders
-
Converts a
ViewExpander
to aToRelContext
. - toRelContext(RelOptTable.ViewExpander, RelOptCluster, List<RelHint>) - Static method in class org.apache.calcite.plan.ViewExpanders
-
Converts a
ViewExpander
to aToRelContext
. - toRex() - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Converts this expression to a
RexNode
. - toRex(LatticeTable, int) - Method in class org.apache.calcite.materialize.LatticeSuggester
-
Converts a column reference to an expression.
- toRex(RelOptCluster, Object) - Method in class org.apache.calcite.rel.externalize.RelJson
-
Translates a JSON expression into a RexNode.
- toRoot() - Method in class org.apache.calcite.test.SqlToRelFixture
- toRow(Supplier<Enumerable<Object[]>>) - Static method in class org.apache.calcite.runtime.Enumerables
-
Deprecated.
- toRow(Supplier<Enumerable<Object[]>>) - Static method in class org.apache.calcite.runtime.Enumerables
-
Converts a supplier of an
Enumerable
over object arrays into a supplier of anEnumerable
overRow
objects. - toRow(Enumerable<Object[]>) - Static method in class org.apache.calcite.runtime.Enumerables
- toRow(ConsumerRecord<byte[], byte[]>) - Method in class org.apache.calcite.adapter.kafka.KafkaRowConverterImpl
-
Parses and reformats a Kafka message from the consumer, to align with the row schema defined as
KafkaRowConverterImpl.rowDataType(String)
. - toRow(ConsumerRecord<K, V>) - Method in interface org.apache.calcite.adapter.kafka.KafkaRowConverter
-
Parses and reformats a Kafka message from the consumer, to align with row type defined as
KafkaRowConverter.rowDataType(String)
. - toRule() - Method in interface org.apache.calcite.adapter.arrow.ArrowRules.ArrowFilterRule.Config
- toRule() - Method in interface org.apache.calcite.adapter.cassandra.CassandraRules.CassandraFilterRule.CassandraFilterRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.cassandra.CassandraRules.CassandraLimitRule.CassandraLimitRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.cassandra.CassandraRules.CassandraSortRule.CassandraSortRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.csv.CsvProjectTableScanRule.Config
- toRule() - Method in interface org.apache.calcite.adapter.druid.DruidRules.DruidAggregateProjectRule.DruidAggregateProjectRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.druid.DruidRules.DruidAggregateRule.DruidAggregateRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.druid.DruidRules.DruidFilterRule.DruidFilterRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.druid.DruidRules.DruidHavingFilterRule.DruidHavingFilterRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.druid.DruidRules.DruidPostAggregationProjectRule.DruidPostAggregationProjectRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.druid.DruidRules.DruidProjectRule.DruidProjectRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.druid.DruidRules.DruidSortRule.DruidSortRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoinRule.Config
- toRule() - Method in interface org.apache.calcite.adapter.enumerable.EnumerableFilterToCalcRule.Config
- toRule() - Method in interface org.apache.calcite.adapter.enumerable.EnumerableLimitRule.Config
- toRule() - Method in interface org.apache.calcite.adapter.enumerable.EnumerableLimitSortRule.Config
- toRule() - Method in interface org.apache.calcite.adapter.enumerable.EnumerableMergeUnionRule.Config
- toRule() - Method in interface org.apache.calcite.adapter.enumerable.EnumerableProjectToCalcRule.Config
- toRule() - Method in interface org.apache.calcite.adapter.file.CsvProjectTableScanRule.Config
- toRule() - Method in interface org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeFilterRule.GeodeFilterRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeSortLimitRule.GeodeSortLimitRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.innodb.InnodbRules.InnodbFilterRule.InnodbFilterRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.innodb.InnodbRules.InnodbSortFilterRule.InnodbSortFilterRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.innodb.InnodbRules.InnodbSortTableScanRule.InnodbSortTableScanRuleConfig
- toRule() - Method in interface org.apache.calcite.adapter.splunk.SplunkPushDownRule.Config
- toRule() - Method in interface org.apache.calcite.interpreter.Bindables.BindableTableScanRule.Config
- toRule() - Method in interface org.apache.calcite.piglet.PigToSqlAggregateRule.Config
- toRule() - Method in interface org.apache.calcite.plan.RelRule.Config
-
Creates a rule that uses this configuration.
- toRule() - Method in interface org.apache.calcite.plan.volcano.AbstractConverter.ExpandConversionRule.Config
- toRule() - Method in interface org.apache.calcite.rel.convert.ConverterRule.Config
- toRule() - Method in interface org.apache.calcite.rel.convert.TraitMatchingRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateCaseToFilterRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateExpandWithinDistinctRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateExtractProjectRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateFilterTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateJoinJoinRemoveRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateJoinRemoveRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateJoinTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateMergeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateProjectConstantToDummyJoinRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateProjectMergeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateProjectPullUpConstantsRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateProjectStarTableRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateReduceFunctionsRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateRemoveRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateStarTableRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateUnionAggregateRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateUnionTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.AggregateValuesRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.CalcMergeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.CalcRemoveRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.CalcSplitRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.CoerceInputsRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.DateRangeRules.FilterDateRangeRule.FilterDateRangeRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.ExchangeRemoveConstantKeysRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterAggregateTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterCalcMergeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterCorrelateRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterFlattenCorrelatedConditionRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterJoinRule.FilterIntoJoinRule.FilterIntoJoinRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterJoinRule.JoinConditionPushRule.JoinConditionPushRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterMergeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterMultiJoinMergeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterProjectTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterRemoveIsNotDistinctFromRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterSampleTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterSetOpTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterTableFunctionTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterTableScanRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterToCalcRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.FilterWindowTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.IntersectToDistinctRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.JoinAddRedundantSemiJoinRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.JoinAssociateRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.JoinCommuteRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.JoinDeriveIsNotNullFilterRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.JoinExtractFilterRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.JoinProjectTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.JoinPushExpressionsRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.JoinPushThroughJoinRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.JoinPushTransitivePredicatesRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.JoinToCorrelateRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.JoinToMultiJoinRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.JoinUnionTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.LoptOptimizeJoinRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.MatchRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewOnlyAggregateRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewOnlyFilterRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewOnlyJoinRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewProjectAggregateRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewProjectFilterRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewProjectJoinRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.MaterializedViewFilterScanRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.MeasureRules.AggregateMeasure2RuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.MeasureRules.AggregateMeasureRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.MeasureRules.FilterSortMeasureRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.MeasureRules.ProjectMeasureRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.MeasureRules.ProjectSortMeasureRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.MinusToDistinctRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectAggregateMergeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectCalcMergeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectFilterTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectJoinJoinRemoveRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectJoinRemoveRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectJoinTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectMergeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectMultiJoinMergeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectOverSumToSum0Rule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectRemoveRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectSetOpTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectTableScanRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectToCalcRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectToWindowRule.CalcToWindowRule.CalcToWindowRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectToWindowRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectToWindowRule.ProjectToLogicalProjectAndWindowRule.ProjectToLogicalProjectAndWindowRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.ProjectWindowTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.PruneEmptyRules.CorrelateLeftEmptyRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.PruneEmptyRules.CorrelateRightEmptyRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.PruneEmptyRules.IntersectEmptyPruneRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.PruneEmptyRules.JoinLeftEmptyRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.PruneEmptyRules.JoinRightEmptyRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.PruneEmptyRules.MinusEmptyPruneRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.PruneEmptyRules.PruneEmptyRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.PruneEmptyRules.RemoveEmptySingleRule.RemoveEmptySingleRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.PruneEmptyRules.SortFetchZeroRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.PruneEmptyRules.UnionEmptyPruneRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.PruneEmptyRules.ZeroMaxRowsRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.ReduceDecimalsRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.CalcReduceExpressionsRule.CalcReduceExpressionsRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.FilterReduceExpressionsRule.FilterReduceExpressionsRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.JoinReduceExpressionsRule.JoinReduceExpressionsRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.ProjectReduceExpressionsRule.ProjectReduceExpressionsRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.WindowReduceExpressionsRule.WindowReduceExpressionsRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.SampleToFilterRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SemiJoinFilterTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SemiJoinJoinTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SemiJoinProjectTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SemiJoinRemoveRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SemiJoinRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SemiJoinRule.JoinOnUniqueToSemiJoinRule.JoinOnUniqueToSemiJoinRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.SemiJoinRule.JoinToSemiJoinRule.JoinToSemiJoinRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.SemiJoinRule.ProjectToSemiJoinRule.ProjectToSemiJoinRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.rules.SingleValuesOptimizationRules.PruneSingleValueRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SortJoinCopyRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SortJoinTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SortMergeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SortProjectTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SortRemoveConstantKeysRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SortRemoveRedundantRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SortRemoveRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SortUnionTransposeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SpatialRules.FilterHilbertRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.SubQueryRemoveRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.TableScanRule.Config
-
Deprecated.
- toRule() - Method in interface org.apache.calcite.rel.rules.UnionEliminatorRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.UnionMergeRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.UnionPullUpConstantsRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.UnionToDistinctRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.UnionToValuesRule.Config
- toRule() - Method in interface org.apache.calcite.rel.rules.ValuesReduceRule.Config
- toRule() - Method in interface org.apache.calcite.rel.stream.StreamRules.DeltaAggregateTransposeRule.DeltaAggregateTransposeRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.stream.StreamRules.DeltaFilterTransposeRule.DeltaFilterTransposeRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.stream.StreamRules.DeltaJoinTransposeRule.DeltaJoinTransposeRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.stream.StreamRules.DeltaProjectTransposeRule.DeltaProjectTransposeRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.stream.StreamRules.DeltaSortTransposeRule.DeltaSortTransposeRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.stream.StreamRules.DeltaTableScanRule.DeltaTableScanRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.stream.StreamRules.DeltaTableScanToEmptyRule.DeltaTableScanToEmptyRuleConfig
- toRule() - Method in interface org.apache.calcite.rel.stream.StreamRules.DeltaUnionTransposeRule.DeltaUnionTransposeRuleConfig
- toRule() - Method in interface org.apache.calcite.sql2rel.RelDecorrelator.AdjustProjectForCountAggregateRule.AdjustProjectForCountAggregateRuleConfig
- toRule() - Method in interface org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationForScalarAggregateRule.RemoveCorrelationForScalarAggregateRuleConfig
- toRule() - Method in interface org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationForScalarProjectRule.RemoveCorrelationForScalarProjectRuleConfig
- toRule() - Method in interface org.apache.calcite.sql2rel.RelDecorrelator.RemoveSingleAggregateRule.RemoveSingleAggregateRuleConfig
- toRule(Class<R>) - Method in interface org.apache.calcite.rel.convert.ConverterRule.Config
- toScientificNotation(Double) - Static method in class org.apache.calcite.util.Util
-
Formats a double value to a String ensuring that the output is in scientific notation if the value is not "special".
- toScientificNotation(BigDecimal) - Static method in class org.apache.calcite.util.Util
-
Formats a
BigDecimal
value to a string in scientific notation For example
A value of 0.00001234 would be formated as1.234E-5
A value of 100000.00 would be formated as1.00E5
A value of 100 (scale zero) would be formated as1E2
- toShort(Number) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toShort(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toShort(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toSql(boolean) - Method in class org.apache.calcite.test.SqlValidatorFixture
- toSql(Lattice.SqlWriter) - Method in class org.apache.calcite.materialize.Lattice.BaseColumn
- toSql(Lattice.SqlWriter) - Method in class org.apache.calcite.materialize.Lattice.Column
- toSql(Lattice.SqlWriter) - Method in class org.apache.calcite.materialize.Lattice.DerivedColumn
- toSql(AggregateCall) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
-
Converts a call to an aggregate function to an expression.
- toSql(Window.Group, ImmutableList<RexLiteral>, int) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- toSql(RelFieldCollation) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
-
Converts a collation to an ORDER BY item.
- toSql(RelNode, SqlDialect) - Method in class org.apache.calcite.statistic.QuerySqlStatisticProvider
- toSql(RelDataType) - Method in interface org.apache.calcite.adapter.java.JavaTypeFactory
-
Converts a type in Java format to a SQL-oriented type.
- toSql(RelDataType) - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl
- toSql(RelDataTypeFactory, RelDataType) - Static method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl
-
Converts a type in Java format to a SQL-oriented type.
- toSql(RexProgram, RexLiteral) - Static method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- toSql(RexProgram, RexNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- toSql(RexProgram, RexNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.MatchRecognizeContext
- toSql(RexLiteral) - Static method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Converts a
RexLiteral
to aSqlLiteral
. - toSql(RexWindowBound) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
-
Converts an expression from
RexWindowBound
toSqlNode
format. - toSql(RexWindowExclusion) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- toSqlString() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- toSqlString() - Method in interface org.apache.calcite.sql.SqlWriter
-
Returns the contents of this writer as a 'certified kocher' SQL string.
- toSqlString() - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Returns the contents of this SQL buffer as a 'certified kocher' SQL string.
- toSqlString(UnaryOperator<SqlWriterConfig>) - Method in class org.apache.calcite.sql.SqlAsofJoin
- toSqlString(UnaryOperator<SqlWriterConfig>) - Method in class org.apache.calcite.sql.SqlJoin
- toSqlString(UnaryOperator<SqlWriterConfig>) - Method in class org.apache.calcite.sql.SqlNode
-
Returns the SQL text of the tree of which this
SqlNode
is the root. - toSqlString(SqlDialect) - Method in class org.apache.calcite.sql.SqlNode
- toSqlString(SqlDialect, boolean) - Method in class org.apache.calcite.sql.SqlNode
-
Returns the SQL text of the tree of which this
SqlNode
is the root. - toStar(List<String>) - Static method in class org.apache.calcite.sql.SqlIdentifier
-
Converts empty strings in a list of names to stars.
- toString() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable
- toString() - Method in class org.apache.calcite.adapter.csv.CsvFilterableTable
- toString() - Method in class org.apache.calcite.adapter.csv.CsvScannableTable
- toString() - Method in class org.apache.calcite.adapter.csv.CsvStreamScannableTable
- toString() - Method in class org.apache.calcite.adapter.csv.CsvTranslatableTable
- toString() - Method in class org.apache.calcite.adapter.druid.DruidQuery.QuerySpec
- toString() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
- toString() - Method in class org.apache.calcite.adapter.enumerable.AggImpState
- toString() - Method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- toString() - Method in class org.apache.calcite.adapter.file.CsvTranslatableTable
- toString() - Method in class org.apache.calcite.adapter.file.JsonScannableTable
- toString() - Method in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- toString() - Method in class org.apache.calcite.adapter.geode.rel.GeodeTable
- toString() - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleScannableTable
- toString() - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- toString() - Method in class org.apache.calcite.adapter.innodb.InnodbTable
- toString() - Method in class org.apache.calcite.adapter.java.ReflectiveSchema
- toString() - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- toString() - Method in class org.apache.calcite.adapter.mongodb.MongoTable
- toString() - Method in class org.apache.calcite.adapter.splunk.SplunkQuery
- toString() - Method in enum org.apache.calcite.interpreter.BindableConvention
- toString() - Method in enum org.apache.calcite.interpreter.InterpretableConvention
- toString() - Method in class org.apache.calcite.interpreter.Row
- toString() - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl.SyntheticRecordType
- toString() - Method in class org.apache.calcite.linq4j.MemoryFactory.Memory
- toString() - Method in class org.apache.calcite.linq4j.QueryProviderImpl.QueryableImpl
- toString() - Method in class org.apache.calcite.linq4j.tree.AbstractNode
- toString() - Method in class org.apache.calcite.materialize.Lattice.BaseColumn
- toString() - Method in class org.apache.calcite.materialize.Lattice.DerivedColumn
- toString() - Method in class org.apache.calcite.materialize.Lattice.Measure
- toString() - Method in class org.apache.calcite.materialize.Lattice
- toString() - Method in class org.apache.calcite.materialize.LatticeNode
- toString() - Method in class org.apache.calcite.materialize.LatticeTable
- toString() - Method in class org.apache.calcite.materialize.MaterializationKey
- toString() - Method in class org.apache.calcite.materialize.TileKey
- toString() - Method in class org.apache.calcite.model.JsonCustomSchema
- toString() - Method in class org.apache.calcite.model.JsonLattice
- toString() - Method in class org.apache.calcite.model.JsonMaterialization
- toString() - Method in class org.apache.calcite.model.JsonView
- toString() - Method in class org.apache.calcite.plan.Convention.Impl
- toString() - Method in interface org.apache.calcite.plan.RelOptCost
-
Forces implementations to override
Object.toString()
and provide a good cost rendering to use during tracing. - toString() - Method in class org.apache.calcite.plan.RelOptCostImpl
- toString() - Method in class org.apache.calcite.plan.RelOptPredicateList
- toString() - Method in class org.apache.calcite.plan.RelOptRule
-
Returns the description of this rule.
- toString() - Method in class org.apache.calcite.plan.RelOptRuleOperand
-
FOR DEBUG ONLY.
- toString() - Method in interface org.apache.calcite.plan.RelTrait
-
Returns a succinct name for this trait.
- toString() - Method in class org.apache.calcite.plan.RelTraitSet
- toString() - Method in class org.apache.calcite.prepare.RelOptTableImpl
- toString() - Method in class org.apache.calcite.profile.Profiler.Column
- toString() - Method in class org.apache.calcite.rel.AbstractRelNode
-
Description; consists of id plus digest.
- toString() - Method in class org.apache.calcite.rel.core.AggregateCall
- toString() - Method in class org.apache.calcite.rel.core.CorrelationId
- toString() - Method in class org.apache.calcite.rel.core.Window.Group
- toString() - Method in class org.apache.calcite.rel.hint.RelHint
- toString() - Method in class org.apache.calcite.rel.metadata.janino.DescriptiveCacheKey
- toString() - Method in class org.apache.calcite.rel.mutable.MutableRel
- toString() - Method in class org.apache.calcite.rel.RelCollationImpl
-
Returns a string representation of this collation, suitably terse given that it will appear in plan traces.
- toString() - Method in class org.apache.calcite.rel.RelFieldCollation
- toString() - Method in class org.apache.calcite.rel.RelReferentialConstraintImpl
- toString() - Method in class org.apache.calcite.rel.RelRoot
- toString() - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.RelType
- toString() - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule.Edge
- toString() - Method in interface org.apache.calcite.rel.type.RelDataType
-
Gets a string representation of this type without detail such as character set and nullability.
- toString() - Method in class org.apache.calcite.rel.type.RelDataTypeFieldImpl
- toString() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- toString() - Method in class org.apache.calcite.rex.RexCall
- toString() - Method in class org.apache.calcite.rex.RexFieldCollation
- toString() - Method in class org.apache.calcite.rex.RexLambda
- toString() - Method in class org.apache.calcite.rex.RexNode
- toString() - Method in class org.apache.calcite.rex.RexProgram
- toString() - Method in class org.apache.calcite.rex.RexRangeRef
- toString() - Method in class org.apache.calcite.rex.RexTableInputRef.RelTableRef
- toString() - Method in class org.apache.calcite.rex.RexWindow
- toString() - Method in enum org.apache.calcite.rex.RexWindowExclusion
- toString() - Method in class org.apache.calcite.runtime.ConsList
- toString() - Method in class org.apache.calcite.runtime.FlatLists.Flat1List
- toString() - Method in class org.apache.calcite.runtime.FlatLists.Flat2List
- toString() - Method in class org.apache.calcite.runtime.FlatLists.Flat3List
- toString() - Method in class org.apache.calcite.runtime.FlatLists.Flat4List
- toString() - Method in class org.apache.calcite.runtime.FlatLists.Flat5List
- toString() - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- toString() - Method in class org.apache.calcite.runtime.JsonFunctions.JsonPathContext
- toString() - Method in class org.apache.calcite.runtime.JsonFunctions.JsonValueContext
- toString() - Method in class org.apache.calcite.runtime.MapEntry
- toString() - Method in class org.apache.calcite.runtime.Pattern.OpPattern
- toString() - Method in class org.apache.calcite.runtime.Pattern.RepeatPattern
- toString() - Method in class org.apache.calcite.runtime.Pattern.SymbolPattern
- toString() - Method in class org.apache.calcite.runtime.SpaceFillingCurve2D.CoveredRange
- toString() - Method in class org.apache.calcite.runtime.SpaceFillingCurve2D.OverlappingRange
- toString() - Method in class org.apache.calcite.runtime.Unit
- toString() - Method in class org.apache.calcite.schema.impl.DelegatingSchema
- toString() - Method in class org.apache.calcite.schema.impl.LongSchemaVersion
- toString() - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Token
- toString() - Method in enum org.apache.calcite.sql.babel.postgresql.AndChain
- toString() - Method in enum org.apache.calcite.sql.babel.postgresql.SqlBegin.TransactionMode
- toString() - Method in class org.apache.calcite.sql.parser.SqlParserPos
- toString() - Method in class org.apache.calcite.sql.parser.SqlParserUtil.ToTreeListItem
- toString() - Method in class org.apache.calcite.sql.parser.StringAndPos
- toString() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- toString() - Method in class org.apache.calcite.sql.SqlAbstractDateTimeLiteral
-
Returns e.g.
- toString() - Method in class org.apache.calcite.sql.SqlAccessType
- toString() - Method in class org.apache.calcite.sql.SqlCollation
- toString() - Method in class org.apache.calcite.sql.SqlDateLiteral
- toString() - Method in class org.apache.calcite.sql.SqlIdentifier
- toString() - Method in class org.apache.calcite.sql.SqlIntervalLiteral.IntervalValue
- toString() - Method in enum org.apache.calcite.sql.SqlJsonEmptyOrError
- toString() - Method in enum org.apache.calcite.sql.SqlJsonEncoding
- toString() - Method in enum org.apache.calcite.sql.SqlJsonQueryEmptyOrErrorBehavior
- toString() - Method in enum org.apache.calcite.sql.SqlMatchRecognize.AfterOption
- toString() - Method in enum org.apache.calcite.sql.SqlMatchRecognize.RowsPerMatchOption
- toString() - Method in class org.apache.calcite.sql.SqlNode
- toString() - Method in class org.apache.calcite.sql.SqlOperator
- toString() - Method in class org.apache.calcite.sql.SqlSampleSpec.SqlSubstitutionSampleSpec
- toString() - Method in class org.apache.calcite.sql.SqlSampleSpec.SqlTableSampleSpec
- toString() - Method in class org.apache.calcite.sql.SqlTimeLiteral
- toString() - Method in class org.apache.calcite.sql.SqlTimestampLiteral
- toString() - Method in class org.apache.calcite.sql.SqlTimestampTzLiteral
- toString() - Method in class org.apache.calcite.sql.SqlTimeTzLiteral
- toString() - Method in class org.apache.calcite.sql.TableCharacteristic
- toString() - Method in class org.apache.calcite.sql.util.IdPair
- toString() - Method in class org.apache.calcite.sql.util.SqlBuilder
- toString() - Method in class org.apache.calcite.sql.util.SqlString
- toString() - Method in class org.apache.calcite.sql.validate.SqlIdentifierMoniker
- toString() - Method in class org.apache.calcite.sql.validate.SqlMonikerImpl
- toString() - Method in class org.apache.calcite.sql.validate.SqlQualified
- toString() - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.Path
- toString() - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMap
- toString() - Method in class org.apache.calcite.test.RelMetadataFixture.MetadataConfig
- toString() - Method in class org.apache.calcite.test.schemata.hr.Department
- toString() - Method in class org.apache.calcite.test.schemata.hr.Dependent
- toString() - Method in class org.apache.calcite.test.schemata.hr.Employee
- toString() - Method in class org.apache.calcite.test.schemata.hr.Event
- toString() - Method in class org.apache.calcite.test.schemata.hr.HierarchySchema.Hierarchy
- toString() - Method in class org.apache.calcite.test.schemata.hr.HierarchySchema
- toString() - Method in class org.apache.calcite.test.schemata.hr.HrSchema
- toString() - Method in class org.apache.calcite.test.schemata.hr.HrSchemaBig
- toString() - Method in class org.apache.calcite.test.schemata.hr.Location
- toString() - Method in class org.apache.calcite.test.schemata.hr.NullableTest
- toString() - Method in class org.apache.calcite.test.schemata.tpch.TpchSchema.Customer
- toString() - Method in class org.apache.calcite.test.schemata.tpch.TpchSchema.LineItem
- toString() - Method in class org.apache.calcite.test.schemata.tpch.TpchSchema.Part
- toString() - Method in class org.apache.calcite.test.schemata.tpch.TpchSchema.PartSupp
- toString() - Method in class org.apache.calcite.tools.Hoist.Hoisted
- toString() - Method in class org.apache.calcite.tools.RelBuilder
-
Converts this RelBuilder to a string.
- toString() - Method in class org.apache.calcite.util.BitString
- toString() - Method in class org.apache.calcite.util.DateString
- toString() - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- toString() - Method in class org.apache.calcite.util.graph.DefaultEdge
- toString() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns a string representation of this bit set.
- toString() - Method in class org.apache.calcite.util.ImmutableIntList
- toString() - Method in class org.apache.calcite.util.mapping.IntPair
- toString() - Method in class org.apache.calcite.util.mapping.Mappings.AbstractMapping
-
Returns a string representation of this mapping.
- toString() - Method in class org.apache.calcite.util.NameMap
- toString() - Method in class org.apache.calcite.util.NameMultimap
- toString() - Method in class org.apache.calcite.util.NameSet
- toString() - Method in class org.apache.calcite.util.NlsString
-
Returns the string quoted for SQL, for example
_ISO-8859-1'is it a plane? no it''s superman!'
. - toString() - Method in class org.apache.calcite.util.Pair
- toString() - Method in class org.apache.calcite.util.Permutation
-
Returns a string representation of this permutation.
- toString() - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Call
- toString() - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Token
- toString() - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- toString() - Method in class org.apache.calcite.util.Sarg
- toString() - Method in class org.apache.calcite.util.Smalls.IntString
- toString() - Method in class org.apache.calcite.util.Smalls.WideSaleSchema
- toString() - Method in class org.apache.calcite.util.TimestampString
- toString() - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
- toString() - Method in class org.apache.calcite.util.TimeString
- toString() - Method in class org.apache.calcite.util.TimeWithTimeZoneString
- toString(boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
CAST(BOOLEAN AS VARCHAR).
- toString(double) - Static method in interface org.apache.calcite.plan.RelOptCost
- toString(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
CAST(DOUBLE AS VARCHAR).
- toString(float) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
CAST(FLOAT AS VARCHAR).
- toString(int) - Method in class org.apache.calcite.util.TimestampString
-
Converts this TimestampString to a string, truncated or padded with zeros to a given precision.
- toString(int) - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
-
Converts this TimestampWithTimeZoneString to a string, truncated or padded with zeros to a given precision.
- toString(int) - Method in class org.apache.calcite.util.TimeString
-
Converts this TimestampString to a string, truncated or padded with zeros to a given precision.
- toString(int) - Method in class org.apache.calcite.util.TimeWithTimeZoneString
-
Converts this TimeWithTimeZoneString to a string, truncated or padded with zeros to a given precision.
- toString(Iterable<T>, String, String, String) - Static method in class org.apache.calcite.util.Util
-
Converts an iterable to a string.
- toString(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
CAST(DECIMAL AS VARCHAR).
- toString(ResultSet) - Static method in class org.apache.calcite.test.CalciteAssert
-
Converts a
ResultSet
to a string. - toString(List<? extends Node>, String, boolean) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Converts a list of expressions to Java source code, optionally emitting extra type information in generics.
- toString(Node) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Converts an expression to Java source code.
- toString(Ast.Node) - Static method in class org.apache.calcite.piglet.Ast
- toString(RelNode, SqlExplainLevel) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Converts a relational expression to a string; returns null if and only if
rel
is null. - toString(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Converts a relational expression to a string, showing just basic attributes.
- toStringArray(List<String>) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Deprecated.
- toStringFromApprox(double, boolean) - Static method in class org.apache.calcite.util.ConversionUtil
-
Converts an approximate value into a string, following the SQL 2003 standard.
- toStringFromByteArray(byte[], int) - Static method in class org.apache.calcite.util.ConversionUtil
-
Converts a byte array into a bit string or a hex string.
- toStringSelector() - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns a selector that calls the
Object.toString()
method on each element. - toStringUnordered() - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- toStruct(RelDataType, SqlNode) - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
-
Converts a type to a struct if it is not already.
- total() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHits
- toTimeFun(Long) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- toTimestamp(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.DateFormatFunction
- toTimestamp(String, String) - Method in class org.apache.calcite.runtime.SqlFunctions.DateFormatFunctionPg
- toTimestampFun(Long) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- toTimestampWithLocalTimeZone(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toTimestampWithLocalTimeZone(String, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toTimeWithLocalTimeZone(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toTimeWithLocalTimeZone(String, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toTree(List<Object>) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Converts a list of {expression, operator, expression, ...} into a tree, taking operator precedence and associativity into account.
- toTreeEx(SqlSpecialOperator.TokenSequence, int, int, SqlKind) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Converts a list of {expression, operator, expression, ...} into a tree, taking operator precedence and associativity into account.
- ToTreeListItem(SqlOperator, SqlParserPos) - Constructor for class org.apache.calcite.sql.parser.SqlParserUtil.ToTreeListItem
- toType(RelDataTypeFactory, Object) - Method in class org.apache.calcite.rel.externalize.RelJson
- toUnchecked(Exception) - Static method in class org.apache.calcite.util.Util
-
Wraps an exception with
RuntimeException
and return it. - toURL(File) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- toValue() - Method in class org.apache.calcite.sql.SqlLiteral
-
For calc program builder - value may be different than
SqlLiteral.unparse(org.apache.calcite.sql.SqlWriter, int, int)
. - toValue() - Method in class org.apache.calcite.sql.SqlNumericLiteral
- TpcdsSchema - Class in org.apache.calcite.adapter.tpcds
-
Schema that provides TPC-DS tables, populated according to a particular scale factor.
- TpcdsSchema(double) - Constructor for class org.apache.calcite.adapter.tpcds.TpcdsSchema
-
Creates a TpcdsSchema.
- TpcdsSchema(double, int, int) - Constructor for class org.apache.calcite.adapter.tpcds.TpcdsSchema
-
Deprecated.
- TpcdsSchemaFactory - Class in org.apache.calcite.adapter.tpcds
-
Factory that creates a
TpcdsSchema
. - TpcdsSchemaFactory() - Constructor for class org.apache.calcite.adapter.tpcds.TpcdsSchemaFactory
- TPCH - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- TpchSchema - Class in org.apache.calcite.adapter.tpch
-
Schema that provides TPC-H tables, populated according to a particular scale factor.
- TpchSchema - Class in org.apache.calcite.test.schemata.tpch
-
TPC-H table schema.
- TpchSchema() - Constructor for class org.apache.calcite.test.schemata.tpch.TpchSchema
- TpchSchema(double, int, int, boolean) - Constructor for class org.apache.calcite.adapter.tpch.TpchSchema
- TpchSchema.Customer - Class in org.apache.calcite.test.schemata.tpch
-
Customer in TPC-H.
- TpchSchema.LineItem - Class in org.apache.calcite.test.schemata.tpch
-
Line Item in TPC-H.
- TpchSchema.Part - Class in org.apache.calcite.test.schemata.tpch
-
Part in TPC-H.
- TpchSchema.PartSupp - Class in org.apache.calcite.test.schemata.tpch
-
Part supplier in TPC-H.
- TpchSchemaFactory - Class in org.apache.calcite.adapter.tpch
-
Factory that creates a
TpchSchema
. - TpchSchemaFactory() - Constructor for class org.apache.calcite.adapter.tpch.TpchSchemaFactory
- trace(String, Object...) - Method in class org.apache.calcite.util.trace.CalciteLogger
- trace(String, Object, Object) - Method in class org.apache.calcite.util.trace.CalciteLogger
-
Logs a TRACE message with two Object parameters.
- trace(String, Object, Object, Object) - Method in class org.apache.calcite.util.trace.CalciteLogger
-
Conditionally logs a TRACE message with three Object parameters.
- trace(String, Object, Object, Object, Object) - Method in class org.apache.calcite.util.trace.CalciteLogger
-
Conditionally logs a TRACE message with four Object parameters.
- TRACER - Static variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- traceTime(String) - Method in class org.apache.calcite.util.trace.CalciteTimingTracer
-
Publishes an event with the time elapsed since the previous event.
- TRAILING - Enum constant in enum org.apache.calcite.sql.fun.SqlTrimFunction.Flag
- trait - Variable in class org.apache.calcite.plan.RelOptRuleOperand
- trait(RelTrait) - Method in interface org.apache.calcite.plan.RelRule.OperandDetailBuilder
-
Sets a trait of this operand.
- traitDef - Variable in class org.apache.calcite.rel.convert.ConverterImpl
- traitDefs(List<RelTraitDef>) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- traitDefs(RelTraitDef...) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- TraitMatchingRule - Class in org.apache.calcite.rel.convert
-
TraitMatchingRule adapts a converter rule, restricting it to fire only when its input already matches the expected output trait.
- TraitMatchingRule(ConverterRule) - Constructor for class org.apache.calcite.rel.convert.TraitMatchingRule
-
Deprecated.
- TraitMatchingRule(ConverterRule, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.convert.TraitMatchingRule
-
Deprecated.
- TraitMatchingRule(TraitMatchingRule.Config) - Constructor for class org.apache.calcite.rel.convert.TraitMatchingRule
-
Creates a TraitMatchingRule.
- TraitMatchingRule.Config - Interface in org.apache.calcite.rel.convert
-
Rule configuration.
- traitSet - Variable in class org.apache.calcite.rel.AbstractRelNode
-
RelTraitSet that describes the traits of this RelNode.
- traitSet() - Method in class org.apache.calcite.plan.RelOptCluster
-
Returns the default trait set for this cluster.
- traitSetOf(RelTrait) - Method in class org.apache.calcite.plan.RelOptCluster
- traitSetOf(RelTrait...) - Method in class org.apache.calcite.plan.RelOptCluster
-
Deprecated.For
traitSetOf(t1, t2)
, useRelOptCluster.traitSet()
().replace(t1).replace(t2). - transform(int, RelTraitSet, RelNode) - Method in class org.apache.calcite.prepare.PlannerImpl
- transform(int, RelTraitSet, RelNode) - Method in interface org.apache.calcite.tools.Planner
-
Converts one relational expression tree into another relational expression based on a particular rule set and requires set of traits.
- transform(F) - Method in class org.apache.calcite.linq4j.TransformedEnumerator
- transform(Iterable<? extends F>, Function<? super F, ? extends T>) - Static method in class org.apache.calcite.util.Util
-
Transforms an iterable, applying a function to each element.
- transform(BiFunction<T, U, R>) - Method in interface org.apache.calcite.runtime.PairList
-
Applies a mapping function to each element of this list.
- transform(UnaryOperator<SqlValidator.Config>) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns this SqlValidator, with the same state, applying a transform to the config.
- transform(UnaryOperator<SqlValidator.Config>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- transform(UnaryOperator<RelBuilder.Config>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a copy of this RelBuilder, with the same state as this, applying a transform to the config.
- transform(Iterator<? extends F>, Function<? super F, ? extends T>) - Static method in class org.apache.calcite.util.Util
-
Transforms an iterator.
- transform(List<? extends F>, Function<? super F, ? extends T>) - Static method in class org.apache.calcite.util.Util
-
Transforms a list, applying a function to each element.
- transform(Enumerator<? extends F>, Function1<? super F, ? extends E>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Applies a function to each element of an Enumerator.
- transform(SqlTypeTransform) - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Returns an operator binding equivalent that is equivalent to this except that a transform has been applied to each operand type.
- transform(Mappings.TargetMapping) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Creates a copy of this aggregate call, applying a mapping to its arguments.
- transform2(BiFunction<T, U, R>) - Method in interface org.apache.calcite.runtime.PairList
-
Applies a mapping function to each element of this list.
- TransformationRule - Interface in org.apache.calcite.rel.rules
-
Logical transformation rule, only logical operator can be rule operand, and only generate logical alternatives.
- transformCoordinates(CoordinateSequence, Geometry) - Method in class org.apache.calcite.runtime.AddZTransformer
- transformCoordinates(CoordinateSequence, Geometry) - Method in class org.apache.calcite.runtime.CoordinateTransformer
- transformCoordinates(CoordinateSequence, Geometry) - Method in class org.apache.calcite.runtime.FlipCoordinatesTransformer
- transformCoordinates(CoordinateSequence, Geometry) - Method in class org.apache.calcite.runtime.ProjectionTransformer
- transformCoordinates(CoordinateSequence, Geometry) - Method in class org.apache.calcite.runtime.RemoveRepeatedPointsTransformer
- TransformedEnumerator<F,
E> - Class in org.apache.calcite.linq4j -
Enumerator that applies a transform to each value from a backing enumerator.
- TransformedEnumerator(Enumerator<? extends F>) - Constructor for class org.apache.calcite.linq4j.TransformedEnumerator
- transformGeometryCollection(GeometryCollection, Geometry) - Method in class org.apache.calcite.runtime.ProjectionTransformer
- transformIndexed(List<? extends F>, BiFunction<? super F, Integer, ? extends T>) - Static method in class org.apache.calcite.util.Util
-
Transforms a list, applying a function to each element, also passing in the element's index in the list.
- transformLinearRing(LinearRing, Geometry) - Method in class org.apache.calcite.runtime.ProjectionTransformer
- transformLineString(LineString, Geometry) - Method in class org.apache.calcite.runtime.ProjectionTransformer
- transformMultiLineString(MultiLineString, Geometry) - Method in class org.apache.calcite.runtime.ProjectionTransformer
- transformMultiPoint(MultiPoint, Geometry) - Method in class org.apache.calcite.runtime.ProjectionTransformer
- transformMultiPolygon(MultiPolygon, Geometry) - Method in class org.apache.calcite.runtime.ProjectionTransformer
- transformNullSemantics() - Method in class org.apache.calcite.rex.RexTransformer
- transformPoint(Point, Geometry) - Method in class org.apache.calcite.runtime.ProjectionTransformer
- transformPolygon(Polygon, Geometry) - Method in class org.apache.calcite.runtime.ProjectionTransformer
- transformPolygon(Polygon, Geometry) - Method in class org.apache.calcite.runtime.RemoveHoleTransformer
- transformTo(RelNode) - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Registers that a rule has produced an equivalent relational expression, but no other equivalences.
- transformTo(RelNode, Map<RelNode, RelNode>) - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Registers that a rule has produced an equivalent relational expression, with specified equivalences.
- transformTo(RelNode, Map<RelNode, RelNode>, RelHintsPropagator) - Method in class org.apache.calcite.plan.hep.HepRuleCall
- transformTo(RelNode, Map<RelNode, RelNode>, RelHintsPropagator) - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Registers that a rule has produced an equivalent relational expression.
- transformTo(RelNode, Map<RelNode, RelNode>, RelHintsPropagator) - Method in class org.apache.calcite.plan.volcano.VolcanoRuleCall
- transformTo(RelNode, RelHintsPropagator) - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Registers that a rule has produced an equivalent relational expression, but no other equivalences.
- transformToFarragoUdxRel(RelOptRuleCall, SplunkTableScan, LogicalFilter, LogicalProject, LogicalProject) - Method in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- transformType(SqlOperatorBinding, RelDataType) - Method in interface org.apache.calcite.sql.type.SqlTypeTransform
-
Transforms a type.
- transientScan(String) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
TableScan
on aTransientTable
with the given name, using as type the top of the stack's type. - transientScan(String, RelDataType) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
TableScan
on aTransientTable
with the given name and type. - transientTable - Variable in class org.apache.calcite.rel.core.RepeatUnion
-
Transient table where repeat union's intermediate results will be stored (optional).
- TransientTable - Interface in org.apache.calcite.schema
-
A transient table is a named table that may come into existence implicitly during the evaluation of a query expression or the execution of a trigger.
- TRANSLATABLE - Enum constant in enum org.apache.calcite.adapter.csv.CsvTable.Flavor
- TRANSLATABLE - Enum constant in enum org.apache.calcite.adapter.file.CsvTable.Flavor
- TranslatableTable - Interface in org.apache.calcite.schema
-
Extension to
Table
that specifies how it is to be translated to arelational expression
. - translate(String) - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- translate(String) - Method in class org.apache.calcite.sql.validate.AliasNamespace
- TRANSLATE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
TRANSLATE
function. - TRANSLATE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
TRANSLATE/CONVERT(char_value USING transcodingName)
function alters the character set of a string value from one base character set to transcodingName. - TRANSLATE_WITH_CHARSET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- translate3(String, String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TRANSLATE(string, search_chars, replacement_chars)
function. - TRANSLATE3 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TRANSLATE3 - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
Deprecated.
- TRANSLATE3 - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
TRANSLATE(string_expr, search_chars, replacement_chars)
function returns string_expr with all occurrences of each character in search_chars replaced by its corresponding character in replacement_chars. - translateCastToTimeExtract(RexNode, TimeZone) - Static method in class org.apache.calcite.adapter.druid.TimeExtractionFunction
-
Translates a CAST expression to a Druid Time extraction function, or null when can not translate the cast.
- translateCharacterSetName(String) - Static method in class org.apache.calcite.sql.SqlUtil
-
Translates a character set name from a SQL-level name into a Java-level name.
- translateCharset(SqlRexContext, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- translateCondition(RexProgram, JavaTypeFactory, BlockBuilder, RexToLixTranslator.InputGetter, Function1<String, RexToLixTranslator.InputGetter>, SqlConformance) - Static method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- translateInput(RelJson, int, Map<String, Object>, RelInput) - Method in interface org.apache.calcite.rel.externalize.RelJson.InputTranslator
-
Transforms an input reference into a RexNode.
- translateList(List<? extends RexNode>) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Translates the list of
RexNode
, using the default output types. - translateList(List<? extends RexNode>, List<? extends Type>) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Translates the list of
RexNode
, while optimizing for output storage. - translateList(List<RexNode>, RexImpTable.NullAs) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- translateList(List<RexNode>, RexImpTable.NullAs, List<? extends Type>) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- translateLiteral(RexLiteral, RelDataType, JavaTypeFactory, RexImpTable.NullAs) - Static method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Translates a literal.
- translateProjects(RexProgram, JavaTypeFactory, SqlConformance, BlockBuilder, PhysType, Expression, RexToLixTranslator.InputGetter, Function1<String, RexToLixTranslator.InputGetter>) - Static method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Deprecated.
- translateProjects(RexProgram, JavaTypeFactory, SqlConformance, BlockBuilder, BlockBuilder, PhysType, Expression, RexToLixTranslator.InputGetter, Function1<String, RexToLixTranslator.InputGetter>) - Static method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Translates a
RexProgram
to a sequence of expressions and declarations. - translateTableFunction(JavaTypeFactory, SqlConformance, BlockBuilder, Expression, RexCall, Expression, PhysType, PhysType) - Static method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- translateWithCharset(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TRANSLATE(s USING transcodingName)
function, also known asCONVERT(s USING transcodingName)
. - treatDynamicCallsAsConstant() - Method in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.Config
-
Whether to treat
dynamic functions
as constants. - trim(boolean, boolean, String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TRIM(... seek FROM s)
function. - trim(boolean, boolean, String, String, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
- trim(String) - Method in interface org.apache.calcite.util.Source
-
Looks for a suffix on a path and returns either the path with the suffix removed or the original path.
- trim(String, String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Trims a string for given characters from left and right.
- trim(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TRIM
function applied to binary string. - trim(RelNode) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Trims unused fields from a relational expression.
- TRIM - Enum constant in enum org.apache.calcite.sql.SqlKind
-
TRIM
function. - TRIM - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TRIM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The "TRIM" function.
- trimChild(RelNode, RelNode, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Trims the fields of an input relational expression.
- trimChildRestore(RelNode, RelNode, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Trims a child relational expression, then adds back a dummy project to restore the fields that were removed.
- trimError() - Method in interface org.apache.calcite.runtime.CalciteResource
- trimFields(Aggregate, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
- trimFields(Calc, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Variant of
RelFieldTrimmer.trimFields(RelNode, ImmutableBitSet, Set)
forLogicalCalc
. - trimFields(Exchange, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
- trimFields(Filter, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
- trimFields(Join, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Variant of
RelFieldTrimmer.trimFields(RelNode, ImmutableBitSet, Set)
forLogicalJoin
. - trimFields(Project, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
- trimFields(Sample, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Variant of
RelFieldTrimmer.trimFields(RelNode, ImmutableBitSet, Set)
forSample
. - trimFields(SetOp, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Variant of
RelFieldTrimmer.trimFields(RelNode, ImmutableBitSet, Set)
forSetOp
(Only UNION ALL is supported). - trimFields(Snapshot, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Variant of
RelFieldTrimmer.trimFields(RelNode, ImmutableBitSet, Set)
forSnapshot
. - trimFields(SortExchange, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
- trimFields(Sort, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Variant of
RelFieldTrimmer.trimFields(RelNode, ImmutableBitSet, Set)
forSort
. - trimFields(TableScan, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
- trimFields(LogicalTableFunctionScan, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
- trimFields(LogicalTableModify, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
- trimFields(LogicalValues, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
- trimFields(RelNode, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Visit method, per
ReflectiveVisitor
. - TRIMMED - Enum constant in enum org.apache.calcite.runtime.Hook
-
Called after de-correlation and field trimming, but before optimization.
- trimNodeIds(String) - Static method in class org.apache.calcite.test.Matchers
- trimOrNull(String) - Method in interface org.apache.calcite.util.Source
-
Looks for a suffix on a path and returns either the path with the suffix removed or null.
- trimRelNode(SqlTestFactory, RelNode) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- trimRelNode(SqlTestFactory, RelNode) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Trims a RelNode.
- TrimResult(RelNode, Mapping) - Constructor for class org.apache.calcite.sql2rel.RelFieldTrimmer.TrimResult
-
Creates a TrimResult.
- trimUnusedFields(boolean, RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Walks over a tree of relational expressions, replacing each
RelNode
with a 'slimmed down' relational expression that projects only the fields required by its consumer. - trimUnusedFields(RelRoot) - Method in class org.apache.calcite.prepare.Prepare
-
Walks over a tree of relational expressions, replacing each
RelNode
with a 'slimmed down' relational expression that projects only the columns required by its consumer. - TRUE - Enum constant in enum org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
If one of the arguments is null, the function returns true.
- TRUE - Enum constant in enum org.apache.calcite.plan.RelOptUtil.Logic
-
A semi-join will have been applied, so that only rows for which the value is TRUE will have been returned.
- TRUE - Enum constant in enum org.apache.calcite.rex.RexUnknownAs
-
Policy that indicates that the expression is being used in a context Where an UNKNOWN value is treated in the same way as TRUE.
- TRUE - Enum constant in enum org.apache.calcite.sql.SqlJsonExistsErrorBehavior
- TRUE - Static variable in interface org.apache.calcite.linq4j.function.Predicate1
-
Predicate that always evaluates to
true
. - TRUE - Static variable in interface org.apache.calcite.linq4j.function.Predicate2
-
Predicate that always evaluates to
true
. - TRUE - Static variable in interface org.apache.calcite.rel.rules.PushProjector.ExprCondition
-
Constant condition that replies
true
for all expressions. - TRUE_EXPR - Static variable in class org.apache.calcite.adapter.enumerable.RexImpTable
- TRUE_EXPR - Static variable in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- TRUE_FALSE - Enum constant in enum org.apache.calcite.plan.RelOptUtil.Logic
-
Nulls are not possible.
- TRUE_FALSE_UNKNOWN - Enum constant in enum org.apache.calcite.plan.RelOptUtil.Logic
-
Three-valued boolean logic.
- TRUE_PREDICATE - Static variable in class org.apache.calcite.rel.rules.FilterJoinRule
-
Deprecated.
- truePredicate1() - Static method in class org.apache.calcite.linq4j.function.Functions
-
A predicate with one parameter that always returns
true
. - truePredicate2() - Static method in class org.apache.calcite.linq4j.function.Functions
-
A predicate with two parameters that always returns
true
. - TRUNC_BIG_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TRUNC(numeric1 [, integer2])" function.
- truncate(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper for rounding.
- truncate(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper for rounding.
- truncate(String, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper for CAST(...
- truncate(ByteString, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper for CAST(...
- TRUNCATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TRUNCATE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
TRUNCATE(numeric [, integer])
function. - TRUNCATE_OR_PAD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TRUNCATE_TABLE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
TRUNCATE TABLE
DDL statement. - truncateOrPad(String, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper for CAST(...
- truncateOrPad(ByteString, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper for CAST(...
- truncateTable(SqlParserPos, SqlIdentifier, boolean) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a TRUNCATE TABLE.
- Try - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A try-catch expression.
- TRY_CAST - Enum constant in enum org.apache.calcite.sql.test.SqlOperatorFixture.CastType
- TRY_CAST - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "TRY_CAST(expr AS type)" function, equivalent to SAFE_CAST.
- tryCatch(Statement, Iterable<? extends CatchBlock>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a TryExpression representing a try block with any number of catch statements and neither a fault nor finally block.
- tryCatch(Statement, CatchBlock...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a TryExpression representing a try block with any number of catch statements and neither a fault nor finally block, with varargs.
- tryCatchFinally(Statement, Iterable<? extends CatchBlock>, Statement) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a TryExpression representing a try block with any number of catch statements and a finally block.
- tryCatchFinally(Statement, Statement, CatchBlock...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a TryExpression representing a try block with any number of catch statements and a finally block, with varargs.
- tryDeriveTypeForCollection(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlQuantifyOperator
-
Derive type for SOME(collection expression), ANY (collection expression).
- tryFinally(Statement, Statement) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a TryExpression representing a try block with a finally block and no catch statements.
- tryOptimizeMethodCall(MethodCallExpression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Optimized method call, possibly converting it to final static field.
- tryOptimizeNewInstance(NewExpression) - Method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Optimizes
new Type()
constructs. - tryOptimizeNewInstance(NewExpression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Optimizes
new Type()
constructs. - TryStatement - Class in org.apache.calcite.linq4j.tree
-
Represents a
try ... catch ... finally
block. - TryStatement(Statement, List<CatchBlock>, Statement) - Constructor for class org.apache.calcite.linq4j.tree.TryStatement
- TryThreadLocal<T> - Class in org.apache.calcite.util
-
Thread-local variable that returns a handle that can be closed.
- TryThreadLocal() - Constructor for class org.apache.calcite.util.TryThreadLocal
- TryThreadLocal.Memo - Interface in org.apache.calcite.util
-
Remembers to set the value back.
- tryUseStar(RelNode, RelOptTable) - Static method in class org.apache.calcite.plan.RelOptMaterialization
-
Converts a relational expression to one that uses a
StarTable
. - ts - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- ts - Variable in class org.apache.calcite.test.schemata.hr.Event
- TUMBLE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
TUMBLE
group function. - TUMBLE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
TUMBLE as a table function.
- TUMBLE_END - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
TUMBLE_END
auxiliary function of theSqlKind.TUMBLE
group function. - TUMBLE_END - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
TUMBLE_END
auxiliary function of theTUMBLE
group function. - TUMBLE_OLD - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
TUMBLE
group function. - TUMBLE_START - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
TUMBLE_START
auxiliary function of theSqlKind.TUMBLE
group function. - TUMBLE_START - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
TUMBLE_START
auxiliary function of theTUMBLE
group function. - tumbling(Enumerable<TSource>, Function1<TSource, TResult>) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
-
Apply tumbling per row from the enumerable input.
- TUMBLING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- tuple() - Method in class org.apache.calcite.runtime.SpaceFillingCurve2D.AbstractRange
- tuple() - Method in interface org.apache.calcite.runtime.SpaceFillingCurve2D.IndexRange
- TUPLE - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- TUPLE_TYPE - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- tuples - Variable in class org.apache.calcite.rel.core.Values
- TupleType(SqlParserPos, List<Ast.FieldSchema>) - Constructor for class org.apache.calcite.piglet.Ast.TupleType
- type - Variable in class org.apache.calcite.linq4j.tree.AbstractNode
- type - Variable in class org.apache.calcite.linq4j.tree.NewExpression
- type - Variable in class org.apache.calcite.linq4j.tree.TypeBinaryExpression
- type - Variable in class org.apache.calcite.model.JsonType
-
Type if this is not a struct.
- type - Variable in class org.apache.calcite.model.JsonTypeAttribute
-
Type of this attribute.
- type - Variable in class org.apache.calcite.rel.core.AggregateCall
- type - Variable in class org.apache.calcite.rel.mutable.MutableRel
- type - Variable in class org.apache.calcite.rex.RexCall
- type - Variable in class org.apache.calcite.rex.RexVariable
- type - Variable in class org.apache.calcite.sql.advise.SqlAdvisorHint
-
One of
SqlMonikerType
. - type - Variable in class org.apache.calcite.sql.ddl.SqlCreateForeignSchema
- type - Variable in class org.apache.calcite.sql.validate.IdentifierNamespace
-
As
AbstractNamespace.rowType
, but not necessarily a struct. - type - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Token
- type() - Method in enum org.apache.calcite.config.CalciteConnectionProperty
- type(String) - Method in class org.apache.calcite.test.SqlValidatorFixture
-
Checks that a query returns a row of the expected type.
- Type(SqlParserPos, Ast.Op) - Constructor for class org.apache.calcite.piglet.Ast.Type
- TYPE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
Type.
- TYPE - Enum constant in enum org.apache.calcite.sql.SqlExplain.Depth
- TYPE_COERCION - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether to make implicit type coercion when type mismatch for validation, default true.
- TYPE_INFO_COLUMNS - Static variable in class org.apache.calcite.jdbc.CalciteMetaImpl
-
The columns returned by
DatabaseMetaData.getTypeInfo()
. - TYPE_SYSTEM - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Type system.
- TYPE_SYSTEM - Static variable in class org.apache.calcite.sql.dialect.RedshiftSqlDialect
- typeAs(Expression, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents an explicit reference or boxing conversion where null is supplied if the conversion fails.
- TypeAs - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An explicit reference or boxing conversion in which null is supplied if the conversion fails, such as (obj as SampleType) in C# or TryCast(obj, SampleType) in Visual Basic.
- TypeBinaryExpression - Class in org.apache.calcite.linq4j.tree
-
Represents an operation between an expression and a type.
- TypeBinaryExpression(ExpressionType, Expression, Type) - Constructor for class org.apache.calcite.linq4j.tree.TypeBinaryExpression
- typeCoercion() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.TYPE_COERCION
. - typeCoercion() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- TypeCoercion - Interface in org.apache.calcite.sql.validate.implicit
-
Default strategies to coerce differing types that participate in operations into compatible ones.
- typeCoercionEnabled() - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Returns whether the validator supports implicit type coercion.
- typeCoercionFactory() - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Returns the type coercion factory.
- TypeCoercionFactory - Interface in org.apache.calcite.sql.validate.implicit
-
Factory for
TypeCoercion
objects. - TypeCoercionImpl - Class in org.apache.calcite.sql.validate.implicit
-
Default implementation of Calcite implicit type cast.
- TypeCoercionImpl(RelDataTypeFactory, SqlValidator) - Constructor for class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
- typeCoercionRules() - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Returns the type coercion rules for explicit type coercion.
- TypeCoercions - Class in org.apache.calcite.sql.validate.implicit
-
Factory class for type coercion instantiation of different sql dialects.
- Typed - Interface in org.apache.calcite.runtime
-
Adds type information to a
Enumerable
. - TYPED_GET_ELEMENT_TYPE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- TYPED_TABLE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
A typed table.
- TYPED_VIEW - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
A typed view.
- typeEntry(String, RelProtoDataType) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Creates a TableEntryImpl with no SQLs.
- TypeEntry(CalciteSchema, String) - Constructor for class org.apache.calcite.jdbc.CalciteSchema.TypeEntry
- TypeEntryImpl(CalciteSchema, String, RelProtoDataType) - Constructor for class org.apache.calcite.jdbc.CalciteSchema.TypeEntryImpl
-
Creates a TypeEntryImpl.
- typeEqual(Expression, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a TypeBinaryExpression that compares run-time type identity.
- TypeEqual - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An exact type test.
- typeFactory - Variable in class org.apache.calcite.jdbc.CalcitePrepare.ParseResult
- typeFactory - Variable in class org.apache.calcite.prepare.CalciteCatalogReader
- typeFactory - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- typeFactory - Variable in class org.apache.calcite.rex.RexBuilder
- typeFactory - Variable in class org.apache.calcite.sql.SqlOperatorBinding
- typeFactory - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- typeFactory - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- typeFactory - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- typeFactoryFactory - Variable in class org.apache.calcite.sql.test.SqlTestFactory
- typeInference() - Method in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- typeInference() - Method in interface org.apache.calcite.sql.type.SqlOperandTypeChecker
-
Converts this type checker to a type inference; returns null if not possible.
- typeIs(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- typeIs(Expression, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a TypeBinaryExpression.
- TypeIs - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A type test, such as obj is SampleType in C# or TypeOf obj is SampleType in Visual Basic.
- typeMap - Variable in class org.apache.calcite.jdbc.CalciteSchema
- typeName - Variable in class org.apache.calcite.sql.type.AbstractSqlType
- typeName() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- typeName(SqlTypeName) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a single-operand checker that passes if the operand's type has a particular
SqlTypeName
. - typeNameToClass(String) - Method in class org.apache.calcite.rel.externalize.RelJson
-
Converts a type name to a class.
- typeNotAssignable(String, String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- typeNotComparable(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- typeNotComparableEachOther(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- typeNotComparableNear(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- typeNotFound(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- typeNotSupported(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- types - Variable in class org.apache.calcite.model.JsonMapSchema
-
Types in this schema.
- types - Variable in class org.apache.calcite.model.JsonRoot
-
List of types in the root schema.
- types - Variable in class org.apache.calcite.sql.type.MeasureSqlType
- types(List<? extends RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Transforms a list of expressions into a list of their types.
- Types - Class in org.apache.calcite.linq4j.tree
- Types.ArrayType - Class in org.apache.calcite.linq4j.tree
-
Array type.
- Types.MapType - Class in org.apache.calcite.linq4j.tree
-
Map type.
- Types.RecordField - Interface in org.apache.calcite.linq4j.tree
-
Field that belongs to a record.
- Types.RecordType - Interface in org.apache.calcite.linq4j.tree
-
Base class for record-like types that do not mapped to (currently loaded) Java
Class
objects. - typesShouldAllBeMap(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- typeSystem - Variable in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- typeSystem - Variable in class org.apache.calcite.sql.type.BasicSqlType
- typeSystem(Class<T>, T) - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.TYPE_SYSTEM
, or a default type system if not set. - typeSystem(Class<T>, T) - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- typeSystem(RelDataTypeSystem) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- typeSystemTransform - Variable in class org.apache.calcite.sql.test.SqlTestFactory
- typeValueSize(RelDataType, Comparable) - Method in class org.apache.calcite.rel.metadata.RelMdSize
-
Estimates the average size (in bytes) of a value of a type.
- TZ_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
-
Types that contain time zone information.
- TZR - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
U
- UNARY_MINUS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Prefix arithmetic minus operator, '
-
'. - UNARY_PLUS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Prefix arithmetic plus operator, '
+
'. - UnaryExpression - Class in org.apache.calcite.linq4j.tree
-
Represents an expression that has a unary operator.
- unaryPlus(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents a unary plus operation.
- unaryPlus(Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents a unary plus operation.
- UnaryPlus - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A unary plus operation, such as (+a).
- UnaryPrefixOperatorConversion - Class in org.apache.calcite.adapter.druid
-
Unary prefix Operator conversion class; used to convert expressions like Unary NOT and Minus.
- UnaryPrefixOperatorConversion(SqlOperator, String) - Constructor for class org.apache.calcite.adapter.druid.UnaryPrefixOperatorConversion
- UnarySuffixOperatorConversion - Class in org.apache.calcite.adapter.druid
-
Unary suffix operator conversion; used to convert function likes expression Unary_Operator.
- UnarySuffixOperatorConversion(SqlOperator, String) - Constructor for class org.apache.calcite.adapter.druid.UnarySuffixOperatorConversion
- UNBOUNDED_FOLLOWING - Static variable in class org.apache.calcite.rex.RexWindowBounds
-
UNBOUNDED FOLLOWING.
- UNBOUNDED_PRECEDING - Static variable in class org.apache.calcite.rex.RexWindowBounds
-
UNBOUNDED PRECEDING.
- unboundedFollowing() - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
UNBOUNDED FOLLOWING
window bound, for use in methods such asRelBuilder.OverCall.rowsFrom(RexWindowBound)
andRelBuilder.OverCall.rangeBetween(RexWindowBound, RexWindowBound)
. - unboundedFollowingWindowNotSupported() - Method in interface org.apache.calcite.runtime.CalciteResource
- unboundedPreceding() - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
UNBOUNDED PRECEDING
window bound, for use in methods such asRelBuilder.OverCall.rowsFrom(RexWindowBound)
andRelBuilder.OverCall.rangeBetween(RexWindowBound, RexWindowBound)
. - UnboundMetadata<M extends @Nullable Metadata> - Interface in org.apache.calcite.rel.metadata
-
Metadata that needs to be bound to a
RelNode
andRelMetadataQuery
before it can be used. - unbox(Class) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Converts a boxed class to a primitive class; returns other types unchanged.
- unbox(Type) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Converts a boxed type to a primitive type; returns other types unchanged.
- unbox(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- unbox(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Converts e.g.
- unbox(Expression, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents an explicit unboxing.
- unbox(Expression, Primitive) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Returns an expression to unbox the value of a boxed-primitive expression.
- Unbox - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An unbox value type operation, such as unbox and unbox.any instructions in MSIL.
- unboxExact(Expression, Primitive) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Returns an expression to unbox the value of a boxed-primitive expression exactly.
- unchain(SqlNode) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Converts a chained string literals into regular literals; returns regular literals unchanged.
- uncollect(List<String>, boolean) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
Uncollect
with given item aliases. - Uncollect - Class in org.apache.calcite.rel.core
-
Relational expression that unnests its input's columns into a relation.
- Uncollect(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.rel.core.Uncollect
-
Deprecated.
- Uncollect(RelOptCluster, RelTraitSet, RelNode, boolean, List<String>) - Constructor for class org.apache.calcite.rel.core.Uncollect
-
Creates an Uncollect.
- Uncollect(RelInput) - Constructor for class org.apache.calcite.rel.core.Uncollect
-
Creates an Uncollect by parsing serialized output.
- UncollectNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
Uncollect
. - UncollectNode(Compiler, Uncollect) - Constructor for class org.apache.calcite.interpreter.UncollectNode
- UNDERFLOW - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName.Limit
- unescapeUnicode(char) - Method in class org.apache.calcite.sql.SqlLiteral
-
Transforms this literal (which must be of type character) into a new one in which 4-digit Unicode escape sequences have been replaced with the corresponding Unicode characters.
- unexpected(E) - Static method in class org.apache.calcite.util.Util
-
Returns an exception indicating that we didn't expect to find this enumeration here.
- unicodeEscapeCharIllegal(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- unicodeEscapeCharLength(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- unicodeEscapeMalformed(int) - Method in interface org.apache.calcite.runtime.CalciteResource
- unicodeEscapeUnexpected() - Method in interface org.apache.calcite.runtime.CalciteResource
- unifyAggregates(MutableAggregate, RexNode, MutableAggregate) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
- UnifyRule(int, SubstitutionVisitor.Operand, SubstitutionVisitor.Operand) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.UnifyRule
- UnifyRuleCall(SubstitutionVisitor.UnifyRule, MutableRel, MutableRel, ImmutableList<MutableRel>) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.UnifyRuleCall
- union(boolean) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Union
of the two most recent relational expressions on the stack. - union(boolean, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Union
of then
most recent relational expressions on the stack. - union(Iterable<? extends ImmutableBitSet>) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Returns the union of a number of bit sets.
- union(BitSet) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns the union of this immutable bit set with a
BitSet
. - union(BitSet, BitSet...) - Static method in class org.apache.calcite.util.BitSets
-
Returns a BitSet that is the union of the given BitSets.
- union(Enumerable<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- union(Enumerable<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- union(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- union(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- union(Enumerable<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Produces the set union of two sequences by using the default equality comparer.
- union(Enumerable<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Produces the set union of two sequences by using the default equality comparer.
- union(Enumerable<TSource>, Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Produces the set union of two sequences by using the default equality comparer.
- union(Enumerable<TSource>, Enumerable<TSource>, EqualityComparer<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Produces the set union of two sequences by using a specified EqualityComparer<TSource>.
- union(Enumerable<TSource>, EqualityComparer<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Produces the set union of two sequences by using a specified
EqualityComparer<TSource>
. - union(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Produces the set union of two sequences by using a specified
EqualityComparer<TSource>
. - union(Queryable<T>, Enumerable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Produces the set union of two sequences by using the default equality comparer.
- union(Queryable<T>, Enumerable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Produces the set union of two sequences by using the default equality comparer.
- union(Queryable<T>, Enumerable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- union(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Produces the set union of two sequences by using a specified
EqualityComparer<T>
. - union(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Produces the set union of two sequences by using a specified
EqualityComparer<T>
. - union(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- union(RexBuilder, RelOptPredicateList) - Method in class org.apache.calcite.plan.RelOptPredicateList
- union(ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns the union of this bit set with another.
- Union - Class in org.apache.calcite.rel.core
-
Relational expression that returns the union of the rows of its inputs, optionally eliminating duplicates.
- Union(RelOptCluster, RelTraitSet, List<RelHint>, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.core.Union
- Union(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.rel.core.Union
- Union(RelInput) - Constructor for class org.apache.calcite.rel.core.Union
-
Creates a Union by parsing serialized output.
- UNION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
UNION
relational operator. - UNION - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- UNION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- UNION_ALL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- UNION_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that removes empty children of a
Union
. - UNION_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- UNION_PULL_UP_CONSTANTS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that pulls up constants through a Union operator.
- UNION_REMOVE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that removes a
Union
if it has only one input. - UNION_TO_DISTINCT - Static variable in class org.apache.calcite.rel.rules.CoreRules
- UNION_TO_VALUES - Static variable in class org.apache.calcite.rel.rules.CoreRules
- UnionEliminatorRule - Class in org.apache.calcite.rel.rules
-
UnionEliminatorRule
checks to see if its possible to optimize a Union call by eliminating the Union operator altogether in the case the call consists of only one input. - UnionEliminatorRule(Class<? extends Union>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.UnionEliminatorRule
-
Deprecated.
- UnionEliminatorRule(UnionEliminatorRule.Config) - Constructor for class org.apache.calcite.rel.rules.UnionEliminatorRule
-
Creates a UnionEliminatorRule.
- UnionEliminatorRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- UnionMergeRule - Class in org.apache.calcite.rel.rules
- UnionMergeRule(Class<? extends SetOp>, String, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.UnionMergeRule
-
Deprecated.
- UnionMergeRule(Class<? extends Union>, RelFactories.SetOpFactory) - Constructor for class org.apache.calcite.rel.rules.UnionMergeRule
-
Deprecated.
- UnionMergeRule(UnionMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.UnionMergeRule
-
Creates a UnionMergeRule.
- UnionMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- UnionNode - Class in org.apache.calcite.interpreter
-
Deprecated.Use
SetOpNode
- UnionNode(Compiler, Union) - Constructor for class org.apache.calcite.interpreter.UnionNode
-
Deprecated.
- UnionOperation - Class in org.apache.calcite.runtime
-
Used at run time by the ST_Union function.
- UnionOperation() - Constructor for class org.apache.calcite.runtime.UnionOperation
- unionPreds(RexBuilder, RexNode, RexNode) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
AND's two predicates together, either of which may be null, removing redundant filters.
- UnionPullUpConstantsRule - Class in org.apache.calcite.rel.rules
-
Planner rule that pulls up constants through a Union operator.
- UnionPullUpConstantsRule(Class<? extends Union>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.UnionPullUpConstantsRule
-
Deprecated.
- UnionPullUpConstantsRule(UnionPullUpConstantsRule.Config) - Constructor for class org.apache.calcite.rel.rules.UnionPullUpConstantsRule
-
Creates a UnionPullUpConstantsRule.
- UnionPullUpConstantsRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- unionRewritingPullProgram() - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewRule.Config
-
If we generate union rewriting, we might want to pull up projections from the query itself to maximize rewriting opportunities.
- UnionToDistinctRule - Class in org.apache.calcite.rel.rules
- UnionToDistinctRule(Class<? extends Union>, RelFactories.SetOpFactory) - Constructor for class org.apache.calcite.rel.rules.UnionToDistinctRule
-
Deprecated.
- UnionToDistinctRule(Class<? extends Union>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.UnionToDistinctRule
-
Deprecated.
- UnionToDistinctRule(UnionToDistinctRule.Config) - Constructor for class org.apache.calcite.rel.rules.UnionToDistinctRule
-
Creates a UnionToDistinctRule.
- UnionToDistinctRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- UnionToValuesRule - Class in org.apache.calcite.rel.rules
- UnionToValuesRule(UnionToValuesRule.Config) - Constructor for class org.apache.calcite.rel.rules.UnionToValuesRule
-
Creates a UnionToValuesRule.
- UnionToValuesRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- unique(Iterable<RexNode>) - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
-
Returns a copy of this AggCall that makes its input values unique by
distinctKeys
before aggregating, as in SQL'sWITHIN DISTINCT
clause. - unique(Function<RelBuilder, RelNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a UNIQUE predicate.
- unique(RelNode) - Static method in class org.apache.calcite.rex.RexSubQuery
-
Creates an UNIQUE sub-query.
- unique(RexNode...) - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
-
Returns a copy of this AggCall that makes its input values unique by
distinctKeys
before aggregating, as in SQL'sWITHIN DISTINCT
clause. - unique(SqlParserPos, SqlIdentifier, SqlNodeList) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a UNIQUE constraint.
- unique(SqlParserPos, SqlIdentifier, SqlNodeList) - Static method in class org.apache.calcite.sql.ddl.SqlKeyConstraint
-
Creates a UNIQUE constraint.
- Unique(SortedSet<Profiler.Column>) - Constructor for class org.apache.calcite.profile.Profiler.Unique
- UNIQUE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
UNIQUE
constraint. - UNIQUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- UNIQUE_KEYS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- uniqueColumnNames() - Method in class org.apache.calcite.materialize.Lattice
- uniqueList - Variable in class org.apache.calcite.profile.Profiler.Profile
- uniqueTableName(CalciteSchema, String) - Static method in class org.apache.calcite.schema.Schemas
-
Generates a table name that is unique within the given schema.
- uniquify() - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Makes sure that field names are unique.
- uniquify() - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- uniquify(String, Set<String>, SqlValidatorUtil.Suggester) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Makes a name distinct from other names which have already been used, adds it to the list, and returns it.
- uniquify(List<? extends String>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Deprecated.
- uniquify(List<? extends String>, boolean) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Makes sure that the names in a list are unique.
- uniquify(List<? extends String>, SqlValidatorUtil.Suggester) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Deprecated.
- uniquify(List<? extends String>, SqlValidatorUtil.Suggester, boolean) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Makes sure that the names in a list are unique.
- unit() - Method in interface org.apache.calcite.rel.type.TimeFrame
-
Returns the built-in unit of this frame, or null if it does not correspond to a built-in unit.
- Unit - Class in org.apache.calcite.runtime
-
Synthetic record with zero fields.
- UNIT_INTERVAL_NUMERIC_LITERAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where type must be a numeric non-NULL literal in the range 0 to 1 inclusive.
- UNIX_DATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- UNIX_DATE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "UNIX_DATE(date)" function; returns the number of days since 1970-01-01.
- UNIX_DATE_CEIL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- UNIX_DATE_EXTRACT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- UNIX_DATE_FLOOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- UNIX_DATE_TO_STRING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- UNIX_MICROS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- UNIX_MICROS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "UNIX_MICROS(bigint)" function; returns the number of microseconds since 1970-01-01 00:00:00.
- UNIX_MILLIS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- UNIX_MILLIS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "UNIX_MILLIS(bigint)" function; returns the number of milliseconds since 1970-01-01 00:00:00.
- UNIX_SECONDS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- UNIX_SECONDS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "UNIX_SECONDS(bigint)" function; returns the number of seconds since 1970-01-01 00:00:00.
- UNIX_TIME_TO_STRING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- UNIX_TIMESTAMP_CEIL - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- UNIX_TIMESTAMP_FLOOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- UNIX_TIMESTAMP_TO_STRING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- unixDate(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- unixDateExtract(String, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- unixDateExtract(TimeUnitRange, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- unixMicros(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- unixMillis(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- unixSeconds(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- UNKNOWN - Enum constant in enum org.apache.calcite.rex.RexUnknownAs
-
Policy that indicates that the expression is being used in a context Where an UNKNOWN value is treated as is.
- UNKNOWN - Enum constant in enum org.apache.calcite.runtime.JsonFunctions.PathMode
- UNKNOWN - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
-
Placeholder for the unknown database.
- UNKNOWN - Enum constant in enum org.apache.calcite.sql.SqlJsonExistsErrorBehavior
- UNKNOWN - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- UNKNOWN - Static variable in class org.apache.calcite.schema.Statistics
-
Returns a
Statistic
that knows nothing about a table. - UNKNOWN_AS_FALSE - Enum constant in enum org.apache.calcite.plan.RelOptUtil.Logic
-
Two-valued logic where UNKNOWN is treated as FALSE.
- UNKNOWN_AS_TRUE - Enum constant in enum org.apache.calcite.plan.RelOptUtil.Logic
-
Two-valued logic where UNKNOWN is treated as TRUE.
- unknownCharacterSet(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- unknownDatatypeName(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- unknownField(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- unknownIdentifier(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- unknownPattern(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- unknownTargetColumn(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- unknownType - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- unmatchInsertColumn(int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- UnmodifiableArrayList<E> - Class in org.apache.calcite.util
-
A view onto an array that cannot be modified by the client.
- UNNEST - Enum constant in enum org.apache.calcite.sql.SqlKind
-
UNNEST
operator. - UNNEST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
UNNEST
operator. - UNNEST_WITH_ORDINALITY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
UNNEST WITH ORDINALITY
operator. - unnestArgument() - Method in interface org.apache.calcite.runtime.CalciteResource
- unordered(RelOptRuleOperand, RelOptRuleOperand...) - Static method in class org.apache.calcite.plan.RelOptRule
-
Deprecated.
- UNORDERED - Enum constant in enum org.apache.calcite.plan.RelOptRuleOperandChildPolicy
-
Signifies that the rule matches any one of its parents' children.
- UNORDERED - Enum constant in enum org.apache.calcite.rel.type.RelDataTypeComparability
- unorderedInputs(RelRule.OperandTransform...) - Method in interface org.apache.calcite.plan.RelRule.OperandDetailBuilder
-
Indicates that this operand has several inputs, unordered.
- unparse(StringBuilder) - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Token
- unparse(SqlWriter) - Method in class org.apache.calcite.sql.SqlCollation
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.babel.postgresql.SqlBegin
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.babel.postgresql.SqlCommit
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.babel.postgresql.SqlDiscard
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.babel.postgresql.SqlRollback
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.babel.postgresql.SqlShow
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.babel.SqlBabelCreateTable
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlAttributeDefinition
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlCheckConstraint
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlColumnDeclaration
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlCreateForeignSchema
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlCreateFunction
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlCreateMaterializedView
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlCreateSchema
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlCreateTable
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlCreateTableLike
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlCreateType
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlCreateView
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlDropObject
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlDropSchema
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlKeyConstraint
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.ddl.SqlTruncateTable
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlAbstractDateTimeLiteral
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlAlienSystemTypeNameSpec
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlAlter
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlBasicTypeNameSpec
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlBinaryStringLiteral
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlCall
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlCharStringLiteral
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlCollectionTypeNameSpec
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlDateLiteral
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlDelete
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlDescribeSchema
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlDescribeTable
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlDynamicParam
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlExplain
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlHint
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlIdentifier
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlInsert
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlIntervalLiteral
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlLambda
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlLiteral
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlMapTypeNameSpec
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlMatchRecognize
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlMerge
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlNode
-
Writes a SQL representation of this node to a writer.
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlNodeList
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlNumericLiteral
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlPivot
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlRowTypeNameSpec
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlSelect
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlSnapshot
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlTableRef
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlTimeLiteral
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlTimestampLiteral
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlTimestampTzLiteral
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlTimeTzLiteral
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlTypeNameSpec
-
Writes a SQL representation of this spec to a writer.
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlUnknownLiteral
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlUnpivot
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlUpdate
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlUserDefinedTypeNameSpec
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlWindow
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlBetweenOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlCaseOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlCastFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlColumnListConstructor
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlConvertFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlCursorConstructor
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlDatetimePlusOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlDatetimeSubtractionOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlDotOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlExtractFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlFloorFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlIntervalOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlItemOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlJsonArrayAggAggFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlJsonArrayFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlJsonExistsFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlJsonObjectAggAggFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlJsonObjectFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlJsonQueryFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlJsonValueFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlLikeOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlLiteralChainOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlMultisetQueryConstructor
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlMultisetValueConstructor
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlOverlapsOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlOverlayFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlPositionFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlPosixRegexOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlRowOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlSequenceValueOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlThrowOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlTranslate3Function
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlTranslateFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlTrimFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlAsofJoin.SqlAsofJoinOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlAsOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlFilterOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlFunction
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlFunctionalOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlInfixOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlJoin.SqlJoinOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlLateralOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlMatchRecognize.SqlMatchRecognizeOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlMeasureOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlNullTreatmentOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlOperator
-
Writes a SQL representation of a call to this operator to a writer, including parentheses if the operators on either side are of greater precedence.
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlSelectOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlSetSemanticsTableOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlSnapshot.SqlSnapshotOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlUnnestOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlValuesOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlWithinDistinctOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlWithinGroupOperator
- unparse(SqlWriter, SqlOperator, SqlCall, int, int) - Method in enum org.apache.calcite.sql.SqlSyntax
-
Converts a call to an operator of this syntax into a string.
- unParse(Ast.UnParser, Ast.Node) - Static method in class org.apache.calcite.piglet.Ast
-
Formats a node and its children as a string.
- unparseAlterOperation(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlAlter
- unparseAlterOperation(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlSetOption
- unparseBinarySyntax(SqlOperator, SqlCall, SqlWriter, int, int) - Static method in class org.apache.calcite.sql.SqlUtil
- unparseBoolLiteral(SqlWriter, SqlLiteral, int, int) - Method in class org.apache.calcite.sql.dialect.OracleSqlDialect
- unparseBoolLiteral(SqlWriter, SqlLiteral, int, int) - Method in class org.apache.calcite.sql.SqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.dialect.ClickHouseSqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.dialect.ExasolSqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.dialect.FireboltSqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.dialect.HiveSqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.dialect.HsqldbSqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.dialect.OracleSqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.dialect.SnowflakeSqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.dialect.SparkSqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.dialect.StarRocksSqlDialect
- unparseCall(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlDialect
- unparseDatetimeFunction(SqlWriter, SqlCall, String, Boolean) - Static method in class org.apache.calcite.sql.fun.SqlFloorFunction
-
Most dialects that natively support datetime floor will use this.
- unparseDateTimeLiteral(SqlWriter, SqlAbstractDateTimeLiteral, int, int) - Method in class org.apache.calcite.sql.dialect.ClickHouseSqlDialect
- unparseDateTimeLiteral(SqlWriter, SqlAbstractDateTimeLiteral, int, int) - Method in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- unparseDateTimeLiteral(SqlWriter, SqlAbstractDateTimeLiteral, int, int) - Method in class org.apache.calcite.sql.dialect.OracleSqlDialect
- unparseDateTimeLiteral(SqlWriter, SqlAbstractDateTimeLiteral, int, int) - Method in class org.apache.calcite.sql.dialect.StarRocksSqlDialect
- unparseDateTimeLiteral(SqlWriter, SqlAbstractDateTimeLiteral, int, int) - Method in class org.apache.calcite.sql.SqlDialect
- unparseFetchUsingAnsi(SqlWriter, SqlNode, SqlNode) - Static method in class org.apache.calcite.sql.SqlDialect
-
Unparses offset/fetch using ANSI standard "OFFSET offset ROWS FETCH NEXT fetch ROWS ONLY" syntax.
- unparseFetchUsingLimit(SqlWriter, SqlNode, SqlNode) - Static method in class org.apache.calcite.sql.SqlDialect
-
Unparses offset/fetch using "LIMIT fetch OFFSET offset" syntax.
- unparseFunctionSyntax(SqlOperator, SqlWriter, SqlCall) - Static method in class org.apache.calcite.sql.SqlUtil
-
Deprecated.
- unparseFunctionSyntax(SqlOperator, SqlWriter, SqlCall, boolean) - Static method in class org.apache.calcite.sql.SqlUtil
-
Unparses a call to an operator that has function syntax.
- unparseHiveTrim(SqlWriter, SqlCall, int, int) - Static method in class org.apache.calcite.util.RelToSqlConverterUtil
-
For usage of TRIM, LTRIM and RTRIM in Hive, see Hive UDF usage.
- unparseLimit(SqlWriter, SqlNode) - Static method in class org.apache.calcite.sql.SqlDialect
- unparseListClause(SqlWriter, SqlNode) - Method in class org.apache.calcite.sql.SqlOperator
-
Deprecated.
- unparseListClause(SqlWriter, SqlNode, SqlKind) - Method in class org.apache.calcite.sql.SqlOperator
-
Deprecated.
- unparseOffset(SqlWriter, SqlNode) - Static method in class org.apache.calcite.sql.SqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.ClickHouseSqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.ExasolSqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.FireboltSqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.HiveSqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.HsqldbSqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.OracleSqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.RedshiftSqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.SparkSqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.SybaseSqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.SqlDialect
-
Converts an offset and fetch into SQL.
- unparseSparkArrayAndMap(SqlWriter, SqlCall, int, int) - Static method in class org.apache.calcite.util.RelToSqlConverterUtil
-
Unparses Array and Map value constructor.
- unparseSqlDatetimeArithmetic(SqlWriter, SqlCall, SqlKind, int, int) - Method in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- unparseSqlDatetimeArithmetic(SqlWriter, SqlCall, SqlKind, int, int) - Method in class org.apache.calcite.sql.SqlDialect
- unparseSqlIdentifierSyntax(SqlWriter, SqlIdentifier, boolean) - Static method in class org.apache.calcite.sql.SqlUtil
-
Unparse a SqlIdentifier syntax.
- unparseSqlIntervalLiteral(SqlWriter, SqlIntervalLiteral, int, int) - Method in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
-
BigQuery interval syntax: INTERVAL int64 time_unit.
- unparseSqlIntervalLiteral(SqlWriter, SqlIntervalLiteral, int, int) - Method in class org.apache.calcite.sql.dialect.Db2SqlDialect
- unparseSqlIntervalLiteral(SqlWriter, SqlIntervalLiteral, int, int) - Method in class org.apache.calcite.sql.dialect.FireboltSqlDialect
-
Firebolt interval syntax: sign INTERVAL int64 time_unit.
- unparseSqlIntervalLiteral(SqlWriter, SqlIntervalLiteral, int, int) - Method in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- unparseSqlIntervalLiteral(SqlWriter, SqlIntervalLiteral, int, int) - Method in class org.apache.calcite.sql.SqlDialect
-
Converts an interval literal to a SQL string.
- unparseSqlIntervalQualifier(SqlWriter, SqlIntervalQualifier, RelDataTypeSystem) - Method in class org.apache.calcite.sql.dialect.BigQuerySqlDialect
- unparseSqlIntervalQualifier(SqlWriter, SqlIntervalQualifier, RelDataTypeSystem) - Method in class org.apache.calcite.sql.dialect.Db2SqlDialect
- unparseSqlIntervalQualifier(SqlWriter, SqlIntervalQualifier, RelDataTypeSystem) - Method in class org.apache.calcite.sql.dialect.FireboltSqlDialect
- unparseSqlIntervalQualifier(SqlWriter, SqlIntervalQualifier, RelDataTypeSystem) - Method in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- unparseSqlIntervalQualifier(SqlWriter, SqlIntervalQualifier, RelDataTypeSystem) - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- unparseSqlIntervalQualifier(SqlWriter, SqlIntervalQualifier, RelDataTypeSystem) - Method in class org.apache.calcite.sql.dialect.PrestoSqlDialect
- unparseSqlIntervalQualifier(SqlWriter, SqlIntervalQualifier, RelDataTypeSystem) - Method in class org.apache.calcite.sql.SqlDialect
-
Converts an interval qualifier to a SQL string.
- unparseTableScanHints(SqlWriter, SqlNodeList, int, int) - Method in class org.apache.calcite.sql.dialect.AnsiSqlDialect
-
Converts table scan hints.
- unparseTableScanHints(SqlWriter, SqlNodeList, int, int) - Method in class org.apache.calcite.sql.SqlDialect
-
Converts table scan hints.
- unparseTopN(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- unparseTopN(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.SybaseSqlDialect
- unparseTopN(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.SqlDialect
-
Converts a fetch into a "SELECT TOP(fetch)".
- unparseWithParentheses(SqlWriter, int, int, boolean) - Method in class org.apache.calcite.sql.SqlNode
- UnparsingTesterImpl() - Constructor for class org.apache.calcite.sql.parser.SqlParserTest.UnparsingTesterImpl
- unpivot(boolean, Iterable<String>, Iterable<String>, Iterable<? extends Map.Entry<? extends List<? extends RexLiteral>, ? extends List<? extends RexNode>>>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an Unpivot.
- UNPIVOT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
UNPIVOT clause.
- unpivotCannotDeriveAxisType(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- unpivotCannotDeriveMeasureType(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- unpivotDuplicate(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- UnpivotNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for an
UNPIVOT
clause. - UnpivotNamespace(SqlValidatorImpl, SqlUnpivot, SqlNode) - Constructor for class org.apache.calcite.sql.validate.UnpivotNamespace
-
Creates an UnpivotNamespace.
- UnpivotScope - Class in org.apache.calcite.sql.validate
-
Scope for expressions in an
UNPIVOT
clause. - UnpivotScope(SqlValidatorScope, SqlUnpivot) - Constructor for class org.apache.calcite.sql.validate.UnpivotScope
-
Creates an UnpivotScope.
- unpivotValueArityMismatch(int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- UNQUOTED_CASING - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
How identifiers are stored if they are not quoted.
- unquotedCasing - Variable in enum org.apache.calcite.config.Lex
- unquotedCasing() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.UNQUOTED_CASING
. - unquotedCasing() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- unquotedCasing() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- unquotedCasing() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- unquoteStringLiteral(String) - Method in class org.apache.calcite.sql.SqlDialect
-
Converts a string literal back into a string.
- Unsafe - Class in org.apache.calcite.test
-
Contains methods that call JDK methods that the forbidden APIs checker does not approve of.
- Unsafe - Class in org.apache.calcite.util
-
Contains methods that call JDK methods that the forbidden APIs checker does not approve of.
- UnsafeX509ExtendedTrustManager - Class in org.apache.calcite.util
-
This class is used to disable SSL Certificate Verification in Calcite adapters that make http calls.
- unset(CalciteConnectionProperty) - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
-
Returns a copy of this configuration with the value of a property removed.
- UNSPECIFIED - Enum constant in enum org.apache.calcite.rel.RelFieldCollation.NullDirection
- UNSPECIFIED - Enum constant in enum org.apache.calcite.sql.babel.TableCollectionType
-
Table collection type is not specified.
- unstrict() - Method in enum org.apache.calcite.sql.validate.SqlMonotonicity
-
If this is a strict monotonicity (StrictlyIncreasing, StrictlyDecreasing) returns the non-strict equivalent (Increasing, Decreasing).
- unsupportedCount - Variable in class org.apache.calcite.rex.RexAnalyzer
- unsupportedIntervalLiteral(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- unsupportedTypeInConvertFunc(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- unsupportedTypeInOrderBy(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- UNVALIDATED - Enum constant in enum org.apache.calcite.sql.validate.SqlValidatorImpl.Status
-
Validation has not started for this scope.
- unwrap(Class<C>) - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- unwrap(Class<C>) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- unwrap(Class<C>) - Method in class org.apache.calcite.schema.impl.AbstractTable
- unwrap(Class<C>) - Method in class org.apache.calcite.schema.impl.ModifiableViewTable
- unwrap(Class<C>) - Method in interface org.apache.calcite.schema.Wrapper
-
Finds an instance of an interface implemented by this object, or returns null if this object does not support that interface.
- unwrap(Class<C>) - Method in class org.apache.calcite.sql.validate.DelegatingSqlValidatorCatalogReader
- unwrap(Class<T>) - Method in class org.apache.calcite.adapter.jdbc.JdbcCatalogSchema
- unwrap(Class<T>) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- unwrap(Class<T>) - Method in class org.apache.calcite.jdbc.CalciteStatement
- unwrap(Class<T>) - Method in class org.apache.calcite.plan.RelOptAbstractTable
- unwrap(Class<T>) - Method in class org.apache.calcite.prepare.RelOptTableImpl
- unwrap(Class<T>) - Method in interface org.apache.calcite.schema.SchemaPlus
-
Returns an underlying object.
- unwrap(Class<T>) - Method in class org.apache.calcite.sql.fun.SqlAnyValueAggFunction
- unwrap(Class<T>) - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- unwrap(Class<T>) - Method in class org.apache.calcite.sql.fun.SqlBitOpAggFunction
- unwrap(Class<T>) - Method in class org.apache.calcite.sql.fun.SqlCountAggFunction
- unwrap(Class<T>) - Method in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
- unwrap(Class<T>) - Method in class org.apache.calcite.sql.fun.SqlSingleValueAggFunction
- unwrap(Class<T>) - Method in class org.apache.calcite.sql.fun.SqlSumAggFunction
- unwrap(Class<T>) - Method in class org.apache.calcite.sql.fun.SqlSumEmptyIsZeroAggFunction
- unwrap(Class<T>) - Method in class org.apache.calcite.sql.SqlAggFunction
- unwrap(Class<T>) - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- unwrap(Class<T>) - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- unwrap(Class<T>) - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns this namespace, or a wrapped namespace, cast to a particular class.
- unwrap(Class<T>) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable
- unwrap(Class<T>) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockRelViewTable
- unwrap(Class<T>) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- unwrap(Class<T>) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable
- unwrap(Expression, Class) - Static method in class org.apache.calcite.schema.Schemas
-
Converts a schema expression to a given type by calling the
SchemaPlus.unwrap(Class)
method. - unwrapOrThrow(Class<C>) - Method in interface org.apache.calcite.schema.Wrapper
-
Finds an instance of an interface implemented by this object, or throws NullPointerException if this object does not support that interface.
- UPDATE - Enum constant in enum org.apache.calcite.rel.core.TableModify.Operation
- UPDATE - Enum constant in enum org.apache.calcite.sql.SqlAccessEnum
- UPDATE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
UPDATE statement.
- UPDATE_ANON_PREFIX - Static variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Alias prefix generated for source columns when rewriting UPDATE to MERGE.
- UPDATE_SET_LIST - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
The SET clause of an UPDATE statement.
- UPDATE_SRC_ALIAS - Static variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Alias generated for the source table when rewriting UPDATE to MERGE.
- UPDATE_TGT_ALIAS - Static variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Alias generated for the target table when rewriting UPDATE to MERGE if no alias was specified by the user.
- updateAlias(Operator, String, boolean) - Method in class org.apache.calcite.piglet.PigRelBuilder
-
Updates the Pig logical operator and its alias with the top relational algebra node.
- updateColumnList - Variable in class org.apache.calcite.rel.mutable.MutableTableModify
- updateInferredColumnType(SqlValidatorScope, SqlNode, int, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
-
Update inferred row type for a query, i.e.
- updateInferredType(SqlNode, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
-
Update inferred type for a SqlNode.
- updateRelInMap(SortedSetMultimap<RelNode, CorrelationId>) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- updateRelInMap(SortedMap<CorrelationId, LogicalCorrelate>) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- updates(int) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- updateSetFolding() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the line-folding policy for the SET clause of an UPDATE statement.
- updateSetListNewline() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether each assignment in the SET clause of an UPDATE or MERGE statement should be on its own line.
- upgrade(String) - Static method in class org.apache.calcite.util.Bug
-
Use this method to flag code that should be re-visited after upgrading a component.
- upper() - Method in class org.apache.calcite.runtime.SpaceFillingCurve2D.AbstractRange
- upper() - Method in interface org.apache.calcite.runtime.SpaceFillingCurve2D.IndexRange
- upper(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL UPPER(string) function.
- UPPER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- UPPER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- UPPER_OPERAND - Static variable in class org.apache.calcite.sql.fun.SqlBetweenOperator
-
Ordinal of the 'upper' operand.
- upperBound - Variable in class org.apache.calcite.rel.core.Window.Group
- upperBound(T[], K, int, int, Function1<T, K>, Comparator<K>) - Static method in class org.apache.calcite.runtime.BinarySearch
-
Taken from http://en.wikipedia.org/wiki/Binary_search_algorithm #Deferred_detection_of_equality Adapted to find upper bound.
- upperBound(T[], K, Function1<T, K>, Comparator<K>) - Static method in class org.apache.calcite.runtime.BinarySearch
-
Performs binary search of the upper bound in the given array.
- upperBound(T[], T, int, int, Comparator<T>) - Static method in class org.apache.calcite.runtime.BinarySearch
-
Performs binary search of the upper bound in the given array.
- upperBound(T[], T, Comparator<T>) - Static method in class org.apache.calcite.runtime.BinarySearch
-
Performs binary search of the upper bound in the given array.
- upperBoundForInputs(RelNode, RelOptCost) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Gets the upper bound of its inputs.
- UPSERT - Enum constant in enum org.apache.calcite.sql.SqlInsertKeyword
- url - Variable in class org.apache.calcite.test.ConnectionSpec
- url() - Method in interface org.apache.calcite.util.Source
- url(String) - Static method in class org.apache.calcite.util.Sources
- URL_DECODE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- URL_DECODE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "URL_DECODE(string)" function.
- URL_ENCODE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- URL_ENCODE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "URL_ENCODE(string)" function.
- urlDecode(String) - Static method in class org.apache.calcite.runtime.UrlFunctions
-
The "URL_DECODE(string)" function for Hive and Spark, which returns original value when decoded error.
- urlEncode(String) - Static method in class org.apache.calcite.runtime.UrlFunctions
-
The "URL_ENCODE(string)" function for Hive and Spark.
- UrlFunctions - Class in org.apache.calcite.runtime
-
A collection of functions used in Url processing.
- use(Lattice.Column, boolean) - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Records a use of a column.
- useAbstractConvertersForConversion(RelTraitSet, RelTraitSet) - Method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- useAbstractConvertersForConversion(RelTraitSet, RelTraitSet) - Method in enum org.apache.calcite.interpreter.BindableConvention
- useAbstractConvertersForConversion(RelTraitSet, RelTraitSet) - Method in enum org.apache.calcite.interpreter.InterpretableConvention
- useAbstractConvertersForConversion(RelTraitSet, RelTraitSet) - Method in class org.apache.calcite.plan.Convention.Impl
- useAbstractConvertersForConversion(RelTraitSet, RelTraitSet) - Method in interface org.apache.calcite.plan.Convention
-
Returns whether we should convert from this trait set to the other trait set.
- usedColumnNames() - Method in class org.apache.calcite.sql.SqlPivot
-
Returns the set of columns that are referenced as an argument to an aggregate function or in a column in the
FOR
clause. - usedColumnNames() - Method in class org.apache.calcite.sql.SqlUnpivot
-
Returns the set of columns that are referenced in the
FOR
clause. - useDefaultFractionalSecondPrecision() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Returns
true
if fractional second precision is not specified. - useDefaultStartPrecision() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Returns
true
if start precision is not specified. - useDoubleMultiplication(RelDataType, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
- useDoubleMultiplication(RelDataType, RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
-
Deprecated.
- useLattices(RelNode, List<RelOptLattice>) - Static method in class org.apache.calcite.plan.RelOptMaterializations
-
Returns a list of RelNode transformed from all possible lattice uses.
- USELESS - Static variable in interface org.apache.calcite.server.DdlExecutor
-
DDL executor that cannot handle any DDL.
- useMaterializedViews(RelNode, List<RelOptMaterialization>) - Static method in class org.apache.calcite.plan.RelOptMaterializations
-
Returns a list of RelNode transformed from all possible combination of materialized view uses.
- useMaterializedViews(RelNode, List<RelOptMaterialization>, List<SubstitutionVisitor.UnifyRule>) - Static method in class org.apache.calcite.plan.RelOptMaterializations
-
Returns a list of RelNode transformed from all possible combination of materialized view uses.
- user(DataContext) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
USER
function. - USER - Enum constant in enum org.apache.calcite.DataContext.Variable
-
The query user.
- USER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- USER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
USER
function. - USER_DEFINED_CONSTRUCTOR - Enum constant in enum org.apache.calcite.sql.SqlFunctionCategory
- USER_DEFINED_FUNCTION - Enum constant in enum org.apache.calcite.sql.SqlFunctionCategory
- USER_DEFINED_PROCEDURE - Enum constant in enum org.apache.calcite.sql.SqlFunctionCategory
- USER_DEFINED_SPECIFIC_FUNCTION - Enum constant in enum org.apache.calcite.sql.SqlFunctionCategory
- USER_DEFINED_TABLE_FUNCTION - Enum constant in enum org.apache.calcite.sql.SqlFunctionCategory
- USER_DEFINED_TABLE_SPECIFIC_FUNCTION - Enum constant in enum org.apache.calcite.sql.SqlFunctionCategory
- UserDefinedAggReflectiveImplementor(AggregateFunctionImpl) - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.UserDefinedAggReflectiveImplementor
- userDefinedFunctionCoercion(SqlValidatorScope, SqlCall, SqlFunction) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Non built-in functions (UDFs) type coercion, compare the types of arguments with rules: Named param: find the desired type by the passed in operand's name Non-named param: find the desired type by formal parameter ordinal
- userDefinedFunctionCoercion(SqlValidatorScope, SqlCall, SqlFunction) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
-
Type coercion for user-defined functions (UDFs).
- username - Variable in class org.apache.calcite.test.ConnectionSpec
- USING - Enum constant in enum org.apache.calcite.sql.JoinConditionType
-
Join clause has a
USING
condition, for example "FROM EMP JOIN DEPT USING (DEPTNO)
". - usingNames(SqlJoin) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Returns the set of field names in the join condition specified by USING or implicitly by NATURAL, de-duplicated and in order.
- UTC_TIMESTAMP - Enum constant in enum org.apache.calcite.DataContext.Variable
- UTC_TZ - Static variable in class org.apache.calcite.test.SqlOperatorTest
- UTF16 - Enum constant in enum org.apache.calcite.sql.SqlJsonEncoding
- UTF32 - Enum constant in enum org.apache.calcite.sql.SqlJsonEncoding
- UTF8 - Enum constant in enum org.apache.calcite.sql.SqlJsonEncoding
- Util - Class in org.apache.calcite.util
-
Miscellaneous utility functions.
- Util.FoundOne - Exception Class in org.apache.calcite.util
-
Exception used to interrupt a tree walk of any kind.
- Util.OverFinder - Class in org.apache.calcite.util
-
Visitor which looks for an OVER clause inside a tree of
SqlNode
objects. - utilDate - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- Utilities - Class in org.apache.calcite.runtime
-
Utility methods called by generated code.
- Utilities() - Constructor for class org.apache.calcite.runtime.Utilities
V
- V2M - Enum constant in enum org.apache.calcite.sql.SqlKind
-
V2M
(value-to-measure) internal operator. - V2M - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
V2M
operator converts a value to a measure. - VALID - Enum constant in enum org.apache.calcite.sql.validate.SqlValidatorImpl.Status
-
Validation has completed (perhaps unsuccessfully).
- validate(String) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
-
Attempts to parse and validate a SQL statement.
- validate(RelDataType) - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- validate(RelDataType) - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- validate(RelDataType) - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Validates this namespace.
- validate(SqlNode) - Method in class org.apache.calcite.prepare.PlannerImpl
- validate(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates an expression tree.
- validate(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validate(SqlNode) - Method in interface org.apache.calcite.tools.Planner
-
Validates a SQL statement.
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlCall
-
Validates this call.
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlDelete
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlDynamicParam
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlIdentifier
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlInsert
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlLiteral
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlMatchRecognize
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlMerge
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlNode
-
Validates this node.
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlNodeList
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlSelect
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlSetOption
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlUpdate
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlWindow
- validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlWith
- VALIDATE - Enum constant in enum org.apache.calcite.sql.test.SqlTests.Stage
- validateAggregateParams(SqlCall, SqlNode, SqlNodeList, SqlNodeList, SqlValidatorScope) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates parameters for aggregate function.
- validateAggregateParams(SqlCall, SqlNode, SqlNodeList, SqlNodeList, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateAndApply(SqlTestFactory, StringAndPos, SqlTester.ValidatedNodeFunction<R>) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- validateAndApply(SqlTestFactory, StringAndPos, SqlTester.ValidatedNodeFunction<R>) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Parses and validates a query, then calls a function on the result.
- validateAndGetType(SqlNode) - Method in class org.apache.calcite.prepare.PlannerImpl
- validateAndGetType(SqlNode) - Method in interface org.apache.calcite.tools.Planner
-
Validates a SQL statement.
- validateAndThen(SqlTestFactory, StringAndPos, SqlTester.ValidatedNodeConsumer) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- validateAndThen(SqlTestFactory, StringAndPos, SqlTester.ValidatedNodeConsumer) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Parses and validates a query, then calls an action on the result.
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.fun.SqlAbstractGroupFunction
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.fun.SqlCaseOperator
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.fun.SqlConvertFunction
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.fun.SqlDotOperator
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.fun.SqlExtractFunction
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.fun.SqlFloorFunction
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.fun.SqlLikeOperator
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.fun.SqlLiteralChainOperator
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.fun.SqlSequenceValueOperator
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.fun.SqlTimestampAddFunction
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.fun.SqlTranslateFunction
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlAggFunction
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlAsOperator
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlBasicFunction
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlFilterOperator
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlFunction
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlMatchRecognize.SqlMatchRecognizeOperator
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlNullTreatmentOperator
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlOperator
-
Validates a call to this operator.
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlOverOperator
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlSetOperator
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlWithinDistinctOperator
- validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlWithinGroupOperator
- validateCall(SqlCall, SqlValidatorScope) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates a call to an operator.
- validateCall(SqlCall, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateCharset(ByteString, Charset) - Static method in class org.apache.calcite.sql.SqlUtil
-
Validate if value can be decoded by given charset.
- validateDataType(SqlDataTypeSpec) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates a data type expression.
- validateDataType(SqlDataTypeSpec) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateDelete(SqlDelete) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates a DELETE statement.
- validateDelete(SqlDelete) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validatedRowType - Variable in class org.apache.calcite.rel.RelRoot
- validateDynamicParam(SqlDynamicParam) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates a dynamic parameter.
- validateDynamicParam(SqlDynamicParam) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- ValidateErrorInfo(int, int, int, int, String) - Constructor for class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
-
Creates a new ValidateErrorInfo with the position coordinates and an error string.
- ValidateErrorInfo(CalciteContextException) - Constructor for class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
-
Creates a new ValidateErrorInfo with an CalciteContextException.
- ValidateErrorInfo(SqlParserPos, String) - Constructor for class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
-
Creates a new ValidateErrorInfo with a SqlParserPos and an error string.
- validateExpr(SqlNode) - Method in class org.apache.calcite.sql.validate.AggregatingSelectScope
- validateExpr(SqlNode) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- validateExpr(SqlNode) - Method in class org.apache.calcite.sql.validate.ParameterScope
- validateExpr(SqlNode) - Method in class org.apache.calcite.sql.validate.GroupByScope
- validateExpr(SqlNode) - Method in class org.apache.calcite.sql.validate.MeasureScope
- validateExpr(SqlNode) - Method in class org.apache.calcite.sql.validate.OrderByScope
- validateExpr(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Performs any scope-specific validation of an expression.
- validateExpr(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlIdentifier
- validateExpr(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlNode
-
Validates this node in an expression context.
- validateExpr(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlNodeList
- validateExpression(RelDataType, SqlNode) - Method in interface org.apache.calcite.sql2rel.InitializerContext
-
Validate the expression with a base table row type.
- validateExpression(RelDataType, SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- validateExprWithRowType(boolean, SqlOperatorTable, RelDataTypeFactory, RelDataType, SqlNode) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Validate the sql node with specified base table row type.
- validateFeature(Feature, SqlParserPos) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates that a particular feature is enabled.
- validateFrom(SqlNode, RelDataType, SqlValidatorScope) - Method in class org.apache.calcite.sql.advise.SqlAdvisorValidator
- validateFrom(SqlNode, RelDataType, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates the FROM clause of a query, or (recursively) a child node of the FROM clause: AS, OVER, JOIN, VALUES, or sub-query.
- validateGroupClause(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates the GROUP BY clause of a SELECT statement.
- validateGroupList(List<RelBuilder.GroupKey>) - Method in class org.apache.calcite.tools.PigRelBuilder
- validateHavingClause(SqlSelect) - Method in class org.apache.calcite.sql.advise.SqlAdvisorValidator
-
Calls the parent class method and masks Farrago exception thrown.
- validateHavingClause(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateHint(RelHint) - Method in class org.apache.calcite.rel.hint.HintStrategyTable
-
Checks if the given hint is valid.
- validateIdentifier(SqlIdentifier, SqlValidatorScope) - Method in class org.apache.calcite.sql.advise.SqlAdvisorValidator
-
Registers the identifier and its scope into a map keyed by ParserPosition.
- validateIdentifier(SqlIdentifier, SqlValidatorScope) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Resolves an identifier to a fully-qualified name.
- validateIdentifier(SqlIdentifier, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.AliasNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.CollectNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.LambdaNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.MatchRecognizeNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.PivotNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.ProcedureNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.SelectNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.SetopNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.TableConstructorNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.UnpivotNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.WithNamespace
- validateInsert(SqlInsert) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates an INSERT statement.
- validateInsert(SqlInsert) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateIntervalQualifier(SqlIntervalQualifier) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates a
SqlIntervalQualifier
. - validateIntervalQualifier(SqlIntervalQualifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateJoin(SqlJoin, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateJoinFilters(List<RexNode>, List<RexNode>, Join, JoinRelType) - Method in class org.apache.calcite.rel.rules.FilterJoinRule
-
Validates that target execution framework can satisfy join filters.
- validateLambda(SqlLambda) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates a lambda expression.
- validateLambda(SqlLambda) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateLiteral(SqlLiteral) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates a literal.
- validateLiteral(SqlLiteral) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateMatchRecognize(SqlCall) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates a MATCH_RECOGNIZE clause.
- validateMatchRecognize(SqlCall) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateMerge(SqlMerge) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates a MERGE statement.
- validateMerge(SqlMerge) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateModality(SqlSelect, SqlModality, boolean) - Method in class org.apache.calcite.sql.advise.SqlAdvisorValidator
- validateModality(SqlSelect, SqlModality, boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates that a query is capable of producing a return of given modality (relational or streaming).
- validateModality(SqlSelect, SqlModality, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateNamespace(SqlValidatorNamespace, RelDataType) - Method in class org.apache.calcite.sql.advise.SqlAdvisorValidator
- validateNamespace(SqlValidatorNamespace, RelDataType) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates a namespace.
- validateOperands(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.SqlOperator
-
Validates the operands of a call, inferring the return type in the process.
- validateOrderList(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates the ORDER BY clause of a SELECT statement.
- validateOver(SqlCall, SqlValidatorScope) - Method in class org.apache.calcite.sql.advise.SqlAdvisorValidator
- validateOver(SqlCall, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateParameterizedExpression(SqlNode, Map<String, RelDataType>) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates an expression tree.
- validateParameterizedExpression(SqlNode, Map<String, RelDataType>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validatePercentage(Double) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Validates whether a value represents a percentage number (that is, a value in the interval [0.0, 1.0]) and returns the value.
- validatePivot(SqlPivot) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateQualifyClause(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateQuantifier(SqlValidator, SqlCall) - Method in class org.apache.calcite.sql.SqlFunction
-
Throws a validation error if a DISTINCT or ALL quantifier is present but not allowed.
- validateQuery(SqlNode, SqlValidatorScope, RelDataType) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Checks that a query is valid.
- validateQuery(SqlNode, SqlValidatorScope, RelDataType) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateResult(Double) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Validates the
result
is valid. - validateSelect(SqlSelect, RelDataType) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates a SELECT statement.
- validateSelectList(SqlNodeList, SqlSelect, RelDataType) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateSequenceValue(SqlValidatorScope, SqlIdentifier) - Method in interface org.apache.calcite.sql.validate.SqlValidator
- validateSequenceValue(SqlValidatorScope, SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateTableFunction(SqlCall, SqlValidatorScope, RelDataType) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateTimeFrame(SqlIntervalQualifier) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates a time frame.
- validateTimeFrame(SqlIntervalQualifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateUnnest(SqlCall, SqlValidatorScope, RelDataType) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateUnpivot(SqlUnpivot) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateUpdate(SqlUpdate) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates an UPDATE statement.
- validateUpdate(SqlUpdate) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateValueAgainstConstraint(SqlNode, RexNode, Supplier<CalciteContextException>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Ensures that a source value does not violate the constraint of the target column.
- validateValues(SqlCall, RelDataType, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates a VALUES clause.
- validateWhereClause(SqlSelect) - Method in class org.apache.calcite.sql.advise.SqlAdvisorValidator
-
Calls the parent class method and masks Farrago exception thrown.
- validateWhereClause(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateWhereOrOn(SqlValidatorScope, SqlNode, String) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateWindow(SqlNode, SqlValidatorScope, SqlCall) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates the right-hand side of an OVER expression.
- validateWindow(SqlNode, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateWindowClause(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateWith(SqlWith, SqlValidatorScope) - Method in interface org.apache.calcite.sql.validate.SqlValidator
- validateWith(SqlWith, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateWithItem(SqlWithItem) - Method in interface org.apache.calcite.sql.validate.SqlValidator
- validateWithItem(SqlWithItem) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validationError(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- ValidationException - Exception Class in org.apache.calcite.tools
-
An Exception thrown when attempting to validate a SQL parse tree.
- ValidationException(String) - Constructor for exception class org.apache.calcite.tools.ValidationException
-
Creates a ValidationException with the specified detail message.
- ValidationException(String, Throwable) - Constructor for exception class org.apache.calcite.tools.ValidationException
-
Creates a ValidationException with the specified detail message and cause.
- ValidationException(Throwable) - Constructor for exception class org.apache.calcite.tools.ValidationException
-
Creates a ValidationException with the specified cause.
- validator - Variable in class org.apache.calcite.sql.validate.IdentifierNamespace
- validator - Variable in class org.apache.calcite.sql.validate.DelegatingScope
- validator - Variable in class org.apache.calcite.sql.validate.ParameterScope
- validator - Variable in class org.apache.calcite.sql.validate.implicit.AbstractTypeCoercion
- validator - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- validatorConfig - Variable in class org.apache.calcite.sql.test.SqlTestFactory
- validatorContext(int, int, int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- validatorContextPoint(int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- validatorUnknownFunction(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- validConstant(Object, Litmus) - Static method in class org.apache.calcite.rex.RexLiteral
-
Returns whether a value is valid as a constant value, using the same criteria as
RexLiteral.valueMatchesType(java.lang.Comparable, org.apache.calcite.sql.type.SqlTypeName, boolean)
. - validRexOperands(int, Litmus) - Method in class org.apache.calcite.sql.fun.SqlBetweenOperator
- validRexOperands(int, Litmus) - Method in class org.apache.calcite.sql.fun.SqlDotOperator
- validRexOperands(int, Litmus) - Method in class org.apache.calcite.sql.fun.SqlInOperator
- validRexOperands(int, Litmus) - Method in class org.apache.calcite.sql.fun.SqlLikeOperator
- validRexOperands(int, Litmus) - Method in class org.apache.calcite.sql.SqlBinaryOperator
- validRexOperands(int, Litmus) - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether the given operands are valid.
- validRexOperands(int, Litmus) - Method in class org.apache.calcite.sql.SqlPostfixOperator
- validRexOperands(int, Litmus) - Method in class org.apache.calcite.sql.SqlPrefixOperator
- value - Variable in class org.apache.calcite.linq4j.tree.ConstantExpression
- value - Variable in class org.apache.calcite.sql.SqlLiteral
-
The value of this literal.
- value - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.IntAndString
- value - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.IntHolder
- value() - Element in annotation type org.apache.calcite.adapter.java.Map
-
Value type.
- value() - Method in class org.apache.calcite.config.CalciteSystemProperty
-
Returns the value of this property.
- value() - Element in annotation type org.apache.calcite.linq4j.function.Hints
- value(RexNode) - Static method in class org.apache.calcite.rex.RexLiteral
- value(SqlNode) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Extracts the value from a literal.
- VALUE_OPERAND - Static variable in class org.apache.calcite.sql.fun.SqlBetweenOperator
-
Ordinal of the 'value' operand.
- valueClass() - Method in enum org.apache.calcite.config.CalciteConnectionProperty
- valueIsNullable() - Element in annotation type org.apache.calcite.adapter.java.Map
-
Whether values may be null.
- valueIsNullable() - Method in class org.apache.calcite.linq4j.tree.Types.MapType
-
Returns whether values may be null.
- valueMatchesType(Comparable, SqlTypeName, boolean) - Static method in class org.apache.calcite.rex.RexLiteral
-
Returns whether a value is appropriate for its type.
- valueMatchesType(Object, SqlTypeName) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Returns whether value is appropriate for its type.
- valueNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- valueOf(byte) - Static method in enum org.apache.calcite.adapter.pig.PigDataType
-
Returns the enum constant of this type with the specified name.
- valueOf(long...) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Returns a new immutable bit set containing all the bits in the given long array.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.cassandra.CassandraMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.csv.CsvTable.Flavor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.druid.DruidType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.druid.Granularity.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.druid.QueryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.enumerable.NullPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.enumerable.WinAggImplementor.SeekType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.file.CsvTable.Flavor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.innodb.InnodbMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.innodb.QueryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.mongodb.MongoMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.os.OsQueryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.pig.PigAggFunction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.pig.PigDataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.redis.RedisDataFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.redis.RedisDataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.spark.SparkMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.chinook.ConnectionFactory.DatabaseWrapper
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.chinook.EnvironmentFairy.User
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.config.CalciteConnectionProperty
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.config.CharLiteralStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.config.Lex
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.config.NullCollation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.DataContext.Variable
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.interpreter.BindableConvention
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.interpreter.InterpretableConvention
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.linq4j.JoinType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.linq4j.OpType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.linq4j.tree.ExpressionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.linq4j.tree.GotoExpressionKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.linq4j.tree.Primitive.Flavor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.model.JsonSchema.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.model.ModelHandler.ExtraOperand
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.piglet.Ast.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.piglet.Ast.Op
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.plan.DeriveMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.plan.hep.HepMatchOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.plan.RelOptRuleOperandChildPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.plan.RelOptUtil.Logic
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.plan.RelOptUtil.SubQueryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.plan.Strong.Policy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.plan.TableAccessMap.Mode
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rel.core.Aggregate.Group
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rel.core.Spool.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rel.core.TableModify.Operation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rel.hint.CompositeHintPredicate.Composition
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rel.metadata.NullSentinel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rel.RelDistribution.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rel.RelFieldCollation.NullDirection
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rel.rules.materialize.MaterializedViewRule.MatchModality
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rel.type.RelDataTypeComparability
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rel.type.StructKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rex.RexDigestIncludeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rex.RexUnknownAs
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rex.RexWindowExclusion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.runtime.Hook
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.runtime.JsonFunctions.JsonModifyMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.runtime.JsonFunctions.PathMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.runtime.Pattern.Op
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.runtime.SpatialTypeUtils.SpatialType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.runtime.SqlFunctions.FlatProductInputType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.runtime.SqlFunctions.JsonScope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.schema.ColumnStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.schema.Schema.TableType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.babel.postgresql.AndChain
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.babel.postgresql.SqlBegin.TransactionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.babel.TableCollectionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.ddl.SqlCreateTableLike.LikeOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.ddl.SqlDdlNodes.FileType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.fun.SqlAvgAggFunction.Subtype
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.fun.SqlBetweenOperator.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.fun.SqlCovarAggFunction.Subtype
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.fun.SqlLibrary
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.fun.SqlTrimFunction.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.JoinConditionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.JoinType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlAccessEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlCollation.Coercibility
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlDialect.CalendarPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlExplain.Depth
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlExplainFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlExplainLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlFunctionCategory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlHint.HintOptionFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlInsertKeyword
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlJdbcDataTypeName
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlJsonConstructorNullClause
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlJsonEmptyOrError
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlJsonEncoding
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlJsonExistsErrorBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlJsonQueryEmptyOrErrorBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlJsonQueryWrapperBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlJsonValueEmptyOrErrorBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlJsonValueReturning
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlMatchRecognize.AfterOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlMatchRecognize.RowsPerMatchOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlNullSemantics
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlSelectKeyword
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlStateCodes
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlSyntax
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlWriter.SubQueryStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SqlWriterConfig.LineFolding
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.TableCharacteristic.Semantics
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.test.SqlOperatorFixture.CastType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.test.SqlOperatorFixture.VmName
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.test.SqlTester.VmName
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.test.SqlTests.Stage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.type.CompositeOperandTypeChecker.Composition
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.type.SqlOperandTypeChecker.Consistency
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.type.SqlTypeFamily
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.type.SqlTypeName.Limit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.type.SqlTypeName
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.validate.SqlModality
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.validate.SqlMonikerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.validate.SqlMonotonicity
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.validate.SqlValidatorImpl.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.statistic.MapSqlStatisticProvider
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.test.CalciteAssert.Config
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.tools.PigRelBuilder.GroupOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.util.BuiltInMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.util.format.FormatElementEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.util.format.postgresql.CapitalizationEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.util.format.postgresql.DateCalendarEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.util.format.postgresql.PatternModifier
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.util.mapping.MappingType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.util.Optionality
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.util.PrecedenceClimbingParser.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(LongBuffer) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Returns a new immutable bit set containing all the bits in the given long buffer.
- valueOf(SqlKind, boolean) - Static method in enum org.apache.calcite.adapter.pig.PigAggFunction
- valueOf(SqlTypeName) - Static method in enum org.apache.calcite.adapter.pig.PigDataType
-
Returns the enum constant of this type with the specified name.
- values - Variable in class org.apache.calcite.interpreter.Context
-
Values of incoming columns from all inputs.
- values() - Static method in enum org.apache.calcite.adapter.cassandra.CassandraMethod
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.csv.CsvTable.Flavor
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.druid.DruidType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.druid.Granularity.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.druid.QueryType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.enumerable.NullPolicy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.enumerable.WinAggImplementor.SeekType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.file.CsvTable.Flavor
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.innodb.InnodbMethod
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.innodb.QueryType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.mongodb.MongoMethod
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.os.OsQueryType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.pig.PigAggFunction
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.pig.PigDataType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.redis.RedisDataFormat
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.redis.RedisDataType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.adapter.spark.SparkMethod
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.chinook.ConnectionFactory.DatabaseWrapper
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.chinook.EnvironmentFairy.User
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.config.CalciteConnectionProperty
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.config.CharLiteralStyle
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.config.Lex
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.config.NullCollation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.DataContext.Variable
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.interpreter.BindableConvention
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.interpreter.InterpretableConvention
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.linq4j.JoinType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.linq4j.OpType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.linq4j.tree.ExpressionType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.linq4j.tree.GotoExpressionKind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.linq4j.tree.Primitive.Flavor
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.model.JsonSchema.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.model.ModelHandler.ExtraOperand
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.piglet.Ast.Direction
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.piglet.Ast.Op
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.plan.DeriveMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.plan.hep.HepMatchOrder
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.plan.RelOptRuleOperandChildPolicy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.plan.RelOptUtil.Logic
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.plan.RelOptUtil.SubQueryType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.plan.Strong.Policy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.plan.TableAccessMap.Mode
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rel.core.Aggregate.Group
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rel.core.Spool.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rel.core.TableModify.Operation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rel.hint.CompositeHintPredicate.Composition
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rel.metadata.NullSentinel
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rel.RelDistribution.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rel.RelFieldCollation.NullDirection
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rel.rules.materialize.MaterializedViewRule.MatchModality
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rel.type.RelDataTypeComparability
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rel.type.StructKind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rex.RexDigestIncludeType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rex.RexUnknownAs
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.rex.RexWindowExclusion
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.runtime.Hook
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.runtime.JsonFunctions.JsonModifyMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.runtime.JsonFunctions.PathMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.runtime.Pattern.Op
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.runtime.SpatialTypeUtils.SpatialType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.runtime.SqlFunctions.FlatProductInputType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.runtime.SqlFunctions.JsonScope
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.schema.ColumnStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.schema.Schema.TableType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.babel.postgresql.AndChain
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.babel.postgresql.SqlBegin.TransactionMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.babel.TableCollectionType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.ddl.SqlCreateTableLike.LikeOption
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.ddl.SqlDdlNodes.FileType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.fun.SqlAvgAggFunction.Subtype
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.fun.SqlBetweenOperator.Flag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.fun.SqlCovarAggFunction.Subtype
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.fun.SqlLibrary
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.fun.SqlTrimFunction.Flag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.JoinConditionType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.JoinType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlAccessEnum
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlCollation.Coercibility
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlDialect.CalendarPolicy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlExplain.Depth
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlExplainFormat
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlExplainLevel
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlFunctionCategory
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlHint.HintOptionFormat
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlInsertKeyword
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlJdbcDataTypeName
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlJsonConstructorNullClause
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlJsonEmptyOrError
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlJsonEncoding
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlJsonExistsErrorBehavior
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlJsonQueryEmptyOrErrorBehavior
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlJsonQueryWrapperBehavior
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlJsonValueEmptyOrErrorBehavior
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlJsonValueReturning
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlKind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlMatchRecognize.AfterOption
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlMatchRecognize.RowsPerMatchOption
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlNullSemantics
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlSelectKeyword
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlStateCodes
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlSyntax
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlWriter.SubQueryStyle
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.SqlWriterConfig.LineFolding
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.TableCharacteristic.Semantics
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.test.SqlOperatorFixture.CastType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.test.SqlOperatorFixture.VmName
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.test.SqlTester.VmName
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.test.SqlTests.Stage
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.type.CompositeOperandTypeChecker.Composition
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.type.SqlOperandTypeChecker.Consistency
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.type.SqlTypeFamily
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.type.SqlTypeName.Limit
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.type.SqlTypeName
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.validate.SqlModality
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.validate.SqlMonikerType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.validate.SqlMonotonicity
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.validate.SqlValidatorImpl.Status
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.statistic.MapSqlStatisticProvider
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.test.CalciteAssert.Config
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.tools.PigRelBuilder.GroupOption
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.util.BuiltInMethod
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.apache.calcite.util.CompositeMap
- values() - Static method in enum org.apache.calcite.util.format.FormatElementEnum
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.util.format.postgresql.CapitalizationEnum
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.util.format.postgresql.DateCalendarEnum
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.util.format.postgresql.PatternModifier
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.util.mapping.MappingType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.util.Optionality
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.util.PrecedenceClimbingParser.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values(String[], Object...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Values
. - values(Iterable<? extends List<RexLiteral>>, RelDataType) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Values
with a specified row type. - values(RelMetadataQuery, RelDataType, ImmutableList<ImmutableList<RexLiteral>>) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Helper method to determine a
Values
's collation. - values(RelDataType) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Values
with a specified row type and zero rows. - values(RelDataType, ImmutableList<ImmutableList<RexLiteral>>) - Static method in class org.apache.calcite.rel.metadata.RelMdDistribution
-
Helper method to determine a
Values
's distribution. - values(RelDataType, Object...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Values
with a specified row type. - Values - Class in org.apache.calcite.rel.core
-
Relational expression whose value is a sequence of zero or more literal row values.
- Values(RelOptCluster, List<RelHint>, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, RelTraitSet) - Constructor for class org.apache.calcite.rel.core.Values
-
Creates a new Values.
- Values(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, RelTraitSet) - Constructor for class org.apache.calcite.rel.core.Values
-
Creates a new Values.
- Values(RelInput) - Constructor for class org.apache.calcite.rel.core.Values
-
Creates a Values by parsing serialized output.
- VALUES - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- VALUES - Enum constant in enum org.apache.calcite.sql.SqlKind
-
VALUES
relational operator. - VALUES - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
VALUES clause.
- VALUES - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
Values
nodes. - VALUES - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- VALUES_FACTORY - Static variable in class org.apache.calcite.adapter.jdbc.JdbcRules
- valuesFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- valuesFolding() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the line-folding policy for the VALUES expression.
- valuesListNewline() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether each row in a VALUES clause should be on its own line.
- ValuesNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
Values
. - ValuesNode(Compiler, Values) - Constructor for class org.apache.calcite.interpreter.ValuesNode
- ValuesReduceRule - Class in org.apache.calcite.rel.rules
-
Planner rule that folds projections and filters into an underlying
LogicalValues
. - ValuesReduceRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.ValuesReduceRule
-
Deprecated.
- ValuesReduceRule(ValuesReduceRule.Config) - Constructor for class org.apache.calcite.rel.rules.ValuesReduceRule
-
Creates a ValuesReduceRule.
- ValuesReduceRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- ValuesStmt(SqlParserPos, Ast.Identifier, Ast.Schema, List<List<Ast.Node>>) - Constructor for class org.apache.calcite.piglet.Ast.ValuesStmt
- valueTypes - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- VAR_POP - Enum constant in enum org.apache.calcite.sql.fun.SqlAvgAggFunction.Subtype
-
Deprecated.
- VAR_POP - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
VAR_POP
aggregate function. - VAR_POP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
VAR_POP
aggregate function. - VAR_SAMP - Enum constant in enum org.apache.calcite.sql.fun.SqlAvgAggFunction.Subtype
-
Deprecated.
- VAR_SAMP - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
VAR_SAMP
aggregate function. - VAR_SAMP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
VAR_SAMP
aggregate function. - VARBINARY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- VARBINARY - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that always returns "VARBINARY".
- VARBINARY_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that always returns "VARBINARY" with nulls allowed if any of the operands allow nulls.
- VARCHAR - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- VARCHAR - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that always returns "VARCHAR".
- VARCHAR_1024 - Static variable in class org.apache.calcite.sql.type.InferTypes
-
Operand type-inference strategy where an unknown operand type is assumed to be VARCHAR(1024).
- VARCHAR_2000 - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that always returns "VARCHAR(2000)".
- VARCHAR_2000_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that always returns "VARCHAR(2000)" with nulls allowed if any of the operands allow nulls.
- VARCHAR_4 - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that always returns "VARCHAR(4)".
- VARCHAR_4_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that always returns "VARCHAR(4)" with nulls allowed if any of the operands allow nulls.
- VARCHAR_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that always returns "VARCHAR" with nulls allowed if any of the operands allow nulls.
- variable(Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ParameterExpression node that can be used to identify a parameter or a variable in an expression tree.
- variable(Type, String) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a ParameterExpression node that can be used to identify a parameter or a variable in an expression tree.
- variable(Consumer<RexCorrelVariable>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a correlation variable for the current input, and writes it into a Consumer.
- variable(Holder<RexCorrelVariable>) - Method in class org.apache.calcite.tools.RelBuilder
-
Deprecated.
- variableFields - Variable in class org.apache.calcite.plan.RelOptUtil.VariableUsedVisitor
- variables - Variable in class org.apache.calcite.plan.RelOptUtil.VariableUsedVisitor
- variables - Variable in class org.apache.calcite.rex.RexAnalyzer
- variables - Variable in class org.apache.calcite.tools.Hoist.Hoisted
- variablesSet - Variable in class org.apache.calcite.rel.core.Join
- variablesSet - Variable in class org.apache.calcite.rel.core.Project
- variablesSet - Variable in class org.apache.calcite.rel.mutable.MutableJoin
- VariableUsedVisitor(RelShuttle) - Constructor for class org.apache.calcite.plan.RelOptUtil.VariableUsedVisitor
- variadic(SqlOperandCountRange) - Static method in class org.apache.calcite.sql.type.OperandTypes
- VARIADIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy for an operator with no restrictions on number or type of operands.
- VARIANCE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
VARIANCE
aggregate function. - varToStr(Hoist.Variable) - Static method in class org.apache.calcite.sql.parser.SqlParserTest
- VERBOSE_CACHING_INSTANCE - Static variable in class org.apache.calcite.statistic.QuerySqlStatisticProvider
-
As
QuerySqlStatisticProvider.SILENT_CACHING_INSTANCE
but prints SQL statements toSystem.out
. - verifyTypeEquivalence(RelNode, RelNode, Object) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Verifies that a row type being added to an equivalence class matches the existing type, raising an assertion if this is not the case.
- version - Variable in class org.apache.calcite.model.JsonRoot
-
Schema model version number.
- Version - Class in org.apache.calcite.util
-
Version string parsed into major and minor parts.
- vertexSet() - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- vertexSet() - Method in interface org.apache.calcite.util.graph.DirectedGraph
- VERTICA - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- VerticaSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Vertica database. - VerticaSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.VerticaSqlDialect
-
Creates a VerticaSqlDialect.
- view - Variable in class org.apache.calcite.model.JsonMaterialization
- view(String) - Method in class org.apache.calcite.test.schemata.hr.HrSchema
- view(String) - Static method in class org.apache.calcite.util.Smalls
- VIEW - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
A relation whose contents are calculated by evaluating a SQL expression.
- VIEW - Enum constant in enum org.apache.calcite.sql.validate.SqlMonikerType
- VIEW_METHOD - Static variable in class org.apache.calcite.util.Smalls
- VIEW_PARTIAL - Enum constant in enum org.apache.calcite.rel.rules.materialize.MaterializedViewRule.MatchModality
- viewConstraintNotSatisfied(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- viewExists(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- viewExpander - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- viewExpander(RelOptTable.ViewExpander) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- ViewExpanders - Class in org.apache.calcite.plan
-
Utilities for
RelOptTable.ViewExpander
andRelOptTable.ToRelContext
. - viewMacro(CalciteSchema, String, List<String>, List<String>, Boolean) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable
- viewMacro(SchemaPlus, String, List<String>) - Static method in class org.apache.calcite.schema.impl.ViewTable
-
Deprecated.
- viewMacro(SchemaPlus, String, List<String>, Boolean) - Static method in class org.apache.calcite.schema.impl.ViewTable
-
Deprecated.
- viewMacro(SchemaPlus, String, List<String>, List<String>, Boolean) - Static method in class org.apache.calcite.schema.impl.ViewTable
-
Table macro that returns a view.
- viewNotFound(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- viewPath - Variable in class org.apache.calcite.schema.impl.ViewTableMacro
- viewSchemaPath - Variable in class org.apache.calcite.model.JsonMaterialization
- viewSql - Variable in class org.apache.calcite.schema.impl.ViewTableMacro
- viewTable(CalcitePrepare.AnalyzeViewResult, String, List<String>, List<String>) - Method in class org.apache.calcite.schema.impl.ViewTableMacro
-
Allows a sub-class to return an extension of
ViewTable
by overriding this method. - ViewTable - Class in org.apache.calcite.schema.impl
-
Table whose contents are defined using an SQL statement.
- ViewTable(Type, RelProtoDataType, String, List<String>, List<String>) - Constructor for class org.apache.calcite.schema.impl.ViewTable
- ViewTableMacro - Class in org.apache.calcite.schema.impl
-
Table function that implements a view.
- ViewTableMacro(CalciteSchema, String, List<String>, List<String>, Boolean) - Constructor for class org.apache.calcite.schema.impl.ViewTableMacro
-
Creates a ViewTableMacro.
- VIRTUAL - Enum constant in enum org.apache.calcite.schema.ColumnStrategy
-
Column is computed and not stored.
- VirtualColumn - Class in org.apache.calcite.adapter.druid
-
Druid Json Expression based Virtual Column.
- VirtualColumn(String, String, DruidType) - Constructor for class org.apache.calcite.adapter.druid.VirtualColumn
- VirtualColumn.Builder - Class in org.apache.calcite.adapter.druid
-
Virtual Column builder.
- VirtualColumnsExpressionFactory - Class in org.apache.calcite.test.catalog
-
Define column strategies for the "VIRTUALCOLUMNS" table.
- VirtualColumnsExpressionFactory() - Constructor for class org.apache.calcite.test.catalog.VirtualColumnsExpressionFactory
- visit(Bindables.BindableTableScan) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(BinaryExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(BinaryExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(BinaryExpression, Expression, Expression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
- visit(BinaryExpression, Expression, Expression) - Method in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- visit(BinaryExpression, Expression, Expression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(BlockStatement) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(BlockStatement) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(BlockStatement, List<Statement>) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(ClassDeclaration) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(ClassDeclaration) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(ClassDeclaration, List<MemberDeclaration>) - Method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
- visit(ClassDeclaration, List<MemberDeclaration>) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(ConditionalExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(ConditionalExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(ConditionalStatement) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(ConditionalStatement) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(ConditionalStatement, List<Node>) - Method in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- visit(ConditionalStatement, List<Node>) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(ConstantExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(ConstantExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(ConstantExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(ConstructorDeclaration) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(ConstructorDeclaration) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(ConstructorDeclaration, BlockStatement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(DeclarationStatement) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(DeclarationStatement) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(DeclarationStatement, Expression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(DefaultExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(DefaultExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(DefaultExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(DynamicExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(DynamicExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(DynamicExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(FieldDeclaration) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(FieldDeclaration) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(FieldDeclaration, Expression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
- visit(FieldDeclaration, Expression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(ForEachStatement) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(ForEachStatement) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(ForEachStatement, ParameterExpression, Expression, Statement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(ForStatement) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(ForStatement) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(ForStatement, List<DeclarationStatement>, Expression, Expression, Statement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(FunctionExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(FunctionExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(FunctionExpression, BlockStatement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(GotoStatement) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(GotoStatement) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(GotoStatement, Expression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(IndexExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(IndexExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(IndexExpression, Expression, List<Expression>) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(InvocationExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(InvocationExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(InvocationExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(LabelStatement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(LabelStatement) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(LabelStatement) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(LambdaExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(LambdaExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(LambdaExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(ListInitExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(ListInitExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(ListInitExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(MemberExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(MemberExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(MemberExpression, Expression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
- visit(MemberExpression, Expression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(MemberInitExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(MemberInitExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(MemberInitExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(MethodCallExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(MethodCallExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(MethodCallExpression, Expression, List<Expression>) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
- visit(MethodCallExpression, Expression, List<Expression>) - Method in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- visit(MethodCallExpression, Expression, List<Expression>) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(MethodDeclaration) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(MethodDeclaration) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(MethodDeclaration, BlockStatement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(NewArrayExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(NewArrayExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(NewArrayExpression, int, Expression, List<Expression>) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(NewExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(NewExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(NewExpression, List<Expression>, List<MemberDeclaration>) - Method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
- visit(NewExpression, List<Expression>, List<MemberDeclaration>) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(ParameterExpression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(ParameterExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(ParameterExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(SwitchStatement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(SwitchStatement) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(SwitchStatement) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(TernaryExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(TernaryExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(TernaryExpression, Expression, Expression, Expression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
- visit(TernaryExpression, Expression, Expression, Expression) - Method in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- visit(TernaryExpression, Expression, Expression, Expression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(ThrowStatement) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(ThrowStatement) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(ThrowStatement, Expression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(TryStatement) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(TryStatement) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(TryStatement, Statement, List<CatchBlock>, Statement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(TypeBinaryExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(TypeBinaryExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(TypeBinaryExpression, Expression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
- visit(TypeBinaryExpression, Expression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(UnaryExpression) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(UnaryExpression) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(UnaryExpression, Expression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
- visit(UnaryExpression, Expression) - Method in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- visit(UnaryExpression, Expression) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(WhileStatement) - Method in interface org.apache.calcite.linq4j.tree.Visitor
- visit(WhileStatement) - Method in class org.apache.calcite.linq4j.tree.VisitorImpl
- visit(WhileStatement, Expression, Statement) - Method in class org.apache.calcite.linq4j.tree.Shuttle
- visit(JsonColumn) - Method in class org.apache.calcite.model.ModelHandler
- visit(JsonCustomSchema) - Method in class org.apache.calcite.model.ModelHandler
- visit(JsonCustomTable) - Method in class org.apache.calcite.model.ModelHandler
- visit(JsonFunction) - Method in class org.apache.calcite.model.ModelHandler
- visit(JsonJdbcSchema) - Method in class org.apache.calcite.model.ModelHandler
- visit(JsonLattice) - Method in class org.apache.calcite.model.ModelHandler
- visit(JsonMapSchema) - Method in class org.apache.calcite.model.ModelHandler
- visit(JsonMaterialization) - Method in class org.apache.calcite.model.ModelHandler
- visit(JsonMeasure) - Method in class org.apache.calcite.model.ModelHandler
- visit(JsonRoot) - Method in class org.apache.calcite.model.ModelHandler
- visit(JsonTile) - Method in class org.apache.calcite.model.ModelHandler
- visit(JsonType) - Method in class org.apache.calcite.model.ModelHandler
- visit(JsonView) - Method in class org.apache.calcite.model.ModelHandler
- visit(Aggregate) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Aggregate) - Method in class org.apache.calcite.piglet.PigRelToSqlConverter
- visit(Aggregate) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits an Aggregate; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(Calc) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a Calc; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(Collect) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Correlate) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a Correlate; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(Filter) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Filter) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a Filter; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(Intersect) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits an Intersect; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(Join) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Join) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a Join; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(Match) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Match) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a Match; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(Minus) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a Minus; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(Project) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Project) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a Project; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(Sample) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a Sample; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(SetOp) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Sort) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Sort) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a Sort; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(TableFunctionScan) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(TableFunctionScan) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visit(TableFunctionScan) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(TableFunctionScan) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(TableFunctionScan) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(TableModify) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a TableModify; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(TableScan) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(TableScan) - Method in class org.apache.calcite.rel.logical.ToLogicalConverter
- visit(TableScan) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a TableScan; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(TableScan) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(TableScan) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(TableScan) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(Uncollect) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Uncollect) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visit(Union) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a Union; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(Values) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Values) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a Values; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(Window) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Window) - Method in class org.apache.calcite.piglet.PigRelToSqlConverter
- visit(Window) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a Window; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(LogicalAggregate) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(LogicalAggregate) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(LogicalAggregate) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(LogicalCalc) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(LogicalCalc) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(LogicalCalc) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(LogicalCorrelate) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(LogicalCorrelate) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(LogicalCorrelate) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(LogicalCorrelate) - Method in class org.apache.calcite.sql2rel.CorrelateProjectExtractor
- visit(LogicalExchange) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(LogicalExchange) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(LogicalExchange) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(LogicalFilter) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(LogicalFilter) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(LogicalFilter) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(LogicalIntersect) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(LogicalIntersect) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(LogicalIntersect) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(LogicalJoin) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(LogicalJoin) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(LogicalJoin) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(LogicalMatch) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(LogicalMatch) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(LogicalMatch) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(LogicalMinus) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(LogicalMinus) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(LogicalMinus) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(LogicalProject) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(LogicalProject) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(LogicalProject) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(LogicalSort) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(LogicalSort) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(LogicalSort) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(LogicalTableModify) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(LogicalTableModify) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(LogicalTableModify) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(LogicalUnion) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(LogicalUnion) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(LogicalUnion) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(LogicalValues) - Method in class org.apache.calcite.rel.RelHomogeneousShuttle
- visit(LogicalValues) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(LogicalValues) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableRelVisitor
- visit(RelNode) - Method in class org.apache.calcite.rel.logical.ToLogicalConverter
- visit(RelNode) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Visits a RelNode; called by
RelToSqlConverter.dispatch(org.apache.calcite.rel.RelNode)
via reflection. - visit(RelNode) - Method in interface org.apache.calcite.rel.RelShuttle
- visit(RelNode) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visit(RelNode) - Method in class org.apache.calcite.sql2rel.CorrelationReferenceFinder
- visit(RelNode) - Method in class org.apache.calcite.sql2rel.DeduplicateCorrelateVariables
- visit(RelNode) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
- visit(RelNode, int, RelNode) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(RelNode, int, RelNode) - Method in class org.apache.calcite.plan.RelTraitPropagationVisitor
-
Deprecated.
- visit(RelNode, int, RelNode) - Method in class org.apache.calcite.rel.RelValidityChecker
- visit(RelNode, int, RelNode) - Method in class org.apache.calcite.rel.RelVisitor
-
Visits a node during a traversal.
- visit(SqlCall) - Method in class org.apache.calcite.sql.util.SqlBasicVisitor
- visit(SqlCall) - Method in class org.apache.calcite.sql.util.SqlShuttle
- visit(SqlCall) - Method in interface org.apache.calcite.sql.util.SqlVisitor
-
Visits a call to a
SqlOperator
. - visit(SqlCall) - Method in class org.apache.calcite.sql.validate.SqlScopedShuttle
- visit(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- visit(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.SqlIdentifierFinder
- visit(SqlCall) - Method in class org.apache.calcite.util.Util.OverFinder
- visit(SqlDataTypeSpec) - Method in class org.apache.calcite.sql.util.SqlBasicVisitor
- visit(SqlDataTypeSpec) - Method in class org.apache.calcite.sql.util.SqlShuttle
- visit(SqlDataTypeSpec) - Method in interface org.apache.calcite.sql.util.SqlVisitor
-
Visits a datatype specification.
- visit(SqlDataTypeSpec) - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- visit(SqlDataTypeSpec) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- visit(SqlDataTypeSpec) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.SqlIdentifierFinder
- visit(SqlDynamicParam) - Method in class org.apache.calcite.sql.util.SqlBasicVisitor
- visit(SqlDynamicParam) - Method in class org.apache.calcite.sql.util.SqlShuttle
- visit(SqlDynamicParam) - Method in interface org.apache.calcite.sql.util.SqlVisitor
-
Visits a dynamic parameter.
- visit(SqlDynamicParam) - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- visit(SqlDynamicParam) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- visit(SqlDynamicParam) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.SqlIdentifierFinder
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql.util.SqlBasicVisitor
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql.util.SqlShuttle
- visit(SqlIdentifier) - Method in interface org.apache.calcite.sql.util.SqlVisitor
-
Visits an identifier.
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.SqlIdentifierFinder
- visit(SqlIntervalQualifier) - Method in class org.apache.calcite.sql.util.SqlBasicVisitor
- visit(SqlIntervalQualifier) - Method in class org.apache.calcite.sql.util.SqlShuttle
- visit(SqlIntervalQualifier) - Method in interface org.apache.calcite.sql.util.SqlVisitor
-
Visits an interval qualifier.
- visit(SqlIntervalQualifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- visit(SqlIntervalQualifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- visit(SqlIntervalQualifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.SqlIdentifierFinder
- visit(SqlLiteral) - Method in class org.apache.calcite.sql.util.SqlBasicVisitor
- visit(SqlLiteral) - Method in class org.apache.calcite.sql.util.SqlShuttle
- visit(SqlLiteral) - Method in interface org.apache.calcite.sql.util.SqlVisitor
-
Visits a literal.
- visit(SqlLiteral) - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- visit(SqlLiteral) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- visit(SqlLiteral) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.SqlIdentifierFinder
- visit(SqlNodeList) - Method in class org.apache.calcite.sql.util.SqlBasicVisitor
- visit(SqlNodeList) - Method in class org.apache.calcite.sql.util.SqlShuttle
- visit(SqlNodeList) - Method in interface org.apache.calcite.sql.util.SqlVisitor
-
Visits a list of
SqlNode
objects. - visit(SqlNodeList) - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- visit(SqlNodeList) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- visit(SqlNodeList) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.SqlIdentifierFinder
- visitAntiOrSemiJoin(Join) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visitArray(RexNode[], boolean[]) - Method in class org.apache.calcite.rex.RexShuttle
-
Visits each of an array of expressions and returns an array of the results.
- visitArrayAnd(RexVisitor<Boolean>, List<RexNode>) - Static method in class org.apache.calcite.rex.RexVisitorImpl
-
Visits an array of expressions, returning the logical 'and' of their results.
- visitArrayOr(RexVisitor<Boolean>, List<RexNode>) - Static method in class org.apache.calcite.rex.RexVisitorImpl
-
Visits an array of expressions, returning the logical 'or' of their results.
- visitCall(RexCall) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Visit
RexCall
. - visitCall(RexCall) - Method in class org.apache.calcite.plan.RelOptUtil.InputFinder
- visitCall(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.DecimalShuttle
-
Rewrites a call in place, from bottom up.
- visitCall(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.CaseShuttle
- visitCall(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- visitCall(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.RexReplacer
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexChecker
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexInterpreter
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexPermuteInputsShuttle
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexShuttle
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexUtil.ExprSimplifier
-
Deprecated.
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexUtil.FieldAccessFinder
- visitCall(RexCall) - Method in interface org.apache.calcite.rex.RexVisitor
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitCall(RexCall, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitCall(RexCall, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitCall(RexCall, P) - Method in class org.apache.calcite.rex.RexBiVisitorImpl
- visitCall(RexCall, R) - Method in class org.apache.calcite.rex.RexUnaryBiVisitor
- visitChild(int, RelNode) - Method in class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
- visitChild(int, RelNode) - Method in class org.apache.calcite.adapter.innodb.InnodbRel.Implementor
- visitChild(int, RelNode) - Method in class org.apache.calcite.adapter.mongodb.MongoRel.Implementor
- visitChild(int, RelNode) - Method in class org.apache.calcite.adapter.pig.PigRel.Implementor
- visitChild(int, RelNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Deprecated.
- visitChild(EnumerableRel, int, EnumerableRel, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- visitChild(RelNode, int, RelNode) - Method in class org.apache.calcite.rel.RelShuttleImpl
-
Visits a particular child of a parent.
- visitChild(RelNode, int, RelNode) - Method in class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.RelNodesExprsHandler
- visitChild(RelNode, int, RelNode) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
- visitChild(SqlVisitor<SqlNode>, SqlNode, int, SqlNode) - Method in class org.apache.calcite.sql.util.SqlShuttle.CallCopyingArgHandler
- visitChild(SqlVisitor<R>, SqlNode, int, SqlNode) - Method in interface org.apache.calcite.sql.util.SqlBasicVisitor.ArgHandler
-
Visits a particular operand of a call, using a given visitor.
- visitChild(SqlVisitor<R>, SqlNode, int, SqlNode) - Method in class org.apache.calcite.sql.util.SqlBasicVisitor.ArgHandlerImpl
- visitChildren(ExpressionVisitor) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Reduces the node and then calls the visitor delegate on the reduced expression.
- visitChildren(ModelHandler) - Method in class org.apache.calcite.model.JsonLattice
- visitChildren(ModelHandler) - Method in class org.apache.calcite.model.JsonMapSchema
- visitChildren(ModelHandler) - Method in class org.apache.calcite.model.JsonSchema
- visitChildren(RelNode) - Method in class org.apache.calcite.rel.RelShuttleImpl
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.plan.RelOptUtil.VariableUsedVisitor
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.RexFieldAccessReplacer
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rex.RexChecker
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rex.RexInterpreter
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rex.RexShuttle
- visitCorrelVariable(RexCorrelVariable) - Method in interface org.apache.calcite.rex.RexVisitor
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitCorrelVariable(RexCorrelVariable, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitCorrelVariable(RexCorrelVariable, P) - Method in class org.apache.calcite.rex.RexBiVisitorImpl
- visitCorrelVariable(RexCorrelVariable, R) - Method in class org.apache.calcite.rex.RexUnaryBiVisitor
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.rex.RexInterpreter
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.rex.RexShuttle
- visitDynamicParam(RexDynamicParam) - Method in interface org.apache.calcite.rex.RexVisitor
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitDynamicParam(RexDynamicParam, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitDynamicParam(RexDynamicParam, P) - Method in class org.apache.calcite.rex.RexBiVisitorImpl
- visitDynamicParam(RexDynamicParam, R) - Method in class org.apache.calcite.rex.RexUnaryBiVisitor
- visitEach(Iterable<? extends RexNode>) - Method in interface org.apache.calcite.rex.RexVisitor
-
Visits a list of expressions.
- visitEach(Iterable<? extends RexNode>, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
-
Visits a list of expressions.
- visitEachIndexed(Iterable<? extends RexNode>) - Method in interface org.apache.calcite.rex.RexBiVisitor
-
Visits a list of expressions, passing the 0-based index of the expression in the list.
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.plan.RelOptUtil.VariableUsedVisitor
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.RexFieldAccessReplacer
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rex.RexChecker
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rex.RexInterpreter
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rex.RexShuttle
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rex.RexUtil.FieldAccessFinder
- visitFieldAccess(RexFieldAccess) - Method in interface org.apache.calcite.rex.RexVisitor
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitFieldAccess(RexFieldAccess, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitFieldAccess(RexFieldAccess, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitFieldAccess(RexFieldAccess, P) - Method in class org.apache.calcite.rex.RexBiVisitorImpl
- visitFieldAccess(RexFieldAccess, R) - Method in class org.apache.calcite.rex.RexUnaryBiVisitor
- visitFieldCollations(List<RexFieldCollation>, boolean[]) - Method in class org.apache.calcite.rex.RexShuttle
-
Visits each of a list of field collations and returns a list of the results.
- visitInput(int, RelNode) - Method in class org.apache.calcite.adapter.arrow.ArrowRel.Implementor
- visitInput(RelNode, int) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Visits an input of the current relational expression, deducing
anon
usingSqlImplementor.isAnon()
. - visitInput(RelNode, int, boolean, boolean, Set<SqlImplementor.Clause>) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visitInput(RelNode, int, boolean, boolean, Set<SqlImplementor.Clause>) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Visits the
i
th input ofe
, the current relational expression. - visitInput(RelNode, int, Set<SqlImplementor.Clause>) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Visits an input of the current relational expression, deducing
anon
usingSqlImplementor.isAnon()
. - visitInput(RelNode, int, SqlImplementor.Clause...) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Visits an input of the current relational expression, with the given expected clauses.
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Visit
RexInputRef
. - visitInputRef(RexInputRef) - Method in class org.apache.calcite.plan.RelOptUtil.InputFinder
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.plan.RelOptUtil.InputReferencedVisitor
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.plan.RelOptUtil.RexInputConverter
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.RexReplacer
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexChecker
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexInterpreter
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexPermuteInputsShuttle
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexShuttle
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexUtil.FixNullabilityShuttle
- visitInputRef(RexInputRef) - Method in interface org.apache.calcite.rex.RexVisitor
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitInputRef(RexInputRef, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitInputRef(RexInputRef, P) - Method in class org.apache.calcite.rex.RexBiVisitorImpl
- visitInputRef(RexInputRef, R) - Method in class org.apache.calcite.rex.RexUnaryBiVisitor
- visitLambda(FunctionExpression<T>) - Method in interface org.apache.calcite.linq4j.tree.ExpressionVisitor
-
Visits the children of the delegate expression.
- visitLambda(RexLambda) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- visitLambda(RexLambda) - Method in class org.apache.calcite.rex.RexInterpreter
- visitLambda(RexLambda) - Method in class org.apache.calcite.rex.RexShuttle
- visitLambda(RexLambda) - Method in interface org.apache.calcite.rex.RexVisitor
- visitLambda(RexLambda) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitLambda(RexLambda, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitLambda(RexLambda, P) - Method in class org.apache.calcite.rex.RexBiVisitorImpl
- visitLambdaRef(RexLambdaRef) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- visitLambdaRef(RexLambdaRef) - Method in class org.apache.calcite.rex.RexInterpreter
- visitLambdaRef(RexLambdaRef) - Method in class org.apache.calcite.rex.RexShuttle
- visitLambdaRef(RexLambdaRef) - Method in interface org.apache.calcite.rex.RexVisitor
- visitLambdaRef(RexLambdaRef) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitList(Iterable<? extends RexNode>) - Method in interface org.apache.calcite.rex.RexVisitor
-
Visits a list and returns a list of the results.
- visitList(Iterable<? extends RexNode>, List<R>) - Method in interface org.apache.calcite.rex.RexVisitor
-
Visits a list and writes the results to another list.
- visitList(Iterable<? extends RexNode>, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
-
Visits a list and returns a list of the results.
- visitList(Iterable<? extends RexNode>, P, List<R>) - Method in interface org.apache.calcite.rex.RexBiVisitor
-
Visits a list and writes the results to another list.
- visitList(List<? extends RexNode>, boolean[]) - Method in class org.apache.calcite.rex.RexShuttle
-
Visits each of a list of expressions and returns a list of the results.
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Visit
RexLiteral
. - visitLiteral(RexLiteral) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.rex.RexInterpreter
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.rex.RexShuttle
- visitLiteral(RexLiteral) - Method in interface org.apache.calcite.rex.RexVisitor
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitLiteral(RexLiteral, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitLiteral(RexLiteral, P) - Method in class org.apache.calcite.rex.RexBiVisitorImpl
- visitLiteral(RexLiteral, R) - Method in class org.apache.calcite.rex.RexUnaryBiVisitor
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexChecker
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexInterpreter
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexPermutationShuttle
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexShuttle
- visitLocalRef(RexLocalRef) - Method in interface org.apache.calcite.rex.RexVisitor
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitLocalRef(RexLocalRef, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitLocalRef(RexLocalRef, P) - Method in class org.apache.calcite.rex.RexBiVisitorImpl
- visitLocalRef(RexLocalRef, R) - Method in class org.apache.calcite.rex.RexUnaryBiVisitor
- visitNode(SqlNode) - Method in interface org.apache.calcite.sql.util.SqlVisitor
-
Asks a
SqlNode
to accept this visitor. - Visitor<R> - Interface in org.apache.calcite.linq4j.tree
-
Node visitor.
- VISITOR_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Represent an operation to be performed on the elements of an object structure.
- VisitorDataContext - Class in org.apache.calcite.plan
-
DataContext for evaluating a RexExpression.
- VisitorDataContext(Object[]) - Constructor for class org.apache.calcite.plan.VisitorDataContext
- VisitorImpl<R> - Class in org.apache.calcite.linq4j.tree
-
Default implementation of
Visitor
, which traverses a tree but does nothing. - VisitorImpl() - Constructor for class org.apache.calcite.linq4j.tree.VisitorImpl
- visitOver(RexOver) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- visitOver(RexOver) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- visitOver(RexOver) - Method in class org.apache.calcite.rex.RexInterpreter
- visitOver(RexOver) - Method in class org.apache.calcite.rex.RexShuttle
- visitOver(RexOver) - Method in interface org.apache.calcite.rex.RexVisitor
- visitOver(RexOver) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitOver(RexOver, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitOver(RexOver, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitOver(RexOver, P) - Method in class org.apache.calcite.rex.RexBiVisitorImpl
- visitOver(RexOver, R) - Method in class org.apache.calcite.rex.RexUnaryBiVisitor
- visitOverAggFunction(SqlAggFunction) - Method in class org.apache.calcite.rex.RexShuttle
- visitPatternFieldRef(RexPatternFieldRef) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- visitPatternFieldRef(RexPatternFieldRef) - Method in class org.apache.calcite.rex.RexInterpreter
- visitPatternFieldRef(RexPatternFieldRef) - Method in class org.apache.calcite.rex.RexShuttle
- visitPatternFieldRef(RexPatternFieldRef) - Method in interface org.apache.calcite.rex.RexVisitor
- visitPatternFieldRef(RexPatternFieldRef) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitPatternFieldRef(RexPatternFieldRef, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitPatternFieldRef(RexPatternFieldRef, P) - Method in class org.apache.calcite.rex.RexBiVisitorImpl
- visitPatternFieldRef(RexPatternFieldRef, R) - Method in class org.apache.calcite.rex.RexUnaryBiVisitor
- visitRangeRef(RexRangeRef) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- visitRangeRef(RexRangeRef) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- visitRangeRef(RexRangeRef) - Method in class org.apache.calcite.rex.RexInterpreter
- visitRangeRef(RexRangeRef) - Method in class org.apache.calcite.rex.RexShuttle
- visitRangeRef(RexRangeRef) - Method in interface org.apache.calcite.rex.RexVisitor
- visitRangeRef(RexRangeRef) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitRangeRef(RexRangeRef, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitRangeRef(RexRangeRef, P) - Method in class org.apache.calcite.rex.RexBiVisitorImpl
- visitRangeRef(RexRangeRef, R) - Method in class org.apache.calcite.rex.RexUnaryBiVisitor
- visitRoot(RelNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Visits a relational expression that has no parent.
- visitScoped(SqlCall) - Method in class org.apache.calcite.sql.validate.SqlScopedShuttle
-
Visits an operator call.
- visitScoped(SqlCall) - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- visitSubQuery(RexSubQuery) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- visitSubQuery(RexSubQuery) - Method in class org.apache.calcite.plan.RelOptUtil.VariableUsedVisitor
- visitSubQuery(RexSubQuery) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- visitSubQuery(RexSubQuery) - Method in class org.apache.calcite.rex.RexInterpreter
- visitSubQuery(RexSubQuery) - Method in class org.apache.calcite.rex.RexShuttle
- visitSubQuery(RexSubQuery) - Method in class org.apache.calcite.rex.RexUtil.SubQueryCollector
- visitSubQuery(RexSubQuery) - Method in class org.apache.calcite.rex.RexUtil.SubQueryFinder
- visitSubQuery(RexSubQuery) - Method in interface org.apache.calcite.rex.RexVisitor
- visitSubQuery(RexSubQuery) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitSubQuery(RexSubQuery, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitSubQuery(RexSubQuery, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitSubQuery(RexSubQuery, P) - Method in class org.apache.calcite.rex.RexBiVisitorImpl
- visitSubQuery(RexSubQuery, R) - Method in class org.apache.calcite.rex.RexUnaryBiVisitor
- visitTableInputRef(RexTableInputRef) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- visitTableInputRef(RexTableInputRef) - Method in class org.apache.calcite.rex.RexInterpreter
- visitTableInputRef(RexTableInputRef) - Method in class org.apache.calcite.rex.RexShuttle
- visitTableInputRef(RexTableInputRef) - Method in interface org.apache.calcite.rex.RexVisitor
- visitTableInputRef(RexTableInputRef) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitTableInputRef(RexTableInputRef, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitTableInputRef(RexTableInputRef, P) - Method in class org.apache.calcite.rex.RexBiVisitorImpl
- visitTableInputRef(RexTableInputRef, R) - Method in class org.apache.calcite.rex.RexUnaryBiVisitor
- visitWindow(RexWindow) - Method in class org.apache.calcite.rex.RexShuttle
- VmstatTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "vmstat" command to share memory statistics.
- VOID - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive
- volcanoPlanner - Variable in class org.apache.calcite.plan.volcano.VolcanoRuleCall
- VolcanoPlanner - Class in org.apache.calcite.plan.volcano
-
VolcanoPlanner optimizes queries by transforming expressions selectively according to a dynamic programming algorithm.
- VolcanoPlanner() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Creates a uninitialized
VolcanoPlanner
. - VolcanoPlanner(RelOptCostFactory, Context) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Creates a
VolcanoPlanner
with a given cost factory. - VolcanoPlanner(Context) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Creates a uninitialized
VolcanoPlanner
. - VolcanoRelMetadataProvider - Class in org.apache.calcite.plan.volcano
-
Deprecated.
- VolcanoRelMetadataProvider() - Constructor for class org.apache.calcite.plan.volcano.VolcanoRelMetadataProvider
-
Deprecated.
- VolcanoRuleCall - Class in org.apache.calcite.plan.volcano
-
VolcanoRuleCall
implements theRelOptRuleCall
interface for VolcanoPlanner. - VolcanoRuleCall(VolcanoPlanner, RelOptRuleOperand, RelNode[], Map<RelNode, List<RelNode>>) - Constructor for class org.apache.calcite.plan.volcano.VolcanoRuleCall
-
Creates a rule call, internal, with array to hold bindings.
- VolcanoTimeoutException - Exception Class in org.apache.calcite.plan.volcano
-
Indicates that planning timed out.
- VolcanoTimeoutException() - Constructor for exception class org.apache.calcite.plan.volcano.VolcanoTimeoutException
W
- W - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- wait(Object) - Static method in class org.apache.calcite.util.Unsafe
-
Calls
Object.wait()
. - warn(String) - Method in class org.apache.calcite.util.trace.CalciteLogger
- warn(String, Object, Object) - Method in class org.apache.calcite.util.trace.CalciteLogger
-
Logs a WARN message with two Object parameters.
- warn(String, Object, Object, Object) - Method in class org.apache.calcite.util.trace.CalciteLogger
-
Conditionally logs a WARN message with three Object parameters.
- warn(String, Object, Object, Object, Object) - Method in class org.apache.calcite.util.trace.CalciteLogger
-
Conditionally logs a WARN message with four Object parameters.
- warn(String, Object...) - Method in class org.apache.calcite.util.trace.CalciteLogger
- WEEK - Enum constant in enum org.apache.calcite.adapter.druid.Granularity.Type
- WEEK - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
WEEK
operator. - WEEK_FRAME_NAMES - Static variable in class org.apache.calcite.rel.type.TimeFrames
-
The names of the frames that are WEEK starting on each week day.
- WEEK_VARIANTS - Static variable in class org.apache.calcite.test.SqlOperatorTest
- WEEKS_IN_MONTH - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- WEEKS_IN_YEAR - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- WEEKS_IN_YEAR_ISO_8601 - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- where(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Filters a sequence of values based on a predicate.
- where(Enumerable<TSource>, Predicate2<TSource, Integer>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Filters a sequence of values based on a predicate.
- where(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- where(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Filters a sequence of values based on a predicate.
- where(Predicate2<T, Integer>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- where(Predicate2<TSource, Integer>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Filters a sequence of values based on a predicate.
- where(Queryable<T>, FunctionExpression<? extends Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Filters a sequence of values based on a predicate.
- where(Queryable<T>, FunctionExpression<? extends Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- where(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Filters a sequence of values based on a predicate.
- where(FunctionExpression<? extends Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- where(FunctionExpression<? extends Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Filters a sequence of values based on a predicate.
- WHERE - Enum constant in enum org.apache.calcite.linq4j.OpType
- WHERE - Enum constant in enum org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- WHERE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- WHERE_LIST - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
WHERE clause.
- WHERE_OPERAND - Static variable in class org.apache.calcite.sql.SqlSelect
- WHERE2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- whereFolding() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the line-folding policy for the WHERE clause.
- whereListItemsOnSeparateLines() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether to print a newline before each AND or OR (whichever is higher level) in WHERE clauses.
- whereN(Queryable<T>, FunctionExpression<? extends Predicate2<T, Integer>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Filters a sequence of values based on a predicate.
- whereN(Queryable<T>, FunctionExpression<? extends Predicate2<T, Integer>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- whereN(Queryable<T>, FunctionExpression<Predicate2<T, Integer>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Filters a sequence of values based on a predicate.
- whereN(FunctionExpression<? extends Predicate2<T, Integer>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- whereN(FunctionExpression<? extends Predicate2<T, Integer>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Filters a sequence of values based on a predicate.
- While - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
While loop.
- while_(Expression, Statement) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a WhileExpression representing a while loop.
- WhileStatement - Class in org.apache.calcite.linq4j.tree
-
Represents a "while" statement.
- WhileStatement(Expression, Statement) - Constructor for class org.apache.calcite.linq4j.tree.WhileStatement
- whiteSpace() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- whole - Variable in class org.apache.calcite.test.SqlValidatorFixture
- wholeExpr(String) - Method in interface org.apache.calcite.test.IntervalTest.Fixture
- wholeExpr(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
-
Creates a test context with a SQL expression.
- WIDE - Enum constant in enum org.apache.calcite.sql.SqlWriterConfig.LineFolding
-
Do not wrap.
- WideProductSale(int, double) - Constructor for class org.apache.calcite.util.Smalls.WideProductSale
- WideSaleSchema() - Constructor for class org.apache.calcite.util.Smalls.WideSaleSchema
- win(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- WinAggAddContext - Interface in org.apache.calcite.adapter.enumerable
-
Information for a call to
AggImplementor.implementAdd(AggContext, AggAddContext)
. - WinAggAddContextImpl - Class in org.apache.calcite.adapter.enumerable.impl
-
Implementation of
WinAggAddContext
. - WinAggAddContextImpl(BlockBuilder, List<Expression>, Function<BlockBuilder, WinAggFrameResultContext>) - Constructor for class org.apache.calcite.adapter.enumerable.impl.WinAggAddContextImpl
-
Deprecated.
- WinAggAddContextImpl(BlockBuilder, List<Expression>, Function<BlockBuilder, WinAggFrameResultContext>) - Constructor for class org.apache.calcite.adapter.enumerable.impl.WinAggAddContextImpl
- WinAggContext - Interface in org.apache.calcite.adapter.enumerable
-
Marker interface to allow
AggImplementor
to tell if it is used in regular or windowed context. - WinAggFrameContext - Interface in org.apache.calcite.adapter.enumerable
-
Provides information on the current window.
- WinAggFrameResultContext - Interface in org.apache.calcite.adapter.enumerable
-
Provides information on the current window when computing the result of the aggregation.
- WinAggImplementor - Interface in org.apache.calcite.adapter.enumerable
-
Implements a windowed aggregate function by generating expressions to initialize, add to, and get a result from, an accumulator.
- WinAggImplementor.SeekType - Enum in org.apache.calcite.adapter.enumerable
-
Allows to access rows in window partition relative to first/last and current row.
- WinAggResetContext - Interface in org.apache.calcite.adapter.enumerable
-
Information for a call to
AggImplementor.implementReset(AggContext, AggResetContext)
. - WinAggResetContextImpl - Class in org.apache.calcite.adapter.enumerable.impl
-
Implementation of
WinAggResetContext
. - WinAggResetContextImpl(BlockBuilder, List<Expression>, Expression, Expression, Expression, Expression, Expression, Expression) - Constructor for class org.apache.calcite.adapter.enumerable.impl.WinAggResetContextImpl
-
Creates window aggregate reset context.
- WinAggResultContext - Interface in org.apache.calcite.adapter.enumerable
-
Information for a call to
AggImplementor.implementResult(AggContext, AggResultContext)
. - WinAggResultContextImpl - Class in org.apache.calcite.adapter.enumerable.impl
-
Implementation of
WinAggResultContext
. - WinAggResultContextImpl(BlockBuilder, List<Expression>, Function<BlockBuilder, WinAggFrameResultContext>) - Constructor for class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
-
Deprecated.
- WinAggResultContextImpl(BlockBuilder, List<Expression>, Function<BlockBuilder, WinAggFrameResultContext>) - Constructor for class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
-
Creates window aggregate result context.
- window(RelMetadataQuery, RelNode, ImmutableList<Window.Group>) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Helper method to determine a
Window
's collation. - Window - Class in org.apache.calcite.rel.core
-
A relational expression representing a set of window aggregates.
- Window(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, List<RexLiteral>, RelDataType, List<Window.Group>) - Constructor for class org.apache.calcite.rel.core.Window
-
Creates a window relational expression.
- Window(RelOptCluster, RelTraitSet, RelNode, List<RexLiteral>, RelDataType, List<Window.Group>) - Constructor for class org.apache.calcite.rel.core.Window
-
Creates a window relational expression.
- WINDOW - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Window specification.
- WINDOW - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Window specification.
- WINDOW - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
Window
nodes. - WINDOW_DECL_LIST - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
The WINDOW clause of a SELECT statement.
- WINDOW_REDUCE_EXPRESSIONS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that reduces constants inside a
LogicalWindow
. - Window.Group - Class in org.apache.calcite.rel.core
-
Group of windowed aggregate calls that have the same window specification.
- Window.RexWinAggCall - Class in org.apache.calcite.rel.core
-
A call to a windowed aggregate function.
- windowDeclListNewline() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether each declaration in a WINDOW clause should be on its own line.
- windowedAggregateIllegalInClause(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- windowFolding() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns the line-folding policy for the WINDOW clause.
- windowHasNegativeSize() - Method in interface org.apache.calcite.runtime.CalciteResource
- windowInHavingNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- windowNameMustBeSimple() - Method in interface org.apache.calcite.runtime.CalciteResource
- windowNames - Variable in class org.apache.calcite.sql.validate.SelectScope
- windowNewline() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether a WINDOW clause should start its own line.
- WindowNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
Window
. - windowNotFound(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- WindowReduceExpressionsRule(Class<? extends Window>, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.WindowReduceExpressionsRule
-
Deprecated.
- WindowReduceExpressionsRule(ReduceExpressionsRule.WindowReduceExpressionsRule.WindowReduceExpressionsRuleConfig) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.WindowReduceExpressionsRule
-
Creates a WindowReduceExpressionsRule.
- winExp(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- winExp2(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- winSql(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- with(StringBuilder) - Method in class org.apache.calcite.materialize.Lattice.SqlWriter
-
Re-binds this writer to a different
StringBuilder
. - with(String, Object) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- with(String, Object) - Method in interface org.apache.calcite.test.ConnectionFactory
- with(Map<String, String>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- with(ConnectionProperty, Object) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- with(ConnectionProperty, Object) - Method in interface org.apache.calcite.test.ConnectionFactory
- with(Lex) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Sets the Lex property.
- with(RelNode, Function<RelBuilder, E>) - Method in class org.apache.calcite.tools.RelBuilder
-
Evaluates an expression with a relational expression temporarily on the stack.
- with(SqlJsonConstructorNullClause) - Method in class org.apache.calcite.sql.fun.SqlJsonArrayAggAggFunction
- with(SqlJsonConstructorNullClause) - Method in class org.apache.calcite.sql.fun.SqlJsonObjectAggAggFunction
- with(CalciteAssert.Config) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- with(CalciteAssert.ConnectionPostProcessor) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- with(CalciteAssert.ConnectionPostProcessor) - Method in interface org.apache.calcite.test.ConnectionFactory
- with(CalciteAssert.SchemaSpec...) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Creates a copy of this AssertThat, adding more schemas.
- with(ConnectionFactory) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Creates a copy of this AssertThat, overriding the connection factory.
- WITH - Enum constant in enum org.apache.calcite.sql.SqlKind
-
WITH clause.
- WITH - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
WITH clause of a SELECT statement.
- WITH_BODY - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
The body query of WITH.
- WITH_CONDITIONAL_ARRAY - Enum constant in enum org.apache.calcite.sql.SqlJsonQueryWrapperBehavior
- WITH_ITEM - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Item in WITH clause.
- WITH_ITEM_TABLE_REF - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Represents a recursive CTE as a table ref.
- WITH_UNCONDITIONAL_ARRAY - Enum constant in enum org.apache.calcite.sql.SqlJsonQueryWrapperBehavior
- withAddJsonTypeOperatorEnabled(boolean) - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
- withAfter(BiFunction<RelOptFixture, RelNode, RelNode>) - Method in class org.apache.calcite.test.RelOptFixture
- withAggregateProjectPullUpConstantsRule(RelOptRule) - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule.Config
- withAggregateUnique(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.Config
- withAllowAlwaysTrueCondition(boolean) - Method in interface org.apache.calcite.rel.rules.JoinAssociateRule.Config
- withAllowAlwaysTrueCondition(boolean) - Method in interface org.apache.calcite.rel.rules.JoinCommuteRule.Config
- withAllowFunctions(boolean) - Method in interface org.apache.calcite.rel.rules.AggregateJoinTransposeRule.Config
- withAllowsFraming(boolean) - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- withAllowsNullTreatment(boolean) - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- withAllowsSeparator(boolean) - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- withAlwaysUseParentheses(boolean) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withApproximate(boolean) - Method in class org.apache.calcite.rel.core.AggregateCall
- withArgList(List<Integer>) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Withs
AggregateCall.getArgList()
. - withBatchSize(int) - Method in interface org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoinRule.Config
- withBefore(BiFunction<RelOptFixture, RelNode, RelNode>) - Method in class org.apache.calcite.test.RelOptFixture
- withBloat(int) - Method in interface org.apache.calcite.rel.rules.FilterProjectTransposeRule.Config
- withBloat(int) - Method in interface org.apache.calcite.rel.rules.ProjectMergeRule.Config
- withBloat(int) - Method in interface org.apache.calcite.tools.RelBuilder.Config
- withBrokenTestsEnabled(boolean) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- withCallRewrite(boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Sets whether to enable rewrite of "macro-like" calls such as COALESCE.
- withCapacity(int) - Static method in interface org.apache.calcite.runtime.PairList
-
Creates an empty PairList with a specified initial capacity.
- withCaseClausesOnNewLines(boolean) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withCaseSensitive(boolean) - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- withCaseSensitive(boolean) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withCaseSensitive(boolean) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns a fixture that matches identifiers by case-sensitive or case-insensitive.
- withCaseSensitive(boolean) - Static method in class org.apache.calcite.sql.validate.SqlNameMatchers
-
Returns a name matcher with the given case sensitivity.
- withCaseSensitive(boolean) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withCatalogReader(SqlTestFactory.CatalogReaderFactory) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- withCatalogReader(SqlTestFactory.CatalogReaderFactory) - Method in class org.apache.calcite.test.SqlToRelFixture
- withCatalogReader(SqlTestFactory.CatalogReaderFactory) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withCatalogReaderFactory(SqlTestFactory.CatalogReaderFactory) - Method in class org.apache.calcite.test.RelMetadataFixture
- withCatalogReaderFactory(SqlTestFactory.CatalogReaderFactory) - Method in class org.apache.calcite.test.RelOptFixture
- withCharLiteralStyles(Iterable<CharLiteralStyle>) - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- withClauseEndsLine(boolean) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withClauseStartsLine(boolean) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withCluster(UnaryOperator<RelOptCluster>) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- withCluster(UnaryOperator<RelOptCluster>) - Method in class org.apache.calcite.test.RelMetadataFixture
- withCoerceNames(boolean) - Method in interface org.apache.calcite.rel.rules.CoerceInputsRule.Config
- withCollation(RelCollation) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Withs
AggregateCall.getCollation()
. - withCollation(RelCollation) - Method in class org.apache.calcite.rel.RelRoot
- withColumnReferenceExpansion(boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Sets whether to enable expansion of column references.
- withConfig(UnaryOperator<SqlParser.Config>) - Method in class org.apache.calcite.sql.parser.SqlParserFixture
- withConfig(UnaryOperator<SqlToRelConverter.Config>) - Method in class org.apache.calcite.test.RelOptFixture
- withConfig(UnaryOperator<SqlToRelConverter.Config>) - Method in class org.apache.calcite.test.SqlToRelFixture
- withConfig(CalciteConnectionConfig) - Static method in class org.apache.calcite.plan.Contexts
-
Deprecated.
- withConformance(SqlConformance) - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- withConformance(SqlConformance) - Method in class org.apache.calcite.sql.parser.SqlParserFixture
- withConformance(SqlConformance) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withConformance(SqlConformance) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns a fixture that tests conformance to a particular SQL language version.
- withConformance(SqlConformance) - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Sets the SQL conformance of the validator.
- withConformance(SqlConformance) - Method in class org.apache.calcite.test.RelOptFixture
- withConformance(SqlConformance) - Method in class org.apache.calcite.test.SqlToRelFixture
- withConformance(SqlConformance) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withConnection(Consumer<Connection>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Performs an action using a connection, and closes the connection afterward.
- withConnectionFactory(UnaryOperator<ConnectionFactory>) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns a fixture that gets connections from a given factory.
- withConnectionFactory(UnaryOperator<ConnectionFactory>) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- withConsumerRelClass(Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.rules.CoerceInputsRule.Config
- withContext(UnaryOperator<Context>) - Method in class org.apache.calcite.test.RelOptFixture
- withConversion(Class<? extends RelNode>, RelTrait, RelTrait, String) - Method in interface org.apache.calcite.rel.convert.ConverterRule.Config
- withConversion(Class<R>, Predicate<? super R>, RelTrait, RelTrait, String) - Method in interface org.apache.calcite.rel.convert.ConverterRule.Config
- withConvertCorrelateToJoin(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.Config
- withConverterRule(ConverterRule) - Method in interface org.apache.calcite.rel.convert.TraitMatchingRule.Config
- withConvertToLinux(boolean) - Method in class org.apache.calcite.sql.parser.SqlParserFixture
-
Sets whether to convert actual strings to Linux (converting Windows CR-LF line endings to Linux LF) before comparing them to expected.
- withCopyFilter(boolean) - Method in interface org.apache.calcite.rel.rules.FilterProjectTransposeRule.Config
- withCopyProject(boolean) - Method in interface org.apache.calcite.rel.rules.FilterProjectTransposeRule.Config
- withCreateValuesRel(boolean) - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
- withDatabaseMajorVersion(int) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withDatabaseMinorVersion(int) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withDatabaseProduct(SqlDialect.DatabaseProduct) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withDatabaseProductName(String) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withDatabaseVersion(String) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withDataTypeSystem(RelDataTypeSystem) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withDecorrelate(boolean) - Method in class org.apache.calcite.test.RelOptFixture
- withDecorrelate(boolean) - Method in class org.apache.calcite.test.SqlToRelFixture
- withDecorrelationEnabled(boolean) - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
- withDecorrelator(RelDecorrelator) - Method in interface org.apache.calcite.sql2rel.RelDecorrelator.Config
- withDedupAggregateCalls(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.Config
- withDefaultNullCollation(NullCollation) - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Sets how NULL values should be collated if an ORDER BY item does not contain NULLS FIRST or NULLS LAST.
- withDefaultSchema(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Sets the default schema of the connection.
- withDescription(String) - Method in interface org.apache.calcite.plan.RelRule.Config
- withDeterministic(boolean) - Method in class org.apache.calcite.sql.SqlBasicFunction
-
Returns a copy of this function with a given determinism.
- withDialect(SqlDialect) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withDialect(SqlDialect) - Method in class org.apache.calcite.sql.parser.SqlParserFixture
- withDiffRepos(DiffRepository) - Method in class org.apache.calcite.test.RelOptFixture
- withDiffRepos(DiffRepository) - Method in class org.apache.calcite.test.SqlToRelFixture
- withDirection(RelFieldCollation.Direction) - Method in class org.apache.calcite.rel.RelFieldCollation
-
Creates a copy of this RelFieldCollation with a different direction.
- withDistinct(boolean) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Withs
AggregateCall.isDistinct()
. - withDistinctKeys(ImmutableBitSet) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Withs
AggregateCall.distinctKeys
. - withDynamic(boolean) - Method in class org.apache.calcite.sql.SqlBasicFunction
- withDynamicTable() - Method in class org.apache.calcite.test.RelOptFixture
- withDynamicTable() - Method in class org.apache.calcite.test.SqlToRelFixture
- withElements(FormatModel, String, Consumer<List<FormatElement>>) - Method in class org.apache.calcite.runtime.SqlFunctions.DateFormatFunction
-
Given a format string and a format model, calls an action with the list of elements obtained by parsing that format string.
- withEmbeddedQuery(boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Sets whether to treat the query being validated as embedded (as opposed to top-level).
- withEpoch(TimestampString) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Replaces the epoch of the most recently added frame.
- withException(Exception) - Static method in class org.apache.calcite.runtime.JsonFunctions.JsonValueContext
- withExpand(boolean) - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
- withExpand(boolean) - Method in class org.apache.calcite.test.RelOptFixture
- withExpand(boolean) - Method in class org.apache.calcite.test.SqlToRelFixture
- withExpanded(boolean) - Method in class org.apache.calcite.sql.SqlBasicCall
-
Sets whether this call is expanded.
- withExplain(boolean) - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
- withExpr(String) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withExpression(String) - Method in class org.apache.calcite.adapter.druid.VirtualColumn.Builder
- withExtendedCatalog() - Method in class org.apache.calcite.test.SqlValidatorFixture
- withExtendedTester() - Method in class org.apache.calcite.test.SqlToRelFixture
- withExtraCondition(Predicate<AggregateCall>) - Method in interface org.apache.calcite.rel.rules.AggregateReduceFunctionsRule.Config
- withFactory(UnaryOperator<SqlTestFactory>) - Method in class org.apache.calcite.sql.parser.SqlParserFixture
-
Creates a copy of this fixture with a new test factory.
- withFactory(UnaryOperator<SqlTestFactory>) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Creates a copy of this fixture with a new test factory.
- withFactory(UnaryOperator<SqlTestFactory>) - Method in class org.apache.calcite.test.RelMetadataFixture
- withFactory(UnaryOperator<SqlTestFactory>) - Method in class org.apache.calcite.test.RelOptFixture
- withFactory(UnaryOperator<SqlTestFactory>) - Method in class org.apache.calcite.test.SqlToRelFixture
- withFactory(UnaryOperator<SqlTestFactory>) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withFastBailOut(boolean) - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewRule.Config
- withFieldIndex(int) - Method in class org.apache.calcite.rel.RelFieldCollation
-
Creates a copy of this RelFieldCollation against a different field.
- withFieldNames(List<String>) - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- withFilter(int) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Withs
AggregateCall.filterArg
. - withFilterAggregateTransposeRule(RelOptRule) - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule.Config
- withFilterProjectTransposeRule(RelOptRule) - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule.Config
- withFlavor(boolean) - Method in interface org.apache.calcite.sql2rel.RelDecorrelator.AdjustProjectForCountAggregateRule.AdjustProjectForCountAggregateRuleConfig
- withFoldLength(int) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withForce(boolean) - Method in interface org.apache.calcite.rel.rules.ProjectMergeRule.Config
- withFraction(String) - Method in class org.apache.calcite.util.TimestampString
-
Sets the fraction field of a
TimestampString
. - withFraction(String) - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
-
Sets the fraction field of a
TimestampString
. - withFraction(String) - Method in class org.apache.calcite.util.TimeString
-
Sets the fraction field of a
TimeString
. - withFraction(String) - Method in class org.apache.calcite.util.TimeWithTimeZoneString
-
Sets the fraction field of a
TimeWithTimeZoneString
. - withFromFolding(SqlWriterConfig.LineFolding) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withFunctionsToReduce(Iterable<SqlKind>) - Method in interface org.apache.calcite.rel.rules.AggregateReduceFunctionsRule.Config
- withFunctionsToReduce(Set<SqlKind>) - Method in interface org.apache.calcite.rel.rules.AggregateReduceFunctionsRule.Config
- withFunctionType(SqlFunctionCategory) - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- withFunctionType(SqlFunctionCategory) - Method in class org.apache.calcite.sql.SqlBasicFunction
-
Returns a copy of this function with a given category.
- withGenerateUnionRewriting(boolean) - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewRule.Config
- withGenerator(BiFunction<SqlOperator, String, String>) - Method in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- withGenerator(BiFunction<SqlOperator, String, String>) - Method in interface org.apache.calcite.sql.type.SqlOperandTypeChecker
-
Returns a copy of this checker with the given signature generator.
- withGroupByFolding(SqlWriterConfig.LineFolding) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withGroupOrder(Optionality) - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- withHavingFolding(SqlWriterConfig.LineFolding) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withHints(List<RelHint>) - Method in class org.apache.calcite.adapter.jdbc.JdbcTableScan
- withHints(List<RelHint>) - Method in interface org.apache.calcite.rel.hint.Hintable
-
Returns a new relational expression with the specified hints
hintList
. - withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalAggregate
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalAsofJoin
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalCalc
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalCorrelate
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalFilter
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalIntersect
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalJoin
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalMinus
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalProject
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalSnapshot
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalSort
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalTableFunctionScan
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalTableScan
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalUnion
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalValues
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.logical.LogicalWindow
- withHints(List<RelHint>) - Method in class org.apache.calcite.rel.RelRoot
-
Creates a copy, assigning the query hints.
- withHints(List<RelHint>) - Method in class org.apache.calcite.test.SqlToRelTestBase.CustomCorrelate
- withHintStrategyTable(HintStrategyTable) - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
- withHook(Hook, Consumer<T>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Adds a hook and a handler for that hook.
- withHook(Hook, Consumer<T>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Adds a hook and a handler for that hook.
- withHook(Hook, Consumer<T>) - Method in class org.apache.calcite.test.RelOptFixture
-
Adds a hook and a handler for that hook.
- withId(String) - Method in interface org.apache.calcite.adapter.splunk.SplunkPushDownRule.Config
- withIdentifierEscapedQuoteString(String) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withIdentifierExpansion(boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Sets whether to enable expansion of identifiers other than column references.
- withIdentifierMaxLength(int) - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- withIdentifierQuoteString(String) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withIdPrefix - Variable in class org.apache.calcite.rel.externalize.RelWriterImpl
- withIgnoreNulls(boolean) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Withs
AggregateCall.ignoreNulls()
. - withImplementation() - Method in class org.apache.calcite.sql.SqlExplain
-
Returns whether physical plan implementation should be returned.
- within(T, double) - Static method in class org.apache.calcite.test.Matchers
-
Deprecated.Use
Matchers.closeTo(double, double)
- WITHIN_DISTINCT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
WITHIN DISTINCT
operator. - WITHIN_DISTINCT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
WITHIN_DISTINCT
operator performs aggregations on distinct data input. - WITHIN_GROUP - Enum constant in enum org.apache.calcite.sql.SqlKind
-
WITHIN GROUP
operator. - WITHIN_GROUP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
WITHIN_GROUP
operator performs aggregations on ordered data input. - withIncludeOuter(boolean) - Method in interface org.apache.calcite.rel.rules.JoinProjectTransposeRule.Config
- withIndentation(int) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withIndexColumnNames(List<String>) - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- withIndexName(String) - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- withinDistinctNotAllowed(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- withinGroupClauseIllegalInAggregate(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- withinGroupNotAllowed(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- withInitial(Supplier<? extends S>) - Static method in class org.apache.calcite.util.TryThreadLocal
-
Creates a TryThreadLocal with a supplier for the initial value.
- withInputTranslator(RelJson.InputTranslator) - Method in class org.apache.calcite.rel.externalize.RelJson
-
Returns a RelJson with a given InputTranslator.
- withInSubQueryThreshold(int) - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
- withInSubQueryThreshold(int) - Method in class org.apache.calcite.test.RelOptFixture
- withInTrait(RelTrait) - Method in interface org.apache.calcite.rel.convert.ConverterRule.Config
- withJavaObj(Object) - Static method in class org.apache.calcite.runtime.JsonFunctions.JsonValueContext
- withJavaObj(JsonFunctions.PathMode, Object) - Static method in class org.apache.calcite.runtime.JsonFunctions.JsonPathContext
- withJethroInfo(JethroDataSqlDialect.JethroInfo) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withJsonBuilder(JsonBuilder) - Method in class org.apache.calcite.rel.externalize.RelJson
-
Returns a RelJson with a given JsonBuilder.
- withKeywordsLowerCase(boolean) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withKind(SqlKind) - Method in class org.apache.calcite.rel.RelRoot
-
Creates a copy, assigning a new kind.
- withKind(SqlKind) - Method in class org.apache.calcite.sql.SqlBasicFunction
-
Returns a copy of this function with a given kind.
- withLateDecorrelate(boolean) - Method in class org.apache.calcite.test.RelOptFixture
- withLeadingComma(boolean) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withLenientOperatorLookup(boolean) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns a fixture that does not fail validation if it encounters an unknown function.
- withLenientOperatorLookup(boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Sets whether this validator should be lenient upon encountering an unknown function.
- withLenientOperatorLookup(boolean) - Method in class org.apache.calcite.test.SqlValidatorFixture
-
Returns a tester that does not fail validation if it encounters an unknown function.
- withLex(Lex) - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- withLex(Lex) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns a fixture that follows a given lexical policy.
- withLex(Lex) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withLibraries(SqlLibrary...) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- withLibrary(SqlLibrary) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
- withLibraryOperatorTable() - Method in class org.apache.calcite.rel.externalize.RelJson
-
Returns a RelJson with an operator table that consists of the standard operators plus operators in all libraries.
- withLineFolding(SqlWriterConfig.LineFolding) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withLineLength(int) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withList - Variable in class org.apache.calcite.sql.SqlWith
- withLiteralEscapedQuoteString(String) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withLiteralQuoteString(String) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withMatchFolding(SqlWriterConfig.LineFolding) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withMatchHandler(RelRule.MatchHandler<ExchangeRemoveConstantKeysRule>) - Method in interface org.apache.calcite.rel.rules.ExchangeRemoveConstantKeysRule.Config
- withMatchHandler(RelRule.MatchHandler<SortMergeRule>) - Method in interface org.apache.calcite.rel.rules.SortMergeRule.Config
- withMatchHandler(RelRule.MatchHandler<SubQueryRemoveRule>) - Method in interface org.apache.calcite.rel.rules.SubQueryRemoveRule.Config
- withMatchHandler(RelRule.MatchHandler<ValuesReduceRule>) - Method in interface org.apache.calcite.rel.rules.ValuesReduceRule.Config
- withMatchNullability(boolean) - Method in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.Config
- withMatchNullFetch(boolean) - Method in interface org.apache.calcite.rel.rules.SortUnionTransposeRule.Config
- withMaterializations(String, boolean, String...) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Adds materializations to the schema.
- withMaterializations(String, String...) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- withMaterializations(String, Function<JsonBuilder, List<Object>>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Adds materializations to the schema.
- withMaxPrecision(RelDataTypeSystem, Function<SqlTypeName, Integer>) - Static method in class org.apache.calcite.test.CustomTypeSystems
-
Decorates a type system so that
RelDataTypeSystem.getMaxPrecision(SqlTypeName)
returns a given value. - withMaxScale(RelDataTypeSystem, Function<SqlTypeName, Integer>) - Static method in class org.apache.calcite.test.CustomTypeSystems
-
Decorates a type system so that
RelDataTypeSystem.getMaxScale(SqlTypeName)
returns a given value. - withMessageArgs(String, Object...) - Method in interface org.apache.calcite.util.Litmus
-
Creates a Litmus that, if it fails, will use the given arguments.
- withMetadataConfig(RelMetadataFixture.MetadataConfig) - Method in class org.apache.calcite.test.RelMetadataFixture
- withMillis(int) - Method in class org.apache.calcite.util.TimestampString
-
Sets the fraction field of a
TimestampString
to a given number of milliseconds. - withMillis(int) - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
-
Sets the fraction field of a
TimestampWithTimeZoneString
to a given number of milliseconds. - withMillis(int) - Method in class org.apache.calcite.util.TimeString
-
Sets the fraction field of a
TimeString
to a given number of milliseconds. - withMillis(int) - Method in class org.apache.calcite.util.TimeWithTimeZoneString
-
Sets the fraction field of a
TimeWithTimeZoneString
to a given number of milliseconds. - withMinimumSurprise(double) - Method in class org.apache.calcite.profile.ProfilerImpl.Builder
- withMinScale(RelDataTypeSystem, Function<SqlTypeName, Integer>) - Static method in class org.apache.calcite.test.CustomTypeSystems
-
Decorates a type system so that
RelDataTypeSystem.getMinScale(SqlTypeName)
returns a given value. - withModel(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- withModel(URL) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- withMonotonicityInference(Function<SqlOperatorBinding, SqlMonotonicity>) - Method in class org.apache.calcite.sql.SqlBasicFunction
-
Returns a copy of this function with a given strategy for inferring whether a call is monotonic.
- withNakedMeasures(boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Deprecated.
- withNakedMeasuresInAggregateQuery(boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Sets whether the validator allows measures to be used without AGGREGATE function in an aggregate query.
- withNakedMeasuresInNonAggregateQuery(boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Sets whether the validator allows measures to be used without AGGREGATE function in a non-aggregate query.
- withName(String) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Withs
AggregateCall.name
. - withName(String) - Method in class org.apache.calcite.adapter.druid.VirtualColumn.Builder
- withName(String) - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
-
Sets
SqlOperator.getName()
. - withName(String) - Method in class org.apache.calcite.sql.fun.SqlFloorFunction
- withName(String) - Method in class org.apache.calcite.sql.SqlBasicFunction
-
Returns a copy of this function with a given name.
- WithNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for
WITH
clause. - withNanos(int) - Method in class org.apache.calcite.util.TimestampString
-
Sets the fraction field of a
TimestampString
to a given number of nanoseconds. - withNanos(int) - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
-
Sets the fraction field of a
TimestampWithTimeZoneString
to a given number of nanoseconds. - withNanos(int) - Method in class org.apache.calcite.util.TimeString
-
Sets the fraction field of a
TimeString
to a given number of nanoseconds. - withNanos(int) - Method in class org.apache.calcite.util.TimeWithTimeZoneString
-
Sets the fraction field of a
TimeString
to a given number of nanoseconds. - withNullable(Boolean) - Method in class org.apache.calcite.sql.SqlDataTypeSpec
-
Returns a copy of this data type specification with a given nullability.
- withNullable(Boolean, SqlParserPos) - Method in class org.apache.calcite.sql.SqlDataTypeSpec
-
Returns a copy of this data type specification with a given nullability, extending the parser position.
- withNullCollation(NullCollation) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withNullDirection(RelFieldCollation.NullDirection) - Method in class org.apache.calcite.rel.RelFieldCollation
-
Creates a copy of this RelFieldCollation with a different null direction.
- withOperandFor(Class<? extends Aggregate>) - Method in interface org.apache.calcite.rel.rules.AggregateReduceFunctionsRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Aggregate>) - Method in interface org.apache.calcite.rel.rules.AggregateRemoveRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Aggregate>, Class<? extends Filter>) - Method in interface org.apache.calcite.rel.rules.AggregateFilterTransposeRule.Config
-
Defines an operand tree for the given 2 classes.
- withOperandFor(Class<? extends Aggregate>, Class<? extends Filter>, Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.rules.AggregateFilterTransposeRule.Config
-
Defines an operand tree for the given 3 classes.
- withOperandFor(Class<? extends Aggregate>, Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.AggregateJoinJoinRemoveRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Aggregate>, Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.AggregateJoinRemoveRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Aggregate>, Class<? extends Join>, boolean) - Method in interface org.apache.calcite.rel.rules.AggregateJoinTransposeRule.Config
-
Defines an operand tree for the given classes, and also sets
AggregateJoinTransposeRule.Config.isAllowFunctions()
. - withOperandFor(Class<? extends Aggregate>, Class<? extends Project>) - Method in interface org.apache.calcite.rel.rules.AggregateProjectConstantToDummyJoinRule.Config
- withOperandFor(Class<? extends Aggregate>, Class<? extends Project>) - Method in interface org.apache.calcite.rel.rules.AggregateProjectMergeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Aggregate>, Class<? extends Project>, Class<StarTable.StarTableScan>) - Method in interface org.apache.calcite.rel.rules.AggregateProjectStarTableRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Aggregate>, Class<? extends Union>) - Method in interface org.apache.calcite.rel.rules.AggregateUnionTransposeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Aggregate>, Class<? extends Union>, Class<? extends RelNode>, Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.rules.AggregateUnionAggregateRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Aggregate>, Class<? extends Values>) - Method in interface org.apache.calcite.rel.rules.AggregateValuesRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Aggregate>, Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.rules.AggregateExtractProjectRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Aggregate>, Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.rules.AggregateProjectPullUpConstantsRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Aggregate>, Class<StarTable.StarTableScan>) - Method in interface org.apache.calcite.rel.rules.AggregateStarTableRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Filter>) - Method in interface org.apache.calcite.rel.rules.FilterMergeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Filter>, Class<? extends Aggregate>) - Method in interface org.apache.calcite.rel.rules.FilterAggregateTransposeRule.Config
-
Defines an operand tree for the given 2 classes.
- withOperandFor(Class<? extends Filter>, Class<? extends Aggregate>, Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.rules.FilterAggregateTransposeRule.Config
-
Defines an operand tree for the given 3 classes.
- withOperandFor(Class<? extends Filter>, Class<? extends Calc>) - Method in interface org.apache.calcite.rel.rules.FilterCalcMergeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Filter>, Class<? extends Correlate>) - Method in interface org.apache.calcite.rel.rules.FilterCorrelateRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Filter>, Class<? extends Project>, Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.rules.FilterProjectTransposeRule.Config
-
Defines an operand tree for the given 3 classes.
- withOperandFor(Class<? extends Filter>, Class<? extends TableScan>) - Method in interface org.apache.calcite.rel.rules.MaterializedViewFilterScanRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Filter>, Class<? extends MultiJoin>) - Method in interface org.apache.calcite.rel.rules.FilterMultiJoinMergeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Filter>, Predicate<Filter>, Class<? extends Project>, Predicate<Project>) - Method in interface org.apache.calcite.rel.rules.FilterProjectTransposeRule.Config
-
Defines an operand tree for the given 2 classes.
- withOperandFor(Class<? extends Intersect>) - Method in interface org.apache.calcite.rel.rules.IntersectToDistinctRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.JoinAddRedundantSemiJoinRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.JoinAssociateRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.JoinCommuteRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.JoinPushExpressionsRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.JoinPushThroughJoinRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.JoinPushTransitivePredicatesRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.JoinToCorrelateRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.JoinToMultiJoinRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.SemiJoinRemoveRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Join>, Class<? extends Filter>) - Method in interface org.apache.calcite.rel.rules.SemiJoinFilterTransposeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Join>, Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.SemiJoinJoinTransposeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Join>, Class<? extends Project>) - Method in interface org.apache.calcite.rel.rules.SemiJoinProjectTransposeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Join>, Class<? extends Union>, boolean) - Method in interface org.apache.calcite.rel.rules.JoinUnionTransposeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Minus>) - Method in interface org.apache.calcite.rel.rules.MinusToDistinctRule.Config
- withOperandFor(Class<? extends Project>) - Method in interface org.apache.calcite.rel.rules.ProjectMergeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Project>, Class<? extends Calc>) - Method in interface org.apache.calcite.rel.rules.ProjectCalcMergeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Project>, Class<? extends Correlate>) - Method in interface org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Project>, Class<? extends Filter>) - Method in interface org.apache.calcite.rel.rules.ProjectFilterTransposeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Project>, Class<? extends Filter>, Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.rules.ProjectFilterTransposeRule.Config
-
Defines an operand tree for the given 3 classes.
- withOperandFor(Class<? extends Project>, Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.ProjectJoinJoinRemoveRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Project>, Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.ProjectJoinRemoveRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Project>, Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.ProjectJoinTransposeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Project>, Class<? extends Join>, Class<? extends Aggregate>) - Method in interface org.apache.calcite.rel.rules.SemiJoinRule.ProjectToSemiJoinRule.ProjectToSemiJoinRuleConfig
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Project>, Class<? extends Window>) - Method in interface org.apache.calcite.rel.rules.ProjectWindowTransposeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Project>, Class<MultiJoin>) - Method in interface org.apache.calcite.rel.rules.ProjectMultiJoinMergeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Sample>) - Method in interface org.apache.calcite.rel.rules.SampleToFilterRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Sort>, Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.SortJoinCopyRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Sort>, Class<? extends Join>) - Method in interface org.apache.calcite.rel.rules.SortJoinTransposeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Sort>, Class<? extends Project>) - Method in interface org.apache.calcite.rel.rules.SortProjectTransposeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Sort>, Class<? extends Project>, Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.rules.SortProjectTransposeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Sort>, Class<? extends Union>) - Method in interface org.apache.calcite.rel.rules.SortUnionTransposeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Union>) - Method in interface org.apache.calcite.rel.rules.UnionEliminatorRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Union>) - Method in interface org.apache.calcite.rel.rules.UnionPullUpConstantsRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Union>) - Method in interface org.apache.calcite.rel.rules.UnionToDistinctRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends Union>) - Method in interface org.apache.calcite.rel.rules.UnionToValuesRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends RelNode>) - Method in interface org.apache.calcite.adapter.splunk.SplunkPushDownRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.rules.CoerceInputsRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.rules.UnionMergeRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.rules.ValuesReduceRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.stream.StreamRules.DeltaAggregateTransposeRule.DeltaAggregateTransposeRuleConfig
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.stream.StreamRules.DeltaFilterTransposeRule.DeltaFilterTransposeRuleConfig
-
Defines an operand tree for the given classes.
- withOperandFor(Class<? extends RelNode>) - Method in interface org.apache.calcite.rel.stream.StreamRules.DeltaProjectTransposeRule.DeltaProjectTransposeRuleConfig
-
Defines an operand tree for the given classes.
- withOperandFor(Class<Join>, Class<Aggregate>) - Method in interface org.apache.calcite.rel.rules.SemiJoinRule.JoinToSemiJoinRule.JoinToSemiJoinRuleConfig
-
Defines an operand tree for the given classes.
- withOperandFor(Class<R>, Predicate<R>) - Method in interface org.apache.calcite.rel.rules.ExchangeRemoveConstantKeysRule.Config
-
Defines an operand tree for the given classes.
- withOperandFor(Class<R>, Predicate<R>) - Method in interface org.apache.calcite.rel.rules.PruneEmptyRules.RemoveEmptySingleRule.RemoveEmptySingleRuleConfig
-
Defines an operand tree for the given classes.
- withOperandHandler(SqlOperandHandler) - Method in class org.apache.calcite.sql.SqlBasicFunction
-
Returns a copy of this function with a given strategy for handling operands.
- withOperandSupplier(RelRule.OperandTransform) - Method in interface org.apache.calcite.plan.RelRule.Config
- withOperandTypeChecker(SqlOperandTypeChecker) - Method in class org.apache.calcite.sql.SqlBasicFunction
- withOperandTypeInference(SqlOperandTypeInference) - Method in class org.apache.calcite.sql.SqlBasicFunction
-
Returns a copy of this function with a given strategy for inferring the types of its operands.
- withOperatorTable(UnaryOperator<SqlOperatorTable>) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- withOperatorTable(SqlOperatorTable) - Method in class org.apache.calcite.rel.externalize.RelJson
-
Returns a RelJson with a given operator table.
- withOperatorTable(SqlOperatorTable) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns a fixture that uses a given operator table.
- withOperatorTable(SqlOperatorTable) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withOrderByFolding(SqlWriterConfig.LineFolding) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withOrdinality - Variable in class org.apache.calcite.rel.core.Uncollect
- withOrdinality - Variable in class org.apache.calcite.rel.mutable.MutableUncollect
- withOrdinality - Variable in class org.apache.calcite.sql.SqlUnnestOperator
-
Whether
WITH ORDINALITY
was specified. - WITHOUT_ARRAY - Enum constant in enum org.apache.calcite.sql.SqlJsonQueryWrapperBehavior
- withOutTrait(RelTrait) - Method in interface org.apache.calcite.rel.convert.ConverterRule.Config
- withOver(boolean) - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- withOverFolding(SqlWriterConfig.LineFolding) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withParanoid(boolean) - Method in class org.apache.calcite.rex.RexSimplify
-
Returns a RexSimplify the same as this but which verifies that the expression before and after simplification are equivalent.
- withParserConfig(UnaryOperator<SqlParser.Config>) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Creates a copy of this fixture with a new parser configuration.
- withParserConfig(UnaryOperator<SqlParser.Config>) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- withParserConfig(UnaryOperator<SqlParser.Config>) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withParserConfig(SqlParser.Config) - Method in interface org.apache.calcite.tools.Hoist.Config
- withParserFactory(SqlParserImplFactory) - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- withPassSize(int) - Method in class org.apache.calcite.profile.ProfilerImpl.Builder
- withPercentile(boolean) - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- withPlanner(RelOptPlanner) - Method in class org.apache.calcite.test.RelOptFixture
- withPlanner(Frameworks.PlannerAction<R>) - Static method in class org.apache.calcite.tools.Frameworks
-
Initializes a container then calls user-specified code with a planner.
- withPlanner(Frameworks.PlannerAction<R>, FrameworkConfig) - Static method in class org.apache.calcite.tools.Frameworks
-
Initializes a container then calls user-specified code with a planner.
- withPlannerContext(UnaryOperator<Context>) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- withPlannerFactory(SqlTestFactory.PlannerFactory) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- withPointQueryKey(List<Object>) - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- withPre(HepProgram) - Method in class org.apache.calcite.test.RelOptFixture
- withPredicate(FilterJoinRule.Predicate) - Method in interface org.apache.calcite.rel.rules.FilterJoinRule.Config
-
Sets
FilterJoinRule.Config.getPredicate()
()}. - withPredicates(RelOptPredicateList) - Method in class org.apache.calcite.rex.RexSimplify
-
Returns a RexSimplify the same as this but with a specified
RexSimplify.predicates
value. - withPredicates(RelMetadataQuery, Function<RelBuilder, E>) - Method in class org.apache.calcite.tools.RelBuilder
-
Performs an action using predicates of the
current node
to simplify. - withPrepare(FrameworkConfig, Frameworks.BasePrepareAction<R>) - Static method in class org.apache.calcite.tools.Frameworks
-
Initializes a container then calls user-specified code with a planner and statement.
- withPrepare(Frameworks.BasePrepareAction<R>) - Static method in class org.apache.calcite.tools.Frameworks
-
As
Frameworks.withPrepare(FrameworkConfig, BasePrepareAction)
but using a default configuration. - withPrepare(Frameworks.PrepareAction<R>) - Static method in class org.apache.calcite.tools.Frameworks
-
Deprecated.
- withPrepareFactory(Supplier<CalcitePrepare>) - Method in class org.apache.calcite.jdbc.Driver
-
Creates a copy of this Driver with a new factory for creating
CalcitePrepare
. - withPreRule(RelOptRule...) - Method in class org.apache.calcite.test.RelOptFixture
- withPreserveExprCondition(PushProjector.ExprCondition) - Method in interface org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.Config
- withPreserveExprCondition(PushProjector.ExprCondition) - Method in interface org.apache.calcite.rel.rules.ProjectFilterTransposeRule.Config
- withPreserveExprCondition(PushProjector.ExprCondition) - Method in interface org.apache.calcite.rel.rules.ProjectJoinTransposeRule.Config
- withPreserveExprCondition(PushProjector.ExprCondition) - Method in interface org.apache.calcite.rel.rules.ProjectSetOpTransposeRule.Config
- withPreventEmptyFieldList(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.Config
- withProgram(HepProgram) - Method in class org.apache.calcite.test.RelOptFixture
- withProjectMergeRule(RelOptRule) - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule.Config
- withProperty(Hook, V) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Adds a property hook.
- withProperty(Hook, V) - Method in class org.apache.calcite.test.RelOptFixture
- withPruneInputOfAggregate(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.Config
- withPushDownConditions(List<RexNode>) - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- withPushJoinCondition(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.Config
- withQueryType(QueryType) - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- withQuoteAllIdentifiers(boolean) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withQuotedCasing(Casing) - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- withQuotedCasing(Casing) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withQuotedCasing(Casing) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns a fixture that applies a given casing policy to quoted identifiers.
- withQuotedCasing(Casing) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withQuoting(boolean) - Method in class org.apache.calcite.sql.parser.SqlParserPos
-
Returns a
SqlParserPos
the same as this but quoted. - withQuoting(Quoting) - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- withQuoting(Quoting) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns a fixture that tests a given SQL quoting style.
- withQuoting(Quoting) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withRangeQueryLowerKey(List<Object>) - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- withRangeQueryLowerOp(ComparisonOperator) - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- withRangeQueryUpperKey(List<Object>) - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- withRangeQueryUpperOp(ComparisonOperator) - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- withRel(Function<RelBuilder, RelNode>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Adds a factory to create a
RelNode
query. - withRel(RelNode) - Method in class org.apache.calcite.rel.RelRoot
-
Creates a copy of this RelRoot, assigning a
RelNode
. - withRelBuilderConfig(UnaryOperator<RelBuilder.Config>) - Method in class org.apache.calcite.test.RelOptFixture
- withRelBuilderConfigTransform(UnaryOperator<RelBuilder.Config>) - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
- withRelBuilderFactory(RelBuilderFactory) - Method in interface org.apache.calcite.plan.RelRule.Config
- withRelBuilderFactory(RelBuilderFactory) - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
- withRelBuilderSimplify(boolean) - Method in class org.apache.calcite.test.RelOptFixture
- withRelFn(Function<RelBuilder, RelNode>) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Creates a copy of this fixture that uses a given function to create a
RelNode
. - withRelSupplier(RelSupplier) - Method in class org.apache.calcite.test.RelOptFixture
- withRelTransform(UnaryOperator<RelNode>) - Method in class org.apache.calcite.test.RelMetadataFixture
- withRemainderConditions(List<RexNode>) - Method in class org.apache.calcite.adapter.innodb.IndexCondition
- withRemoveRedundantDistinct(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.Config
- withRemoveSortInSubQuery(boolean) - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
- withRemoveUnused(boolean) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- withReturnTypeInference(SqlReturnTypeInference) - Method in class org.apache.calcite.sql.fun.SqlFloorFunction
- withReturnTypeInference(SqlReturnTypeInference) - Method in class org.apache.calcite.sql.SqlBasicFunction
-
Returns a copy of this function with a given strategy for inferring returned type.
- withRight(boolean) - Method in interface org.apache.calcite.rel.rules.JoinPushThroughJoinRule.Config
- withRoundingMode(RelDataTypeSystem, RoundingMode) - Static method in class org.apache.calcite.test.CustomTypeSystems
-
Decorates a type system so that
RelDataTypeSystem.roundingMode()
returns a given value. - withRule(RelOptRule...) - Method in class org.apache.calcite.test.RelOptFixture
- withRuleFactory(Function<ConverterRule.Config, ConverterRule>) - Method in interface org.apache.calcite.rel.convert.ConverterRule.Config
- withSchema(String, Schema) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Sets the default schema to a given schema.
- withSchemaPath(List<String>) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- withSchemaPath(List<String>) - Method in interface org.apache.calcite.prepare.Prepare.CatalogReader
-
Returns a catalog reader the same as this one but with a possibly different schema path.
- withSelectFolding(SqlWriterConfig.LineFolding) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withSelectListExtraIndentFlag(boolean) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withSelectListItemsOnSeparateLines(boolean) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withSimplifier(BiFunction<RelBuilder, RexSimplify, RexSimplify>, Function<RelBuilder, E>) - Method in class org.apache.calcite.tools.RelBuilder
-
Performs an action with a temporary simplifier.
- withSimplify(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.Config
- withSimplifyLimit(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.Config
- withSimplifyValues(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.Config
- withSmart(boolean) - Method in interface org.apache.calcite.rel.rules.FilterJoinRule.Config
- withSql(String) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Creates a copy of this fixture that uses a given SQL query.
- withSql(String) - Method in class org.apache.calcite.test.SqlToRelFixture
- withSql(String) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withSqlConformance(SqlConformance) - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Deprecated.
- withSqlToRelConfig(UnaryOperator<SqlToRelConverter.Config>) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- withStatic(SqlStaticAggFunction) - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
-
Sets that value to be returned when
SqlBasicAggFunction.unwrap(java.lang.Class<T>)
is applied toSqlStaticAggFunction
.class
. - withStrictException(Exception) - Static method in class org.apache.calcite.runtime.JsonFunctions.JsonPathContext
- withStrictException(String, Exception) - Static method in class org.apache.calcite.runtime.JsonFunctions.JsonPathContext
- withSubQueryRules() - Method in class org.apache.calcite.test.RelOptFixture
- withSubQueryStyle(SqlWriter.SubQueryStyle) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withSwapOuter(boolean) - Method in interface org.apache.calcite.rel.rules.JoinCommuteRule.Config
- withSyntax(SqlSyntax) - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- withSyntax(SqlSyntax) - Method in class org.apache.calcite.sql.SqlBasicFunction
-
Returns a copy of this function with a given syntax.
- withTester(UnaryOperator<SqlTester>) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Creates a copy of this fixture with a new tester.
- withTester(UnaryOperator<SqlTester>) - Method in class org.apache.calcite.test.RelMetadataFixture
- withTester(UnaryOperator<SqlTester>) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withTester(SqlParserTest.Tester) - Method in class org.apache.calcite.sql.parser.SqlParserFixture
- withThrowIfNotUnique(boolean) - Method in interface org.apache.calcite.rel.rules.AggregateExpandWithinDistinctRule.Config
- withTimeUnitCodes(Map<String, ? extends TimeUnit>) - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- withTimeZone(TimeZone) - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
- withTimeZone(TimeZone) - Method in class org.apache.calcite.util.TimeWithTimeZoneString
- withTreatDynamicCallsAsConstant(boolean) - Method in interface org.apache.calcite.rel.rules.ReduceExpressionsRule.Config
- withTrim(boolean) - Method in class org.apache.calcite.test.RelOptFixture
- withTrim(boolean) - Method in class org.apache.calcite.test.SqlToRelFixture
- withTrimUnusedFields(boolean) - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
- withType() - Method in class org.apache.calcite.sql.SqlExplain
-
Returns whether type should be returned.
- withType(DruidType) - Method in class org.apache.calcite.adapter.druid.VirtualColumn.Builder
- withTypeCoercion(boolean) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withTypeCoercionEnabled(boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Sets whether to enable implicit type coercion for validation, default true.
- withTypeCoercionFactory(TypeCoercionFactory) - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Sets a factory to create type coercion instance that overrides the default coercion rules defined in
TypeCoercionImpl
. - withTypeCoercionRules(SqlTypeCoercionRule) - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Sets the
SqlTypeCoercionRule
instance which defines the type conversion matrix for the explicit type coercion. - withTypeFactoryFactory(SqlTestFactory.TypeFactoryFactory) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- withTypeSystem(UnaryOperator<RelDataTypeSystem>) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- withUnionRewritingPullProgram(HepProgram) - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewRule.Config
- withUnknownAsFalse(boolean) - Method in class org.apache.calcite.rex.RexSimplify
-
Deprecated.Use methods with a
RexUnknownAs
argument, such asRexSimplify.simplify(RexNode, RexUnknownAs)
. - withUnknownException(Exception) - Static method in class org.apache.calcite.runtime.JsonFunctions.JsonPathContext
- withUnquotedCasing(Casing) - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- withUnquotedCasing(Casing) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withUnquotedCasing(Casing) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns a fixture that applies a given casing policy to unquoted identifiers.
- withUnquotedCasing(Casing) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withUpdateSetFolding(SqlWriterConfig.LineFolding) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withUpdateSetListNewline(boolean) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withUsingGroupingSets(boolean) - Method in interface org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule.Config
- withValidation(int) - Method in class org.apache.calcite.sql.SqlBasicFunction
- withValidator(SqlTestFactory.ValidatorFactory) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- withValidatorCallRewrite(boolean) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withValidatorColumnReferenceExpansion(boolean) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withValidatorConfig(UnaryOperator<SqlValidator.Config>) - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns a fixture with a given validator configuration.
- withValidatorConfig(UnaryOperator<SqlValidator.Config>) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- withValidatorConfig(UnaryOperator<SqlValidator.Config>) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withValidatorIdentifierExpansion(boolean) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withValuesFolding(SqlWriterConfig.LineFolding) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withValuesListNewline(boolean) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withVolcanoPlanner(boolean) - Method in class org.apache.calcite.test.RelOptFixture
- withVolcanoPlanner(boolean, Consumer<VolcanoPlanner>) - Method in class org.apache.calcite.test.RelOptFixture
- withWhereFolding(SqlWriterConfig.LineFolding) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withWhereListItemsOnSeparateLines(boolean) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withWhole(boolean) - Method in class org.apache.calcite.test.SqlValidatorFixture
- withWholeFilter(boolean) - Method in interface org.apache.calcite.rel.rules.ProjectFilterTransposeRule.Config
- withWholeProject(boolean) - Method in interface org.apache.calcite.rel.rules.ProjectFilterTransposeRule.Config
- withWindowDeclListNewline(boolean) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withWindowFolding(SqlWriterConfig.LineFolding) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- withWindowNewline(boolean) - Method in interface org.apache.calcite.sql.SqlWriterConfig
- wouldEqual(ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Returns whether the bit set that would be created by this Builder would equal a given bit set.
- wrap(Properties) - Method in enum org.apache.calcite.config.CalciteConnectionProperty
- wrappedCharset - Variable in class org.apache.calcite.sql.SqlCollation
- Wrapper - Interface in org.apache.calcite.schema
-
Mix-in interface that allows you to find sub-objects.
- wrapperBoolean - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- wrapperByte - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- wrapperCharacter - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- wrapperDouble - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- wrapperFloat - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- wrapperInteger - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- wrapperLong - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- wrapperShort - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- wraps - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
-
Wrapped objects that can be obtained by calling
MockCatalogReader.MockTable.unwrap(Class)
. - write(char[], int, int) - Method in class org.apache.calcite.util.StackWriter
- write(int) - Method in class org.apache.calcite.util.StackWriter
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.DefaultDimensionSpec
- write(JsonGenerator) - Method in interface org.apache.calcite.adapter.druid.DruidJson
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.DruidQuery.JsonPostAggregation
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.ExtractionDimensionSpec
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.TimeExtractionFunction
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.VirtualColumn
- write(String, int, int) - Method in class org.apache.calcite.util.StackWriter
- write(RexNode) - Method in class org.apache.calcite.materialize.Lattice.SqlWriter
-
Writes an expression.
- WRITE_ACCESS - Enum constant in enum org.apache.calcite.plan.TableAccessMap.Mode
-
Deprecated.Table is accessed for write only.
- WRITE_ONLY - Static variable in class org.apache.calcite.sql.SqlAccessType
- writeArray(JsonGenerator, List<?>) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
- writeField(JsonGenerator, String, Object) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
- writeFieldIf(JsonGenerator, String, Object) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
- writeObject(JsonGenerator, Object) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
- writeToFile() - Method in class org.apache.calcite.plan.visualizer.RuleMatchVisualizer
-
Writes the HTML and JS files of the rule match visualization.
- writeType - Variable in class org.apache.calcite.rel.core.Spool
-
How the spool forwards elements to consumers.
- WRONG_FORMAT_MESSAGE - Static variable in interface org.apache.calcite.sql.test.SqlOperatorFixture
- wrongNumberOfParam(String, int, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- wrongNumOfArguments() - Method in interface org.apache.calcite.runtime.CalciteResource
- WW - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
X
- x - Variable in class org.apache.calcite.test.schemata.hr.Location
- XML - Enum constant in enum org.apache.calcite.sql.SqlExplainFormat
-
Indicates that the plan should be output in XML format.
- XML_TRANSFORM - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- XML_TRANSFORM - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
- XmlFunctions - Class in org.apache.calcite.runtime
-
A collection of functions used in Xml processing.
- XmlOutput - Class in org.apache.calcite.util
-
Streaming XML output.
- XmlOutput(PrintWriter) - Constructor for class org.apache.calcite.util.XmlOutput
-
Constructs a new XmlOutput based on a
PrintWriter
. - XmlOutput(Writer) - Constructor for class org.apache.calcite.util.XmlOutput
-
Constructs a new XmlOutput based on any
Writer
. - xmlTransform(String, String) - Static method in class org.apache.calcite.runtime.XmlFunctions
Y
- y - Variable in class org.apache.calcite.test.schemata.hr.Location
- Y - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- YEAR - Enum constant in enum org.apache.calcite.adapter.druid.Granularity.Type
- YEAR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
YEAR
operator. - YEAR_INTERVAL_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- YEAR_VARIANTS - Static variable in class org.apache.calcite.test.SqlOperatorTest
- YEARS - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- YEARS_IN_CENTURY - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- YEARS_IN_CENTURY_ISO_8601 - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- YEARS_IN_MILLENIA - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- YEARS_IN_MILLENIA_ISO_8601 - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- YEARS_ISO_8601 - Enum constant in enum org.apache.calcite.util.format.postgresql.ChronoUnitEnum
- YearWithCommasCompiledPattern - Class in org.apache.calcite.util.format.postgresql.format.compiled
-
The date/time format compiled component for the year formatted with a comma after the thousands (such as "2,024").
- YearWithCommasCompiledPattern(Set<PatternModifier>) - Constructor for class org.apache.calcite.util.format.postgresql.format.compiled.YearWithCommasCompiledPattern
- YearWithCommasFormatPattern - Class in org.apache.calcite.util.format.postgresql.format
-
The date/time format component for the year formatted with a comma after the thousands (such as "2,024").
- YearWithCommasFormatPattern() - Constructor for class org.apache.calcite.util.format.postgresql.format.YearWithCommasFormatPattern
- YY - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- YYY - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
- YYYY - Enum constant in enum org.apache.calcite.util.format.FormatElementEnum
Z
- ZERO - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName.Limit
- ZERO - Static variable in class org.apache.calcite.sql.parser.SqlParserPos
-
SqlParserPos representing line one, character one.
- zip(E[]) - Static method in class org.apache.calcite.linq4j.Ord
-
Returns a numbered list based on an array.
- zip(Iterable<? extends E>) - Static method in class org.apache.calcite.linq4j.Ord
-
Creates an iterable of
Ord
s over an iterable. - zip(Iterable<? extends K>, Iterable<? extends V>) - Static method in class org.apache.calcite.util.Pair
-
Converts two iterables into an iterable of
Pair
s. - zip(Iterator<? extends E>) - Static method in class org.apache.calcite.linq4j.Ord
-
Creates an iterator of
Ord
s over an iterator. - zip(List<? extends E>) - Static method in class org.apache.calcite.linq4j.Ord
-
Returns a numbered list.
- zip(List<? extends Number>, List<? extends Number>) - Static method in class org.apache.calcite.util.mapping.IntPair
-
Converts two lists into a list of
IntPair
s, whose length is the lesser of the lengths of the source lists. - zip(List<? extends Number>, List<? extends Number>, boolean) - Static method in class org.apache.calcite.util.mapping.IntPair
-
Converts two lists into a list of
IntPair
s. - zip(List<? extends K>, List<? extends V>) - Static method in class org.apache.calcite.util.Pair
-
Converts two lists into a list of
Pair
s, whose length is the lesser of the lengths of the source lists. - zip(List<? extends K>, List<? extends V>, boolean) - Static method in class org.apache.calcite.util.Pair
-
Converts two lists into a list of
Pair
s. - zip(K[], V[]) - Static method in class org.apache.calcite.util.Pair
-
Converts two arrays into a list of
Pair
s. - zip(Enumerable<T0>, Enumerable<T1>, Function2<T0, T1, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Applies a specified function to the corresponding elements of two sequences, producing a sequence of the results.
- zip(Enumerable<T1>, Function2<T, T1, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- zip(Enumerable<T1>, Function2<TSource, T1, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Applies a specified function to the corresponding elements of two sequences, producing a sequence of the results.
- zip(Enumerable<T1>, FunctionExpression<Function2<T, T1, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- zip(Enumerable<T1>, FunctionExpression<Function2<T, T1, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Merges two sequences by using the specified predicate function.
- zip(Queryable<T>, Enumerable<T1>, FunctionExpression<Function2<T, T1, TResult>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Merges two sequences by using the specified predicate function.
- zip(Queryable<T>, Enumerable<T1>, FunctionExpression<Function2<T, T1, TResult>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- zip(Queryable<T0>, Enumerable<T1>, FunctionExpression<Function2<T0, T1, TResult>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Merges two sequences by using the specified predicate function.
- zipMutable(List<K>, List<V>) - Static method in class org.apache.calcite.util.Pair
-
Returns a mutable list of pairs backed by a pair of mutable lists.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
Lists.transform(java.util.List<F>, com.google.common.base.Function<? super F, ? extends T>)