A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- 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 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- abs2(int) - Static method in class org.apache.calcite.adapter.clone.ColumnLoader.ValueSet
-
Two's complement absolute on int value.
- abs2(long) - Static method in class org.apache.calcite.adapter.clone.ColumnLoader.ValueSet
-
Two's complement absolute on long value.
- ABSENT_ON_NULL - org.apache.calcite.sql.SqlJsonConstructorNullClause
- absentOverClause() - Method in interface org.apache.calcite.runtime.CalciteResource
- ABSTRACT_ENUMERABLE_CTOR - 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.
- AbstractCached() - Constructor for class org.apache.calcite.jdbc.CachingCalciteSchema.AbstractCached
- 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 which converts an
AbstractConverter
into a chain of converters from the source relation to the target traits. - abstractConverters - Variable in class org.apache.calcite.plan.volcano.RelSet
-
List of
AbstractConverter
objects which have not yet been satisfied. - 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
- AbstractImmutableList<E> - Class in org.apache.calcite.runtime
-
Base class for lists whose contents are constant after creation.
- AbstractImmutableList() - Constructor for class org.apache.calcite.runtime.AbstractImmutableList
- AbstractIndexedListIterator(int, int) - Constructor for class org.apache.calcite.util.ImmutableIntList.AbstractIndexedListIterator
- AbstractJoinExtractFilterRule - Class in org.apache.calcite.rel.rules
- AbstractJoinExtractFilterRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.AbstractJoinExtractFilterRule
-
Creates an AbstractJoinExtractFilterRule.
- AbstractMapping() - Constructor for class org.apache.calcite.util.mapping.Mappings.AbstractMapping
- AbstractMaterializedViewRule - Class in org.apache.calcite.rel.rules
- AbstractMaterializedViewRule(RelOptRuleOperand, RelBuilderFactory, String, boolean, HepProgram, boolean) - Constructor for class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
Creates a AbstractMaterializedViewRule.
- AbstractMaterializedViewRule.Edge - Class in org.apache.calcite.rel.rules
-
Edge for graph
- AbstractMaterializedViewRule.EquivalenceClasses - Class in org.apache.calcite.rel.rules
-
Class representing an equivalence class, i.e., a set of equivalent columns
- AbstractMaterializedViewRule.MatchModality - Enum in org.apache.calcite.rel.rules
-
Complete, view partial, or query partial.
- AbstractMaterializedViewRule.MaterializedViewAggregateRule - Class in org.apache.calcite.rel.rules
-
Materialized view rewriting for aggregate
- AbstractMaterializedViewRule.MaterializedViewJoinRule - Class in org.apache.calcite.rel.rules
-
Materialized view rewriting for join
- AbstractMaterializedViewRule.MaterializedViewOnlyAggregateRule - Class in org.apache.calcite.rel.rules
-
Rule that matches Aggregate.
- AbstractMaterializedViewRule.MaterializedViewOnlyFilterRule - Class in org.apache.calcite.rel.rules
-
Rule that matches Filter.
- AbstractMaterializedViewRule.MaterializedViewOnlyJoinRule - Class in org.apache.calcite.rel.rules
-
Rule that matches Join.
- AbstractMaterializedViewRule.MaterializedViewProjectAggregateRule - Class in org.apache.calcite.rel.rules
-
Rule that matches Project on Aggregate.
- AbstractMaterializedViewRule.MaterializedViewProjectFilterRule - Class in org.apache.calcite.rel.rules
-
Rule that matches Project on Filter.
- AbstractMaterializedViewRule.MaterializedViewProjectJoinRule - Class in org.apache.calcite.rel.rules
-
Rule that matches Project on Join.
- AbstractMaterializedViewRule.NodeLineage - Class in org.apache.calcite.rel.rules
-
Expression lineage details.
- AbstractMaterializedViewRule.ViewPartialRewriting - Class in org.apache.calcite.rel.rules
-
View partitioning result
- AbstractModifiableTable(String) - Constructor for class org.apache.calcite.sql.ddl.SqlCreateTable.AbstractModifiableTable
- AbstractNamespace - Class in org.apache.calcite.sql.validate
-
Abstract implementation of
SqlValidatorNamespace
. - AbstractNamespace(SqlValidatorImpl, SqlNode) - Constructor for class org.apache.calcite.sql.validate.AbstractNamespace
-
Creates an AbstractNamespace.
- AbstractNode - Class in org.apache.calcite.linq4j.tree
-
Abstract implementation of
Node
. - AbstractNode(ExpressionType, Type) - Constructor for class org.apache.calcite.linq4j.tree.AbstractNode
- 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
- 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
. - AbstractSingleNode<T extends SingleRel> - Class in org.apache.calcite.interpreter
-
An interpreter that takes expects one incoming source relational expression.
- AbstractSingleNode(Compiler, T) - Constructor for class org.apache.calcite.interpreter.AbstractSingleNode
- 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
- 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
- AbstractUnifyRule(SubstitutionVisitor.Operand, SubstitutionVisitor.Operand, int) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.AbstractUnifyRule
- accAdvance(AggAddContext, Expression, Expression) - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- ACCEL_ONLY_TABLE - org.apache.calcite.schema.Schema.TableType
-
An accel-only table.
- 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(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.AbstractNode
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.BinaryExpression
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.ConditionalExpression
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.ConstantExpression
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.ConstantUntypedNull
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.FunctionExpression
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.IndexExpression
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.MemberExpression
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.MethodCallExpression
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.NewArrayExpression
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.NewExpression
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.ParameterExpression
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.Statement
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.TernaryExpression
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.TypeBinaryExpression
- accept(ExpressionWriter, int, int) - Method in class org.apache.calcite.linq4j.tree.UnaryExpression
- 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.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.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.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.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(RelDataType) - Method in class org.apache.calcite.plan.RelOptUtil.TypeDumper
- 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.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(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.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.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(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundBounded
- 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
- accept(T, Shuttle) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- ACCEPT_ALL - org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext
-
Accept any kind of expression in this context.
- ACCEPT_CURSOR - org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext
-
Accept only CURSOR constructors, parenthesized queries, or non-query expressions in this context.
- ACCEPT_NON_QUERY - org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext
-
Accept only non-query expressions in this context.
- ACCEPT_NONCURSOR - org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext
-
Accept any kind of expression in this context, with the exception of CURSOR constructors.
- ACCEPT_NONQUERY - Static variable in enum org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext
-
Deprecated.
- ACCEPT_QUERY - org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext
-
Accept only query expressions in this context.
- ACCEPT_SUB_QUERY - org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext
-
Accept only parenthesized queries or non-query expressions in this context.
- ACCEPT_SUBQUERY - Static variable in enum org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext
-
Deprecated.
- accept0(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.AbstractNode
- accept0(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.BlockStatement
- accept0(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.ConditionalStatement
- accept0(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.DeclarationStatement
- accept0(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.ForStatement
- accept0(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.GotoStatement
- accept0(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.ThrowStatement
- accept0(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.TryStatement
- accept0(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.WhileStatement
- 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.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.SqlWindow.SqlWindowOperator
- acceptDeclarations(List<DeclarationStatement>, Shuttle) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- acceptExpressions(List<Expression>, Shuttle) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- acceptFields(List<RelDataTypeField>) - Method in class org.apache.calcite.plan.RelOptUtil.TypeDumper
- acceptMemberDeclarations(List<MemberDeclaration>, Shuttle) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- acceptNodes(List<? extends Node>, Visitor<R>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- acceptNodes(List<Node>, Shuttle) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- acceptParameterExpressions(List<ParameterExpression>, Shuttle) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- acceptStatements(List<Statement>, Shuttle) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- ACCESS - org.apache.calcite.sql.SqlDialect.DatabaseProduct
- accessEnums - Variable in class org.apache.calcite.sql.SqlAccessType
- accessMap - Variable in class org.apache.calcite.plan.TableAccessMap
- accessNotAllowed(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- accessor - Variable in class org.apache.calcite.runtime.Resources.Prop
- 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.
- AccountingClassLoader(ClassLoader, ResourceFinder, String, File) - Constructor for class org.apache.calcite.util.javac.JaninoCompiler.AccountingClassLoader
- accumulator - Variable in class org.apache.calcite.adapter.enumerable.impl.AggResetContextImpl
- accumulator - Variable in class org.apache.calcite.interpreter.AggregateNode.FilterAccumulator
- 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 - Variable in class org.apache.calcite.adapter.enumerable.SourceSorter
- accumulatorAdder() - Method in interface org.apache.calcite.adapter.enumerable.AggregateLambdaFactory
- accumulatorAdder() - Method in class org.apache.calcite.adapter.enumerable.OrderedAggregateLambdaFactory
- accumulatorAdder() - Method in class org.apache.calcite.adapter.enumerable.SequencedAdderAggregateLambdaFactory
- accumulatorAdderDecorator - Variable in class org.apache.calcite.adapter.enumerable.SequencedAdderAggregateLambdaFactory
- accumulatorAdders - Variable in class org.apache.calcite.adapter.enumerable.SequencedAdderAggregateLambdaFactory.AccumulatorAdderSeq
- AccumulatorAdderSeq(List<Function2<TAccumulate, TSource, TAccumulate>>) - Constructor for class org.apache.calcite.adapter.enumerable.SequencedAdderAggregateLambdaFactory.AccumulatorAdderSeq
- accumulatorFactories - Variable in class org.apache.calcite.interpreter.AggregateNode
- accumulatorInitializer - Variable in class org.apache.calcite.adapter.enumerable.OrderedAggregateLambdaFactory
- accumulatorInitializer - Variable in class org.apache.calcite.adapter.enumerable.SequencedAdderAggregateLambdaFactory
- accumulatorInitializer() - Method in interface org.apache.calcite.adapter.enumerable.AggregateLambdaFactory
- accumulatorInitializer() - Method in class org.apache.calcite.adapter.enumerable.OrderedAggregateLambdaFactory
- accumulatorInitializer() - Method in class org.apache.calcite.adapter.enumerable.SequencedAdderAggregateLambdaFactory
- accumulatorLength - Variable in class org.apache.calcite.interpreter.AggregateNode.ScalarAccumulatorDef
- AccumulatorList() - Constructor for class org.apache.calcite.interpreter.AggregateNode.AccumulatorList
- accumulators - Variable in class org.apache.calcite.interpreter.AggregateNode.Grouping
- accumulatorType - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- accurate - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.CastOptimizedImplementor
- 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 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ACTIVE - org.apache.calcite.rel.metadata.NullSentinel
-
Placeholder that means that a request for metadata is already active, therefore this request forms a cycle.
- activeNamespaces - Variable in class org.apache.calcite.sql.advise.SqlAdvisorValidator
- actives - Variable in class org.apache.calcite.linq4j.tree.BlockBuilder.SubstituteVariableVisitor
- actor - Variable in class org.apache.calcite.materialize.MaterializationService
- actualInputFieldCount - Variable in class org.apache.calcite.adapter.enumerable.EnumerableWindow.WindowRelInputGetter
- adapt(List<T1>, Function1<T1, 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>)
- 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 equivalent AggregateCall that is adapted to a new input types and/or number of columns in GROUP BY.
- add() - Method in class org.apache.calcite.rex.RexFieldCollation.Initializer
- 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, E) - Method in class org.apache.calcite.runtime.AbstractImmutableList
- 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(long, long) - Method in class org.apache.calcite.interpreter.AggregateNode.LongSum
- add(ImmutableSet<SqlKind>) - Method in class org.apache.calcite.rex.RexFieldCollation.Initializer
- add(E) - Method in class org.apache.calcite.runtime.AbstractImmutableList
- add(E) - Method in class org.apache.calcite.util.ChunkList
- add(E) - Method in class org.apache.calcite.util.ChunkList.ChunkListIterator
- 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.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(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(Comparable) - Method in class org.apache.calcite.adapter.clone.ColumnLoader.ValueSet
- add(Comparable) - Method in class org.apache.calcite.profile.ProfilerImpl.HllCollector
- add(Double, Double) - Static method in class org.apache.calcite.util.NumberUtil
- add(String) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
- add(String) - Method in class org.apache.calcite.util.NameSet
- add(String, String) - Method in class org.apache.calcite.adapter.mongodb.MongoRel.Implementor
- 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 class org.apache.calcite.jdbc.CalciteSchema
- add(String, Lattice) - Method in class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- add(String, Lattice) - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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 class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- add(String, RelProtoDataType) - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- add(String, RelProtoDataType) - Method in interface org.apache.calcite.schema.SchemaPlus
-
Adds a type to this schema.
- add(String, Function) - Method in class org.apache.calcite.jdbc.CalciteSchema
- add(String, Function) - Method in class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- add(String, Function) - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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.CachingCalciteSchema
-
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 class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- add(String, Schema) - Method in class org.apache.calcite.jdbc.SimpleCalciteSchema
- add(String, Schema) - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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, Table) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Defines a table within this schema.
- add(String, Table) - Method in class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- add(String, Table) - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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(Consumer<T>) - Method in enum org.apache.calcite.runtime.Hook
-
Adds a handler for this Hook.
- add(Function<T, R>) - Method in enum org.apache.calcite.runtime.Hook
-
Deprecated.Use
Hook.add(Consumer)
. - add(List<Comparable>) - Method in class org.apache.calcite.profile.ProfilerImpl.Collector
- add(List<Comparable>) - Method in class org.apache.calcite.profile.ProfilerImpl.CompositeCollector
- add(List<Comparable>) - Method in class org.apache.calcite.profile.ProfilerImpl.HllCompositeCollector
- add(List<Comparable>) - Method in class org.apache.calcite.profile.ProfilerImpl.HllSingletonCollector
- add(List<Comparable>) - Method in class org.apache.calcite.profile.ProfilerImpl.SingletonCollector
- add(List<RexNode>, List<RexLocalRef>, RexLocalRef, RelDataType, RexShuttle, boolean) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Adds a set of expressions, projections and filters, applying a shuttle first.
- add(Map<String, String>, List<String>) - Method in class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
-
Adds newly projected fields and restricted predicates.
- 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(RelNode) - Method in class org.apache.calcite.plan.volcano.RelSet
-
Adds a relational expression to a set, with its results available under a particular calling convention.
- add(RelNode) - Method in class org.apache.calcite.plan.volcano.RelSubset
-
Adds expression
rel
to this subset. - 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(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(SqlKind, SqlKind...) - Method in class org.apache.calcite.rex.RexFieldCollation.Initializer
- add(SqlNode) - Method in class org.apache.calcite.sql.parser.Span
-
Adds a node's position to the list, and returns this Span.
- add(SqlNode) - Method in class org.apache.calcite.sql.SqlNodeList
- add(SqlOperator) - Method in class org.apache.calcite.sql.util.ListSqlOperatorTable
- add(SqlOperatorTable) - Method in class org.apache.calcite.sql.util.ChainedSqlOperatorTable
-
Adds an underlying table.
- add(SqlTypeName, Set<SqlTypeName>) - Method in class org.apache.calcite.sql.type.SqlTypeAssignmentRules.Builder
- add(PrecedenceClimbingParser.Token) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- add(T, T) - Method in class org.apache.calcite.interpreter.AggregateNode.NumericComparison
- add(TSource) - Method in class org.apache.calcite.adapter.enumerable.OrderedAggregateLambdaFactory.LazySource
- Add - org.apache.calcite.linq4j.tree.ExpressionType
-
An addition operation, such as a + b, without overflow checking, for numeric operands.
- ADD_MONTHS - org.apache.calcite.util.BuiltInMethod
- ADD_MONTHS_INT - org.apache.calcite.util.BuiltInMethod
- addAbstractConverters(VolcanoPlanner, RelOptCluster, RelSubset, boolean) - Method in class org.apache.calcite.plan.volcano.RelSet
- addAdditionalFilters(RelBuilder, LoptMultiJoin, LoptJoinTree, LoptJoinTree, List<RexNode>) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Determines whether any additional filters are applicable to a join tree.
- addAggCall(AggregateCall, int, boolean, List<AggregateCall>, Map<AggregateCall, RexNode>, List<RelDataType>) - 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
- addAggregation(String, String) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
- addAlias(String) - Method in class org.apache.calcite.tools.RelBuilder.Field
- 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 E>) - Method in class org.apache.calcite.runtime.AbstractImmutableList
- addAll(Iterable<? extends E>) - Method in class org.apache.calcite.util.ImmutableNullableList.Builder
-
Adds each element of
elements
to theImmutableNullableList
. - 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 E>) - Method in class org.apache.calcite.runtime.AbstractImmutableList
- addAll(Iterator<? extends E>) - Method in class org.apache.calcite.util.ImmutableNullableList.Builder
-
Adds each element of
elements
to theImmutableNullableList
. - 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. - addAllocation(ClosableAllocation) - Method in interface org.apache.calcite.util.ClosableAllocationOwner
-
Assigns ownership of a ClosableAllocation to this owner.
- addAllocation(ClosableAllocation) - Method in class org.apache.calcite.util.CompoundClosableAllocation
- addAnd(ImmutableList.Builder<RexNode>, Set<RexNode>, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
- 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 - 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
An addition compound assignment operation, such as (a += b), with overflow checking, for numeric operands.
- addAuxiliaryGroupExpr(SqlNode, int, AuxiliaryConverter) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- 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.
- addCasts - Variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- addCasts - Variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule.RexReplacer
- 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 - 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.EmptyScope
- 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.
- 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. - addComplement(ExpressionType, ExpressionType) - Static method in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- 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. - addDimension(Lattice.Column) - Method in class org.apache.calcite.materialize.Lattice.TileBuilder
- 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(LatticeTable, LatticeTable, List<IntPair>) - Method in class org.apache.calcite.materialize.LatticeSpace
- 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) - Method in class org.apache.calcite.adapter.enumerable.EnumerableJoin
- addEpsilon(double) - Method in class org.apache.calcite.adapter.enumerable.EnumerableThetaJoin
- addEquivalenceClass(RexTableInputRef, RexTableInputRef) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.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.
- addExpr(RexNode, String) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
-
Adds an expression, deducing an appropriate name if possible.
- addExpressionForReuse(DeclarationStatement) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- addFactorToTree(RelMetadataQuery, RelBuilder, LoptMultiJoin, LoptSemiJoinOptimizer, LoptJoinTree, int, BitSet, List<RexNode>, boolean) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Adds a new factor into the current join tree.
- addFieldDef(String, FileFieldType, Map<String, Object>, int) - Method in class org.apache.calcite.adapter.file.FileRowConverter
- addFields(List<RelDataTypeField>, List<RelDataType>, List<String>, Set<String>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
- addFields(RelDataType, List<RelDataTypeField>) - Static method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
-
Adds all fields in
type
tofieldList
, renumbering the fields (if necessary) to ensure that their index matches their position in the list. - addFile(String) - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- addFilter(RexNode, Object[]) - Method in class org.apache.calcite.adapter.csv.CsvFilterableTable
- addFilters(LoptMultiJoin, LoptJoinTree, int, LoptJoinTree, List<RexNode>, boolean) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Determines which join filters can be added to the current join tree.
- addFormatIfNecessary(PredicateAnalyzer.LiteralExpression, QueryBuilders.RangeQueryBuilder) - Static method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer
-
By default, range queries on date/time need use the format of the source to parse the literal.
- addFunction(StringBuilder, String, Class) - Static method in class org.apache.calcite.adapter.os.SqlShell
- 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(String) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
- 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.
- addGroupExpr(SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- 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.
- addImplicitFuncNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema
- addImplicitFuncNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit function names to a builder.
- addImplicitFuncNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.SimpleCalciteSchema
- addImplicitFunctionsToBuilder(ImmutableList.Builder<Function>, String, boolean) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema
- addImplicitFunctionsToBuilder(ImmutableList.Builder<Function>, String, boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit functions to a builder.
- addImplicitFunctionsToBuilder(ImmutableList.Builder<Function>, String, boolean) - Method in class org.apache.calcite.jdbc.SimpleCalciteSchema
- addImplicitSubSchemaToBuilder(ImmutableSortedMap.Builder<String, CalciteSchema>) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema
- addImplicitSubSchemaToBuilder(ImmutableSortedMap.Builder<String, CalciteSchema>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit sub-schemas to a builder.
- addImplicitSubSchemaToBuilder(ImmutableSortedMap.Builder<String, CalciteSchema>) - Method in class org.apache.calcite.jdbc.SimpleCalciteSchema
- addImplicitTablesBasedOnNullaryFunctionsToBuilder(ImmutableSortedMap.Builder<String, Table>) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema
- addImplicitTablesBasedOnNullaryFunctionsToBuilder(ImmutableSortedMap.Builder<String, Table>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit table functions to a builder.
- addImplicitTablesBasedOnNullaryFunctionsToBuilder(ImmutableSortedMap.Builder<String, Table>) - Method in class org.apache.calcite.jdbc.SimpleCalciteSchema
- addImplicitTableToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema
- addImplicitTableToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit tables to a builder.
- addImplicitTableToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.SimpleCalciteSchema
- addImplicitTypeNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema
- addImplicitTypeNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit type names to a builder.
- addImplicitTypeNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.SimpleCalciteSchema
- addInternal(RelNode) - Method in class org.apache.calcite.plan.volcano.RelSet
-
Adds an expression
rel
to this set, without creating aRelSubset
. - addJoinKey(List<RexNode>, RexNode, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
- addJVMInvokeOptions(BenchmarkParams) - Method in class org.apache.calcite.benchmarks.FlightRecorderProfiler
- addJVMOptions(BenchmarkParams) - Method in class org.apache.calcite.benchmarks.FlightRecorderProfiler
- 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.
- addListener(RelOptListener) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- addMatch(VolcanoRuleMatch) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Adds a rule match.
- 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
- addMaterializedViews() - Method in class org.apache.calcite.adapter.cassandra.CassandraSchema
-
Add all materialized views defined in the schema to this column family
- 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
- addMonths(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Adds a given number of months to a date, represented as the number of days since the epoch.
- addMonths(long, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Adds a given number of months to a timestamp, represented as the number of milliseconds since the epoch.
- addNot(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
- addOnJoinFieldRefCounts(List<RelNode>, int, RexNode, List<int[]>) - Method in class org.apache.calcite.rel.rules.JoinToMultiJoinRule
-
Adds on to the existing join condition reference counts the references from the new join condition.
- addOr(ImmutableList.Builder<RexNode>, Set<RexNode>, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
- 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
- addOrderItem(List<SqlNode>, RelFieldCollation) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- addOrExpandField(List<SqlNode>, Set<String>, List<Map.Entry<String, RelDataType>>, boolean, SelectScope, SqlIdentifier, RelDataTypeField) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- addOutputColumn(List<String>, List<RelDataType>, int, int, SqlOperatorBinding, RelDataTypeField) - Method in class org.apache.calcite.sql.type.TableFunctionReturnTypeInference
- addPath(List<Step>) - Method in class org.apache.calcite.materialize.LatticeSpace
- addPath(Path, String) - Method in class org.apache.calcite.materialize.MutableNode
- addPatternVar(String) - Method in class org.apache.calcite.sql.validate.MatchRecognizeScope
- addPredicate(Map<String, Object>, String, Object) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
- addPredicate(Map<String, Object>, String, Object) - Method in class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
- 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.
- addProjectionRule(LogicalProject, RelNode) - Static method in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- addProperty(ImmutableMap.Builder<Meta.DatabaseProperty, Object>, Meta.DatabaseProperty) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- addQuery(RelNode) - Method in class org.apache.calcite.materialize.LatticeSuggester
-
Adds a query.
- addRelToGraph(RelNode) - Method in class org.apache.calcite.plan.hep.HepPlanner
- addRelToSet(RelNode, RelSet) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- 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.
- ADDRESS_BITS_PER_WORD - Static variable in class org.apache.calcite.util.ImmutableBitSet
- addResult(RexNode) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- addRule(RelOptRule) - Method in interface org.apache.calcite.jdbc.CalcitePrepare.SparkHandler.RuleSetBuilder
- addRule(RelOptRule) - Method in class org.apache.calcite.plan.hep.HepPlanner
- addRule(RelOptRule) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Registers a rule.
- addRule(RelOptRule) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- 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.
- addScalar - Variable in class org.apache.calcite.interpreter.AggregateNode.ScalarAccumulatorDef
- 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.
- addSort(String, RelFieldCollation.Direction) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
- addStatement(String) - Method in class org.apache.calcite.adapter.pig.PigRel.Implementor
- addStatement(CalciteConnection, Meta.StatementHandle) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerImpl
- 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(ImmutableMap.Builder<String, Table>, Map<String, Object>) - Method in class org.apache.calcite.adapter.file.FileSchema
- addTable(ImmutableMap.Builder<String, Table>, Source, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.file.FileSchema
- 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
- addToSelectList(List<SqlNode>, Set<String>, List<Map.Entry<String, RelDataType>>, SqlNode, SqlValidatorScope, 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.
- addToTop(RelMetadataQuery, RelBuilder, LoptMultiJoin, LoptSemiJoinOptimizer, LoptJoinTree, int, List<RexNode>, boolean) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Creates a join tree with the new factor added to the top of the tree
- addTrait(T, RelTrait) - Static method in class org.apache.calcite.plan.RelOptUtil
- 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.
- addView(StringBuilder, String, String) - Static method in class org.apache.calcite.adapter.os.SqlShell
- addWindowName(String) - Method in class org.apache.calcite.sql.validate.SelectScope
- addWindows(Multimap<LogicalWindow.WindowKey, RexOver>, RexOver, int) - Static method in class org.apache.calcite.rel.logical.LogicalWindow
- AdjacentIterator(Iterator<E>) - Constructor for class org.apache.calcite.util.Pair.AdjacentIterator
- adjacents(Iterable<T>) - Static method in class org.apache.calcite.util.Pair
-
Returns an iterator that iterates over (i, i + 1) pairs in an iterable.
- adjustCondition(LogicalProject, SemiJoin) - Method in class org.apache.calcite.rel.rules.SemiJoinProjectTransposeRule
-
Pulls the project above the semijoin and returns the resulting semijoin condition.
- adjustFilter(LoptMultiJoin, LoptJoinTree, LoptJoinTree, RexNode, int, List<Integer>, List<RelDataTypeField>) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Adjusts a filter to reflect a newly added factor in the middle of an existing join tree
- 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.
- adjustments - Variable in class org.apache.calcite.plan.RelOptUtil.RexInputConverter
- AdjustProjectForCountAggregateRule(boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.sql2rel.RelDecorrelator.AdjustProjectForCountAggregateRule
- adjustSemiJoinCondition(LoptMultiJoin, int, RexNode, int, int) - Method in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
-
Modifies the semijoin condition to reflect the fact that the RHS is now the second factor into a join and the LHS is the first
- 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
- ADMIN - org.apache.calcite.chinook.EnvironmentFairy.User
- advance() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
-
Moves to the next key that is present in both sides.
- advance() - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping.MappingItr
- ADVISOR - Static variable in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction
- ADVISOR - Static variable in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction2
- afi - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.UserDefinedAggReflectiveImplementor
- after - Variable in class org.apache.calcite.plan.SubstitutionVisitor.Replacement
- after - Variable in class org.apache.calcite.rel.core.Match
- after - Variable in class org.apache.calcite.sql.SqlMatchRecognize
- after() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- AfterOption(String) - Constructor for enum org.apache.calcite.sql.SqlMatchRecognize.AfterOption
- afterTableFunction(SqlToRelConverter.Blackboard, SqlCall, LogicalTableFunctionScan) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- afterTrial(BenchmarkResult, long, File, File) - Method in class org.apache.calcite.benchmarks.FlightRecorderProfiler
- agg - Variable in class org.apache.calcite.adapter.enumerable.EnumerableAggregate.AggContextImpl
- 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 - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Workspace for building aggregates.
- AGG_INDEX - org.apache.calcite.adapter.enumerable.WinAggImplementor.SeekType
-
The index of row that is aggregated.
- AGG_LAMBDA_FACTORY_ACC_ADDER - org.apache.calcite.util.BuiltInMethod
- AGG_LAMBDA_FACTORY_ACC_INITIALIZER - org.apache.calcite.util.BuiltInMethod
- AGG_LAMBDA_FACTORY_ACC_RESULT_SELECTOR - org.apache.calcite.util.BuiltInMethod
- AGG_LAMBDA_FACTORY_ACC_SINGLE_GROUP_RESULT_SELECTOR - org.apache.calcite.util.BuiltInMethod
- AGG_ON_FIRST_INPUT - Static variable in class org.apache.calcite.rel.rules.AggregateUnionAggregateRule
-
Instance that matches an
Aggregate
as the left input ofUnion
. - AGG_ON_SECOND_INPUT - Static variable in class org.apache.calcite.rel.rules.AggregateUnionAggregateRule
-
Instance that matches an
Aggregate
as the right input ofUnion
. - 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
-
Creates an AggCallBinding
- AggCallImpl(SqlAggFunction, boolean, boolean, RexNode, String, ImmutableList<RexNode>, ImmutableList<RexNode>) - Constructor for class org.apache.calcite.tools.RelBuilder.AggCallImpl
- AggCallImpl2(AggregateCall) - Constructor for class org.apache.calcite.tools.RelBuilder.AggCallImpl2
- aggCallMapping - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- 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
- aggCalls - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
-
Expressions to be evaluated as rows are being placed into the aggregate's hash table.
- AggChecker - Class in org.apache.calcite.sql.validate
-
Visitor which throws an exception if any component of the expression is not a group expression.
- AggChecker(SqlValidatorImpl, AggregatingScope, List<SqlNode>, List<SqlNode>, boolean) - Constructor for class org.apache.calcite.sql.validate.AggChecker
-
Creates an AggChecker.
- AggContext - Interface in org.apache.calcite.adapter.enumerable
-
Information on the aggregate calculation context.
- AggContextImpl(AggImpState, JavaTypeFactory) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableAggregate.AggContextImpl
- AggConverter(SqlToRelConverter.Blackboard, SqlSelect) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
-
Creates an AggConverter.
- aggFinder - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- AggFinder - Class in org.apache.calcite.sql.validate
-
Visitor that looks for an aggregate function inside a tree of
SqlNode
objects and throwsUtil.FoundOne
when it finds one. - AggFinder(SqlOperatorTable, boolean, boolean, boolean, AggFinder) - Constructor for class org.apache.calcite.sql.validate.AggFinder
-
Creates an AggFinder.
- AggFinder.AggIterable - Class in org.apache.calcite.sql.validate
-
Iterates over all aggregates.
- aggFunction - Variable in class org.apache.calcite.interpreter.AggregateNode.UdaAccumulatorFactory
- aggFunction - Variable in class org.apache.calcite.rel.core.AggregateCall
- aggFunction - Variable in class org.apache.calcite.tools.RelBuilder.AggCallImpl
- 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
- AggIterable(SqlOperatorTable, boolean, boolean, boolean, AggFinder) - Constructor for class org.apache.calcite.sql.validate.AggFinder.AggIterable
- aggMap - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable
- aggMapping - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- aggOrOverFinder - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- aggOrOverOrGroupFinder - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- aggregate - Variable in class org.apache.calcite.materialize.LatticeSuggester.MutableMeasure
- aggregate - Variable in class org.apache.calcite.rel.rules.AggregateJoinTransposeRule.Side
- aggregate - Variable in class org.apache.calcite.sql.validate.AggVisitor
-
Whether to find regular (non-windowed) aggregates.
- aggregate(MongoDatabase, List<Map.Entry<String, Class>>, List<String>) - Method in class org.apache.calcite.adapter.mongodb.MongoTable
-
Executes an "aggregate" operation on the underlying collection.
- aggregate(List<String>, List<Map.Entry<String, Class>>, List<Map.Entry<String, RelFieldCollation.Direction>>, List<String>, List<Map.Entry<String, String>>, Long, Long) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
- 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<T, T, T>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
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>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>, FunctionExpression<Function1<TAccumulate, TResult>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- aggregate(FunctionExpression<Function2<T, T, T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- aggregate(FunctionExpression<Function2<T, T, T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- aggregate(FunctionExpression<Function2<TSource, TSource, TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Applies an accumulator function over a sequence.
- aggregate(RelBuilder.GroupKey, Iterable<RelBuilder.AggCall>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
Aggregate
with a list of calls. - aggregate(RelBuilder.GroupKey, List<AggregateCall>) - Method in class org.apache.calcite.tools.RelBuilder
- 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>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- aggregate(TAccumulate, Function2<TAccumulate, T, TAccumulate>, Function1<TAccumulate, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- aggregate(TAccumulate, Function2<TAccumulate, T, TAccumulate>, Function1<TAccumulate, TResult>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- aggregate(TAccumulate, Function2<TAccumulate, TSource, TAccumulate>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Applies an accumulator function over a sequence.
- 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.linq4j.DefaultQueryable
- aggregate(TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- aggregate(TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>, FunctionExpression<Function1<TAccumulate, TResult>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- aggregate(TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>, FunctionExpression<Function1<TAccumulate, TResult>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- aggregate(TAccumulate, FunctionExpression<Function2<TAccumulate, TSource, TAccumulate>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Applies an accumulator function over a sequence.
- aggregate(TAccumulate, FunctionExpression<Function2<TAccumulate, TSource, TAccumulate>>, FunctionExpression<Function1<TAccumulate, TResult>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.rel.core.Aggregate
-
Creates an Aggregate.
- Aggregate(RelInput) - Constructor for class org.apache.calcite.rel.core.Aggregate
-
Creates an Aggregate by parsing serialized output.
- AGGREGATE - org.apache.calcite.rel.mutable.MutableRelType
- AGGREGATE - org.apache.calcite.util.BuiltInMethod
- AGGREGATE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- AGGREGATE - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category consisting of all built-in aggregate functions.
- AGGREGATE_FILTER_TRANSPOSE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- 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_PROJECT - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- 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
-
What kind of roll-up is it?
- aggregateCall - Variable in class org.apache.calcite.tools.RelBuilder.AggCallImpl2
- aggregateCall(SqlAggFunction, boolean, boolean, RexNode, ImmutableList<RexNode>, String, 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, boolean, List<Integer>, int, RelCollation, RelDataType, String) - Constructor for class org.apache.calcite.rel.core.AggregateCall
-
Creates an AggregateCall.
- 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
- aggregateCalls - Variable in class org.apache.calcite.rel.core.Match.AggregateFinder
- aggregateCallsPerVar - Variable in class org.apache.calcite.rel.core.Match.AggregateFinder
- aggregateCallsPreVar - Variable in class org.apache.calcite.rel.core.Match
- aggregateCorrelatorOutput(Correlate, LogicalProject, Set<Integer>) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- aggregateCount - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternValidator
- 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
- 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.
- 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
-
Creates an AggregateExtractProjectRule.
- AggregateExtractProjectRule(RelOptRuleOperand, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateExtractProjectRule
- aggregateFactory - Variable in class org.apache.calcite.tools.RelBuilder
- AggregateFactoryImpl() - Constructor for class org.apache.calcite.rel.core.RelFactories.AggregateFactoryImpl
- AggregateFilterTransposeRule - Class in org.apache.calcite.rel.rules
- AggregateFilterTransposeRule() - Constructor for class org.apache.calcite.rel.rules.AggregateFilterTransposeRule
- AggregateFilterTransposeRule(RelOptRuleOperand, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateFilterTransposeRule
-
Creates an AggregateFilterTransposeRule.
- AggregateFinder() - Constructor for class org.apache.calcite.rel.core.Match.AggregateFinder
- AggregateFinder() - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.AggregateFinder
- 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. - AggregateFunctionImpl(Class<?>, List<FunctionParameter>, List<Class<?>>, Class<?>, Class<?>, Method, Method, Method, Method) - Constructor for class org.apache.calcite.schema.impl.AggregateFunctionImpl
-
Private constructor; use
AggregateFunctionImpl.create(java.lang.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
- aggregateInWithinGroupIllegal() - Method in interface org.apache.calcite.runtime.CalciteResource
- 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
-
Creates an AggregateJoinTransposeRule.
- 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.Side - Class in org.apache.calcite.rel.rules
-
Work space for an input to a join.
- AggregateLambdaFactory<TSource,TOrigAccumulate,TAccumulate,TResult,TKey> - Interface in org.apache.calcite.adapter.enumerable
-
Generates lambda functions used in
EnumerableAggregate
. - 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.Accumulator - Interface in org.apache.calcite.interpreter
-
Defines function implementation for things like
count()
andsum()
. - AggregateNode.AccumulatorFactory - Interface in org.apache.calcite.interpreter
-
Creates an
AggregateNode.Accumulator
. - AggregateNode.AccumulatorList - Class in org.apache.calcite.interpreter
-
A list of accumulators used during grouping.
- AggregateNode.CountAccumulator - Class in org.apache.calcite.interpreter
-
Accumulator for calls to the COUNT function.
- AggregateNode.DoubleSum - Class in org.apache.calcite.interpreter
-
Implementation of
SUM
over DOUBLE values as a user-defined aggregate. - AggregateNode.FilterAccumulator - Class in org.apache.calcite.interpreter
-
Accumulator that applies a filter to another accumulator.
- AggregateNode.Grouping - Class in org.apache.calcite.interpreter
-
Internal class to track groupings.
- 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.MaxDouble - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the minimum ofdouble
andreal
values as a user-defined aggregate. - AggregateNode.MaxFloat - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the minimum offloat
values as a user-defined aggregate. - AggregateNode.MaxInt - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the minimum ofinteger
values as a user-defined aggregate. - AggregateNode.MaxLong - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the minimum oflong
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.
- AggregateNode.ScalarAccumulator - Class in org.apache.calcite.interpreter
-
Accumulator powered by
Scalar
code fragments. - AggregateNode.ScalarAccumulatorDef - Class in org.apache.calcite.interpreter
-
Accumulator powered by
Scalar
code fragments. - AggregateNode.UdaAccumulator - Class in org.apache.calcite.interpreter
-
Accumulator based upon a user-defined aggregate.
- AggregateNode.UdaAccumulatorFactory - Class in org.apache.calcite.interpreter
-
Accumulator factory based on a user-defined aggregate function.
- AggregateOnProjectToAggregateUnifyRule() - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.AggregateOnProjectToAggregateUnifyRule
- 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
- aggregateProjectPullUpConstantsRule - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewAggregateRule
-
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
-
Creates an AggregateProjectPullUpConstantsRule.
- AggregateReduceFunctionsRule - Class in org.apache.calcite.rel.rules
-
Planner rule that reduces aggregate functions in
Aggregate
s to simpler forms. - AggregateReduceFunctionsRule(RelOptRuleOperand, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Creates an AggregateReduceFunctionsRule.
- 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
) 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
-
Creates an AggregateRemoveRule.
- 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
-
Creates an AggregateStarTableRule.
- AggregateToAggregateUnifyRule() - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.AggregateToAggregateUnifyRule
- 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
-
Creates a AggregateUnionAggregateRule.
- AggregateUnionAggregateRule(Class<? extends Aggregate>, RelFactories.AggregateFactory, Class<? extends Union>, RelFactories.SetOpFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateUnionAggregateRule
-
Deprecated.
- 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
-
Creates an AggregateUnionTransposeRule.
- AggregateUnionTransposeRule(Class<? extends Aggregate>, RelFactories.AggregateFactory, Class<? extends Union>, RelFactories.SetOpFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateUnionTransposeRule
-
Deprecated.
- AggregateValuesRule - Class in org.apache.calcite.rel.rules
- AggregateValuesRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateValuesRule
-
Creates an AggregateValuesRule.
- AggregatingScope - Interface in org.apache.calcite.sql.validate
-
An extension to the
SqlValidatorScope
interface which indicates that the scope is aggregating. - aggregatingSelectScope - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- AggregatingSelectScope - Class in org.apache.calcite.sql.validate
-
Scope for resolving identifiers within a SELECT statement that has a GROUP BY clause.
- AggregatingSelectScope(SqlValidatorScope, SqlSelect, boolean) - Constructor for class org.apache.calcite.sql.validate.AggregatingSelectScope
-
Creates an AggregatingSelectScope
- AggregatingSelectScope.Resolved - Class in org.apache.calcite.sql.validate
-
Information about an aggregating scope that can only be determined after validation has occurred.
- aggregation - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonFilteredAggregation
- aggregation() - Method in interface org.apache.calcite.adapter.enumerable.AggContext
-
Returns the aggregation being implemented.
- aggregation() - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregate.AggContextImpl
- aggregations - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Aggregations
- aggregations - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Bucket
- aggregations - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Result
- aggregations - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
-
Elastic aggregation (
MIN / MAX / COUNT
etc.) statements (functions). - aggregations() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Result
- Aggregations(List<? extends ElasticsearchJson.Aggregation>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Aggregations
- AGGREGATIONS - Static variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
-
Used for constructing (possibly nested) Elastic aggregation nodes.
- aggregationsAsMap - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Aggregations
- AggregationsDeserializer() - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.AggregationsDeserializer
- aggregators - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonSegmentMetadata
- 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.
- AggVisitor - Class in org.apache.calcite.sql.validate
-
Visitor that can find aggregate and windowed aggregate functions.
- AggVisitor(SqlOperatorTable, boolean, boolean, boolean, AggFinder) - Constructor for class org.apache.calcite.sql.validate.AggVisitor
-
Creates an AggVisitor.
- algorithm - Variable in class org.apache.calcite.materialize.Lattice
- algorithm - Variable in class org.apache.calcite.materialize.Lattice.Builder
- 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.materialize.Lattice.Builder
- 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.Lattice.Vertex
- alias - Variable in class org.apache.calcite.materialize.LatticeNode
- alias - Variable in class org.apache.calcite.materialize.LatticeSuggester.DerivedColRef
- alias - Variable in class org.apache.calcite.materialize.LatticeTable
- alias - Variable in class org.apache.calcite.materialize.MutableNode
- alias - Variable in class org.apache.calcite.sql.SqlDelete
- alias - Variable in class org.apache.calcite.sql.SqlMerge
- alias - Variable in class org.apache.calcite.sql.SqlUpdate
- alias - Variable in class org.apache.calcite.tools.RelBuilder.AggCallImpl
- alias - Variable in class org.apache.calcite.tools.RelBuilder.GroupKeyImpl
- alias(String) - Method in interface org.apache.calcite.tools.RelBuilder.GroupKey
-
Assigns an alias to this group key.
- alias(String) - Method in class org.apache.calcite.tools.RelBuilder.GroupKeyImpl
- 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.SqlValidatorImpl
-
Returns the alias of a "expr AS alias" expression.
- ALIAS - 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)
. - aliasCount(SqlNameMatcher, String) - Method in class org.apache.calcite.sql.validate.OrderByScope
-
Returns the number of columns in the SELECT clause that have
name
as their implicit (e.g. - aliases - Variable in class org.apache.calcite.materialize.Lattice.Builder.Fixer
- aliases - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.AliasContext
- aliases - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- aliases - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
- aliasList - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.OrderExpressionExpander
- 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
- all - Variable in class org.apache.calcite.rel.core.SetOp
- all - Variable in class org.apache.calcite.rel.mutable.MutableSetOp
- all - Variable in class org.apache.calcite.sql.fun.SqlMultisetSetOperator
- all - Variable in class org.apache.calcite.sql.SqlSetOperator
- 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(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(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- all(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- all(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- all(FunctionExpression<Predicate1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Determines whether all the elements of a sequence satisfy a condition.
- all(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- all(SqlKind) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Returns the operator for
ALL comparisonKind
. - ALL - org.apache.calcite.adapter.druid.Granularity.Type
- ALL - org.apache.calcite.rel.type.RelDataTypeComparability
- ALL - org.apache.calcite.sql.SqlKind
-
The "ALL" quantification operator.
- ALL - org.apache.calcite.sql.SqlSelectKeyword
- ALL - Static variable in class org.apache.calcite.sql.SqlAccessType
- ALL_ATTRIBUTES - 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_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 - org.apache.calcite.util.BuiltInMethod
- ALL_RELS - Static variable in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- ALL_ROWS - org.apache.calcite.sql.SqlMatchRecognize.RowsPerMatchOption
- ALL_RULES - Static variable in class org.apache.calcite.plan.volcano.RuleQueue
- ALL_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- allAggregatesHaveFilters(List<AggregateCall>) - Static method in class org.apache.calcite.adapter.druid.DruidRules.DruidAggregateProjectRule
- allAssignable(boolean, Class[], Class[]) - Static method in class org.apache.calcite.linq4j.tree.Types
- allAssignable(Class, Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Returns whether two objects can both be assigned to a given class.
- allContain(List<ImmutableBitSet>, int) - Static method in class org.apache.calcite.rel.core.Aggregate
- allContain(List<ImmutableBitSet>, int) - Static method in class org.apache.calcite.sql.validate.AggregatingSelectScope
- allCorrelateVariables - Variable in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- allExprs - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- allExprs - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter.InputToCommonExprConverter
- allFields - Variable in class org.apache.calcite.adapter.druid.DruidTable
- allFieldsBitSet - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- AllGranularity() - Constructor for enum org.apache.calcite.adapter.druid.Granularities.AllGranularity
- allJoinFilters - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
All join filters associated with the MultiJoin, decomposed into a list.
- allLessThan(Collection<Integer>, int, Litmus) - Static method in class org.apache.calcite.sql2rel.RelDecorrelator
- allLiterals(List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether every expression in a list is a literal.
- allMatch(SubstitutionVisitor, List<SubstitutionVisitor.Operand>, List<MutableRel>) - Static method in class org.apache.calcite.plan.SubstitutionVisitor.InternalOperand
- allMethodsDeterministic(Class) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Checks if all the methods in given class are deterministic (i.e.
- allNotNull(E[], Litmus) - Static method in class org.apache.calcite.plan.volcano.VolcanoRuleMatch
-
Returns whether all elements of a given array are not-null; fails if any are null.
- allNull(Object[], int, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns whether all values for a given column are null.
- allNull(List<RexNode>) - Method in class org.apache.calcite.plan.Strong
-
Returns whether all expressions in a list are definitely null.
- allNullable(List<RelDataType>) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether all of array of types are nullable.
- allocations - Variable in class org.apache.calcite.util.CompoundClosableAllocation
-
List of owned ClosableAllocation objects.
- ALLOW_SPATIAL_FUNCTIONS - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeSchemaFactory
- allowBangEqual() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
-
Deprecated.
- allowBangEqual() - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- allowDups - Variable in class org.apache.calcite.rex.RexUtil.ExpressionNormalizer
- allowedRules - Variable in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- allowedSignatures - 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
- 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
- allowExtendedTrim() - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- 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
- allowFunctions - Variable in class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
- 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
- allowInfiniteCostConverters() - Method in interface org.apache.calcite.util.SaffronProperties
-
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.
- 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
- allowNull - Variable in class org.apache.calcite.sql.type.LiteralOperandTypeChecker
- allowPartial - Variable in class org.apache.calcite.sql.SqlWindow
-
Whether to allow partial results.
- allowPrintErr() - Method in class org.apache.calcite.benchmarks.FlightRecorderProfiler
- allowPrintOut() - Method in class org.apache.calcite.benchmarks.FlightRecorderProfiler
- 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.SqlDialect
- allowsFilter() - Method in class org.apache.calcite.sql.fun.SqlAbstractGroupFunction
- 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.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
- allowsNoPrecNoScale() - Method in enum org.apache.calcite.sql.type.SqlTypeName
- 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
- allPredicatesHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- allRows - Variable in class org.apache.calcite.rel.core.Match
- allRules - Variable in class org.apache.calcite.plan.hep.HepPlanner
- allSame(List<E>) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- allSatisfiable(List<Lattice.Measure>, TileKey) - Method in class org.apache.calcite.materialize.MaterializationService
- allSets - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
List of all sets.
- allSimple() - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns whether there are any composite traits in this set.
- allTypeInfo() - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- allWeaker(SubstitutionVisitor, List<SubstitutionVisitor.Operand>, List<MutableRel>) - Static method in class org.apache.calcite.plan.SubstitutionVisitor.InternalOperand
- alpha - Variable in class org.apache.calcite.rex.RexPatternFieldRef
- alpha - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.NavigationReplacer
- alphaNumeric - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonBound
- ALTER_INDEX - org.apache.calcite.sql.SqlKind
-
ALTER INDEX
DDL statement. - ALTER_MATERIALIZED_VIEW - org.apache.calcite.sql.SqlKind
-
ALTER MATERIALIZED VIEW
DDL statement. - ALTER_SEQUENCE - org.apache.calcite.sql.SqlKind
-
ALTER SEQUENCE
DDL statement. - ALTER_SESSION - org.apache.calcite.sql.SqlKind
-
ALTER SESSION
DDL statement. - ALTER_TABLE - org.apache.calcite.sql.SqlKind
-
ALTER TABLE
DDL statement. - ALTER_VIEW - org.apache.calcite.sql.SqlKind
-
ALTER VIEW
DDL statement. - alternateIds - Variable in class org.apache.calcite.sql2rel.DeduplicateCorrelateVariables.DeduplicateCorrelateVariablesShuttle
- always(Expression) - Static method in class org.apache.calcite.linq4j.tree.OptimizeShuttle
-
Returns whether an expression always evaluates to true or false.
- alwaysCopy - Variable in class org.apache.calcite.sql.util.SqlShuttle.CallCopyingArgHandler
- alwaysFalse() - Static method in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonExpressionFilter
-
We need to push to Druid an expression that always evaluates to false.
- AlwaysNull() - Constructor for exception org.apache.calcite.adapter.enumerable.RexToLixTranslator.AlwaysNull
- alwaysQuoteCData - Variable in class org.apache.calcite.util.XmlOutput
- alwaysTrue() - Static method in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonExpressionFilter
-
We need to push to Druid an expression that always evaluates to true.
- alwaysUseParentheses - Variable in class org.apache.calcite.sql.pretty.SqlFormatOptions
- alwaysUseParentheses - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- ambitious - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
If true, the planner keeps applying rules as long as they continue to reduce the cost.
- analyze(RexNode) - Static method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer
-
Walks the expression tree, attempting to convert the entire tree into an equivalent Elasticsearch query filter.
- 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_(SqlValidator, String, SqlNode, RelRoot, boolean) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- analyzeCall(RexCall, ReduceExpressionsRule.ReducibleExprLocator.Constancy) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- analyzeCondition() - Method in class org.apache.calcite.rel.core.EquiJoin
- analyzeCondition() - Method in class org.apache.calcite.rel.core.Join
-
Analyzes the join condition.
- analyzeGroupExpr(SqlValidatorScope, SqlValidatorUtil.GroupAnalyzer, SqlNode) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Analyzes a component of a tuple in a GROUPING SETS clause.
- 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.
- analyzeGroupTuple(SqlValidatorScope, SqlValidatorUtil.GroupAnalyzer, List<SqlNode>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Analyzes a tuple in a GROUPING SETS clause.
- analyzeOperands(List<RexNode>) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.BinaryArithmeticExpander
-
Convenience method for reading characteristics of operands (such as scale, precision, whole digits) into an ArithmeticExpander.
- 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
- ancestors - Variable in class org.apache.calcite.sql.SqlUtil.Genealogist
- and(boolean, PredicateAnalyzer.QueryExpression...) - Static method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
-
if partial expression, we will need to complete it with a full filter
- and(Iterable<? extends RexNode>) - Method in class org.apache.calcite.rex.RexUtil.CnfHelper
- and(Iterable<? extends RexNode>) - Method in class org.apache.calcite.rex.RexUtil.DnfHelper
- 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(RexBuilder, RexNode, RexNode) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- and(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an 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...) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a single-operand checker that passes if all of the rules pass.
- And - org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise or logical AND operation, such as
a & b
in Java. - AND - org.apache.calcite.adapter.druid.DruidJsonFilter.Type
- AND - org.apache.calcite.adapter.enumerable.NullPolicy
-
If any of the arguments are false, result is false; else if any arguments are null, result is null; else true.
- AND - org.apache.calcite.piglet.Ast.Op
- AND - org.apache.calcite.sql.SqlKind
-
The logical "AND" operator.
- AND - org.apache.calcite.sql.type.CompositeOperandTypeChecker.Composition
- AND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Logical
AND
operator. - 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 - 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise or logical AND compound assignment operation, such as (a &= b) in C#.
- andExpressions(SqlNode, SqlNode) - Static method in class org.apache.calcite.sql.SqlUtil
- AndFinder() - Constructor for class org.apache.calcite.sql.fun.SqlBetweenOperator.AndFinder
- 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 ...
. - andOr(RexCall) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor
- andOrList(SqlWriter, SqlKind) - Method in class org.apache.calcite.sql.SqlNodeList
- ANON_FIELDS - Static variable in class org.apache.calcite.rel.core.Project.Flags
-
Deprecated.
- ANONYMOUS_ROW - Static variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Similar to
SqlStdOperatorTable.ROW
, but does not print "ROW". - 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 - org.apache.calcite.linq4j.CorrelateJoinType
-
Anti-join.
- ANTI - org.apache.calcite.sql.SemiJoinType
-
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() - Method in class org.apache.calcite.linq4j.Linq4j.CollectionEnumerable
- any() - Method in class org.apache.calcite.linq4j.Linq4j.IterableEnumerable
- any() - Static method in class org.apache.calcite.plan.RelOptRule
-
Creates a list of child operands that signifies that the operand matches any number of child relational expressions.
- 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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- any(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- any(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- any(FunctionExpression<Predicate1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Determines whether any element of a sequence satisfies a condition.
- ANY - org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Consumer has no preferred representation.
- ANY - org.apache.calcite.adapter.enumerable.NullPolicy
-
If any of the arguments are null, return null.
- ANY - org.apache.calcite.plan.RelOptRuleOperandChildPolicy
-
Signifies that operand can have any number of children.
- ANY - 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 - org.apache.calcite.rel.RelDistribution.Type
-
Not a valid distribution, but indicates that a consumer will accept any distribution.
- ANY - org.apache.calcite.sql.type.SqlTypeFamily
- ANY - 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_CHILDREN - Static variable in class org.apache.calcite.plan.RelOptRuleOperandChildren
- ANY_ITEM - org.apache.calcite.util.BuiltInMethod
- ANY_NUMERIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_VALUE - 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. - anyAnyOperands(RexCall) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.BinaryImplementor
-
Returns whether any of a call's operands have ANY type.
- anyNull(List<RexNode>) - Method in class org.apache.calcite.plan.Strong
-
Returns whether any expressions in a list are definitely null.
- anyNullable(List<? extends RelDataType>) - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- anyNullable(List<RelDataTypeField>) - Static method in class org.apache.calcite.sql.fun.SqlInOperator
- AnyOperand(Class<? extends MutableRel>) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.AnyOperand
- append(char) - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
- 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(Object) - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
- append(Type) - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
- append(String) - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
- append(String) - Method in class org.apache.calcite.piglet.Ast.UnParser
- 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(AbstractNode) - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
- append(Expression) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- append(Ast.Node) - Method in class org.apache.calcite.piglet.Ast.UnParser
- 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(Source) - Method in class org.apache.calcite.util.Sources.FileSource
- append(T) - Method in class org.apache.calcite.linq4j.tree.Expressions.FluentArrayList
- 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
- append_(String, Expression, boolean) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- 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 class org.apache.calcite.linq4j.tree.Expressions.FluentArrayList
- appendAll(Iterable<T>) - Method in interface org.apache.calcite.linq4j.tree.Expressions.FluentList
- appendAll(T...) - Method in class org.apache.calcite.linq4j.tree.Expressions.FluentArrayList
- appendAll(T...) - Method in interface org.apache.calcite.linq4j.tree.Expressions.FluentList
- appendIf(boolean, T) - Method in class org.apache.calcite.linq4j.tree.Expressions.FluentArrayList
- appendIf(boolean, 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.
- appendIfNotNull(T) - Method in class org.apache.calcite.linq4j.tree.Expressions.FluentArrayList
- appendIfNotNull(T) - Method in interface org.apache.calcite.linq4j.tree.Expressions.FluentList
- appendList(StringBuilder, int, List<Object>) - Method in class org.apache.calcite.util.JsonBuilder
- appendList(List<? extends Ast.Node>) - Method in class org.apache.calcite.piglet.Ast.UnParser
- appendMap(StringBuilder, int, Map<String, Object>) - Method in class org.apache.calcite.util.JsonBuilder
- appendPosixDaylightTransition(TimeZone, StringBuilder, int, int, int, int, int, int, boolean, boolean) - Static method in class org.apache.calcite.util.Util
-
Writes a daylight savings time transition to a POSIX timezone description.
- appendPosixTime(StringBuilder, int) - Static method in class org.apache.calcite.util.Util
-
Given a time expressed in milliseconds, append the time formatted as "hh[:mm[:ss]]".
- 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
- applicableRules(MutableRel, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor
- apply() - Method in class org.apache.calcite.adapter.jdbc.JdbcUtils.ObjectArrayRowBuilder
- apply() - Method in interface org.apache.calcite.linq4j.function.Function0
- apply() - Method in class org.apache.calcite.linq4j.function.Functions.Ignore
- apply(ImmutableList<RexLiteral>) - Static method in class org.apache.calcite.rel.core.Values
-
Helps render tuples as strings.
- apply(Class<? extends RelNode>) - Method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.plan.hep.HepRelMetadataProvider
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.plan.volcano.VolcanoRelMetadataProvider
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.rel.metadata.CachingRelMetadataProvider
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.rel.metadata.ChainedRelMetadataProvider
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in interface org.apache.calcite.rel.metadata.RelMetadataProvider
-
Retrieves metadata of a particular type and for a particular sub-class of relational expression.
- apply(Iterable<? extends RexNode>) - Method in class org.apache.calcite.rex.RexShuttle
-
Applies this shuttle to each expression in an iterable.
- apply(Object) - Method in class org.apache.calcite.adapter.java.ReflectiveSchema.FieldSelector
- apply(String, int, int) - Method in interface org.apache.calcite.sql.validate.SqlValidatorUtil.Suggester
- apply(List<Object>) - Method in class org.apache.calcite.adapter.java.ReflectiveSchema.MethodTableMacro
- apply(List<Object>) - Method in class org.apache.calcite.schema.impl.MaterializedViewTable.MaterializedViewTableMacro
- apply(List<Object>) - Method in class org.apache.calcite.schema.impl.TableFunctionImpl
- apply(List<Object>) - Method in class org.apache.calcite.schema.impl.TableMacroImpl
-
Applies arguments to yield a table.
- apply(List<Object>) - Method in class org.apache.calcite.schema.impl.ViewTableMacro
- apply(List<Object>) - Method in interface org.apache.calcite.schema.TableMacro
-
Applies arguments to yield a table.
- 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<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 class org.apache.calcite.tools.Frameworks.PrepareAction
- 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, Aggregate, StarTable.StarTableScan) - Method in class org.apache.calcite.rel.rules.AggregateStarTableRule
- 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.MaterializedViewSubstitutionVisitor.FilterToFilterUnifyRule1
- apply(SubstitutionVisitor.UnifyRuleCall) - Method in class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor.FilterToProjectUnifyRule1
- apply(SubstitutionVisitor.UnifyRuleCall) - Method in class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor.ProjectToProjectUnifyRule1
- apply(SubstitutionVisitor.UnifyRuleCall) - Method in class org.apache.calcite.plan.SubstitutionVisitor.AggregateOnProjectToAggregateUnifyRule
- apply(SubstitutionVisitor.UnifyRuleCall) - Method in class org.apache.calcite.plan.SubstitutionVisitor.AggregateToAggregateUnifyRule
- apply(SubstitutionVisitor.UnifyRuleCall) - Method in class org.apache.calcite.plan.SubstitutionVisitor.FilterToFilterUnifyRule
- apply(SubstitutionVisitor.UnifyRuleCall) - Method in class org.apache.calcite.plan.SubstitutionVisitor.FilterToProjectUnifyRule
- apply(SubstitutionVisitor.UnifyRuleCall) - Method in class org.apache.calcite.plan.SubstitutionVisitor.ProjectToFilterUnifyRule
- apply(SubstitutionVisitor.UnifyRuleCall) - Method in class org.apache.calcite.plan.SubstitutionVisitor.ProjectToProjectUnifyRule
- apply(SubstitutionVisitor.UnifyRuleCall) - Method in class org.apache.calcite.plan.SubstitutionVisitor.ScanToProjectUnifyRule
- apply(SubstitutionVisitor.UnifyRuleCall) - Method in class org.apache.calcite.plan.SubstitutionVisitor.TrivialRule
- apply(SubstitutionVisitor.UnifyRuleCall) - Method in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRule
-
Applies this rule to a particular node in a query.
- apply(SubstitutionVisitor.UnifyRule, MutableRel, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor
- apply(Join, JoinRelType, RexNode) - Method in interface org.apache.calcite.rel.rules.FilterJoinRule.Predicate
- apply(MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableRel.MutableRelDumper
- apply(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.druid.DruidTable.MapRelProtoDataType
- 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) - 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(SqlNode, Resources.ExInst<SqlValidatorException>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.ValidationErrorFunction
- 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.rel.RelDistribution
- apply(Mappings.TargetMapping) - Method in class org.apache.calcite.rel.RelDistributions.RelDistributionImpl
- 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(HttpRequest) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport.HttpFunction
- apply(Response) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport.JsonParserFn
- apply(T) - Method in class org.apache.calcite.runtime.PredicateImpl
-
Deprecated.
- 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 class org.apache.calcite.linq4j.function.Functions.Ignore
- 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 class org.apache.calcite.linq4j.function.Functions.Ignore
- apply(T0, T1) - Method in interface org.apache.calcite.linq4j.function.Predicate2
- apply(TAccumulate, TSource) - Method in class org.apache.calcite.adapter.enumerable.SequencedAdderAggregateLambdaFactory.AccumulatorAdderSeq
- 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.
- applyCasing(String, Casing) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
- applyFields(Mappings.TargetMapping, List<RelFieldCollation>) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a mapping to a list of field collations.
- applyInternal(HttpRequest) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport.HttpFunction
- 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.
- applyResultSelector(Function2<K, Enumerable<V>, TResult>) - Method in class org.apache.calcite.linq4j.LookupImpl
- applyRule(RelOptRule, HepRelVertex, boolean) - Method in class org.apache.calcite.plan.hep.HepPlanner
- applyRules(Collection<RelOptRule>, boolean) - Method in class org.apache.calcite.plan.hep.HepPlanner
- 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
- applyTransformationResults(HepRelVertex, HepRuleCall, RelTrait) - Method in class org.apache.calcite.plan.hep.HepPlanner
- 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 - Variable in class org.apache.calcite.rel.core.AggregateCall
- approximate - Variable in class org.apache.calcite.tools.RelBuilder.AggCallImpl
- 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(boolean) - Method in class org.apache.calcite.tools.RelBuilder.AggCallImpl
- approximate(boolean) - Method in class org.apache.calcite.tools.RelBuilder.AggCallImpl2
- APPROXIMATE_DECIMAL - org.apache.calcite.config.CalciteConnectionProperty
-
Whether approximate results from aggregate functions on DECIMAL types are acceptable.
- APPROXIMATE_DISTINCT_COUNT - org.apache.calcite.config.CalciteConnectionProperty
-
Whether approximate results from
COUNT(DISTINCT ...)
aggregate functions are acceptable. - APPROXIMATE_NUMERIC - org.apache.calcite.sql.type.SqlTypeFamily
- APPROXIMATE_TOP_N - 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
- approximateDecimal() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- approximateDistinctCount() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- approximateDistinctCount() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- approximateTopN() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- approximateTopN() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- ARBITRARY - org.apache.calcite.plan.hep.HepMatchOrder
-
Match in arbitrary order.
- ARCHIVE - 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(HepRelVertex, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- 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(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(SemiJoin, 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(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.
- 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)
. - areSelfJoinKeysUnique(RelMetadataQuery, RelNode, RelNode, RexNode) - Static method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Determines if the equality portion of a self-join condition is between identical keys that are unique.
- arg(SqlWriter, SqlCall, int, int, int) - Method in class org.apache.calcite.sql.fun.SqlOverlapsOperator
- 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_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_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. - 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
- argList - Variable in class org.apache.calcite.rel.core.AggregateCall
- argList(StringBuilder, Method) - Static method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
-
Returns e.g.
- argOrdinal - Variable in class org.apache.calcite.interpreter.AggregateNode.UdaAccumulatorFactory
- argOrdinals() - Method in class org.apache.calcite.materialize.Lattice.Measure
-
Returns a list of argument ordinals.
- args - Variable in class org.apache.calcite.adapter.os.Processes.ProcessFactory
- args - Variable in class org.apache.calcite.adapter.os.SqlShell
- 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.runtime.Resources.Inst
- args - Variable in class org.apache.calcite.util.javac.JaninoCompiler
- args - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Call
- argsList - Variable in class org.apache.calcite.util.javac.JavaCompilerArgs
- argsMatchFields(Field[], Class<?>[]) - Static method in class org.apache.calcite.linq4j.tree.ConstantExpression
- argTypes - Variable in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
-
Deprecated.
- argTypesValid(SqlCallBinding) - Method in class org.apache.calcite.sql.fun.SqlLiteralChainOperator
- argument - Variable in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CastExpression
- ARGUMENT_ASSIGNMENT - 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. - ARGUMENT_MATCH - org.apache.calcite.runtime.Resources.Validation
-
Checks that the parameters of the method are consistent with the format elements in the base message.
- argumentMustBeLiteral(String) - 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.SqlUnnestOperator
- 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 - Variable in class org.apache.calcite.materialize.LatticeSuggester.MutableMeasure
- 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.
- argumentsMatch(List<RelDataType>) - Method in class org.apache.calcite.sql.dialect.JethroDataSqlDialect.JethroSupportedFunction
- array - Variable in class org.apache.calcite.linq4j.tree.IndexExpression
- array(Object...) - Static method in class org.apache.calcite.runtime.SqlFunctions
- Array - Annotation Type in org.apache.calcite.adapter.java
-
Annotation that indicates that a field is an array type.
- ARRAY - org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Records must be represented as arrays.
- ARRAY - org.apache.calcite.adapter.enumerable.JavaRowFormat
- ARRAY - org.apache.calcite.sql.type.SqlTypeFamily
- ARRAY - org.apache.calcite.sql.type.SqlTypeName
- ARRAY - org.apache.calcite.util.BuiltInMethod
- ARRAY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_CARTESIAN_PRODUCT - Static variable in class org.apache.calcite.runtime.SqlFunctions
- ARRAY_COMPARER - org.apache.calcite.util.BuiltInMethod
- ARRAY_COMPARER - Static variable in class org.apache.calcite.linq4j.function.Functions
- ARRAY_ITEM - org.apache.calcite.util.BuiltInMethod
- ARRAY_NICE - org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Consumer would prefer that records are represented as arrays, but can accommodate records represented as objects.
- ARRAY_OR_MAP - Static variable in class org.apache.calcite.sql.fun.SqlItemOperator
- ARRAY_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The ARRAY Query Constructor.
- ARRAY_QUERY_CONSTRUCTOR - org.apache.calcite.sql.SqlKind
-
Array Query Constructor, e.g.
- ARRAY_TO_RDD - org.apache.calcite.adapter.spark.SparkMethod
- ARRAY_VALUE_CONSTRUCTOR - 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.
- ArrayBindable - Interface in org.apache.calcite.runtime
-
Extension to
Bindable
that returns rows that are arrays of objects. - arrayClass(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- 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. - arrayEnumerator() - Method in class org.apache.calcite.adapter.clone.ArrayTable.Content
- ArrayEnumerator(int, List<ArrayTable.Column>) - Constructor for class org.apache.calcite.adapter.clone.ArrayTable.Content.ArrayEnumerator
- ArrayEnumeratorCursor - Class in org.apache.calcite.runtime
- ArrayEnumeratorCursor(Enumerator<Object[]>) - Constructor for class org.apache.calcite.runtime.ArrayEnumeratorCursor
-
Creates an ArrayEnumeratorCursor.
- ArrayEqualityComparer() - Constructor for class org.apache.calcite.linq4j.function.Functions.ArrayEqualityComparer
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
An indexing operation in a one-dimensional array, such as
array[index]
in Java. - 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) - 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) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
As
SqlFunctions.arrayItem(java.util.List, int)
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 - 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
-
Represents a length field of a RecordType
- ArrayLengthRecordField(String, Class) - Constructor for class org.apache.calcite.linq4j.tree.ArrayLengthRecordField
- arrayOrObjectValueRequiredInStrictModeOfJsonQueryFunc(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- ArrayRowConverter(List<CsvFieldType>, int[]) - Constructor for class org.apache.calcite.adapter.csv.CsvEnumerator.ArrayRowConverter
- ArrayRowConverter(List<CsvFieldType>, int[], boolean) - Constructor for class org.apache.calcite.adapter.csv.CsvEnumerator.ArrayRowConverter
- arrays(Comparator<V>) - Method in class org.apache.calcite.runtime.SortedMultiMap
- ARRAYS_AS_LIST - org.apache.calcite.util.BuiltInMethod
- 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.
- ArrayTable - Class in org.apache.calcite.adapter.clone
-
Implementation of table that reads rows from column stores, one per column.
- ArrayTable(Type, RelProtoDataType, Supplier<ArrayTable.Content>) - Constructor for class org.apache.calcite.adapter.clone.ArrayTable
-
Creates an ArrayTable.
- ArrayTable.BitSlicedPrimitiveArray - Class in org.apache.calcite.adapter.clone
-
Representation that stores numeric values in a bit-sliced array.
- ArrayTable.ByteStringDictionary - Class in org.apache.calcite.adapter.clone
-
Representation that stores byte-string column values.
- ArrayTable.Column - Class in org.apache.calcite.adapter.clone
-
Column definition and value set.
- ArrayTable.Constant - Class in org.apache.calcite.adapter.clone
-
Representation of a column that has the same value for every row.
- ArrayTable.Content - Class in org.apache.calcite.adapter.clone
-
Contents of a table.
- ArrayTable.Content.ArrayEnumerator - Class in org.apache.calcite.adapter.clone
-
Enumerator over a table with more than one column; each element returned is an array.
- ArrayTable.Content.ObjectEnumerator - Class in org.apache.calcite.adapter.clone
-
Enumerator over a table with a single column; each element returned is an object.
- ArrayTable.ObjectArray - Class in org.apache.calcite.adapter.clone
-
Representation that stores the column values in an array.
- ArrayTable.ObjectDictionary - Class in org.apache.calcite.adapter.clone
-
Representation that stores the values of a column as a dictionary of objects.
- ArrayTable.PrimitiveArray - Class in org.apache.calcite.adapter.clone
-
Representation that stores the values of a column in an array of primitive values.
- ArrayTable.PrimitiveDictionary - Class in org.apache.calcite.adapter.clone
-
Representation that stores column values in a dictionary of primitive values, then uses a short code for each row.
- ArrayTable.Representation - Interface in org.apache.calcite.adapter.clone
-
Representation of the values of a column.
- ArrayTable.RepresentationType - Enum in org.apache.calcite.adapter.clone
-
How a column's values are represented.
- ArrayTable.StringDictionary - Class in org.apache.calcite.adapter.clone
-
Representation that stores string column values.
- 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.
- arrayType(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- arrayType(Type, int) - Static method in class org.apache.calcite.linq4j.tree.Types
- 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
- ARTIFICIAL_SELECTIVITY_FUNC - Static variable in class org.apache.calcite.rel.metadata.RelMdUtil
- 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 interface org.apache.calcite.tools.RelBuilder.AggCall
-
Returns a copy of this AggCall with a given alias.
- as(String) - Method in class org.apache.calcite.tools.RelBuilder.AggCallImpl
- as(String) - Method in class org.apache.calcite.tools.RelBuilder.AggCallImpl2
- as(String) - Method in class org.apache.calcite.tools.RelBuilder
-
Assigns a table alias to the top entry on the stack.
- as(SqlNode, String) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- AS - org.apache.calcite.sql.SqlKind
-
AS operator
- 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 - org.apache.calcite.adapter.spark.SparkMethod
- AS_ENUMERABLE - org.apache.calcite.util.BuiltInMethod
- AS_ENUMERABLE2 - org.apache.calcite.util.BuiltInMethod
- AS_IS - org.apache.calcite.plan.Strong.Policy
-
This kind of expression may be null.
- AS_LIST - org.apache.calcite.util.BuiltInMethod
- AS_QUERYABLE - org.apache.calcite.util.BuiltInMethod
- ASC - org.apache.calcite.piglet.Ast.Direction
- ASC - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeSort
- ASCENDING - org.apache.calcite.rel.RelFieldCollation.Direction
-
Ascending direction: A value is always followed by a greater or equal value.
- asCopy(Object...) - Static method in class org.apache.calcite.interpreter.Row
-
Creates a Row.
- asd(boolean, List<RexNode>, StringBuilder, List<String>, int) - Method in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- asEnumerable() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- asEnumerable() - Method in class org.apache.calcite.linq4j.DefaultQueryable
- 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.
- 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.
- 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 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- 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.
- asList() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Aggregations
-
The list of
ElasticsearchJson.Aggregation
s. - 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
-
Adapts an array of
boolean
into aList
ofBoolean
. - asList(byte[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Adapts an array of
byte
into aList
ofByte
. - asList(char[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Adapts an array of
char
into aList
ofCharacter
. - asList(double[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Adapts an array of
double
into aList
ofDouble
. - asList(float[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Adapts an array of
float
into aList
ofFloat
. - asList(int[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Adapts an array of
int
into aList
ofInteger
. - asList(int[]) - Static method in class org.apache.calcite.util.IntList
-
Deprecated.
- asList(long[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Adapts an array of
long
into aList
ofLong
. - asList(short[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Adapts an array of
short
into aList
ofShort
. - asList(Object) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Adapts a primitive array into a
List
. - asList(ArrayTable.Representation, Object) - Static method in class org.apache.calcite.adapter.clone.ArrayTable.Column
-
Returns a list view onto a data set.
- 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()
. - asMap() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Aggregations
-
Returns the
ElasticsearchJson.Aggregation
s keyed by aggregation name. - 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.linq4j.DefaultQueryable
- 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.cassandra.CassandraTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.clone.ArrayTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.clone.ListTable
- 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.FileTable
- 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.java.ReflectiveSchema.ReflectiveTable
- 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.adapter.splunk.SplunkTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.tpcds.TpcdsSchema.TpcdsQueryableTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.tpch.TpchSchema.TpchQueryableTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl.MetadataTable
- 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.sql.ddl.SqlCreateTable.MutableArrayTable
- 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.
- assertBasic(SqlTypeName) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- assertionsAreEnabled() - Static method in class org.apache.calcite.rex.RexProgramBuilder
-
Returns whether assertions are enabled in this class.
- assertNoCycles() - Method in class org.apache.calcite.plan.hep.HepPlanner
- assertPartialValid(int[], int[]) - Static method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- assertRowType() - Method in class org.apache.calcite.rel.core.Values
-
Returns true if all tuples match rowType; otherwise, assert on mismatch.
- asSet() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Creates a view onto this bit set as a set of integers.
- assign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an assignment operation.
- Assign - org.apache.calcite.linq4j.tree.ExpressionType
-
An assignment operation, such as (a = b).
- assignableFrom(Class, Class) - Static method in class org.apache.calcite.linq4j.tree.Types
-
Returns whether a parameter is assignable from an argument by virtue of (a) sub-classing (e.g.
- 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.
- assignSolveOrder() - Method in class org.apache.calcite.plan.RelOptRule
-
Builds each operand's solve-order.
- asSql(boolean, boolean) - 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.
- Ast - Class in org.apache.calcite.piglet
-
Abstract syntax tree.
- Ast() - Constructor for class org.apache.calcite.piglet.Ast
- 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.UnParser - Class in org.apache.calcite.piglet
-
Contains output and indentation level while a tree of nodes is being converted to text.
- Ast.ValuesStmt - Class in org.apache.calcite.piglet
-
Parse tree node for VALUES statement.
- ASYMMETRIC - org.apache.calcite.sql.fun.SqlBetweenOperator.Flag
- AT_LEAST_ONE - org.apache.calcite.runtime.Resources.Validation
-
Checks that there is at least one resource in the bundle.
- 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 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- 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 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- atom(Object) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- atom(Object) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- ATOM - org.apache.calcite.util.PrecedenceClimbingParser.Type
- atomicBoolean - Variable in class org.apache.calcite.util.CancelFlag
-
The flag that holds the cancel state.
- 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 a attribute definition.
- ATTRIBUTE_DEF - 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
- AttributeImpl(Lattice.Column, TileSuggester.TableImpl) - Constructor for class org.apache.calcite.materialize.TileSuggester.AttributeImpl
- attributes - Variable in class org.apache.calcite.materialize.TileSuggester.SchemaImpl
- attributes - Variable in class org.apache.calcite.model.JsonType
-
Definition of the attributes of this type.
- auto - Variable in class org.apache.calcite.materialize.Lattice
- auto - Variable in class org.apache.calcite.materialize.Lattice.Builder
- 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_ROW_BUILDER_FACTORY - Static variable in class org.apache.calcite.runtime.ResultSetEnumerable
- AUTO_TEMP - org.apache.calcite.config.CalciteConnectionProperty
-
Whether to store query results in temporary tables.
- AutoClosingIterator(Iterator<ElasticsearchJson.Result>, Consumer<String>) - Constructor for class org.apache.calcite.adapter.elasticsearch.Scrolling.AutoClosingIterator
- 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.
- autoTemp() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- autoTemp() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- 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 - 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
. - auxiliaryGroupExprs - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
-
The auxiliary group-by expressions.
- 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
- avaticaType(JavaTypeFactory, RelDataType, RelDataType) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- 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 - org.apache.calcite.util.BuiltInMethod
- AVERAGE_ROW_SIZE - 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(Queryable<T>, FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- averageBigDecimal(FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- averageBigDecimal(FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- averageBigDecimal(FunctionExpression<BigDecimalFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(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(SemiJoin, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Sort, 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(Queryable<T>, FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- averageDouble(FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- averageDouble(FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- averageDouble(FunctionExpression<DoubleFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- averageFloat(FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- averageFloat(FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- averageFloat(FunctionExpression<FloatFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- averageInteger(FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- averageInteger(FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- averageInteger(FunctionExpression<IntegerFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Computes the average of a sequence of int values that is obtained by invoking a projection function on each element of the input sequence.
- averageJoinColumnSizes(Join, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- 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(Queryable<T>, FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- averageLong(FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- averageLong(FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- averageLong(FunctionExpression<LongFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- averageNullableBigDecimal(FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- averageNullableBigDecimal(FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- averageNullableBigDecimal(FunctionExpression<NullableBigDecimalFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- averageNullableDouble(FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- averageNullableDouble(FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- averageNullableDouble(FunctionExpression<NullableDoubleFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- averageNullableFloat(FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- averageNullableFloat(FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- averageNullableFloat(FunctionExpression<NullableFloatFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- averageNullableInteger(FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- averageNullableInteger(FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- averageNullableInteger(FunctionExpression<NullableIntegerFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- averageNullableLong(FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- averageNullableLong(FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- averageNullableLong(FunctionExpression<NullableLongFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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<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 - org.apache.calcite.sql.fun.SqlAvgAggFunction.Subtype
-
Deprecated.
- AVG - 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.
- AvgVarianceConvertlet(SqlKind) - Constructor for class org.apache.calcite.sql2rel.StandardConvertletTable.AvgVarianceConvertlet
B
- B - Static variable in class org.apache.calcite.plan.RelOptUtil
- Babel - Class in org.apache.calcite.sql.babel
-
SQL parser that accepts a wide variety of dialects.
- Babel() - Constructor for class org.apache.calcite.sql.babel.Babel
- BABEL - org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that allows anything supported by any dialect.
- BACKTRACK - org.apache.calcite.example.maze.Maze.Direction
- backUp() - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
- backupMethodName - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.BinaryImplementor
- badFormat(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- badLowerBoundary() - Method in interface org.apache.calcite.runtime.CalciteResource
- badUpperBoundary() - Method in interface org.apache.calcite.runtime.CalciteResource
- bag(List<Ast.Node>, RelDataType) - Method in class org.apache.calcite.piglet.Handler
- BAG - org.apache.calcite.piglet.Ast.Op
- BAG_TYPE - 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 - Variable in class org.apache.calcite.runtime.Resources.Inst
- BASE_DIRECTORY - org.apache.calcite.model.ModelHandler.ExtraOperand
-
Base directory from which to read files.
- BaseColRef(LatticeSuggester.TableRef, int) - Constructor for class org.apache.calcite.materialize.LatticeSuggester.BaseColRef
- BaseColumn(int, String, String, String) - Constructor for class org.apache.calcite.materialize.Lattice.BaseColumn
- baseColumns - Variable in class org.apache.calcite.materialize.Lattice.Builder
- BaseContext(SqlDialect, int) - Constructor for class org.apache.calcite.rel.rel2sql.SqlImplementor.BaseContext
- baseDirectory - Variable in class org.apache.calcite.adapter.file.FileSchema
- BaseMatcher(boolean) - Constructor for class org.apache.calcite.sql.validate.SqlNameMatchers.BaseMatcher
- BaseQueryable<TSource> - Class in org.apache.calcite.linq4j
-
Skeleton implementation of
Queryable
. - BaseQueryable(QueryProvider, Type, Expression) - Constructor for class org.apache.calcite.linq4j.BaseQueryable
- baseTraits - Variable in class org.apache.calcite.plan.RelTraitPropagationVisitor
- baseTypeName - Variable in class org.apache.calcite.sql.SqlDataTypeSpec
- baseUnit(SqlTypeName) - Static method in class org.apache.calcite.rex.RexBuilder
-
Returns the lowest granularity unit for the given unit.
- 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, int, int, SqlCollation, SerializableCharset) - Constructor for class org.apache.calcite.sql.type.BasicSqlType
-
Internal constructor.
- 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.
- baz(ParameterExpression, ParameterExpression, BlockStatement) - Static method in class org.apache.calcite.interpreter.JaninoRexCompiler
-
Given a method that implements
Scalar.execute(Context, Object[])
, adds a bridge method that implementsScalar.execute(Context)
, and compiles. - bb - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- bb - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.DeferredLookup
- bean - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- Bean(SqlPrettyWriter) - Constructor for class org.apache.calcite.sql.pretty.SqlPrettyWriter.Bean
- before - Variable in class org.apache.calcite.plan.RelOptListener.RuleAttemptedEvent
- before - Variable in class org.apache.calcite.plan.SubstitutionVisitor.Replacement
- before() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- beforeTrial(BenchmarkParams) - Method in class org.apache.calcite.benchmarks.FlightRecorderProfiler
- begin() - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
-
Increases the indentation level.
- begin(String) - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
- beginBeginTag(String) - Method in class org.apache.calcite.util.XmlOutput
- BeginGroup() - Constructor for class org.apache.calcite.plan.hep.HepInstruction.BeginGroup
- 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. - belongsToDag(HepRelVertex) - Method in class org.apache.calcite.plan.hep.HepPlanner
-
Returns whether the vertex is valid.
- 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.
- best - Variable in class org.apache.calcite.plan.volcano.RelSubset
-
best known plan
- bestCost - Variable in class org.apache.calcite.plan.volcano.RelSubset
-
cost of best known plan (it may have improved since)
- bestMatch() - Method in class org.apache.calcite.sql.validate.SqlNameMatchers.BaseMatcher
- bestMatch() - Method in class org.apache.calcite.sql.validate.SqlNameMatchers.LiberalNameMatcher
- bestMatch(List<SqlFunction>, int, RelDataTypePrecedenceList) - Static method in class org.apache.calcite.sql.SqlUtil
- bestString() - Method in interface org.apache.calcite.sql.validate.SqlNameMatcher
-
Returns the most recent match.
- bestString() - Method in class org.apache.calcite.sql.validate.SqlNameMatchers.BaseMatcher
- between(int, int) - Static method in class org.apache.calcite.sql.type.SqlOperandCountRanges
- BETWEEN - org.apache.calcite.sql.SqlKind
-
The "BETWEEN" operator.
- BETWEEN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- BETWEEN_NAMES - Static variable in class org.apache.calcite.sql.fun.SqlBetweenOperator
- betweenWithoutAnd() - Method in interface org.apache.calcite.runtime.CalciteResource
- BEVEL - org.apache.calcite.runtime.GeoFunctions.JoinStyle
- BIG_DECIMAL_SUM - Static variable in class org.apache.calcite.linq4j.Extensions
- BIG_INT_MAX_UNSCALED - Static variable in class org.apache.calcite.util.NumberUtil
- BIG_INT_MIN_UNSCALED - Static variable in class org.apache.calcite.util.NumberUtil
- BIG_INT_TEN_POW - Static variable in class org.apache.calcite.util.NumberUtil
- BIG_QUERY - org.apache.calcite.sql.SqlDialect.DatabaseProduct
- BigDecimalFunction1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function that takes one parameter and returns a
BigDecimal
value. - bigDecimalValue() - Method in class org.apache.calcite.sql.SqlLiteral
-
Returns a numeric literal's value as a
BigDecimal
. - BIGINT - 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 an 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 - org.apache.calcite.util.mapping.MappingType
- binary(Expression, SqlBinaryOperator) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.EmptyScalarTranslator
- binary(RexCall) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor
-
Process a call which is a binary operation, transforming into an equivalent query expression.
- BINARY - org.apache.calcite.sql.SqlSyntax
-
Binary operator syntax, as in "x + y".
- BINARY - org.apache.calcite.sql.type.SqlTypeFamily
- BINARY - org.apache.calcite.sql.type.SqlTypeName
- BINARY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- BINARY_SEARCH5_LOWER - org.apache.calcite.util.BuiltInMethod
- BINARY_SEARCH5_UPPER - org.apache.calcite.util.BuiltInMethod
- BINARY_SEARCH6_LOWER - org.apache.calcite.util.BuiltInMethod
- BINARY_SEARCH6_UPPER - org.apache.calcite.util.BuiltInMethod
- BINARY_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- BinaryArithmeticExpander(RexBuilder) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule.BinaryArithmeticExpander
- BinaryExpression - Class in org.apache.calcite.linq4j.tree
-
Represents an expression that has a binary operator.
- BinaryExpression(ExpressionType, Type, Expression, Expression) - Constructor for class org.apache.calcite.linq4j.tree.BinaryExpression
- BinaryImplementor(ExpressionType, String) - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.BinaryImplementor
- 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 expression 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(Geometry, int) - Static method in class org.apache.calcite.runtime.GeoFunctions
- bind(Geometry, SpatialReference) - Static method in class org.apache.calcite.runtime.GeoFunctions
- 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(List<ParameterExpression>, List<RexNode>) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.EmptyScalarTranslator
- bind(List<ParameterExpression>, List<RexNode>) - Method in interface org.apache.calcite.prepare.CalcitePrepareImpl.ScalarTranslator
- 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.BindableJoin
- 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 - Variable in class org.apache.calcite.jdbc.CalcitePrepare.CalciteSignature
- 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 - org.apache.calcite.util.BuiltInMethod
- 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_PROJECT_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- 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_UNION_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
- BindableAggregateRule(RelBuilderFactory) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableAggregateRule
-
Creates a BindableAggregateRule.
- BindableConvention - Enum in org.apache.calcite.interpreter
-
Calling convention that returns results as an
Enumerable
of object arrays. - BindableConvention() - Constructor for enum org.apache.calcite.interpreter.BindableConvention
- BindableFilter(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableFilter
- BindableFilterRule(RelBuilderFactory) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableFilterRule
-
Creates a BindableFilterRule.
- 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(RelBuilderFactory) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableJoinRule
-
Creates a BindableJoinRule.
- BindableProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableProject
- BindableProjectRule(RelBuilderFactory) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableProjectRule
-
Creates a BindableProjectRule.
- 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() - Constructor for class org.apache.calcite.interpreter.Bindables
- 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.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.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.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.BindableUnion - Class in org.apache.calcite.interpreter
-
Implementation of
Union
in bindable calling convention. - Bindables.BindableUnionRule - Class in org.apache.calcite.interpreter
-
Rule to convert an
LogicalUnion
to aBindables.BindableUnion
. - 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
. - BindableSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableSort
- BindableSortRule(RelBuilderFactory) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableSortRule
-
Creates a BindableSortRule.
- BindableTableScan(RelOptCluster, RelTraitSet, RelOptTable, ImmutableList<RexNode>, ImmutableIntList) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableTableScan
-
Creates a BindableTableScan.
- BindableTableScanRule(RelBuilderFactory) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableTableScanRule
-
Creates a BindableTableScanRule.
- BindableUnion(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableUnion
- BindableUnionRule(RelBuilderFactory) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableUnionRule
-
Creates a BindableUnionRule.
- BindableValues(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, RelTraitSet) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableValues
- BindableValuesRule(RelBuilderFactory) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableValuesRule
-
Creates a BindableValuesRule.
- BindableWindow(RelOptCluster, RelTraitSet, RelNode, List<RexLiteral>, RelDataType, List<Window.Group>) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableWindow
-
Creates an BindableWindowRel.
- BindableWindowRule(RelBuilderFactory) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableWindowRule
-
Creates a BindableWindowRule.
- bindExecute(StatementTest.HrPreparedStatement) - Method in class org.apache.calcite.benchmarks.StatementTest
- 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
- BIT_SET_INCLUSION_ORDERING - Static variable in class org.apache.calcite.util.PartiallyOrderedSet
-
Ordering that orders bit sets by inclusion.
- BIT_SLICED_PRIMITIVE_ARRAY - org.apache.calcite.adapter.clone.ArrayTable.RepresentationType
-
Bit-sliced primitive array.
- bitCount - Variable in class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- bitCount - Variable in class org.apache.calcite.util.BitString
- bits - Variable in class org.apache.calcite.util.BitString
- 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.
- BITS_PER_WORD - Static variable in class org.apache.calcite.util.ImmutableBitSet
- bitSet - Variable in class org.apache.calcite.materialize.Lattice.Tile
- bitSet() - Method in class org.apache.calcite.materialize.Lattice.Tile
- BitSets - Class in org.apache.calcite.util
-
Utility functions for
BitSet
. - BitSets() - Constructor for class org.apache.calcite.util.BitSets
- BitSets.Closure - Class in org.apache.calcite.util
-
Setup equivalence Sets for each position.
- BitSlicedPrimitiveArray(int, int, Primitive, boolean) - Constructor for class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- BitString - Class in org.apache.calcite.util
-
String of bits.
- BitString(String, int) - Constructor for class org.apache.calcite.util.BitString
- BLACK - 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.
- 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 - 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.
- BlockBuilder.InlineVariableVisitor - Class in org.apache.calcite.linq4j.tree
-
Inline Variable Visitor.
- BlockBuilder.Slot - Class in org.apache.calcite.linq4j.tree
-
Holds the number of times a declaration was used.
- BlockBuilder.SubstituteVariableVisitor - Class in org.apache.calcite.linq4j.tree
-
Substitute Variable Visitor.
- BlockBuilder.UseCounter - Class in org.apache.calcite.linq4j.tree
-
Use counter.
- BlockingQueueEnumerator() - Constructor for class org.apache.calcite.adapter.druid.DruidConnectionImpl.BlockingQueueEnumerator
- blocks - Variable in class org.apache.calcite.adapter.enumerable.NestedBlockBuilderImpl
- Blocks - Class in org.apache.calcite.linq4j.tree
-
Helper methods concerning
BlockStatement
s. - Blocks() - Constructor for class org.apache.calcite.linq4j.tree.Blocks
- BlockStatement - Class in org.apache.calcite.linq4j.tree
-
Represents a block that contains a sequence of expressions where variables can be defined.
- BlockStatement(List<Statement>, Type) - Constructor for class org.apache.calcite.linq4j.tree.BlockStatement
- 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.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
- BOOLEAN - org.apache.calcite.adapter.csv.CsvFieldType
- BOOLEAN - org.apache.calcite.adapter.file.FileFieldType
- BOOLEAN - org.apache.calcite.linq4j.tree.Primitive
- BOOLEAN - org.apache.calcite.sql.type.SqlTypeFamily
- BOOLEAN - 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_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_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_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 - org.apache.calcite.util.BuiltInMethod
- BOOLEAN_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- BOOLEAN_VALUEOF_BOOL - Static variable in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- booleanFalse - Variable in class org.apache.calcite.rex.RexBuilder
- BooleanProp(Resources.PropertyAccessor, Method) - Constructor for class org.apache.calcite.runtime.Resources.BooleanProp
- booleanTrue - Variable in class org.apache.calcite.rex.RexBuilder
- booleanType - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- booleanValue() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.LiteralExpression
- 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
- booleanValue(Resources.BooleanProp) - Method in enum org.apache.calcite.runtime.Resources.EmptyPropertyAccessor
- booleanValue(Resources.BooleanProp) - Method in class org.apache.calcite.runtime.Resources.PropertiesAccessor
- booleanValue(Resources.BooleanProp) - Method in interface org.apache.calcite.runtime.Resources.PropertyAccessor
- booleanValue(Resources.BooleanProp, boolean) - Method in enum org.apache.calcite.runtime.Resources.EmptyPropertyAccessor
- booleanValue(Resources.BooleanProp, boolean) - Method in class org.apache.calcite.runtime.Resources.PropertiesAccessor
- booleanValue(Resources.BooleanProp, boolean) - Method in interface org.apache.calcite.runtime.Resources.PropertyAccessor
- boolQuery() - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A Query that matches documents matching boolean combinations of other queries.
- BoolQueryBuilder() - Constructor for class org.apache.calcite.adapter.elasticsearch.QueryBuilders.BoolQueryBuilder
- boosted - Variable in class org.apache.calcite.plan.volcano.RelSubset
-
Flag indicating whether this RelSubset's importance was artificially boosted.
- boostedSubsets - Variable in class org.apache.calcite.plan.volcano.RuleQueue
-
The set of RelSubsets whose importance is currently in an artificially raised state.
- boostImportance(Collection<RelSubset>, double) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Artificially boosts the importance of the given
RelSubset
s by a given factor. - BOTH - org.apache.calcite.plan.RelOptUtil.Side
- BOTH - org.apache.calcite.sql.fun.SqlTrimFunction.Flag
- BOTH_PROJECT - Static variable in class org.apache.calcite.rel.rules.JoinProjectTransposeRule
- BOTH_PROJECT_INCLUDE_OUTER - Static variable in class org.apache.calcite.rel.rules.JoinProjectTransposeRule
- BOTTOM_UP - org.apache.calcite.plan.hep.HepMatchOrder
-
Match from leaves up.
- bottomNode - Variable in class org.apache.calcite.util.PartiallyOrderedSet
- bound - Variable in class org.apache.calcite.linq4j.tree.NewArrayExpression
- Bound(String) - Constructor for enum org.apache.calcite.sql.SqlWindow.Bound
- BOUND - org.apache.calcite.adapter.druid.DruidJsonFilter.Type
- 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 class org.apache.calcite.linq4j.tree.Expressions
- 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(Bindable) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableInterpretable
-
Converts a bindable over scalar values into an array bindable, with each row as an array of 1 element.
- BOX - org.apache.calcite.linq4j.tree.Primitive.Flavor
-
A type that boxes a primitive, e.g.
- BOX_MAP - Static variable in enum org.apache.calcite.linq4j.tree.Primitive
- boxClass - Variable in enum org.apache.calcite.linq4j.tree.Primitive
- boxClassName(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
-
Boxes a type, if it is primitive, and returns the type name.
- 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
- 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 - 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, 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) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a break statement.
- 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_METHODS - Static variable in class org.apache.calcite.adapter.enumerable.EnumUtils
- 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 - 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.
- Bucket(Object, String, ElasticsearchJson.Aggregations) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Bucket
- buckets - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.MultiBucketsAggregation
- buckets() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.MultiBucketsAggregation
- buf - Variable in class org.apache.calcite.linq4j.tree.ExpressionWriter
- buf - Variable in class org.apache.calcite.materialize.Lattice.SqlWriter
- buf - Variable in class org.apache.calcite.piglet.Ast.UnParser
- buf - Variable in class org.apache.calcite.profile.ProfilerImpl.HllCompositeCollector
- buf - Variable in class org.apache.calcite.rel.mutable.MutableRel.MutableRelDumper
- buf - Variable in class org.apache.calcite.sql.util.SqlBuilder
- buffer(GeoFunctions.Geom, double, int, GeoFunctions.CapStyle, GeoFunctions.JoinStyle, float) - Static method in class org.apache.calcite.runtime.GeoFunctions
- 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
-
Return a Row object
- build() - Method in interface org.apache.calcite.jdbc.CachingCalciteSchema.Cached
-
Creates a new value.
- 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.profile.ProfilerImpl.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 class org.apache.calcite.rex.RexFieldCollation.Initializer
- build() - Method in class org.apache.calcite.schema.impl.ReflectiveFunctionBase.ParameterListBuilder
- build() - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Builds a
SqlParser.Config
. - build() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
-
Builds a
SqlToRelConverter.Config
. - 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.ImmutableBitSet.Rebuilder
- 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.PrecedenceClimbingParser.Builder
- 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(List<Context>, Context) - Static method in class org.apache.calcite.plan.Contexts
-
Recursively populates a list of contexts.
- 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.
- build(ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSet.Rebuilder
- buildCheapestPlan(VolcanoPlanner) - Method in class org.apache.calcite.plan.volcano.RelSubset
-
Recursively builds a tree consisting of the cheapest plan at each node.
- buildDynamic() - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Creates a dynamic struct type with the current contents of this builder.
- builder - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
- builder - Variable in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- builder - Variable in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- builder - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.ConstantScoreQueryBuilder
- builder - Variable in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- builder - Variable in class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
- builder - Variable in class org.apache.calcite.piglet.Handler
- builder - Variable in class org.apache.calcite.plan.RexImplicationChecker
- builder - Variable in class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.RexFieldAccessReplacer
- builder - Variable in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Factory for constructing new relational expressions
- builder - Variable in class org.apache.calcite.rex.RexAnalyzer.VariableCollector
- builder - Variable in class org.apache.calcite.rex.RexCopier
- builder - Variable in class org.apache.calcite.rex.RexFieldCollation.Initializer
- builder - Variable in class org.apache.calcite.schema.impl.ReflectiveFunctionBase.ParameterListBuilder
- builder - Variable in class org.apache.calcite.sql2rel.DeduplicateCorrelateVariables.DeduplicateCorrelateVariablesShuttle
- builder() - Static method in class org.apache.calcite.adapter.druid.VirtualColumn
- builder() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- builder() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- builder() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- 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() - 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.schema.impl.ReflectiveFunctionBase
-
Creates a ParameterListBuilder.
- 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(CalciteSchema, String) - Static method in class org.apache.calcite.materialize.Lattice
- builder(LatticeSpace, CalciteSchema, String) - Static method in class org.apache.calcite.materialize.Lattice
- builder(RelNode, SqlImplementor.Clause...) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Once you have a Result of implementing a child relational expression, call this method to create a Builder to implement the current relational expression by adding additional clauses to the SQL query.
- 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.sql.type.SqlTypeAssignmentRules.Builder
-
Creates an empty Builder.
- Builder() - Constructor for class org.apache.calcite.util.ImmutableNullableList.Builder
-
Creates a new builder.
- Builder() - Constructor for class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- Builder(long[]) - Constructor for class org.apache.calcite.util.ImmutableBitSet.Builder
- Builder(LatticeSpace, CalciteSchema, String) - Constructor for class org.apache.calcite.materialize.Lattice.Builder
- Builder(LatticeSpace, CalciteSchema, MutableNode) - Constructor for class org.apache.calcite.materialize.Lattice.Builder
-
Creates a Builder based upon a mutable node.
- Builder(RelNode, List<SqlImplementor.Clause>, SqlSelect, SqlImplementor.Context, 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(SqlTypeAssignmentRules.Builder) - Constructor for class org.apache.calcite.sql.type.SqlTypeAssignmentRules.Builder
-
Creates a Builder as a copy of another Builder.
- 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.
- buildFinalPlan(HepRelVertex) - Method in class org.apache.calcite.plan.hep.HepPlanner
- buildList(DirectedGraph<V, E>, V) - Static method in class org.apache.calcite.util.graph.DepthFirstIterator
- buildListRecurse(Collection<V>, Set<V>, DirectedGraph<V, E>, V) - Static method in class org.apache.calcite.util.graph.DepthFirstIterator
- built - Variable in class org.apache.calcite.jdbc.CachingCalciteSchema.AbstractCached
- BUILT_IN_OPERATORS_LIST - Static variable in class org.apache.calcite.sql.SqlDialect
-
Built-in scalar functions and operators common for every dialect.
- 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.All - Interface in org.apache.calcite.rel.metadata
-
The built-in forms of metadata.
- 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.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.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(Class, String, Class...) - Constructor for enum org.apache.calcite.runtime.Resources.BuiltinMethod
- BuiltInMethod - Enum in org.apache.calcite.util
-
Built-in methods.
- BuiltInMethod(Class, Class...) - Constructor for enum org.apache.calcite.util.BuiltInMethod
-
Defines a constructor.
- BuiltInMethod(Class, String, boolean) - Constructor for enum org.apache.calcite.util.BuiltInMethod
-
Defines a field.
- BuiltInMethod(Class, String, Class...) - Constructor for enum org.apache.calcite.util.BuiltInMethod
-
Defines a method.
- BuiltInMethod(Method, Constructor, Field) - Constructor for enum org.apache.calcite.util.BuiltInMethod
- bundle - Variable in class org.apache.calcite.runtime.Resources.ShadowResourceBundle
- bundle() - Method in class org.apache.calcite.runtime.Resources.Inst
- BUNDLE_HAS_RESOURCE - org.apache.calcite.runtime.Resources.Validation
-
Checks that each method's resource key corresponds to a resource in the bundle.
- BY - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- BYTE - org.apache.calcite.adapter.csv.CsvFieldType
- BYTE - org.apache.calcite.adapter.file.FileFieldType
- BYTE - org.apache.calcite.linq4j.tree.Primitive
- BYTE_STRING_DICTIONARY - org.apache.calcite.adapter.clone.ArrayTable.RepresentationType
-
Compressed byte array table.
- BYTES_PER_CHARACTER - Static variable in class org.apache.calcite.rel.metadata.RelMdSize
-
Bytes per character (2).
- ByteStringDictionary() - Constructor for class org.apache.calcite.adapter.clone.ArrayTable.ByteStringDictionary
- bytesValue - Variable in class org.apache.calcite.util.NlsString
C
- c - Variable in class org.apache.calcite.materialize.Lattice.Builder.Fixer
- c - Variable in class org.apache.calcite.materialize.LatticeSuggester.BaseColRef
- C - Static variable in class org.apache.calcite.materialize.MaterializationService
- cache - Variable in class org.apache.calcite.adapter.geode.rel.GeodeSchema
- cache - Variable in class org.apache.calcite.adapter.jdbc.JdbcUtils.DataSourcePool
- cache - Variable in class org.apache.calcite.jdbc.CachingCalciteSchema
- cache - Variable in class org.apache.calcite.jdbc.CachingCalciteSchema.SubSchemaCache
-
Cached
CalciteSchema
wrappers. - cache - Variable in class org.apache.calcite.materialize.CachingLatticeStatisticProvider
- cache - Variable in class org.apache.calcite.model.JsonSchema
-
Whether to cache metadata (tables, functions and sub-schemas) generated by this schema.
- cache - Variable in class org.apache.calcite.plan.RelTraitSet
- cache - Variable in class org.apache.calcite.rel.metadata.CachingRelMetadataProvider
- cache - Variable in class org.apache.calcite.rel.metadata.MetadataFactoryImpl
- Cache() - Constructor for class org.apache.calcite.plan.RelTraitSet.Cache
- CACHE - Static variable in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
-
Global cache.
- CACHED_FACTORY - Static variable in class org.apache.calcite.materialize.SqlLatticeStatisticProvider
- CACHED_SQL - Static variable in class org.apache.calcite.materialize.Lattices
-
Statistics provider that uses SQL then stores the results in a cache.
- cachedImportance - Variable in class org.apache.calcite.plan.volcano.VolcanoRuleMatch
- CacheEntry() - Constructor for class org.apache.calcite.rel.metadata.CachingRelMetadataProvider.CacheEntry
- cacheEquivalenceClasses - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.EquivalenceClasses
- cacheEquivalenceClassesMap - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.EquivalenceClasses
- CachingCalciteSchema - Class in org.apache.calcite.jdbc
-
Concrete implementation of
CalciteSchema
that caches tables, functions and sub-schemas. - CachingCalciteSchema(CalciteSchema, Schema, String) - Constructor for class org.apache.calcite.jdbc.CachingCalciteSchema
-
Creates a CachingCalciteSchema.
- CachingCalciteSchema(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.CachingCalciteSchema
- CachingCalciteSchema.AbstractCached<T> - Class in org.apache.calcite.jdbc
-
Implementation of
CachingCalciteSchema.Cached
that drives fromCachingCalciteSchema.cache
. - CachingCalciteSchema.Cached<T> - Interface in org.apache.calcite.jdbc
-
Strategy for caching the value of an object and re-creating it if its value is out of date as of a given timestamp.
- CachingCalciteSchema.SubSchemaCache - Class in org.apache.calcite.jdbc
-
Information about the implicit sub-schemas of an
CalciteSchema
. - CachingInvocationHandler(Metadata) - Constructor for class org.apache.calcite.rel.metadata.CachingRelMetadataProvider.CachingInvocationHandler
- CachingLatticeStatisticProvider - Class in org.apache.calcite.materialize
-
Implementation of
LatticeStatisticProvider
that caches single-column statistics and computes multi-column statistics from these. - CachingLatticeStatisticProvider(Lattice, LatticeStatisticProvider) - Constructor for class org.apache.calcite.materialize.CachingLatticeStatisticProvider
-
Creates a CachingStatisticProvider.
- CachingRelMetadataProvider - Class in org.apache.calcite.rel.metadata
-
Implementation of the
RelMetadataProvider
interface that caches results from an underlying provider. - CachingRelMetadataProvider(RelMetadataProvider, RelOptPlanner) - Constructor for class org.apache.calcite.rel.metadata.CachingRelMetadataProvider
- CachingRelMetadataProvider.CacheEntry - Class in org.apache.calcite.rel.metadata
-
An entry in the cache.
- CachingRelMetadataProvider.CachingInvocationHandler - Class in org.apache.calcite.rel.metadata
-
Implementation of
InvocationHandler
for calls to aCachingRelMetadataProvider
. - 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, RelNode, RexProgram) - Constructor for class org.apache.calcite.rel.core.Calc
-
Creates a Calc.
- Calc(RelOptCluster, RelTraitSet, RelNode, RexProgram, List<RelCollation>) - Constructor for class org.apache.calcite.rel.core.Calc
-
Deprecated.
- CALC - org.apache.calcite.rel.mutable.MutableRelType
- CALC_INSTANCE - Static variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Singleton rule that reduces constants inside a
LogicalCalc
. - 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_RULES - Static variable in class org.apache.calcite.tools.Programs
- CALCITE - org.apache.calcite.sql.SqlDialect.DatabaseProduct
- CALCITE - Static variable in class org.apache.calcite.chinook.ConnectionFactory
- CALCITE - Static variable in class org.apache.calcite.sql.SqlDialect
-
Deprecated.Use
CalciteSqlDialect.DEFAULT
instead. - 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
- CALCITE_2539_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_461_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether the remaining issues raised in [CALCITE-461] Convert more planner rules to handle grouping sets are fixed.
- 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 - org.apache.calcite.chinook.ConnectionFactory.DatabaseWrapper
- CALCITE_AS_SPECIFIC_USER - org.apache.calcite.chinook.ConnectionFactory.DatabaseWrapper
- 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
- CalciteConnectionImpl - Class in org.apache.calcite.jdbc
-
Implementation of JDBC connection in the Calcite engine.
- CalciteConnectionImpl(Driver, AvaticaFactory, String, Properties, CalciteSchema, JavaTypeFactory) - Constructor for class org.apache.calcite.jdbc.CalciteConnectionImpl
-
Creates a CalciteConnectionImpl.
- CalciteConnectionImpl.CalciteQueryable<T> - Class in org.apache.calcite.jdbc
-
Implementation of Queryable.
- CalciteConnectionImpl.CalciteServerImpl - Class in org.apache.calcite.jdbc
-
Implementation of Server.
- CalciteConnectionImpl.CalciteServerStatementImpl - Class in org.apache.calcite.jdbc
-
Implementation of
CalciteServerStatement
. - CalciteConnectionImpl.ContextImpl - Class in org.apache.calcite.jdbc
-
Implementation of Context.
- CalciteConnectionImpl.DataContextImpl - Class in org.apache.calcite.jdbc
-
Implementation of DataContext.
- CalciteConnectionImpl.RootSchema - Class in org.apache.calcite.jdbc
-
Schema that has no parents.
- CalciteConnectionImpl.SlimDataContext - Class in org.apache.calcite.jdbc
-
Implementation of
DataContext
that has few variables and isSerializable
. - CalciteConnectionProperty - Enum in org.apache.calcite.config
-
Properties that may be specified on the JDBC connect string.
- CalciteConnectionProperty(String, ConnectionProperty.Type, Object, boolean) - Constructor for enum org.apache.calcite.config.CalciteConnectionProperty
- CalciteConnectionProperty(String, ConnectionProperty.Type, Object, boolean, Class) - Constructor for enum org.apache.calcite.config.CalciteConnectionProperty
- 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 in org.apache.calcite.runtime
-
Exception which contains information about the textual context of the causing exception.
- CalciteContextException(String, Throwable) - Constructor for exception org.apache.calcite.runtime.CalciteContextException
-
Creates a new CalciteContextException object.
- CalciteContextException(String, Throwable, int, int, int, int) - Constructor for exception org.apache.calcite.runtime.CalciteContextException
-
Creates a new CalciteContextException object.
- CalciteContextException(String, Throwable, String) - Constructor for exception org.apache.calcite.runtime.CalciteContextException
-
Creates a new CalciteContextException object.
- CalciteException - Exception in org.apache.calcite.runtime
-
Base class for all exceptions originating from Farrago.
- CalciteException(String, Throwable) - Constructor for exception 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
- calciteFunc - Variable in enum org.apache.calcite.adapter.pig.PigAggFunction
- CalciteJdbc41Connection(Driver, AvaticaFactory, String, Properties, CalciteSchema, JavaTypeFactory) - Constructor for class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41Connection
- CalciteJdbc41DatabaseMetaData(CalciteConnectionImpl) - Constructor for class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41DatabaseMetaData
- 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.
- CalciteJdbc41Factory.CalciteJdbc41Connection - Class in org.apache.calcite.jdbc
-
Implementation of connection for JDBC 4.1.
- CalciteJdbc41Factory.CalciteJdbc41DatabaseMetaData - Class in org.apache.calcite.jdbc
-
Implementation of database metadata for JDBC 4.1.
- CalciteJdbc41Factory.CalciteJdbc41PreparedStatement - Class in org.apache.calcite.jdbc
-
Implementation of prepared statement for JDBC 4.1.
- CalciteJdbc41Factory.CalciteJdbc41Statement - Class in org.apache.calcite.jdbc
-
Implementation of statement for JDBC 4.1.
- CalciteJdbc41PreparedStatement(CalciteConnectionImpl, Meta.StatementHandle, CalcitePrepare.CalciteSignature, int, int, int) - Constructor for class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- CalciteJdbc41Statement(CalciteConnectionImpl, Meta.StatementHandle, int, int, int) - Constructor for class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41Statement
- 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
- CalciteMaterializer - Class in org.apache.calcite.prepare
-
Context for populating a
Prepare.Materialization
. - CalciteMaterializer(CalcitePrepareImpl, CalcitePrepare.Context, Prepare.CatalogReader, CalciteSchema, RelOptPlanner, SqlRexConvertletTable) - Constructor for class org.apache.calcite.prepare.CalciteMaterializer
- CalciteMaterializer.Callback - Class in org.apache.calcite.prepare
-
Called when we discover a star table that matches.
- CalciteMaterializer.RelNullShuttle - Class in org.apache.calcite.prepare
-
Implementation of
RelShuttle
that returns each relational expression unchanged. - 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
- CalciteMetaImpl.CalciteMetaSchema - Class in org.apache.calcite.jdbc
-
Metadata describing a Calcite schema.
- CalciteMetaImpl.CalciteMetaTable - Class in org.apache.calcite.jdbc
-
Metadata describing a Calcite table.
- CalciteMetaImpl.LimitIterator<E> - Class in org.apache.calcite.jdbc
-
Iterator that returns at most
limit
rows from an underlyingIterator
. - CalciteMetaImpl.MetadataTable<E> - Class in org.apache.calcite.jdbc
-
Table whose contents are metadata.
- CalciteMetaSchema(CalciteSchema, String, String) - Constructor for class org.apache.calcite.jdbc.CalciteMetaImpl.CalciteMetaSchema
- CalciteMetaTable(Table, String, String, String) - Constructor for class org.apache.calcite.jdbc.CalciteMetaImpl.CalciteMetaTable
- 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.Dummy.TrivialSparkHandler - Class in org.apache.calcite.jdbc
-
Implementation of
CalcitePrepare.SparkHandler
that either does nothing or throws for each method. - 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.
- CalcitePreparedExplain(RelDataType, RelDataType, RelRoot, SqlExplainFormat, SqlExplainLevel) - Constructor for class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparedExplain
- CalcitePreparedStatement - Class in org.apache.calcite.jdbc
-
Implementation of
PreparedStatement
for the Calcite engine. - CalcitePreparedStatement(CalciteConnectionImpl, Meta.StatementHandle, Meta.Signature, int, int, int) - Constructor for class org.apache.calcite.jdbc.CalcitePreparedStatement
-
Creates a CalcitePreparedStatement.
- CalcitePrepareImpl - Class in org.apache.calcite.prepare
-
Shit just got real.
- CalcitePrepareImpl() - Constructor for class org.apache.calcite.prepare.CalcitePrepareImpl
- CalcitePrepareImpl.CalcitePreparedExplain - Class in org.apache.calcite.prepare
-
An
EXPLAIN
statement, prepared and ready to execute. - CalcitePrepareImpl.CalcitePreparingStmt - Class in org.apache.calcite.prepare
-
Holds state for the process of preparing a SQL statement.
- CalcitePrepareImpl.EmptyScalarTranslator - Class in org.apache.calcite.prepare
-
Basic translator.
- CalcitePrepareImpl.LambdaScalarTranslator - Class in org.apache.calcite.prepare
-
Translator that looks for parameters.
- CalcitePrepareImpl.ScalarTranslator - Interface in org.apache.calcite.prepare
-
Translator from Java AST to
RexNode
. - CalcitePreparingStmt(CalcitePrepareImpl, CalcitePrepare.Context, Prepare.CatalogReader, RelDataTypeFactory, CalciteSchema, EnumerableRel.Prefer, RelOptPlanner, Convention, SqlRexConvertletTable) - Constructor for class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- CalciteQueryable(CalciteConnection, Type, Expression) - Constructor for class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteQueryable
- 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. - CalciteResultSet(AvaticaStatement, CalcitePrepare.CalciteSignature, ResultSetMetaData, TimeZone, Meta.Frame) - Constructor for class org.apache.calcite.jdbc.CalciteResultSet
-
Creates a CalciteResultSet.
- CalciteRootSchema - Class in org.apache.calcite.jdbc
-
Deprecated.
- CalciteRootSchema(Schema) - Constructor for class org.apache.calcite.jdbc.CalciteRootSchema
-
Deprecated.Creates a root schema.
- calciteSchema - Variable in class org.apache.calcite.jdbc.CalciteMetaImpl.CalciteMetaSchema
- calciteSchema() - Method in class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- 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.SchemaPlusImpl - Class in org.apache.calcite.jdbc
-
Implementation of
SchemaPlus
based on aCalciteSchema
. - 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.
- CalciteServerImpl() - Constructor for class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerImpl
- CalciteServerStatement - Interface in org.apache.calcite.server
-
Statement within a Calcite server.
- CalciteServerStatementImpl(CalciteConnectionImpl) - Constructor for class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerStatementImpl
- 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.
- 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
- 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, SqlConformance) - Constructor for class org.apache.calcite.prepare.CalciteSqlValidator
- CalciteStatement - Class in org.apache.calcite.jdbc
-
Implementation of
Statement
for the Calcite engine. - CalciteStatement(CalciteConnectionImpl, Meta.StatementHandle, int, int, int) - Constructor for class org.apache.calcite.jdbc.CalciteStatement
-
Creates a CalciteStatement.
- calciteTable - Variable in class org.apache.calcite.jdbc.CalciteMetaImpl.CalciteMetaTable
- 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
-
Planner rule that merges a
LogicalCalc
onto aLogicalCalc
. - CalcMergeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.CalcMergeRule
-
Creates a CalcMergeRule.
- CalcReduceExpressionsRule(Class<? extends Calc>, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.CalcReduceExpressionsRule
- CalcReduceExpressionsRule(Class<? extends Calc>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.CalcReduceExpressionsRule
-
Deprecated.
- CalcRelSplitter - Class in org.apache.calcite.rel.rules
- CalcRelSplitter(Calc, RelBuilder, CalcRelSplitter.RelType[]) - Constructor for class org.apache.calcite.rel.rules.CalcRelSplitter
-
Constructs a CalcRelSplitter.
- CalcRelSplitter.CannotImplement - Exception in org.apache.calcite.rel.rules
-
Control exception for
CalcRelSplitter.ImplementTester
. - CalcRelSplitter.HighestUsageFinder - Class in org.apache.calcite.rel.rules
-
Builds an array of the highest level which contains an expression which uses each expression as an input.
- CalcRelSplitter.ImplementTester - Class in org.apache.calcite.rel.rules
-
Visitor which returns whether an expression can be implemented in a given type of relational expression.
- CalcRelSplitter.InputToCommonExprConverter - Class in org.apache.calcite.rel.rules
-
Shuttle which converts every reference to an input field in an expression to a reference to a common sub-expression.
- CalcRelSplitter.MaxInputFinder - Class in org.apache.calcite.rel.rules
-
Finds the highest level used by any of the inputs of a given expression.
- 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(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.CalcRemoveRule
-
Creates a CalcRemoveRule.
- CalcSplitRule - Class in org.apache.calcite.rel.rules
- CalcSplitRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.CalcSplitRule
-
Creates a CalcSplitRule.
- CalcToWindowRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectToWindowRule.CalcToWindowRule
-
Creates a CalcToWindowRule.
- calculateFlattenedOffset(RelDataType, int) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- 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. - CalendarPolicy() - Constructor for enum org.apache.calcite.sql.SqlDialect.CalendarPolicy
- call - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- call - Variable in class org.apache.calcite.adapter.enumerable.impl.AggResultContextImpl
- call - Variable in class org.apache.calcite.interpreter.AggregateNode.CountAccumulator
- call - Variable in class org.apache.calcite.plan.SubstitutionVisitor.UnifyResult
- call - Variable in class org.apache.calcite.sql.SqlCallBinding
- call - Variable in class org.apache.calcite.sql.util.SqlShuttle.CallCopyingArgHandler
- call - Variable in class org.apache.calcite.sql.validate.AliasNamespace
- call - Variable in class org.apache.calcite.sql.validate.ProcedureNamespace
- call - Variable in class org.apache.calcite.sql.validate.SetopNamespace
- call() - Method in interface org.apache.calcite.adapter.enumerable.AggResultContext
- 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, 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, Type, TimeUnit) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.FloorImplementor
- 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, List<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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A method call, such as in the
obj.sampleMethod()
expression. - Call(SqlParserPos, Ast.Op, ImmutableList<Ast.Node>) - Constructor for class org.apache.calcite.piglet.Ast.Call
- 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(PrecedenceClimbingParser.Op, ImmutableList<PrecedenceClimbingParser.Token>) - Constructor for class org.apache.calcite.util.PrecedenceClimbingParser.Call
- CALL - org.apache.calcite.util.PrecedenceClimbingParser.Type
- call2(boolean, RexToLixTranslator, RexCall) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- Callback(RelNode, CalciteSchema.TableEntry, RelOptTableImpl) - Constructor for class org.apache.calcite.prepare.CalciteMaterializer.Callback
- callBackupMethodAnyType(RexToLixTranslator, RexCall, List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.BinaryImplementor
- CallCopyingArgHandler(SqlCall, boolean) - Constructor for class org.apache.calcite.sql.util.SqlShuttle.CallCopyingArgHandler
- callId - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner.RuleProvenance
- CallImplementor - Interface in org.apache.calcite.adapter.enumerable
-
Implements a call via given translator.
- calls - Variable in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- calls - Variable in class org.apache.calcite.sql.validate.AggFinder.AggIterable
- CallSiteBinder - Interface in org.apache.calcite.linq4j.tree
-
Creates a
DynamicExpression
that represents a dynamic operation bound by the providedCallSiteBinder
. - camelName - Variable in enum org.apache.calcite.config.CalciteConnectionProperty
- 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
- canAssignFrom(RelDataType, RelDataType) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a value of
type2
can be assigned to a variable oftype1
. - canAssignFrom(RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Tests whether a value can be assigned to a site.
- canBeLong(Object) - Method in class org.apache.calcite.adapter.clone.ColumnLoader.ValueSet
- 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 true if fromType can be cast to toType.
- canCastFrom(SqlCallBinding, boolean, RelDataType, RelDataType) - Method in class org.apache.calcite.sql.fun.SqlJsonValueFunction
- canCastFrom(SqlTypeName, SqlTypeName) - Method in class org.apache.calcite.sql.type.SqlTypeAssignmentRules
-
Returns whether it is valid to cast a value of from type
from
to typeto
. - canCastFrom(SqlTypeName, SqlTypeName, boolean) - Method in class org.apache.calcite.sql.type.SqlTypeAssignmentRules
-
Deprecated.
- CANCEL_FLAG - 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.adapter.csv.CsvEnumerator
- cancelFlag - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerStatementImpl
- 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.
- canCombine(RelNode, boolean) - Method in class org.apache.calcite.rel.rules.JoinToMultiJoinRule
-
Returns whether an input can be merged into a given relational expression without changing semantics.
- 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, RelCollation, RelCollation, RelNode) - 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.
- canConvert(RelOptPlanner, T, T, RelNode) - Method in class org.apache.calcite.plan.RelTraitDef
-
Tests whether the given RelTrait can be converted to another RelTrait.
- canConvert(RelDataType, RelDataType) - Static method in class org.apache.calcite.schema.Schemas
- 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
- canConvertStringInCompare(RelDataTypeFamily) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether a character data type can be implicitly converted to a given family in a compare operation.
- canConvertSubQuery() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.NoOpSubQueryConverter
- canConvertSubQuery() - Method in interface org.apache.calcite.sql2rel.SubQueryConverter
- canExpand(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.PassThroughExpander
- canExpand(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.ReinterpretExpander
- 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. - canHandle(RelOptTable) - Static method in class org.apache.calcite.interpreter.Bindables.BindableTableScan
- canHandle(Table) - 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.
- 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. - canImplement(SqlAggFunction, SqlDialect) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules
-
Returns whether this JDBC data source can implement a given aggregate function.
- canJoinOnCondition(RexNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcJoinRule
-
Returns whether a condition is supported by
JdbcRules.JdbcJoin
. - canNotApplyOp2Type(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- cannotCastValue(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- cannotConvert(Object, Class) - Static method in class org.apache.calcite.runtime.SqlFunctions
- 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
- cannotEvaluate() - Method in class org.apache.calcite.linq4j.tree.BinaryExpression
- cannotImplement() - Method in class org.apache.calcite.rel.convert.ConverterImpl
-
Deprecated.
- CannotImplement() - Constructor for exception org.apache.calcite.rel.rules.CalcRelSplitter.CannotImplement
- cannotOverrideWindowAttribute() - Method in interface org.apache.calcite.runtime.CalciteResource
- CannotPlanException(String) - Constructor for exception 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
- canonicalId - Variable in class org.apache.calcite.sql2rel.DeduplicateCorrelateVariables.DeduplicateCorrelateVariablesShuttle
- canonize(RelSubset) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
If a subset has one or more equivalent subsets (owing to a set having merged with another), returns the subset which is the leader of the equivalence class.
- 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
-
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.
- canonizeNode(RexBuilder, RexNode) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
-
Reorders some of the operands in this expression so structural comparison, i.e., based on string representation, can be more precise.
- canPush(Aggregate, ImmutableBitSet) - Method in class org.apache.calcite.rel.rules.FilterAggregateTransposeRule
- canReduce() - Method in class org.apache.calcite.linq4j.tree.Expression
-
Indicates that the node can be reduced to a simpler node.
- canReinterpretOverflow(RexCall) - Static method in class org.apache.calcite.rex.RexUtil
- canRemoveCastFromLiteral(RelDataType, Comparable, SqlTypeName) - Method in class org.apache.calcite.rex.RexBuilder
- canRewriteExtract(RexNode) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- canRollUp(TimeUnit, TimeUnit) - Static method in class org.apache.calcite.rex.RexSimplify
-
Method that returns whether we can rollup from inner time unit to outer time unit.
- canSimplify(RexCall, RexCall, RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.ReinterpretExpander
-
Detect, in a generic, but strict way, whether it is possible to simplify a reinterpret cast.
- 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
- CapStyle() - Constructor for enum org.apache.calcite.runtime.GeoFunctions.CapStyle
- cardinality - Variable in class org.apache.calcite.adapter.clone.ArrayTable.Column
- cardinality - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonColumn
- cardinality - Variable in class org.apache.calcite.profile.Profiler.Distribution
- cardinality - Variable in class org.apache.calcite.profile.ProfilerImpl.Space
-
Number of distinct values.
- cardinality() - Method in class org.apache.calcite.profile.SimpleProfiler.Space
-
Number of distinct values.
- 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(double, ImmutableBitSet) - Method in class org.apache.calcite.profile.ProfilerImpl.Run
-
Estimates the cardinality of a collection of columns represented by
columnOrdinals
, drawing on existing distributions. - cardinality(List<Lattice.Column>) - Method in class org.apache.calcite.materialize.CachingLatticeStatisticProvider
- 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(List<Lattice.Column>) - Method in class org.apache.calcite.materialize.ProfilerLatticeStatisticProvider
- cardinality(List<Lattice.Column>) - Method in class org.apache.calcite.materialize.SqlLatticeStatisticProvider
- cardinality(Lattice, Lattice.Column) - Method in class org.apache.calcite.materialize.SqlLatticeStatisticProvider
- cardinality(SqlStatisticProvider, LatticeTable) - Method in class org.apache.calcite.materialize.Step
-
Temporary method.
- 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_MAP - Static variable in enum org.apache.calcite.materialize.MapSqlStatisticProvider
- CARDINALITY_VIOLATION - 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.
- CardOfProjExpr(RelMetadataQuery, Project) - Constructor for class org.apache.calcite.rel.metadata.RelMdUtil.CardOfProjExpr
- 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
- CartesianProductListEnumerator(List<Enumerator<E>>) - Constructor for class org.apache.calcite.linq4j.Linq4j.CartesianProductListEnumerator
- cartesians - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- 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 - org.apache.calcite.sql.SqlKind
-
A "CASE" expression.
- CASE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- case_(List<Comparable>) - Method in class org.apache.calcite.rex.RexInterpreter
- case_(RexBuilder, RexNode...) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- CASE_INSENSITIVE - Static variable in class org.apache.calcite.sql.validate.SqlNameMatchers
- CASE_SENSITIVE - org.apache.calcite.config.CalciteConnectionProperty
-
Whether identifiers are matched case-sensitively.
- CASE_SENSITIVE - Static variable in class org.apache.calcite.sql.validate.SqlNameMatchers
- CaseBranch(RexNode, RexNode) - Constructor for class org.apache.calcite.rex.RexSimplify.CaseBranch
- caseClausesOnNewLines - Variable in class org.apache.calcite.sql.pretty.SqlFormatOptions
- caseClausesOnNewLines - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- CaseExpander(RexBuilder) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule.CaseExpander
- CaseImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.CaseImplementor
- CaseInsensitiveComparator - Class in org.apache.calcite.util
-
Comparator that compares all strings differently, but if two strings are equal in case-insensitive match they are right next to each other.
- CaseInsensitiveComparator() - Constructor for class org.apache.calcite.util.CaseInsensitiveComparator
- CaseInsensitiveComparator.Key - Class in org.apache.calcite.util
-
Enables to create floor and ceiling keys for given string.
- caseSensitive - Variable in enum org.apache.calcite.config.Lex
- caseSensitive - Variable in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- caseSensitive - Variable in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- caseSensitive - Variable in class org.apache.calcite.sql.validate.SqlNameMatchers.BaseMatcher
- caseSensitive() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- caseSensitive() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- caseSensitive() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- caseSensitive() - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- CaseShuttle() - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.CaseShuttle
- CASSANDRA_OP - Static variable in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraSortRule
- CASSANDRA_QUERYABLE_QUERY - org.apache.calcite.adapter.cassandra.CassandraMethod
- CassandraConverterRule(Class<? extends RelNode>, String) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraConverterRule
- CassandraConverterRule(Class<R>, Predicate<? super R>, String) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraConverterRule
- CassandraEnumerator - Class in org.apache.calcite.adapter.cassandra
-
Enumerator that reads from a Cassandra column family.
- CassandraEnumerator(ResultSet, RelProtoDataType) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraEnumerator
-
Creates a CassandraEnumerator.
- cassandraFieldNames(RelDataType) - Static method in class org.apache.calcite.adapter.cassandra.CassandraRules
- 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
- CassandraFilter.Translator - Class in org.apache.calcite.adapter.cassandra
-
Translates
RexNode
expressions into Cassandra expression strings. - CassandraFilterRule() - Constructor for class org.apache.calcite.adapter.cassandra.CassandraRules.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() - Constructor for class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraLimitRule
- CassandraMethod - Enum in org.apache.calcite.adapter.cassandra
-
Builtin methods in the Cassandra adapter.
- CassandraMethod(Class, String, Class...) - Constructor for enum org.apache.calcite.adapter.cassandra.CassandraMethod
- 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() - 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() - Constructor for class org.apache.calcite.adapter.cassandra.CassandraRules
- CassandraRules.CassandraConverterRule - Class in org.apache.calcite.adapter.cassandra
-
Base class for planner rules that convert a relational expression to Cassandra calling convention.
- CassandraRules.CassandraFilterRule - Class in org.apache.calcite.adapter.cassandra
-
Rule to convert a
LogicalFilter
to aCassandraFilter
. - CassandraRules.CassandraLimitRule - Class in org.apache.calcite.adapter.cassandra
-
Rule to convert a
EnumerableLimit
to aCassandraLimit
. - 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.RexToCassandraTranslator - Class in org.apache.calcite.adapter.cassandra
-
Translator from
RexNode
to strings in Cassandra's expression language. - CassandraSchema - Class in org.apache.calcite.adapter.cassandra
-
Schema mapped onto a Cassandra column family
- CassandraSchema(String, int, String, String, String, SchemaPlus, String) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraSchema
-
Creates a Cassandra schema.
- CassandraSchema(String, int, String, SchemaPlus, String) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraSchema
-
Creates a Cassandra schema.
- CassandraSchema(String, String, String, String, SchemaPlus, String) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraSchema
-
Creates a Cassandra schema.
- CassandraSchema(String, String, SchemaPlus, 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() - Constructor for class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraSortRule
- cassandraTable - Variable in class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
- cassandraTable - Variable in class org.apache.calcite.adapter.cassandra.CassandraTableScan
- 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
- CassandraTable(CassandraSchema, 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(RelBuilderFactory) - 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.linq4j.DefaultQueryable
- cast(Class<T2>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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 interface org.apache.calcite.linq4j.ExtendedQueryable
- 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<?>, 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(Queryable<T>, Class<T2>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- cast(RexCall, List<Comparable>) - Method in class org.apache.calcite.rex.RexInterpreter
- 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 - org.apache.calcite.sql.SqlKind
-
The "CAST" operator.
- CAST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
CAST
operator. - CastArgAsDoubleExpander(RexBuilder) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule.CastArgAsDoubleExpander
- CastArgAsTypeExpander(RexBuilder) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule.CastArgAsTypeExpander
- castCharToDateTime(TimeZone, String, SqlTypeName, String) - Static method in class org.apache.calcite.adapter.druid.DruidSqlCastConverter
- castDateTimeToChar(TimeZone, String, SqlTypeName) - Static method in class org.apache.calcite.adapter.druid.DruidSqlCastConverter
- CastExpander(RexBuilder) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule.CastExpander
- CastExpression(RelDataType, PredicateAnalyzer.TerminalExpression) - Constructor for class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CastExpression
- 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.
- CastImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.CastImplementor
- CastingEnumerator(Enumerator<?>, Class<T>) - Constructor for class org.apache.calcite.linq4j.EnumerableDefaults.CastingEnumerator
- 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
- castNullLiteralIfNeeded(RexNode, RelDataType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- CastOptimizedImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.CastOptimizedImplementor
- 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. - castSingle() - Method in class org.apache.calcite.linq4j.QueryableDefaults.ReplayableQueryable
-
Convenience method, for
QueryableRecorder
methods that return a scalar value such asboolean
orBigDecimal
. - castToValidatedType(SqlNode, RexNode, SqlValidator, RexBuilder) - Static method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Casts a RexNode value to the validated type of a SqlCall.
- castToValidatedType(SqlRexContext, SqlCall, RexNode) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Casts a RexNode value to the validated type of a SqlCall.
- catalog - Variable in class org.apache.calcite.adapter.jdbc.JdbcSchema
- CATALOG - org.apache.calcite.sql.validate.SqlMonikerType
- 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.sql.validate.SqlValidatorImpl
- catalogReader - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- catalogs() - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- CatalogScope - Class in org.apache.calcite.sql.validate
-
Implementation of
SqlValidatorScope
that can see all schemas in the current catalog. - CatalogScope(SqlValidatorScope, List<String>) - Constructor for class org.apache.calcite.sql.validate.CatalogScope
- 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.
- 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 - Variable in class org.apache.calcite.sql.SqlFunction
- category(SqlOperator) - Static method in class org.apache.calcite.sql.util.ListSqlOperatorTable
- cdata(String) - Method in class org.apache.calcite.util.XmlOutput
-
Writes a CDATA section.
- cdata(String, boolean) - Method in class org.apache.calcite.util.XmlOutput
-
Writes a CDATA section (as
XmlOutput.cdata(String)
). - 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(Calendar, TimeUnitRange) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- ceil(RexCall, List<Comparable>) - Method in class org.apache.calcite.rex.RexInterpreter
- CEIL - org.apache.calcite.sql.SqlKind
-
The "CEIL" function
- CEIL - org.apache.calcite.util.BuiltInMethod
- CEIL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CEIL
function. - CeilExpander(RexBuilder) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule.CeilExpander
- ceilingKey(String) - Method in class org.apache.calcite.util.CaseInsensitiveComparator
- 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
- ceilRange(TimeUnitRange, SqlKind, Calendar) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- cellReader - Variable in class org.apache.calcite.adapter.file.FileRowConverter.FieldDef
- CellReader(Map<String, Object>) - Constructor for class org.apache.calcite.adapter.file.FileRowConverter.CellReader
- cellSeq - Variable in class org.apache.calcite.adapter.file.FileRowConverter.FieldDef
- chain(Iterable<? extends Context>) - Static method in class org.apache.calcite.plan.Contexts
- chain(Context...) - Static method in class org.apache.calcite.plan.Contexts
-
Returns a context that wraps a list of contexts.
- chain(SqlReturnTypeInference...) - Static method in class org.apache.calcite.sql.type.ReturnTypes
- 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.
- ChainContext(ImmutableList<Context>) - Constructor for class org.apache.calcite.plan.Contexts.ChainContext
- chainedInitialize(Map<VolcanoPlannerPhase, Set<String>>) - Method in class org.apache.calcite.plan.volcano.ChainedPhaseRuleMappingInitializer
-
Extend this method to provide phase-to-rule mappings beyond what is provided by this initializer's subordinate.
- ChainedInvocationHandler(List<Metadata>) - Constructor for class org.apache.calcite.rel.metadata.ChainedRelMetadataProvider.ChainedInvocationHandler
- ChainedPhaseRuleMappingInitializer - Class in org.apache.calcite.plan.volcano
-
ChainedPhaseRuleMappingInitializer is an abstract implementation of
VolcanoPlannerPhaseRuleMappingInitializer
that allows additional rules to be layered on top of those configured by a subordinateVolcanoPlannerPhaseRuleMappingInitializer
. - ChainedPhaseRuleMappingInitializer(VolcanoPlannerPhaseRuleMappingInitializer) - Constructor for class org.apache.calcite.plan.volcano.ChainedPhaseRuleMappingInitializer
- 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.
- ChainedRelMetadataProvider.ChainedInvocationHandler - Class in org.apache.calcite.rel.metadata
-
Invocation handler that calls a list of
Metadata
objects, returning the first non-null value. - ChainedSqlOperatorTable - Class in org.apache.calcite.sql.util
-
ChainedSqlOperatorTable implements the
SqlOperatorTable
interface by chaining together any number of underlying operator table instances. - ChainedSqlOperatorTable(List<SqlOperatorTable>) - Constructor for class org.apache.calcite.sql.util.ChainedSqlOperatorTable
-
Creates a table based on a given list.
- changeConvention(RelNode, Convention, Convention, Multimap<Pair<Convention, Convention>, ConverterRule>) - Method in class org.apache.calcite.plan.ConventionTraitDef
-
Tries to convert a relational expression to the target convention of an arc.
- 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
- changeTraitsUsingConverters(RelNode, RelTraitSet) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- changeTraitsUsingConverters(RelNode, RelTraitSet, boolean) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- CHAR - org.apache.calcite.adapter.csv.CsvFieldType
- CHAR - org.apache.calcite.adapter.file.FileFieldType
- CHAR - org.apache.calcite.linq4j.tree.Primitive
- CHAR - org.apache.calcite.sql.type.SqlTypeName
- CHAR_LENGTH - 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 - org.apache.calcite.sql.type.SqlTypeFamily
- CHARACTER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- CHARACTER_LENGTH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- CHARARRAY - org.apache.calcite.adapter.pig.PigDataType
- charCount - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- charEmpty - Variable in class org.apache.calcite.rex.RexBuilder
- charLength(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL CHARACTER_LENGTH(string) function.
- charset - Variable in class org.apache.calcite.adapter.file.FileReader
- charset - Variable in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- charset - Variable in class org.apache.calcite.sql.parser.SqlParserUtil.ParsedCollation
- charset - Variable in class org.apache.calcite.util.NlsString
- charset - Variable in class org.apache.calcite.util.SerializableCharset
- charsetEncoding(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- charsetName - Variable in class org.apache.calcite.util.NlsString
- charsetName - Variable in class org.apache.calcite.util.SerializableCharset
- charSetName - Variable in class org.apache.calcite.sql.SqlDataTypeSpec
- CheapestPlanReplacer(VolcanoPlanner) - Constructor for class org.apache.calcite.plan.volcano.RelSubset.CheapestPlanReplacer
- check(boolean, String, Object...) - Method in interface org.apache.calcite.util.Litmus
-
Checks a condition.
- check(SqlParserPos, SqlIdentifier, SqlNode) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a CHECK constraint.
- check(SqlCallBinding) - Method in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- check(SqlNode) - Method in class org.apache.calcite.sql.SqlUtil.Genealogist
- CHECK - org.apache.calcite.sql.SqlKind
-
CHECK
constraint. - 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
- checkCancel() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Checks to see whether cancellation has been requested, and if so, throws an exception.
- checkCharsetAndCollateConsistentIfCharType(RelDataType) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
- checkClientTrusted(X509Certificate[], String) - Method in class org.apache.calcite.runtime.TrustAllSslSocketFactory.DummyTrustManager
- checkConditionContainsInputRefOrLiterals(RexNode, RexNode, List<String>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeFilterRule
-
Checks whether a condition contains input refs of literals.
- checkConstraint(SqlValidatorTable, SqlNode, RelDataType) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates insert values against the constraint of a modifiable view.
- checkConstraint(SqlValidatorTable, SqlUpdate, RelDataType) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates updates against the constraint of a modifiable view.
- checkConvertedType(SqlNode, RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- checkCorVars(LogicalCorrelate, LogicalProject, LogicalFilter, List<RexFieldAccess>) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Checks whether the correlations in projRel and filter are related to the correlated variables provided by corRel.
- checkDateFormat(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Checks if the date/time format is valid
- checkDefault() - Method in class org.apache.calcite.runtime.Resources.Prop
- checkDefault2() - Method in class org.apache.calcite.runtime.Resources.Prop
- checkDuplicateSubsets(Deque<RelSubset>, RelOptRuleOperand, RelNode[]) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Recursively checks whether there are any duplicate subsets along any path from root of the operand tree to one of the leaves.
- Checker(RelDataType, List<RelDataType>, RelNode.Context, Litmus) - Constructor for class org.apache.calcite.rex.RexProgram.Checker
-
Creates a Checker.
- checkExtendedColumnTypes(SqlNodeList) - Method in class org.apache.calcite.sql.validate.TableNamespace
-
Ensures that extended columns that have the same name as a base column also have the same data-type.
- checkFieldCount(SqlNode, SqlValidatorTable, SqlNode, RelDataType, RelDataType) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- checkForIncompatibleDateTimeOperands(RexCall) - Static method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer
-
If one operand in a binary operator is a DateTime type, but the other isn't, we should not push down the predicate
- checkForSatisfiedConverters(RelSet, RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- checkIdentifierListForDuplicates(List<SqlNode>, SqlValidatorImpl.ValidationErrorFunction) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Checks that there are no duplicates in a list of
SqlIdentifier
. - checkIndent() - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
- CheckingUserDefinedFunctionVisitor() - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.CheckingUserDefinedFunctionVisitor
- 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.
- checkInputsPresentInExplain(RelNode) - Method in class org.apache.calcite.rel.externalize.RelWriterImpl
- checkLeadFieldInRange(RelDataTypeSystem, int, BigDecimal, TimeUnit, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- checkOperandCount(SqlValidator, SqlOperandTypeChecker, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlJsonApiCommonSyntaxOperator
- 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.SqlJsonObjectFunction
- 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.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.SqlJsonObjectFunction
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlJsonValueFunction
- 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.SqlSubstringFunction
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.fun.SqlTrimFunction
- 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.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.FamilyOperandTypeChecker
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.LiteralOperandTypeChecker
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.MultisetOperandTypeChecker
- checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.calcite.sql.type.OperandTypes.PeriodOperandTypeChecker
- 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(SqlOperatorBinding) - 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) - 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
- 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.
- checkRange(int, int) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Checks that fromIndex ...
- checkRequiredAttributes(Object, String...) - Method in class org.apache.calcite.model.ModelHandler
- checkRollUp(SqlNode, SqlNode, SqlNode, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- checkRollUp(SqlNode, SqlNode, SqlNode, SqlValidatorScope, String) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- checkRollUpInGroupBy(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- checkRollUpInOrderBy(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- checkRollUpInSelectList(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- checkRollUpInUsing(SqlIdentifier, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- checkRollUpInWindow(SqlWindow, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- checkRollUpInWindowDecl(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- checkServerTrusted(X509Certificate[], String) - Method in class org.apache.calcite.runtime.TrustAllSslSocketFactory.DummyTrustManager
- 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.LiteralOperandTypeChecker
- checkSingleOperandType(SqlCallBinding, SqlNode, int, boolean) - Method in class org.apache.calcite.sql.type.OperandTypes.PeriodOperandTypeChecker
- 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.
- checkSpecialLiterals(SqlWindow, SqlValidator) - Static method in class org.apache.calcite.sql.SqlWindow
- checkSupport(RexImplicationChecker.InputUsageFinder, RexImplicationChecker.InputUsageFinder) - Method in class org.apache.calcite.plan.RexImplicationChecker
-
Looks at the usage of variables in first and second conjunction to decide whether this kind of expression is currently supported for proving first implies second.
- checkTarget(ImmutableBitSet, Set<RexNode>, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- checkType(SqlCallBinding, boolean, RelDataType) - Method in class org.apache.calcite.sql.type.ComparableOperandTypeChecker
- checkTypeAssignment(RelDataType, RelDataType, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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.
- 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.
- 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
- child - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter
- child - Variable in class org.apache.calcite.sql.validate.CollectNamespace
- child - Variable in class org.apache.calcite.sql.validate.CollectScope
- childBitmap - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Bitmap containing the fields in the RelNode that the projection is being pushed past, if the RelNode is not a join.
- childFactory - Variable in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
- childFields - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Fields from the RelNode that the projection is being pushed past
- childFunction - Variable in class org.apache.calcite.util.PartiallyOrderedSet
- childList - Variable in class org.apache.calcite.util.PartiallyOrderedSet.Node
- childPolicy - Variable in class org.apache.calcite.plan.RelOptRuleOperand
-
Whether child operands can be matched in any order.
- childPreserveExprs - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Expressions referenced in the projection/filter that should be preserved.
- childRel - Variable in class org.apache.calcite.rel.rules.PushProjector
- children - Variable in class org.apache.calcite.materialize.LatticeNode
- children - Variable in class org.apache.calcite.materialize.MutableNode
- children - Variable in class org.apache.calcite.plan.RelOptRuleOperand
- children - Variable in class org.apache.calcite.sql.validate.ListScope
-
List of child
SqlValidatorNamespace
objects and their names. - children(SqlValidatorScope) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
- childrenAccept(MutableRelVisitor) - Method in class org.apache.calcite.rel.mutable.MutableBiRel
- childrenAccept(MutableRelVisitor) - Method in class org.apache.calcite.rel.mutable.MutableLeafRel
- childrenAccept(MutableRelVisitor) - Method in class org.apache.calcite.rel.mutable.MutableMultiRel
- childrenAccept(MutableRelVisitor) - Method in class org.apache.calcite.rel.mutable.MutableRel
- childrenAccept(MutableRelVisitor) - Method in class org.apache.calcite.rel.mutable.MutableSingleRel
- 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.
- chooseBestEdge(List<LoptMultiJoin.Edge>, Comparator<LoptMultiJoin.Edge>) - Method in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule
- 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
- chooseFixedRep(int, Primitive, long, long) - Method in class org.apache.calcite.adapter.clone.ColumnLoader.ValueSet
-
Chooses a representation for a fixed-precision primitive type (boolean, byte, char, short, int, long).
- chooseLevels(RexNode[], int, int[], int[]) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter
-
Figures out which expressions to calculate at which level.
- chooseRep(int) - Method in class org.apache.calcite.adapter.clone.ColumnLoader.ValueSet
- 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
- chosenSemiJoins - Variable in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
-
Semijoins corresponding to each join factor, if they are going to be filtered by semijoins.
- chunk - Variable in class org.apache.calcite.util.ChunkList.ChunkListIterator
- CHUNK_SIZE - Static variable in class org.apache.calcite.util.ChunkList
- 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.
- ChunkList.ChunkListIterator - Class in org.apache.calcite.util
-
Iterator over a
ChunkList
. - ChunkListIterator(Object[], int, int, int, int) - Constructor for class org.apache.calcite.util.ChunkList.ChunkListIterator
- CLASS_DIR - Static variable in class org.apache.calcite.adapter.spark.SparkHandlerImpl
- CLASS_FAMILIES - Static variable in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- 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.
- classDecl(JavaTypeFactoryImpl.SyntheticRecordType) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- 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 ou deterministic expressions to final static fields.
- ClassDeclarationFinder(Function1<ClassDeclarationFinder, ClassDeclarationFinder>) - Constructor for class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Creates optimizer with no parent.
- ClassDeclarationFinder(ClassDeclarationFinder) - Constructor for class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Creates a child optimizer.
- classes - Variable in class org.apache.calcite.plan.AbstractRelOptPlanner
- classes - Variable in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider.Space
- classHasPublicZeroArgsConstructor(Class<?>) - Static method in class org.apache.calcite.schema.impl.ReflectiveFunctionBase
-
Verifies if given class has public constructor with zero arguments.
- classId - Variable in class org.apache.calcite.adapter.spark.SparkHandlerImpl
- CLASSIFIER - org.apache.calcite.sql.SqlKind
- CLASSIFIER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
CLASSIFIER
function to be used withinMATCH_RECOGNIZE
. - classifyFilters(RelNode, List<RexNode>, JoinRelType, 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.
- classLoader - Variable in class org.apache.calcite.util.javac.JaninoCompiler
- classLoader - Variable in class org.apache.calcite.util.javac.JavaCompilerArgs
- className - Variable in class org.apache.calcite.model.JsonFunction
-
Name of the class that implements this function.
- className - Variable in class org.apache.calcite.sql.ddl.SqlCreateFunction
- className(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- classOperands - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Operands that apply to a given class of
RelNode
. - classServer - Variable in class org.apache.calcite.adapter.spark.SparkHandlerImpl
- classToTypeName(Class<? extends RelNode>) - Method in class org.apache.calcite.rel.externalize.RelJson
-
Inverse of
RelJson.typeNameToClass(java.lang.String)
. - Clause() - Constructor for enum org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- clauses - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- clauses - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
- clauseStartsLine - Variable in class org.apache.calcite.sql.pretty.SqlFormatOptions
- clauseStartsLine - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- clazz - Variable in class org.apache.calcite.adapter.clone.ColumnLoader.ValueSet
- clazz - Variable in enum org.apache.calcite.adapter.csv.CsvFieldType
- clazz - Variable in enum org.apache.calcite.adapter.file.FileFieldType
- clazz - Variable in class org.apache.calcite.adapter.java.ReflectiveSchema
- clazz - Variable in enum org.apache.calcite.DataContext.Variable
- clazz - Variable in class org.apache.calcite.jdbc.JavaRecordType
- clazz - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.CastingEnumerator
- clazz - Variable in class org.apache.calcite.linq4j.tree.ArrayLengthRecordField
- clazz - Variable in class org.apache.calcite.plan.RelOptRuleOperand
- clazz - Variable in class org.apache.calcite.plan.SubstitutionVisitor.Operand
- clazz - Variable in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- clazz - Variable in class org.apache.calcite.runtime.RecordEnumeratorCursor
- clazz - Variable in class org.apache.calcite.util.CastingList
- clean(Object, RelDataType) - Static method in class org.apache.calcite.rex.RexBuilder
-
Converts the type of a value to comply with
RexLiteral.valueMatchesType(java.lang.Comparable, org.apache.calcite.sql.type.SqlTypeName, boolean)
. - CLEANUP - org.apache.calcite.plan.volcano.VolcanoPlannerPhase
- clear() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.WrapMap
- clear() - Method in class org.apache.calcite.linq4j.LookupImpl
- clear() - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Clears this BlockBuilder.
- clear() - Method in class org.apache.calcite.linq4j.tree.Evaluator
- clear() - Method in class org.apache.calcite.materialize.MaterializationService
-
De-registers all materialized tables in the system.
- clear() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- clear() - Method in class org.apache.calcite.plan.hep.HepPlanner
- clear() - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
- 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 internal data structure for this rule queue.
- clear() - Method in class org.apache.calcite.plan.volcano.RuleQueue.PhaseMatchList
- clear() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- clear() - Method in class org.apache.calcite.runtime.AbstractImmutableList
- 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.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.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.InverseMapping
- 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.PartialFunctionImpl
- 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
. - clearCachedImportance() - Method in class org.apache.calcite.plan.volcano.VolcanoRuleMatch
-
Clears the cached importance value of this rule match.
- 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.
- clearImportanceBoost() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Clear all importance boosts.
- 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
- client - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchema
- clientCache - Variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleEnumerator
- clientCache - Variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleScannableTable
- clientCache - Variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchema
- 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.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.MutableSemiJoin
- 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() - Method in class org.apache.calcite.util.XmlOutput.StringEscaper
- 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
- cloneArray(SqlNode[]) - Static method in class org.apache.calcite.sql.SqlNode
-
Deprecated.
- cloneChildren() - Method in class org.apache.calcite.rel.mutable.MutableMultiRel
- clonedOperands - Variable in class org.apache.calcite.sql.util.SqlShuttle.CallCopyingArgHandler
- cloneJoinFieldRefCountsMap() - Method in class org.apache.calcite.rel.rules.MultiJoin
-
Returns a deep copy of
MultiJoin.joinFieldRefCountsMap
. - 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
. - ClosableAllocation - Interface in org.apache.calcite.util
-
ClosableAllocation represents an object which requires a call in order to release resources early rather than waiting for finalization.
- ClosableAllocationOwner - Interface in org.apache.calcite.util
-
ClosableAllocationOwner represents an object which can take ownership of ClosableAllocations and guarantee that they will be cleaned up correctly when its own closeAllocation() is called.
- close - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- close() - Method in class org.apache.calcite.adapter.cassandra.CassandraEnumerator
- close() - Method in class org.apache.calcite.adapter.clone.ArrayTable.Content.ArrayEnumerator
- close() - Method in class org.apache.calcite.adapter.clone.ArrayTable.Content.ObjectEnumerator
- close() - Method in class org.apache.calcite.adapter.csv.CsvEnumerator
- close() - Method in class org.apache.calcite.adapter.csv.CsvStreamReader
-
Closes the underlying reader.
- close() - Method in class org.apache.calcite.adapter.csv.JsonEnumerator
- close() - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl.BlockingQueueEnumerator
- close() - Method in class org.apache.calcite.adapter.elasticsearch.Scrolling.AutoClosingIterator
- close() - Method in class org.apache.calcite.adapter.file.FileEnumerator
- close() - Method in class org.apache.calcite.adapter.file.FileReader
- close() - Method in class org.apache.calcite.adapter.geode.rel.GeodeEnumerator
- close() - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleEnumerator
- close() - Method in class org.apache.calcite.adapter.mongodb.MongoEnumerator
- close() - Method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.SplunkResultEnumerator
- close() - Method in class org.apache.calcite.interpreter.Interpreter
- close() - Method in class org.apache.calcite.interpreter.Interpreter.EnumeratorSource
- close() - Method in class org.apache.calcite.interpreter.Interpreter.ListSource
- 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 class org.apache.calcite.linq4j.EnumerableDefaults.CastingEnumerator
- close() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- close() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.SkipWhileEnumerator
- close() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileEnumerator
- close() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileLongEnumerator
- close() - Method in interface org.apache.calcite.linq4j.Enumerator
-
Closes this enumerable and releases resources.
- close() - Method in class org.apache.calcite.linq4j.Linq4j.EnumeratorIterator
- close() - Method in class org.apache.calcite.linq4j.Linq4j.IterableEnumerator
- close() - Method in class org.apache.calcite.linq4j.Linq4j.ListEnumerator
- close() - Method in class org.apache.calcite.linq4j.Linq4j.SingletonEnumerator
- close() - Method in class org.apache.calcite.linq4j.Linq4j.SingletonNullEnumerator
- 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.rel.rules.DateRangeRules.ExtractFinder
- 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.runtime.ResultSetEnumerable.ResultSetEnumerator
- 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(Closeable) - Static method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- close(Connection, Statement, ResultSet) - Static method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- close(ResultSet, Statement) - Static method in class org.apache.calcite.benchmarks.StatementTest
- 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
- closeAllocation() - Method in interface org.apache.calcite.util.ClosableAllocation
-
Closes this object.
- closeAllocation() - Method in class org.apache.calcite.util.CompoundClosableAllocation
- closeClientCache() - Static method in class org.apache.calcite.adapter.geode.util.GeodeUtils
- closed - Variable in class org.apache.calcite.adapter.elasticsearch.Scrolling.AutoClosingIterator
-
Was
Scrolling.AutoClosingIterator.closer
consumer already called ? - closeIfPossible(Connection, Statement) - Method in class org.apache.calcite.runtime.ResultSetEnumerable
- closeIterator(Iterator<T>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Closes an iterator, if it can be closed.
- closer - Variable in class org.apache.calcite.adapter.elasticsearch.Scrolling.AutoClosingIterator
- 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
- closeScroll(Iterable<String>) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- closeStatement(Meta.StatementHandle) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- closure - Variable in class org.apache.calcite.util.BitSets.Closure
- closure - Variable in class org.apache.calcite.util.ImmutableBitSet.Closure
- closure(Function<E, Iterable<E>>, E, List<E>, Set<E>) - Method in class org.apache.calcite.util.PartiallyOrderedSet
- 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.
- Closure(SortedMap<Integer, BitSet>) - Constructor for class org.apache.calcite.util.BitSets.Closure
- Closure(SortedMap<Integer, ImmutableBitSet>) - Constructor for class org.apache.calcite.util.ImmutableBitSet.Closure
- cluster - Variable in class org.apache.calcite.plan.SubstitutionVisitor
- cluster - Variable in class org.apache.calcite.prepare.LixToRelTranslator
- cluster - Variable in class org.apache.calcite.rel.AbstractRelNode
- cluster - Variable in class org.apache.calcite.rel.externalize.RelJsonReader
- cluster - Variable in class org.apache.calcite.rel.mutable.MutableRel
- cluster - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter
- cluster - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- cluster - Variable in class org.apache.calcite.tools.RelBuilder
- CLUSTERED - 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.
- clusteringKeys - Variable in class org.apache.calcite.adapter.cassandra.CassandraFilter
- clusteringKeys - Variable in class org.apache.calcite.adapter.cassandra.CassandraFilter.Translator
- clusteringOrder - Variable in class org.apache.calcite.adapter.cassandra.CassandraTable
- cm - Variable in class org.apache.calcite.sql2rel.RelDecorrelator
- cm - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.DecorrelateRexShuttle
- CnfHelper(RexBuilder, int) - Constructor for class org.apache.calcite.rex.RexUtil.CnfHelper
- cnt - Variable in class org.apache.calcite.interpreter.AggregateNode.CountAccumulator
- 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(RexCall, List<Comparable>) - Method in class org.apache.calcite.rex.RexInterpreter
- Coalesce - 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 - org.apache.calcite.sql.SqlKind
-
The "COALESCE" operator.
- COALESCE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The COALESCE builtin function.
- CoalesceImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.CoalesceImplementor
- code - Variable in class org.apache.calcite.rex.RexExecutable
- code - Variable in enum org.apache.calcite.runtime.GeoFunctions.Type
- CodesFunction - Class in org.apache.calcite.chinook
-
Example Table Function for lateral join checks
- CodesFunction() - Constructor for class org.apache.calcite.chinook.CodesFunction
- coerce(Object, RelDataType) - Static method in class org.apache.calcite.sql.validate.SqlUserDefinedTableMacro
- COERCE_INSTANCE - Static variable in class org.apache.calcite.sql.type.SqlTypeAssignmentRules
- 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
-
Creates a CoerceInputsRule.
- coerceNames - Variable in class org.apache.calcite.rel.rules.CoerceInputsRule
- coercibility - Variable in class org.apache.calcite.sql.SqlCollation
- Coercibility() - Constructor for enum org.apache.calcite.sql.SqlCollation.Coercibility
- COERCIBLE - org.apache.calcite.sql.SqlCollation.Coercibility
- COERCIBLE - Static variable in class org.apache.calcite.sql.SqlCollation
- collapseExpandedIsNotDistinctFromExpr(RexCall, RexBuilder) - Static method in class org.apache.calcite.plan.RelOptUtil
- 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 - Variable in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- collation - Variable in class org.apache.calcite.sql.ddl.SqlAttributeDefinition
- collation - Variable in class org.apache.calcite.sql.SqlIdentifier
-
This identifier's collation (if any).
- collation - Variable in class org.apache.calcite.sql.type.BasicSqlType
- collation - Variable in class org.apache.calcite.util.NlsString
- collation() - Method in class org.apache.calcite.rel.core.Window.Group
- collation(RexNode, RelFieldCollation.Direction, RelFieldCollation.NullDirection, List<RexNode>) - Static method in class org.apache.calcite.tools.RelBuilder
- collationHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- collationList - Variable in class org.apache.calcite.jdbc.CalcitePrepare.CalciteSignature
- collationName - Variable in class org.apache.calcite.sql.SqlCollation
- collations - Variable in class org.apache.calcite.adapter.clone.ArrayTable.Content
- collations - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonLimit
- 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(EnumerableMergeJoin, 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(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(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 - org.apache.calcite.util.BuiltInMethod
- collationsCompatible(RelCollation, RelCollation) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraSortRule
-
Check if it is possible to exploit native CQL sorting for a given collation.
- 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
-
Creates a Collect.
- Collect(RelInput) - Constructor for class org.apache.calcite.rel.core.Collect
-
Creates a Collect by parsing serialized output.
- COLLECT - org.apache.calcite.rel.mutable.MutableRelType
- COLLECT - org.apache.calcite.sql.SqlKind
-
The
COLLECT
aggregate function. - COLLECT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The COLLECT operator.
- collectAliases(ImmutableMap.Builder<String, RelDataType>, SqlNode, Iterator<RelDataType>) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- COLLECTED - 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.
- collectGarbage() - Method in class org.apache.calcite.plan.hep.HepPlanner
- CollectImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.CollectImplementor
- collecting - Variable in class org.apache.calcite.plan.hep.HepInstruction.EndGroup
- 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 - org.apache.calcite.util.BuiltInMethod
- COLLECTION_ADDALL - org.apache.calcite.util.BuiltInMethod
- COLLECTION_OR_MAP - Static variable in class org.apache.calcite.sql.type.OperandTypes
- COLLECTION_SIZE - org.apache.calcite.util.BuiltInMethod
- COLLECTION_TABLE - 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.
- CollectionEnumerable(Collection<T>) - Constructor for class org.apache.calcite.linq4j.Linq4j.CollectionEnumerable
- collectionName - Variable in class org.apache.calcite.adapter.mongodb.MongoTable
- COLLECTIONS_EMPTY_LIST - org.apache.calcite.util.BuiltInMethod
- COLLECTIONS_REVERSE_ORDER - org.apache.calcite.util.BuiltInMethod
- COLLECTIONS_SINGLETON_LIST - org.apache.calcite.util.BuiltInMethod
- collectionsTypeName - Variable in class org.apache.calcite.sql.SqlDataTypeSpec
- CollectNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for COLLECT and TABLE constructs.
- CollectNamespace(SqlCall, SqlValidatorScope, SqlNode) - Constructor for class org.apache.calcite.sql.validate.CollectNamespace
-
Creates a CollectNamespace.
- collectOperandTypes() - Method in class org.apache.calcite.sql.SqlOperatorBinding
-
Collects the types of the bound operands into a list.
- collectOperandTypes(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.sql.fun.SqlBetweenOperator
- collector - Variable in class org.apache.calcite.profile.ProfilerImpl.Space
- Collector(ProfilerImpl.Space) - Constructor for class org.apache.calcite.profile.ProfilerImpl.Collector
- 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.
- CollectScope - Class in org.apache.calcite.sql.validate
-
The name-resolution context for expression inside a multiset call.
- CollectScope(SqlValidatorScope, SqlValidatorScope, SqlCall) - Constructor for class org.apache.calcite.sql.validate.CollectScope
- collectTableRefs(List<LatticeSuggester.Frame>, List<LatticeSuggester.Hop>) - Static method in class org.apache.calcite.materialize.LatticeSuggester.Frame
- 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.
- ColRef() - Constructor for class org.apache.calcite.materialize.LatticeSuggester.ColRef
- column - Variable in class org.apache.calcite.materialize.Lattice.BaseColumn
-
Name of the column.
- column - Variable in class org.apache.calcite.materialize.TileSuggester.AttributeImpl
- column - Variable in class org.apache.calcite.sql.SqlDescribeTable
- column(int) - Method in class org.apache.calcite.materialize.LatticeSuggester.Frame
- 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.materialize.Lattice.Column
- Column(int, String) - Constructor for class org.apache.calcite.profile.Profiler.Column
-
Creates a Column.
- Column(ArrayTable.Representation, Object, int) - Constructor for class org.apache.calcite.adapter.clone.ArrayTable.Column
- COLUMN - org.apache.calcite.sql.validate.SqlMonikerType
- COLUMN_DECL - org.apache.calcite.sql.SqlKind
-
Column declaration.
- COLUMN_LIST - org.apache.calcite.sql.SqlKind
-
The non-standard constructor used to pass a COLUMN_LIST parameter to a user-defined transform.
- COLUMN_LIST - org.apache.calcite.sql.type.SqlTypeFamily
- COLUMN_LIST - 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 - org.apache.calcite.util.BuiltInMethod
- COLUMN_UNIQUENESS - org.apache.calcite.util.BuiltInMethod
- columnAliases - Variable in class org.apache.calcite.materialize.Lattice.Builder.Fixer
- columnAliasList - Variable in class org.apache.calcite.materialize.Lattice.Builder.Fixer
- columnAmbiguous(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- columnCount - Variable in class org.apache.calcite.adapter.jdbc.JdbcUtils.ObjectArrayRowBuilder
- columnCount - Variable in class org.apache.calcite.materialize.LatticeSuggester.Frame
- columnCountMismatch() - Method in interface org.apache.calcite.runtime.CalciteResource
- columnCountMismatchInSetop(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- ColumnDef(SqlNode, RelDataType, ColumnStrategy) - Constructor for class org.apache.calcite.sql.ddl.SqlCreateTable.ColumnDef
- columnFamily - Variable in class org.apache.calcite.adapter.cassandra.CassandraTable
- 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.materialize.Lattice.Builder.Fixer
- 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.ddl.SqlKeyConstraint
- columnList - Variable in class org.apache.calcite.sql.SqlInsert
- columnList - Variable in class org.apache.calcite.sql.SqlWithItem
- columnListParamToParentCursorMap - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.FunctionParamInfo
-
Maps a column list parameter to the parent cursor parameter it references.
- ColumnLoader<T> - Class in org.apache.calcite.adapter.clone
-
Column loader.
- ColumnLoader(JavaTypeFactory, Enumerable<T>, RelProtoDataType, List<ColumnMetaData.Rep>) - Constructor for class org.apache.calcite.adapter.clone.ColumnLoader
-
Creates a column loader, and performs the load.
- ColumnLoader.Kev - Class in org.apache.calcite.adapter.clone
-
Key-value pair.
- ColumnLoader.ValueSet - Class in org.apache.calcite.adapter.clone
-
Set of values of a column, created during the load process, and converted to a serializable (and more compact) form before load completes.
- columnMapping - Variable in class org.apache.calcite.jdbc.CalcitePrepare.AnalyzeViewResult
- columnMapping - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin.RemovableSelfJoin
-
A mapping that maps references to columns from the right factor to columns in the left factor, if the column is referenced in both factors
- columnMapping - Variable in class org.apache.calcite.schema.impl.ModifiableViewTable
- columnMappings - Variable in class org.apache.calcite.rel.core.TableFunctionScan
- columnMappings - Variable in class org.apache.calcite.rel.mutable.MutableTableFunctionScan
- columnMappings - Variable in class org.apache.calcite.sql.type.TableFunctionReturnTypeInference
- columnMonotonicities - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- 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
- columnNumber - Variable in class org.apache.calcite.sql.parser.SqlParserPos
- 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. - columnOrdinal - Variable in class org.apache.calcite.profile.ProfilerImpl.HllSingletonCollector
- columnOrdinal - Variable in class org.apache.calcite.profile.ProfilerImpl.SingletonCollector
- columnOrdinals - Variable in class org.apache.calcite.profile.ProfilerImpl.CompositeCollector
- columnOrdinals - Variable in class org.apache.calcite.profile.ProfilerImpl.HllCompositeCollector
- columnOrdinals - Variable in class org.apache.calcite.profile.ProfilerImpl.Space
- columnOrdinals - Variable in class org.apache.calcite.profile.SimpleProfiler.Space
- columnOrdinals() - Method in class org.apache.calcite.profile.Profiler.Distribution
- columnOriginHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- columnPairs - Variable in class org.apache.calcite.rel.RelReferentialConstraintImpl
- columnPrefix - Variable in class org.apache.calcite.adapter.tpch.TpchSchema
- columnPrefixes - Variable in class org.apache.calcite.adapter.tpch.TpchSchema
- columns - Variable in class org.apache.calcite.adapter.clone.ArrayTable.Content.ArrayEnumerator
- columns - Variable in class org.apache.calcite.adapter.clone.ArrayTable.Content
- columns - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonSegmentMetadata
- columns - Variable in class org.apache.calcite.adapter.druid.DruidQuery.ScanQuery
- 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 - Variable in class org.apache.calcite.profile.Profiler.Distribution
- columns - Variable in class org.apache.calcite.profile.Profiler.FunctionalDependency
- columns - Variable in class org.apache.calcite.profile.Profiler.Unique
- columns - Variable in class org.apache.calcite.profile.ProfilerImpl.Run
- columns - Variable in class org.apache.calcite.profile.ProfilerImpl.Space
- columns - Variable in class org.apache.calcite.profile.SimpleProfiler.Run
- columns - Variable in class org.apache.calcite.profile.SimpleProfiler.Space
- columns - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference.ExprsItr
- columns - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin.Edge
- columns(MetaImpl.MetaTable) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- columnsByAlias - Variable in class org.apache.calcite.materialize.Lattice.Builder
- columnSets - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference.ExprsItr
- columnStrategies(RelOptTable) - Static method in class org.apache.calcite.prepare.RelOptTableImpl
- ColumnStrategy - Enum in org.apache.calcite.schema
-
Describes how a column gets populated.
- ColumnStrategy() - Constructor for enum org.apache.calcite.schema.ColumnStrategy
- columnToPathOffset(Lattice.BaseColumn) - Method in class org.apache.calcite.materialize.Lattice
- columnTypeMismatchInSetop(int, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- columnUniquenessHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- columnValues - Variable in class org.apache.calcite.profile.ProfilerImpl.CompositeCollector
- combinationsPerPass - Variable in class org.apache.calcite.profile.ProfilerImpl.Builder
- combinationsPerPass - Variable in class org.apache.calcite.profile.ProfilerImpl
-
The number of combinations to consider per pass.
- combine(List<SqlTypeName>, List<SqlTypeName>) - Static method in enum org.apache.calcite.sql.type.SqlTypeName
- combine(RelDataTypeFactoryImpl, IntervalSqlType) - Method in class org.apache.calcite.sql.type.IntervalSqlType
-
Combines two IntervalTypes and returns the result.
- combine(SqlMonotonicity, SqlMonotonicity) - Method in class org.apache.calcite.sql.validate.SetopNamespace
- combinedMap() - Method in class org.apache.calcite.util.CompositeMap
- combinedRowType(List<RelNode>) - Method in interface org.apache.calcite.interpreter.Compiler
- combinedRowType(List<RelNode>) - Method in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
- combineFractionalSecondPrecisionPreservingDefault(RelDataTypeSystem, SqlIntervalQualifier, SqlIntervalQualifier) - Static method in class org.apache.calcite.sql.SqlIntervalQualifier
- combineInputs(Join, RelNode, RelNode, List<ImmutableBitSet>, List<int[]>) - Method in class org.apache.calcite.rel.rules.JoinToMultiJoinRule
-
Combines the inputs into a LogicalJoin into an array of inputs.
- combineJoinFilters(Join, RelNode, RelNode) - Method in class org.apache.calcite.rel.rules.JoinToMultiJoinRule
-
Combines the join filters from the left and right inputs (if they are MultiJoinRels) with the join filter in the joinrel into a single AND'd join filter, unless the inputs correspond to null generating inputs in an outer join
- combineOuterJoins(Join, List<RelNode>, RelNode, RelNode, List<Pair<JoinRelType, RexNode>>) - Method in class org.apache.calcite.rel.rules.JoinToMultiJoinRule
-
Combines the outer join conditions and join types from the left and right join inputs.
- combinePostJoinFilters(Join, RelNode, RelNode) - Method in class org.apache.calcite.rel.rules.JoinToMultiJoinRule
-
Combines the post-join filters from the left and right inputs (if they are MultiJoinRels) into a single AND'd filter.
- combineStartPrecisionPreservingDefault(RelDataTypeSystem, SqlIntervalQualifier, SqlIntervalQualifier) - Static method in class org.apache.calcite.sql.SqlIntervalQualifier
- COMMA - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- COMMA - 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_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
- commaList(List<T>) - Static method in class org.apache.calcite.util.Util
-
Converts a list of a string, with commas between elements.
- commaList(SqlWriter) - Method in class org.apache.calcite.sql.SqlNodeList
- 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.
- COMMENT - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- comments - Variable in class org.apache.calcite.benchmarks.ParserBenchmark
- commission - Variable in class org.apache.calcite.benchmarks.StatementTest.Employee
- commit(Meta.ConnectionHandle) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- COMMIT - org.apache.calcite.sql.SqlKind
-
COMMIT
session control statement. - commonFactors(List<RexNode>) - Method in class org.apache.calcite.rex.RexUtil.CnfHelper
- 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(RelOptRuleOperand) - Constructor for class org.apache.calcite.plan.CommonRelSubExprRule
-
Creates a
CommonRelSubExprRule
. - CommonRelSubExprRules() - Constructor for class org.apache.calcite.plan.hep.HepInstruction.CommonRelSubExprRules
- COMMUTE - Static variable in class org.apache.calcite.prepare.CalcitePrepareImpl
- COMP_OP_TYPES - Static variable in class org.apache.calcite.adapter.enumerable.RexImpTable.BinaryImplementor
-
Types that can be arguments to comparison operators such as
<
. - compact - Variable in class org.apache.calcite.util.XmlOutput
- COMPACT_NUMERIC_TYPES - Static variable in class org.apache.calcite.sql.type.SqlTypeExplicitPrecedenceList
- comparability - Variable in class org.apache.calcite.sql.type.ObjectSqlType
- COMPARABLE_EMPTY_LIST - org.apache.calcite.util.BuiltInMethod
- COMPARABLE_EMPTY_LIST - Static variable in class org.apache.calcite.runtime.FlatLists
- COMPARABLE_MAX - Static variable in class org.apache.calcite.linq4j.Extensions
- COMPARABLE_MIN - Static variable in class org.apache.calcite.linq4j.Extensions
- 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.
- comparableComparator() - Static method in class org.apache.calcite.linq4j.Extensions
- ComparableEmptyList() - Constructor for class org.apache.calcite.runtime.FlatLists.ComparableEmptyList
- ComparableListImpl(List<T>) - Constructor for class org.apache.calcite.runtime.FlatLists.ComparableListImpl
- 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 - Variable in class org.apache.calcite.adapter.enumerable.SourceSorter
- comparator() - Method in class org.apache.calcite.interpreter.SortNode
- comparator(RelFieldCollation) - Method in class org.apache.calcite.interpreter.SortNode
- 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.CaseInsensitiveComparator
- 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 - org.apache.calcite.util.BuiltInMethod
- comparators - Variable in class org.apache.calcite.runtime.ArrayComparator
- comparators(boolean[]) - Static method in class org.apache.calcite.runtime.ArrayComparator
- compare(boolean, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Boolean comparison.
- 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(C, C) - Static method in class org.apache.calcite.util.Pair
-
Compares a pair of comparable values of the same type.
- compare(Comparable, Comparable) - Method in class org.apache.calcite.linq4j.function.Functions.NullsFirstComparator
- compare(Comparable, Comparable) - Method in class org.apache.calcite.linq4j.function.Functions.NullsFirstReverseComparator
- compare(Comparable, Comparable) - Method in class org.apache.calcite.linq4j.function.Functions.NullsLastComparator
- compare(Comparable, Comparable) - Method in class org.apache.calcite.linq4j.function.Functions.NullsLastReverseComparator
- compare(Comparable, Comparable) - Static method in class org.apache.calcite.runtime.Utilities
- compare(Comparable, Comparable, int) - Static method in class org.apache.calcite.rel.RelFieldCollation
-
Utility method that compares values taking into account null direction.
- compare(Integer, Integer) - Method in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer.FactorCostComparator
- compare(Object[], Object[]) - Method in class org.apache.calcite.runtime.ArrayComparator
- compare(Object, Object) - Method in class org.apache.calcite.util.CaseInsensitiveComparator
- compare(List<Comparable>, IntPredicate) - Method in class org.apache.calcite.rex.RexInterpreter
- compare(List<Lattice.Column>, List<Lattice.Column>) - Static method in class org.apache.calcite.materialize.Lattice.Measure
- compare(List<T>, List<T>) - Static method in class org.apache.calcite.runtime.FlatLists.ComparableListImpl
- compare(List<T>, List<T>, int) - Static method in class org.apache.calcite.runtime.FlatLists.ComparableListImpl
- compare(List, List) - Static method in class org.apache.calcite.runtime.Utilities
- compare(RelSubset, RelSubset) - Method in class org.apache.calcite.plan.volcano.RuleQueue.RelImportanceComparator
- compare(VolcanoRuleMatch, VolcanoRuleMatch) - Method in class org.apache.calcite.plan.volcano.RuleQueue.RuleMatchImportanceComparator
- compare(RelNode, RelNode) - Method in class org.apache.calcite.rel.RelNodes.RelNodeComparator
- compare(T, T) - Static method in class org.apache.calcite.runtime.FlatLists.ComparableListImpl
- COMPARE - org.apache.calcite.sql.type.SqlOperandTypeChecker.Consistency
-
Make arguments of consistent type using comparison semantics.
- COMPARE - org.apache.calcite.util.BuiltInMethod
- compare_(Object, Object) - Static method in class org.apache.calcite.runtime.Utilities
- COMPARE_NULLS_FIRST - org.apache.calcite.util.BuiltInMethod
- COMPARE_NULLS_LAST - org.apache.calcite.util.BuiltInMethod
- compareExtract(SqlKind, RexNode, RexLiteral) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- compareFieldWithLiteral(RexNode, RexNode, List<String>) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraFilterRule
-
Check if an equality operation is comparing a primary key column with a literal.
- compareFloorCeil(SqlKind, RexNode, RexLiteral, TimeUnitRange, boolean) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- compareNullsFirst(Comparable, Comparable) - Static method in class org.apache.calcite.runtime.Utilities
- compareNullsLast(Comparable, Comparable) - Static method in class org.apache.calcite.runtime.Utilities
- compareNullsLast(List, List) - Static method in class org.apache.calcite.runtime.Utilities
- 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 - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.WrapMap
- comparer - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.Wrapped
- 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
. - compareResult - Variable in class org.apache.calcite.util.CaseInsensitiveComparator.Key
- 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.ComparableEmptyList
- compareTo(List) - Method in class org.apache.calcite.runtime.FlatLists.ComparableListImpl
- 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(ColumnLoader.Kev) - Method in class org.apache.calcite.adapter.clone.ColumnLoader.Kev
- 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(RelMultipleTrait) - Method in class org.apache.calcite.rel.RelDistributions.RelDistributionImpl
- compareTo(Profiler.Column) - Method in class org.apache.calcite.profile.Profiler.Column
- compareTo(SimpleProfiler.Space) - Method in class org.apache.calcite.profile.SimpleProfiler.Space
- 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(RelDecorrelator.CorDef) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorDef
- compareTo(RelDecorrelator.CorRef) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorRef
- 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(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
- 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(RexNode, SqlKind, RexLiteral) - Constructor for class org.apache.calcite.rex.RexSimplify.Comparison
- COMPARISON - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of comparison operators.
- COMPARISON_OPERATORS - Static variable in class org.apache.calcite.adapter.enumerable.RexImpTable.BinaryImplementor
- comparisonFunction - Variable in class org.apache.calcite.interpreter.AggregateNode.NumericComparison
- comparisonKind - Variable in class org.apache.calcite.sql.fun.SqlQuantifyOperator
- 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>, AbstractMaterializedViewRule.EquivalenceClasses, Set<RexTableInputRef.RelTableRef>, Multimap<RexTableInputRef, RexTableInputRef>) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
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>, AbstractMaterializedViewRule.EquivalenceClasses, Project, RelNode, Set<RexTableInputRef.RelTableRef>) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
It checks whether the query can be rewritten using the view even though the query uses additional tables.
- compensateViewPartial(RelBuilder, RexBuilder, RelMetadataQuery, RelNode, Project, RelNode, Set<RexTableInputRef.RelTableRef>, AbstractMaterializedViewRule.EquivalenceClasses, Project, RelNode, Set<RexTableInputRef.RelTableRef>) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewAggregateRule
- compensateViewPartial(RelBuilder, RexBuilder, RelMetadataQuery, RelNode, Project, RelNode, Set<RexTableInputRef.RelTableRef>, AbstractMaterializedViewRule.EquivalenceClasses, Project, RelNode, Set<RexTableInputRef.RelTableRef>) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewJoinRule
- 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(String, Object) - Static method in class org.apache.calcite.rex.RexExecutable
- compile(String, String, MetadataDef<M>, List<Object>) - Static method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- 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.Interpreter.CompilerImpl
- compile(List<RexNode>, RelDataType) - Method in class org.apache.calcite.interpreter.Interpreter.FooCompiler
- compile(List<RexNode>, RelDataType) - Method in interface org.apache.calcite.interpreter.Interpreter.ScalarCompiler
- 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 class org.apache.calcite.jdbc.CalcitePrepare.Dummy.TrivialSparkHandler
- compile(ClassDeclaration, String) - Method in interface org.apache.calcite.jdbc.CalcitePrepare.SparkHandler
- compile(RexBuilder, List<RexNode>, RexToLixTranslator.InputGetter) - Method in class org.apache.calcite.rex.RexExecutorImpl
- compile(RexBuilder, List<RexNode>, RexToLixTranslator.InputGetter, RelDataType) - Method in class org.apache.calcite.rex.RexExecutorImpl
- compiledFunction - Variable in class org.apache.calcite.rex.RexExecutable
- 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
. - CompilerImpl(Interpreter, RelOptCluster) - Constructor for class org.apache.calcite.interpreter.Interpreter.CompilerImpl
- COMPLETE - org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MatchModality
- completeConversion(RelNode, boolean, RelTraitSet, Expressions.FluentList<RelTraitDef>) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Converts traits using well-founded induction.
- COMPLEX - org.apache.calcite.adapter.druid.DruidType
- ComplexMetric - Class in org.apache.calcite.adapter.druid
-
Used to store information about available complex metrics in the Druid Adapter
- ComplexMetric(String, DruidType) - Constructor for class org.apache.calcite.adapter.druid.ComplexMetric
- complexMetrics - Variable in class org.apache.calcite.adapter.druid.DruidTable
- component() - Method 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 - Variable in class org.apache.calcite.linq4j.tree.Types.ArrayType
- componentIsNullable() - Method 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.
- componentPositions - Variable in class org.apache.calcite.sql.SqlIdentifier
-
A list of the positions of the components of compound identifiers.
- componentType - Variable in class org.apache.calcite.linq4j.tree.Types.ArrayType
- componentType - Variable in class org.apache.calcite.piglet.Ast.BagType
- compose(RexBuilder, Iterable<RexNode>) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- 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.
- CompositeCollector(ProfilerImpl.Space, int[], int) - Constructor for class org.apache.calcite.profile.ProfilerImpl.CompositeCollector
- CompositeEnumerable(List<Enumerable<E>>) - Constructor for class org.apache.calcite.linq4j.Linq4j.CompositeEnumerable
- CompositeList<T> - Class in org.apache.calcite.util
-
Read-only list that is the concatenation of sub-lists.
- CompositeList(ImmutableList<List<T>>) - Constructor for class org.apache.calcite.util.CompositeList
-
Creates a CompositeList.
- 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, SqlOperandCountRange) - Constructor for class org.apache.calcite.sql.type.CompositeOperandTypeChecker
-
Package private.
- 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. - CompositeSingleOperandTypeChecker(CompositeOperandTypeChecker.Composition, ImmutableList<? extends SqlSingleOperandTypeChecker>, String) - Constructor for class org.apache.calcite.sql.type.CompositeSingleOperandTypeChecker
-
Package private.
- composition - Variable in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- Composition() - Constructor for enum org.apache.calcite.sql.type.CompositeOperandTypeChecker.Composition
- CompoundClosableAllocation - Class in org.apache.calcite.util
-
CompoundClosableAllocation represents a collection of ClosableAllocations which share a common lifecycle.
- CompoundClosableAllocation() - Constructor for class org.apache.calcite.util.CompoundClosableAllocation
- compoundOrderByProhibitsRange() - Method in interface org.apache.calcite.runtime.CalciteResource
- CompoundQueryExpression(boolean) - Constructor for class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- CompoundQueryExpression(boolean, QueryBuilders.BoolQueryBuilder) - Constructor for class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- comprises(RelTrait...) - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns whether this trait set comprises precisely the list of given traits.
- computeBestCost(RelOptPlanner) - Method in class org.apache.calcite.plan.volcano.RelSubset
-
Computes the best
RelNode
in this subset. - computeClosure(int) - Method in class org.apache.calcite.util.BitSets.Closure
- computeClosure(int) - Method in class org.apache.calcite.util.ImmutableBitSet.Closure
- computeCompensationPredicates(RexBuilder, RexSimplify, AbstractMaterializedViewRule.EquivalenceClasses, Triple<RexNode, RexNode, RexNode>, AbstractMaterializedViewRule.EquivalenceClasses, Triple<RexNode, RexNode, RexNode>, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
We check whether the predicates in the source are contained in the predicates in the target.
- computeDigest() - Method in class org.apache.calcite.plan.hep.HepRelVertex
- computeDigest() - Method in class org.apache.calcite.plan.volcano.RelSubset
- computeDigest() - Method in class org.apache.calcite.plan.volcano.VolcanoRuleMatch
-
Computes a string describing this rule match.
- computeDigest() - Method in class org.apache.calcite.rel.AbstractRelNode
-
Computes the digest.
- computeDigest() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
-
Computes the digest field.
- computeDigest() - Method in class org.apache.calcite.rex.RexWindow
- 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
- 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. - computeFieldCount(Map<String, RelDataType>) - Static method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- computeFilter(Filter, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Translates Filter rel to Druid Filter Json object if possible.
- computeHistogramType(RelDataType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.HistogramShuttle
-
Returns the type for a histogram function.
- computeImportance() - Method in class org.apache.calcite.plan.volcano.VolcanoRuleMatch
-
Computes the importance of this rule match.
- computeImportance(RelSubset) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Computes the importance of a node.
- computeImportanceOfChild(RelMetadataQuery, RelSubset, RelSubset) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Returns the importance of a child to a parent.
- 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.
- computeJoinCardinality(RelMetadataQuery, LoptMultiJoin, LoptSemiJoinOptimizer, LoptJoinTree, List<RexNode>, int) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Computes the cardinality of the join columns from a particular factor, when that factor is joined with another join tree.
- computeNewRank(Expression, WinAggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.DenseRankImplementor
- computeNewRank(Expression, WinAggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.RankImplementor
- computeNext(ElasticsearchJson.Result) - Method in class org.apache.calcite.adapter.elasticsearch.Scrolling.SequentialIterator
- computeNextMapping(int) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference.ExprsItr
- computeOneMinusEpsilon() - Static method in class org.apache.calcite.plan.volcano.RuleQueue
- computeOutputRowType() - Method in class org.apache.calcite.rex.RexProgramBuilder
- computeProjectAsScan(Project, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Translates list of projects to Druid Column names and Virtual Columns if any We can not use
Pair.zip(Object[], Object[])
, since size can be different - computeProjectGroupSet(Project, ImmutableBitSet, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Computes the project group set.
- computeScore(RelNode, RelNode, SemiJoin) - Method in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
-
Computes a score relevant to applying a set of semijoins on a fact table.
- computeSelfCost(RelOptPlanner) - Method in class org.apache.calcite.rel.AbstractRelNode
- computeSelfCost(RelOptPlanner) - Method in interface org.apache.calcite.rel.RelNode
-
Deprecated.Call
RelMetadataQuery.getNonCumulativeCost(RelNode)
; if you wish to override the default cost formula, override theRelNode.computeSelfCost(RelOptPlanner, RelMetadataQuery)
method. - 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.EnumerableInterpreter
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.enumerable.EnumerableJoin
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMergeJoin
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.enumerable.EnumerableSemiJoin
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.enumerable.EnumerableThetaJoin
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindow
- 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.jdbc.JdbcRules.JdbcCalc
- 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.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.SemiJoin
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.rel.core.Sort
- 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, SemiJoin) - 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, 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, SemiJoin) - 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.
- computeSort(Integer, List<Integer>, List<RelFieldCollation.Direction>, ImmutableBitSet, List<String>) - Method in class org.apache.calcite.adapter.druid.DruidQuery
- computeString() - Method in class org.apache.calcite.plan.RelTraitSet
-
Outputs the traits of this set as a String.
- computeString() - Method in class org.apache.calcite.rel.core.Window.Group
- computeTables() - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- computeTiles() - Method in class org.apache.calcite.materialize.Lattice
- computeTopologicalOrdering(RexNode[], List<Set<Integer>>) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter
-
Computes the order in which to visit expressions, so that we decide the level of an expression only after the levels of lower expressions have been decided.
- con - Variable in class org.apache.calcite.benchmarks.StatementTest.HrConnection
- concat(ImmutableList<E>, ImmutableList<E>) - Static method in class org.apache.calcite.plan.RelOptPredicateList
-
Concatenates two immutable lists, avoiding a copy it possible.
- concat(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
string || string
operator. - concat(EnumSet<E>, EnumSet<E>...) - Static method in enum org.apache.calcite.sql.SqlKind
- concat(List<String>, List<String>) - Method in class org.apache.calcite.sql.validate.SqlNameMatchers.BaseMatcher
- 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.linq4j.DefaultQueryable
- concat(Enumerable<T>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- concat(Enumerable<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Concatenates two sequences.
- concat(Enumerable<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, Enumerable<T>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- CONCAT - org.apache.calcite.util.BuiltInMethod
- CONCAT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
String concatenation operator, '
||
'. - concat1(List<SqlLiteral>) - Method in class org.apache.calcite.sql.SqlAbstractStringLiteral
-
Helper routine for
SqlUtil.concatenateLiterals(java.util.List<org.apache.calcite.sql.SqlLiteral>)
. - concat1(List<SqlLiteral>) - Method in class org.apache.calcite.sql.SqlBinaryStringLiteral
- concat1(List<SqlLiteral>) - Method in class org.apache.calcite.sql.SqlCharStringLiteral
- concatenate(List) - Static method in class org.apache.calcite.model.JsonLattice
-
Converts a list of strings into a multi-line string.
- 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.
- cond - Variable in class org.apache.calcite.rex.RexSimplify.CaseBranch
- condition - Variable in class org.apache.calcite.interpreter.FilterNode
- condition - Variable in class org.apache.calcite.interpreter.JoinNode
- 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.piglet.Ast.FilterStmt
- condition - Variable in class org.apache.calcite.plan.RelOptMaterialization.ProjectFilterTable
- 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 - Variable in class org.apache.calcite.rel.mutable.MutableSemiJoin
- condition - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin.Edge
- condition - Variable in class org.apache.calcite.rex.RexProgram
-
The optional condition.
- condition - Variable in class org.apache.calcite.sql.SqlDelete
- condition - Variable in class org.apache.calcite.sql.SqlJoin
- condition - Variable in class org.apache.calcite.sql.SqlMerge
- condition - Variable in class org.apache.calcite.sql.SqlUpdate
- 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 - 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
- conditionRef - Variable in class org.apache.calcite.rex.RexProgramBuilder
- conditions - Variable in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.JoinVertex
-
Zero or more join conditions.
- conditionType - Variable in class org.apache.calcite.sql.SqlJoin
-
Value must be a
SqlLiteral
, one of the integer codes forJoinConditionType
. - condMustBeBoolean(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- config - Variable in class org.apache.calcite.adapter.file.FileRowConverter.FieldDef
- config - Variable in class org.apache.calcite.prepare.CalciteCatalogReader
- config - Variable in class org.apache.calcite.prepare.PlannerImpl
- config - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- config - Variable in class org.apache.calcite.tools.Frameworks.PrepareAction
- config() - Method in interface org.apache.calcite.jdbc.CalciteConnection
- config() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- config() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.ContextImpl
- config() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.Context
- configBuilder() - Static method in class org.apache.calcite.sql.parser.SqlParser
-
Builder for a
SqlParser.Config
. - configBuilder() - Static method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Creates a builder for a
SqlToRelConverter.Config
. - configBuilder(SqlParser.Config) - Static method in class org.apache.calcite.sql.parser.SqlParser
-
Builder for a
SqlParser.Config
that starts with an existingConfig
. - ConfigBuilder() - Constructor for class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- ConfigBuilder() - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- ConfigBuilder() - Constructor for class org.apache.calcite.tools.Frameworks.ConfigBuilder
-
Creates a ConfigBuilder, initializing to defaults.
- ConfigBuilder(FrameworkConfig) - Constructor for class org.apache.calcite.tools.Frameworks.ConfigBuilder
-
Creates a ConfigBuilder, initializing from an existing config.
- ConfigImpl(boolean, boolean, boolean, boolean, boolean, boolean, int, RelBuilderFactory) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- ConfigImpl(int, Casing, Casing, Quoting, boolean, SqlConformance, SqlParserImplFactory) - Constructor for class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- conformance - Variable in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- conformance - Variable in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- conformance - Variable in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- conformance - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- conformance() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- conformance() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- conformance() - Method in class org.apache.calcite.prepare.PlannerImpl
- conformance() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- conformance() - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- CONFORMANCE - 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.adapter.splunk.search.SplunkConnectionImpl
- connect(String, boolean) - Method in class org.apache.calcite.chinook.ConnectionFactory
- connect(String, Properties) - Method in class org.apache.calcite.adapter.splunk.SplunkDriver
- connect(Map<String, Integer>) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchemaFactory
-
Builds elastic rest client from user configuration
- connect(CalciteSchema, JavaTypeFactory) - Static method in class org.apache.calcite.jdbc.CalciteMetaImpl
-
A trojan-horse method, subject to change without notice.
- connect(CalciteSchema, JavaTypeFactory) - Method in class org.apache.calcite.jdbc.Driver
-
Creates an internal connection.
- connect(CalciteSchema, JavaTypeFactory, Properties) - Method in class org.apache.calcite.jdbc.Driver
-
Creates an internal connection.
- CONNECT_STRING_PREFIX - Static variable in class org.apache.calcite.jdbc.Driver
- connection - Variable in class org.apache.calcite.adapter.splunk.SplunkDriver.WrappingSplunkConnection
- connection - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerStatementImpl
- connection - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl.ContextImpl
- connection - Variable in class org.apache.calcite.model.ModelHandler
- connection - Variable in class org.apache.calcite.schema.Schemas.DummyDataContext
- connection() - Method in class org.apache.calcite.chinook.CalciteConnectionProvider
- connection() - Method in enum org.apache.calcite.chinook.ConnectionFactory.DatabaseWrapper
- CONNECTION_PROVIDER - Static variable in class org.apache.calcite.chinook.ChinookAvaticaServer.CalciteChinookMetaFactory
- ConnectionFactory - Class in org.apache.calcite.chinook
-
Wrapping connection factory for quidem
- ConnectionFactory() - Constructor for class org.apache.calcite.chinook.ConnectionFactory
- ConnectionFactory.DatabaseWrapper - Enum in org.apache.calcite.chinook
-
Wrapping with Fairy environmental decoration
- cons(E, List<? extends E>) - Static method in class org.apache.calcite.util.Static
-
Builds a list.
- consistency - Variable in class org.apache.calcite.sql.type.ComparableOperandTypeChecker
- Consistency() - Constructor for enum org.apache.calcite.sql.type.SqlOperandTypeChecker.Consistency
- consistentType(SqlRexContext, SqlOperandTypeChecker.Consistency, List<RelDataType>) - Static method in class org.apache.calcite.sql2rel.StandardConvertletTable
- ConsList<E> - Class in org.apache.calcite.runtime
-
List that consists of a head element and an immutable non-empty list.
- ConsList(E, List<E>) - Constructor for class org.apache.calcite.runtime.ConsList
- Constancy() - Constructor for enum org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator.Constancy
- 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(R) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns a 1-parameter function that always returns the same value.
- Constant - org.apache.calcite.linq4j.tree.ExpressionType
-
A constant value.
- Constant(int) - Constructor for class org.apache.calcite.adapter.clone.ArrayTable.Constant
- CONSTANT - org.apache.calcite.adapter.clone.ArrayTable.RepresentationType
-
Constant.
- CONSTANT - org.apache.calcite.sql.validate.SqlMonotonicity
- CONSTANT_NULL_FUNCTION1 - Static variable in class org.apache.calcite.linq4j.function.Functions
- CONSTANT_REDUCTION_RULES - Static variable in class org.apache.calcite.prepare.CalcitePrepareImpl
- constantArrayList(List<T>, Class) - Static method in class org.apache.calcite.adapter.cassandra.CassandraToEnumerableConverter
-
E.g.
- constantArrayList(List<T>, Class) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchToEnumerableConverter
-
E.g.
- constantArrayList(List<T>, Class) - Static method in class org.apache.calcite.adapter.geode.rel.GeodeToEnumerableConverter
-
E.g.
- constantArrayList(List<T>, Class) - Static method in class org.apache.calcite.adapter.mongodb.MongoToEnumerableConverter
-
E.g.
- 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
- ConstantFinder() - Constructor for class org.apache.calcite.rex.RexProgram.ConstantFinder
- ConstantFinder() - Constructor for class org.apache.calcite.rex.RexUtil.ConstantFinder
- constantList(List<T>) - Static method in class org.apache.calcite.adapter.cassandra.CassandraToEnumerableConverter
-
E.g.
- constantList(List<T>) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchToEnumerableConverter
-
E.g.
- constantList(List<T>) - Static method in class org.apache.calcite.adapter.geode.rel.GeodeToEnumerableConverter
-
E.g.
- constantList(List<T>) - Static method in class org.apache.calcite.adapter.mongodb.MongoToEnumerableConverter
-
E.g.
- constantMap - Variable in class org.apache.calcite.plan.RelOptPredicateList
-
A map of each (e, constant) pair that occurs within
RelOptPredicateList.pulledUpPredicates
. - constantNull - Variable in class org.apache.calcite.rex.RexBuilder
- 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
-
Creates a constant for the SQL
NULL
value. - constants - Variable in class org.apache.calcite.adapter.enumerable.EnumerableWindow.WindowRelInputGetter
- 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
- constants - Variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- constantScoreQuery(QueryBuilders.QueryBuilder) - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A query that wraps another query and simply returns a constant score equal to the query boost for every document in the query.
- ConstantScoreQueryBuilder(QueryBuilders.QueryBuilder) - Constructor for class org.apache.calcite.adapter.elasticsearch.QueryBuilders.ConstantScoreQueryBuilder
- constantStringList(List<String>) - Static method in class org.apache.calcite.adapter.splunk.SplunkTableScan
- 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.
- ConstantUntypedNull() - Constructor for class org.apache.calcite.linq4j.tree.ConstantUntypedNull
- constExprs - Variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- constraint - Variable in class org.apache.calcite.jdbc.CalcitePrepare.AnalyzeViewResult
- constraint - Variable in class org.apache.calcite.schema.impl.ModifiableViewTable
- 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
- constructFuncList(String...) - Static method in class org.apache.calcite.sql.SqlJdbcFunctionCall
- constructNewNodes(List<RelNode>, boolean, int, RelNode, RelNode...) - Static method in class org.apache.calcite.adapter.druid.DruidRules.DruidAggregateProjectRule
-
Returns a new List of RelNodes in the order of the given order of the oldNodes, the given
Filter
, and any extra nodes. - 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
- constructorMap - Variable in class org.apache.calcite.rel.externalize.RelJson
- constructorSupplier(Class<T>) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable
- constructSql92ReservedWordList() - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
-
Builds a comma-separated list of JDBC reserved words.
- consumeQuery(ListIterator<SqlSimpleParser.Token>, List<SqlSimpleParser.Token>) - Method in class org.apache.calcite.sql.advise.SqlSimpleParser
- consumerRelClass - Variable in class org.apache.calcite.rel.rules.CoerceInputsRule
- consumeSelect(ListIterator<SqlSimpleParser.Token>, List<SqlSimpleParser.Token>) - Method in class org.apache.calcite.sql.advise.SqlSimpleParser
- 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
. - 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.
- containNoNonTrivialAggs(List<RexNode>, Litmus) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether an array of exp contains no aggregate function calls whose arguments are not
RexInputRef
s. - contains(int) - Method in class org.apache.calcite.util.IntegerIntervalSet
- contains(Object) - Method in class org.apache.calcite.runtime.AbstractImmutableList
- contains(Object) - Method in class org.apache.calcite.util.IntegerIntervalSet
- contains(Object) - Method in class org.apache.calcite.util.PartiallyOrderedSet
- contains(String) - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Query
- 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) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, T, EqualityComparer<T>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(RelCollation, List<Integer>) - Static method in class org.apache.calcite.rel.RelCollations
- 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(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) - Method in class org.apache.calcite.linq4j.Linq4j.CollectionEnumerable
- 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 - org.apache.calcite.sql.SqlKind
-
The "CONTAINS" operator for periods.
- CONTAINS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- 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.runtime.AbstractImmutableList
- containsAnd(SqlNode) - Method in class org.apache.calcite.sql.fun.SqlBetweenOperator.AndFinder
- containsAvgStddevVarCall(List<AggregateCall>) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Returns whether any of the aggregates are calls to AVG, STDDEV_*, VAR_*.
- containsCorrelation(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether an expression contains a
RexCorrelVariable
. - containsDistinctCall() - Method in class org.apache.calcite.rel.core.Aggregate
-
Returns whether any of the aggregates are DISTINCT.
- containsFalse(Iterable<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
- containsFieldAccess(RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a given tree contains any
RexFieldAccess
nodes. - containsGet(RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil
- 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. - containsInOperator(SqlNode) - Static method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
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.linq4j.EnumerableDefaults.WrapMap
- containsKey(Object) - Method in class org.apache.calcite.linq4j.LookupImpl
- 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.
- containsKey(ImmutableBitSet) - Method in class org.apache.calcite.profile.ProfilerImpl.Run
- containsKey(ImmutableBitSet, boolean) - Method in class org.apache.calcite.profile.SimpleProfiler.Run
-
Returns whether a set of column ordinals matches or contains a unique key.
- containsLimit(DruidQuery.QuerySpec) - Static method in class org.apache.calcite.adapter.druid.DruidQuery.DruidQueryNode
- 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(SelectScope, SqlNodeList) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Returns whether any of the given expressions are sorted.
- 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.
- containsMultisetOrWindowedAgg(Calc) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Predicate for whether a
Calc
contains multisets or windowed aggregates. - containsMultisetOrWindowedAgg(Filter) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Predicate for whether a
Filter
contains multisets or windowed aggregates. - containsMultisetOrWindowedAgg(Project) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Predicate for whether a
Project
contains multisets or windowed aggregates. - 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).
- containsNull - Variable in class org.apache.calcite.adapter.clone.ColumnLoader.ValueSet
- containsNull(List<Comparable>) - Method in class org.apache.calcite.rex.RexInterpreter
- 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.
- containsNullableFields(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Determines whether any of the fields in a given relational expression may contain null values, taking into account constraints on the field types and also deduced predicates.
- containsNullLiteral(SqlNodeList) - Static method in class org.apache.calcite.sql2rel.SqlToRelConverter
- containsOnlyConjunctions(RexNode) - Method in class org.apache.calcite.adapter.pig.PigFilter
- containsOuter() - Method in class org.apache.calcite.rel.rules.MultiJoin
- containsOver(List<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.
- containsRowArg(List<SqlNode>) - Method in class org.apache.calcite.sql.SqlFunction
- containsShallow(T[], RelTrait) - Static method in class org.apache.calcite.plan.RelTraitSet
-
Returns whether an element occurs within an array.
- 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. - 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.
- containsTrue(Iterable<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
- 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
- containsUsedDefinedFunction - Variable in class org.apache.calcite.adapter.jdbc.JdbcRules.CheckingUserDefinedFunctionVisitor
- containsUserDefinedFunction() - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.CheckingUserDefinedFunctionVisitor
- containsValue(Object) - Method in class org.apache.calcite.linq4j.LookupImpl
- containsValue(Object) - Method in class org.apache.calcite.util.CompositeMap
- content(String) - Method in class org.apache.calcite.util.XmlOutput
-
Writes content.
- Content(List<? extends ArrayTable.Column>, int, int) - Constructor for class org.apache.calcite.adapter.clone.ArrayTable.Content
-
Deprecated.
- Content(List<? extends ArrayTable.Column>, int, Iterable<? extends RelCollation>) - Constructor for class org.apache.calcite.adapter.clone.ArrayTable.Content
- contentQueue - Variable in class org.apache.calcite.adapter.csv.CsvStreamReader
- contentQueue - Variable in class org.apache.calcite.adapter.csv.CsvStreamReader.CsvContentListener
- contents - Variable in class org.apache.calcite.util.ImmutableNullableList.Builder
- context - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- context - Variable in class org.apache.calcite.interpreter.FilterNode
- context - Variable in class org.apache.calcite.interpreter.JoinNode
- context - Variable in class org.apache.calcite.interpreter.ProjectNode
- context - Variable in class org.apache.calcite.materialize.Lattice.SqlWriter
- 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.rel2sql.SqlImplementor.Builder
- context - Variable in class org.apache.calcite.rex.RexChecker
- context - Variable in class org.apache.calcite.sql2rel.RelDecorrelator
- context - Variable in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- context - Variable in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- 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(DataContext) - Constructor for class org.apache.calcite.interpreter.Context
- 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 - org.apache.calcite.util.BuiltInMethod
- CONTEXT_VALUES - org.apache.calcite.util.BuiltInMethod
- ContextImpl(CalciteConnectionImpl) - Constructor for class org.apache.calcite.jdbc.CalciteConnectionImpl.ContextImpl
- ContextImpl(SqlDialect.DatabaseProduct, String, String, int, int, String, NullCollation, RelDataTypeSystem, JethroDataSqlDialect.JethroInfo) - Constructor for class org.apache.calcite.sql.SqlDialect.ContextImpl
- contexts - Variable in class org.apache.calcite.plan.Contexts.ChainContext
- Contexts - Class in org.apache.calcite.plan
-
Utilities for
Context
. - Contexts() - Constructor for class org.apache.calcite.plan.Contexts
- Contexts.ChainContext - Class in org.apache.calcite.plan
-
Context that wraps a chain of contexts.
- Contexts.EmptyContext - Class in org.apache.calcite.plan
-
Empty context.
- Contexts.WrapContext - Class in org.apache.calcite.plan
-
Context that wraps an object.
- contextVariableNames - Variable in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
- Continue - 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.
- contractVertices(HepRelVertex, HepRelVertex, List<HepRelVertex>) - Method in class org.apache.calcite.plan.hep.HepPlanner
- ControlFlowException - Exception 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 org.apache.calcite.util.ControlFlowException
- convention - Variable in class org.apache.calcite.adapter.jdbc.JdbcSchema
- Convention - Interface in org.apache.calcite.plan
-
Calling convention trait.
- 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.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 the convention trait.
- ConventionTraitDef() - Constructor for class org.apache.calcite.plan.ConventionTraitDef
- ConventionTraitDef.ConversionData - Class in org.apache.calcite.plan
-
Workspace for converting from one convention to another.
- conversionCache - Variable in class org.apache.calcite.plan.ConventionTraitDef
-
Weak-key cache of RelOptPlanner to ConversionData.
- ConversionData() - Constructor for class org.apache.calcite.plan.ConventionTraitDef.ConversionData
- conversionGraph - Variable in class org.apache.calcite.plan.ConventionTraitDef.ConversionData
- ConversionUtil - Class in org.apache.calcite.util
-
Utility functions for converting from one type to another
- ConversionUtil() - Constructor for class org.apache.calcite.util.ConversionUtil
- convert(Object) - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleEnumerator
- convert(Object, Class) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchEnumerators
- convert(Object, Class) - Static method in class org.apache.calcite.adapter.geode.util.GeodeUtils
- convert(Object, Class) - Static method in class org.apache.calcite.adapter.mongodb.MongoEnumerator
- convert(String, Column) - Static method in class org.apache.calcite.adapter.tpcds.TpcdsSchema
- convert(CsvFieldType, String) - Method in class org.apache.calcite.adapter.csv.CsvEnumerator.RowConverter
- 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.RexToLixTranslator
- convert(Expression, Type, Type) - Static method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- convert(RelOptPlanner, RelNode, Convention, boolean) - Method in class org.apache.calcite.plan.ConventionTraitDef
- 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(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(LogicalFilter, CassandraTableScan) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraFilterRule
- convert(LogicalFilter, GeodeTableScan) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeFilterRule
- 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.ElasticsearchRules.ElasticsearchAggregateRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.ElasticsearchFilterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.ElasticsearchProjectRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.ElasticsearchSortRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchToEnumerableConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableBindable.EnumerableToBindableConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCalcRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCollectRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCorrelateRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableFilterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableInterpreterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableIntersectRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableJoinRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMergeJoinRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableMinusRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableProjectRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableSemiJoinRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableSortRule
- 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.EnumerableUncollectRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableUnionRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableValuesRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindowRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeAggregateRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeProjectRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.geode.rel.GeodeToEnumerableConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcAggregateRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcCalcRule
- 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.MongoRules.MongoAggregateRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.mongodb.MongoRules.MongoFilterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.mongodb.MongoRules.MongoProjectRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.mongodb.MongoRules.MongoSortRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.mongodb.MongoToEnumerableConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.pig.PigRules.PigAggregateRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.pig.PigRules.PigFilterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.pig.PigRules.PigJoinRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.pig.PigRules.PigProjectRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.pig.PigRules.PigTableScanRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.pig.PigToEnumerableConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.spark.EnumerableToSparkConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.spark.JdbcToSparkConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.spark.SparkRules.EnumerableToSparkConverterRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.spark.SparkRules.SparkCalcRule
- convert(RelNode) - Method in class org.apache.calcite.adapter.spark.SparkRules.SparkToEnumerableConverterRule
- 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.BindableProjectRule
- convert(RelNode) - Method in class org.apache.calcite.interpreter.Bindables.BindableSortRule
- convert(RelNode) - Method in class org.apache.calcite.interpreter.Bindables.BindableUnionRule
- 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(PrecedenceClimbingParser.Token) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- convert(Elements) - Method in class org.apache.calcite.adapter.file.FileRowConverter.FieldDef
- Convert - org.apache.calcite.linq4j.tree.ExpressionType
-
A cast or conversion operation, such as
(SampleType) obj
in Java. - CONVERT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- convert_(CalcitePrepare.Context, String, boolean, boolean, CalciteCatalogReader, SqlValidator, SqlNode) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- 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.
- 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
- convertArguments(RelDataTypeFactory, List<SqlNode>, Function, SqlIdentifier, boolean) - Static method in class org.apache.calcite.sql.validate.SqlUserDefinedTableMacro
-
Converts arguments from
SqlNode
to java object format. - convertArray(SqlRexContext, SqlArrayValueConstructor, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- 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(RexToSqlNodeConverter, RexCall) - Method in class org.apache.calcite.rex.RexSqlStandardConvertletTable.EquivConvertlet
- 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.AvgVarianceConvertlet
- convertCall(SqlRexContext, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Converts a call to an operator into a
RexCall
to the same operator. - convertCall(SqlRexContext, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable.FloorCeilConvertlet
- convertCall(SqlRexContext, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable.GreatestConvertlet
- convertCall(SqlRexContext, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable.RegrCovarianceConvertlet
- convertCall(SqlRexContext, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable.TimestampAddConvertlet
- convertCall(SqlRexContext, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable.TimestampDiffConvertlet
- convertCall(SqlRexContext, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable.TrimConvertlet
- convertCall(SqlRexContext, SqlCall, SqlOperator) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- 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
- 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 - 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, int) - Static method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- convertCursor(SqlToRelConverter.Blackboard, SqlToRelConverter.SubQuery) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertDatetimeMinus(SqlRexContext, SqlDatetimeSubtractionOperator, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertDelete(SqlDelete) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertDynamicParam(SqlDynamicParam) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- CONVERTED - org.apache.calcite.runtime.Hook
-
Called with the output of sql-to-rel-converter.
- convertedInputExprs - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
-
Input expressions for the group columns and aggregates, in
RexNode
format. - converter - Variable in class org.apache.calcite.adapter.file.FileEnumerator
- converter - Variable in class org.apache.calcite.adapter.file.FileTable
- converter - Variable in class org.apache.calcite.rel.convert.TraitMatchingRule
- converter(List<CsvFieldType>, int[]) - Static method in class org.apache.calcite.adapter.csv.CsvEnumerator
- 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.
- converterOperatorMap - Variable in class org.apache.calcite.adapter.druid.DruidQuery
-
This operator map provides DruidSqlOperatorConverter instance to convert a Calcite RexNode to Druid Expression when possible.
- ConverterRelOptRuleOperand(Class<R>, RelTrait, Predicate<? super R>) - Constructor for class org.apache.calcite.plan.RelOptRule.ConverterRelOptRuleOperand
- 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
-
Creates a
ConverterRule
. - 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
-
Creates a
ConverterRule
with a predicate. - ConverterRules() - Constructor for class org.apache.calcite.plan.hep.HepInstruction.ConverterRules
- convertExists(SqlNode, RelOptUtil.SubQueryType, RelOptUtil.Logic, boolean, RelDataType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts an EXISTS or IN predicate into a join.
- convertExpression(SqlNode) - Method in interface org.apache.calcite.sql2rel.InitializerContext
- 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
- convertExpressionList(RexToSqlNodeConverter, List<RexNode>) - Method in class org.apache.calcite.rex.RexSqlStandardConvertletTable
- convertExpressionList(SqlRexContext, List<SqlNode>, SqlOperandTypeChecker.Consistency) - Static method in class org.apache.calcite.sql2rel.StandardConvertletTable
- 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
-
Converts a FROM clause into a relational expression.
- convertFunction(SqlRexContext, SqlFunction, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertGroupSet(SqlValidatorScope, SqlValidatorUtil.GroupAnalyzer, ImmutableList.Builder<ImmutableBitSet>, SqlNode) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Analyzes a GROUPING SETS item in a GROUP BY clause.
- convertGroupToAuxiliaryCalls(SqlCall) - 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).
- convertIdentifier(SqlToRelConverter.Blackboard, SqlIdentifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts an identifier into an expression in a given scope.
- convertIdentifier(SqlToRelConverter.Blackboard, SqlIdentifier, SqlNodeList) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- 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
- convertInToOr(SqlToRelConverter.Blackboard, List<RexNode>, SqlNodeList, SqlInOperator) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts "x IN (1, 2, ...)" to "x=1 OR x=2 OR ...".
- convertIsDistinctFrom(SqlRexContext, SqlCall, boolean) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertJdbc(SqlRexContext, SqlJdbcFunctionCall, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertJoinCondition(SqlToRelConverter.Blackboard, SqlValidatorNamespace, SqlValidatorNamespace, SqlNode, JoinConditionType, RelNode, RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertJoinType(JoinType) - Static method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertletTable - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- convertletTable - Variable in class org.apache.calcite.prepare.PlannerImpl
- convertletTable - Variable in class org.apache.calcite.rex.RexToSqlNodeConverterImpl
- convertletTable - Variable in class org.apache.calcite.sql2rel.SqlNodeToRexConverterImpl
- convertletTable - Variable in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- convertletTable - Variable in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- 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.
- convertLiteralInValuesList(SqlNode, SqlToRelConverter.Blackboard, RelDataType, int) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertMap(SqlRexContext, SqlMapValueConstructor, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertMatchRecognize(SqlToRelConverter.Blackboard, SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertMerge(SqlMerge) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertMonopole(RelBuilder, Aggregate, List<Integer>, int) - Method in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
-
Converts an aggregate relational expression that contains just one distinct aggregate function (or perhaps several over the same arguments) and no non-distinct aggregate functions.
- convertMultiset(SqlRexContext, SqlMultisetValueConstructor, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertMultisetQuery(SqlRexContext, SqlMultisetQueryConstructor, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertMultisets(List<SqlNode>, SqlToRelConverter.Blackboard) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertNode(RexNode) - Method in interface org.apache.calcite.rex.RexToSqlNodeConverter
- convertNode(RexNode) - Method in class org.apache.calcite.rex.RexToSqlNodeConverterImpl
- convertNonCorrelatedSubQuery(SqlToRelConverter.SubQuery, SqlToRelConverter.Blackboard, RelNode, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Determines if a sub-query is non-correlated and if so, converts it to a constant.
- convertNormalRow(String[]) - Method in class org.apache.calcite.adapter.csv.CsvEnumerator.ArrayRowConverter
- 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
-
Creates an operand for a converter rule.
- 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
- convertOver(SqlToRelConverter.Blackboard, SqlNode) - 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.
- convertOverlapsOperand(SqlRexContext, SqlParserPos, SqlNode) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- convertPlus(SqlRexContext, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- 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.
- convertQueryOrInList(SqlToRelConverter.Blackboard, SqlNode, RelDataType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertQueryRecursive(SqlNode, boolean, RelDataType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Recursively converts a query to a relational expression.
- convertQueryString(List<PredicateAnalyzer.Expression>, PredicateAnalyzer.Expression) - Static method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor
- 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(String[]) - Method in class org.apache.calcite.adapter.csv.CsvEnumerator.ArrayRowConverter
- convertRow(String[]) - Method in class org.apache.calcite.adapter.csv.CsvEnumerator.RowConverter
- convertRow(String[]) - Method in class org.apache.calcite.adapter.csv.CsvEnumerator.SingleColumnRowConverter
- convertRow(SqlRexContext, SqlRowOperator, SqlCall) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
-
Converts a ROW.
- convertRowConstructor(SqlToRelConverter.Blackboard, SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts a row constructor into a relational expression.
- convertRowValues(SqlToRelConverter.Blackboard, SqlNode, Collection<SqlNode>, boolean, RelDataType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- 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, SqlSelect) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Implementation of
SqlToRelConverter.convertSelect(SqlSelect, boolean)
; derived class may override. - convertSelectList(SqlToRelConverter.Blackboard, SqlSelect, List<SqlNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- 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.
- convertSingletonDistinct(RelBuilder, Aggregate, Set<Pair<List<Integer>, Integer>>) - Method in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
-
Converts an aggregate with one distinct aggregate and one or more non-distinct aggregates to multi-phase aggregates (see reference example below).
- convertSortExpression(SqlNode, RelFieldCollation.Direction, RelFieldCollation.NullDirection) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Converts an item in an ORDER BY clause inside a window (OVER) clause, extracting DESC, NULLS LAST and NULLS FIRST flags first.
- convertStreamRow(String[]) - Method in class org.apache.calcite.adapter.csv.CsvEnumerator.ArrayRowConverter
- convertSubQuery(SqlCall, SqlToRelConverter, boolean, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.NoOpSubQueryConverter
- convertSubQuery(SqlCall, SqlToRelConverter, boolean, boolean) - Method in interface org.apache.calcite.sql2rel.SubQueryConverter
-
Converts the sub-query to an equivalent expression.
- convertTableAccess - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- convertTableAccess - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- convertTimeUnit(TimeUnitRange) - Static method in class org.apache.calcite.sql.dialect.HsqldbSqlDialect
- convertTo(Expression, PhysType) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
-
Converts an enumerable of this physical type to an enumerable that uses a given physical type for its rows.
- convertTo(Expression, PhysType) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- 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.
- convertToStruct(RelDataType) - Method in class org.apache.calcite.sql.validate.AbstractNamespace
- convertTypeToSpec(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Converts an instance of RelDataType to an instance of SqlDataTypeSpec.
- convertUpdate(SqlUpdate) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- convertUsing(SqlValidatorNamespace, SqlValidatorNamespace, List<String>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Returns an expression for matching columns of a USING clause or inferred from NATURAL JOIN.
- convertValues(SqlCall, RelDataType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts a SELECT statement's parse tree into a relational expression.
- convertValuesImpl(SqlToRelConverter.Blackboard, SqlCall, RelDataType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts a values clause (as in "INSERT INTO T(x,y) VALUES (1,2)") into a relational expression.
- convertWhere(SqlToRelConverter.Blackboard, SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts a WHERE clause.
- convertWith(SqlWith, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Converts a WITH sub-query into a relational expression.
- coordinatorUrl - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- coordinatorUrl - Variable in class org.apache.calcite.adapter.druid.DruidSchema
- 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
-
Creates a copy of this RelFieldCollation against a different field.
- copy(int, Predicate<PrecedenceClimbingParser.Token>) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- copy(E[], int) - Method in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRule
- copy(Iterable<? extends List<E>>) - Static method in class org.apache.calcite.tools.RelBuilder
-
Converts an iterable of lists into an immutable list of immutable lists with the same contents.
- 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(Function<Lattice.Column, Lattice.Column>) - Method in class org.apache.calcite.materialize.Lattice.Measure
-
Copies this measure, mapping its arguments using a given function.
- copy(List<Integer>) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- 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
-
Creates an equivalent AggregateCall with new argument ordinals.
- 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.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.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.FileTableScan
- 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.jdbc.JdbcRules.JdbcCalc
- 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.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.Match
- 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.Sort
- 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.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.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.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.adapter.elasticsearch.ElasticsearchAggregate
- copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregate
- copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeAggregate
- copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcAggregate
- copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.adapter.mongodb.MongoAggregate
- copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.adapter.pig.PigAggregate
- copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.interpreter.Bindables.BindableAggregate
- copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.rel.core.Aggregate
-
Creates a copy of this aggregate.
- copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.rel.logical.LogicalAggregate
- 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.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, 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.EnumerableSort
- 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.jdbc.JdbcRules.JdbcSort
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.adapter.mongodb.MongoSort
- 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, 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, SemiJoinType) - Method in class org.apache.calcite.adapter.enumerable.EnumerableCorrelate
- copy(RelTraitSet, RelNode, RelNode, CorrelationId, ImmutableBitSet, SemiJoinType) - Method in class org.apache.calcite.rel.core.Correlate
- copy(RelTraitSet, RelNode, RelNode, CorrelationId, ImmutableBitSet, SemiJoinType) - Method in class org.apache.calcite.rel.logical.LogicalCorrelate
- 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.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.logical.LogicalFilter
- 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, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.calcite.adapter.enumerable.EnumerableJoin
- 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.EnumerableSemiJoin
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.calcite.adapter.enumerable.EnumerableThetaJoin
- 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.core.SemiJoin
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.calcite.rel.logical.LogicalJoin
- copy(RelNode, RelDataType, RexNode, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, List<RexNode>, RelCollation, RexNode) - Method in class org.apache.calcite.rel.core.Match
- copy(RelNode, RelDataType, RexNode, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, List<RexNode>, RelCollation, RexNode) - Method in class org.apache.calcite.rel.logical.LogicalMatch
- copy(AbstractMaterializedViewRule.EquivalenceClasses) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.EquivalenceClasses
- copy(RelDataType) - Method in class org.apache.calcite.prepare.RelOptTableImpl
-
Creates a copy of this RelOptTable.
- copy(RelDataType) - Method in class org.apache.calcite.rex.RexCopier
- 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(SqlCall, SqlOperator) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Creates a copy of a call with a new operator.
- 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.
- copyArrayType(RelDataType, boolean) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- copyFilter - Variable in class org.apache.calcite.rel.rules.FilterProjectTransposeRule
- copyFromCollection(Collection<? extends Number>) - Static method in class org.apache.calcite.util.ImmutableIntList
- copyIntervalType(RelDataType, boolean) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- copyMap(Map<K, ? extends SortedSet<V>>) - Static method in class org.apache.calcite.rel.core.Match
-
Creates an immutable map of a map of sorted sets.
- copyMapType(RelDataType, boolean) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- copyMultisetType(RelDataType, boolean) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- copyObjectType(RelDataType, boolean) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- copyOf(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.ImmutableNullableList
-
Returns an immutable list containing the given elements, in order.
- copyOf(Iterable<? extends Number>) - Static method in class org.apache.calcite.util.ImmutableIntList
-
Creates an ImmutableIntList from an iterable of
Number
. - 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(T...) - Static method in class org.apache.calcite.runtime.FlatLists
-
Creates a memory-, CPU- and cache-efficient comparable immutable list, always copying the contents.
- copyOuterJoinInfo(MultiJoin, List<Pair<JoinRelType, RexNode>>, int, List<RelDataTypeField>, List<RelDataTypeField>) - Method in class org.apache.calcite.rel.rules.JoinToMultiJoinRule
-
Copies outer join data from a source MultiJoin to a new set of arrays.
- copyProject - Variable in class org.apache.calcite.rel.rules.FilterProjectTransposeRule
- copyRecordType(RelRecordType, boolean, boolean) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- copySimpleType(RelDataType, boolean) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- 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.
- copyValues(SqlTypeName) - Method in class org.apache.calcite.sql.type.SqlTypeAssignmentRules.Builder
- CorDef(CorrelationId, int) - Constructor for class org.apache.calcite.sql2rel.RelDecorrelator.CorDef
- corDefOutputs - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.Frame
- CoreCompiler(Interpreter, RelOptCluster) - Constructor for class org.apache.calcite.interpreter.Nodes.CoreCompiler
- CorelMap(Multimap<RelNode, RelDecorrelator.CorRef>, SortedMap<CorrelationId, RelNode>, Map<RexFieldAccess, RelDecorrelator.CorRef>) - Constructor for class org.apache.calcite.sql2rel.RelDecorrelator.CorelMap
- CorelMapBuilder() - Constructor for class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
- corr - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.CorDef
- corr - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.CorRef
- CorRef(CorrelationId, int, int) - Constructor for class org.apache.calcite.sql2rel.RelDecorrelator.CorRef
- 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 - org.apache.calcite.sql.SqlKind
-
Reference to correlation variable.
- Correlate - Class in org.apache.calcite.rel.core
-
A relational operator that performs nested-loop joins.
- Correlate(RelOptCluster, RelTraitSet, RelNode, RelNode, CorrelationId, ImmutableBitSet, SemiJoinType) - Constructor for class org.apache.calcite.rel.core.Correlate
-
Creates a Correlate.
- Correlate(RelInput) - Constructor for class org.apache.calcite.rel.core.Correlate
-
Creates a Correlate by parsing serialized output.
- CORRELATE - org.apache.calcite.rel.mutable.MutableRelType
- CORRELATE_JOIN - org.apache.calcite.util.BuiltInMethod
- correlateFactory - Variable in class org.apache.calcite.tools.RelBuilder
- CorrelateFactoryImpl() - Constructor for class org.apache.calcite.rel.core.RelFactories.CorrelateFactoryImpl
- correlateJoin(CorrelateJoinType, Enumerable<TSource>, Function1<TSource, Enumerable<TInner>>, Function2<TSource, TInner, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns elements of
outer
for which there is a member ofinner
with a matching key. - correlateJoin(CorrelateJoinType, Function1<T, Enumerable<TInner>>, Function2<T, TInner, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- correlateJoin(CorrelateJoinType, 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). - CorrelateJoinType - Enum in org.apache.calcite.linq4j
-
Specifies the type of correlation operation: inner, left, semi, or anti.
- CorrelateJoinType() - Constructor for enum org.apache.calcite.linq4j.CorrelateJoinType
- correlates - Variable in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- CorrelationCollector() - Constructor for class org.apache.calcite.plan.RelOptUtil.CorrelationCollector
- 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.
- CorrelationFinder() - Constructor for class org.apache.calcite.rex.RexUtil.CorrelationFinder
- 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(int, String) - 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
- 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.
- CorrelationReferenceFinder.MyRexVisitor - Class in org.apache.calcite.sql2rel
-
Replaces alternative names of correlation variable to its canonical name.
- CorrelationUse(CorrelationId, ImmutableBitSet, RelNode) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.CorrelationUse
- correlTableMap - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor
- corrIdGenerator - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
- corrVars - Variable in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- 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 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- cost - Variable in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.Vertex
- COST_IMPROVEMENT - Static variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
- 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 - Variable in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- costFactory - Variable in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- 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 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- couldImplement(Method, Method) - Static method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
- count - Variable in class org.apache.calcite.adapter.elasticsearch.Scrolling.SequentialIterator
- count - Variable in class org.apache.calcite.linq4j.tree.BlockBuilder.Slot
- count - Variable in class org.apache.calcite.piglet.Ast.LimitStmt
- count - Variable in class org.apache.calcite.profile.ProfilerImpl.SurpriseQueue
- count - Variable in class org.apache.calcite.rel.type.RelDataTypeImpl.Slot
- 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 class org.apache.calcite.linq4j.Linq4j.CollectionEnumerable
- count() - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope.Resolved
- count() - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.ResolvedImpl
- count(boolean[]) - Static method in class org.apache.calcite.rel.rules.CalcRelSplitter
-
Returns the number of bits set in an array.
- 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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- count(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- count(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- count(FunctionExpression<Predicate1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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 - org.apache.calcite.adapter.pig.PigAggFunction
- COUNT - 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 - org.apache.calcite.adapter.pig.PigAggFunction
- CountAccumulator(AggregateCall) - Constructor for class org.apache.calcite.interpreter.AggregateNode.CountAccumulator
- countBits(long[]) - Static method in class org.apache.calcite.util.ImmutableBitSet
- CountImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.CountImplementor
- 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. - countMap - Variable in class org.apache.calcite.util.graph.TopologicalOrderIterator
- countQuotesIn(String) - Method in class org.apache.calcite.runtime.Resources.Inst
- 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. - countTrivial(List<RexLocalRef>) - Static method in class org.apache.calcite.rex.RexProgram
-
Returns the number of expressions at the front of an array which are simply projections of the same field.
- CountWinImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.CountWinImplementor
- COVAR_AVG_AGG_FUNCTIONS - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of SqlCovarAggFunction.
- COVAR_POP - org.apache.calcite.sql.fun.SqlCovarAggFunction.Subtype
-
Deprecated.
- COVAR_POP - 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 - org.apache.calcite.sql.fun.SqlCovarAggFunction.Subtype
-
Deprecated.
- COVAR_SAMP - 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 - Variable in class org.apache.calcite.plan.volcano.VolcanoCost
- 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.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<?>) - 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(Class<T>) - Static method in class org.apache.calcite.runtime.Resources
-
Creates an instance of the resource object, using the class's name as the name of the resource file.
- 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, Class<T>) - Static method in class org.apache.calcite.runtime.Resources
-
Creates an instance of the resource object.
- create(String, Resources.PropertyAccessor, Class<T>) - Static method in class org.apache.calcite.runtime.Resources
- 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(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(Properties, Class<T>) - Static method in class org.apache.calcite.runtime.Resources
-
Creates an instance of the resource object that can access properties but not resources.
- create(DruidSchema, String, List<Interval>, Map<String, SqlTypeName>, Set<String>, String, Map<String, List<ComplexMetric>>) - Static method in class org.apache.calcite.adapter.druid.DruidTable
-
Creates a
DruidTable
by copying the given parameters. - create(DruidSchema, String, List<Interval>, Map<String, SqlTypeName>, Set<String>, String, DruidConnectionImpl, Map<String, List<ComplexMetric>>) - Static method in class org.apache.calcite.adapter.druid.DruidTable
-
Creates a
DruidTable
by using the givenDruidConnectionImpl
to populate the other parameters. - create(PredicateAnalyzer.TerminalExpression) - Static method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- create(ColumnMetaData.AvaticaType, Iterable<Object>) - Method in class org.apache.calcite.jdbc.CalciteResultSet
- create(Compiler, TableScan, ImmutableList<RexNode>, ImmutableIntList) - Static method in class org.apache.calcite.interpreter.TableScanNode
-
Creates a TableScanNode.
- 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(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) - 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, RelOptTable, DruidTable, List<Interval>, List<RelNode>, Map<SqlOperator, DruidSqlOperatorConverter>) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Creates a DruidQuery.
- 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(RelOptSchema, RelDataType, List<String>, Expression) - Static method in class org.apache.calcite.prepare.RelOptTableImpl
- 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(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) - 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(ProfilerImpl.Space, int) - Static method in class org.apache.calcite.profile.ProfilerImpl.Collector
-
Creates an initial collector of the appropriate kind.
- create(MetadataDef<M>) - Method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- create(MetadataHandler, ImmutableList<Method>) - Static method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider.Space2
- create(MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRuleCall
-
Creates a
SubstitutionVisitor.UnifyRuleCall
based on the parent ofquery
. - 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>, List<String>) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableProject
- create(RelNode, List<? extends RexNode>, List<String>) - Static method in class org.apache.calcite.rel.logical.LogicalProject
-
Creates a LogicalProject.
- 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<? extends RexNode>, RelDataType) - Static method in class org.apache.calcite.rel.logical.LogicalProject
-
Creates a LogicalProject, specifying row type rather than field names.
- 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, CorrelationId, ImmutableBitSet, SemiJoinType) - Static method in class org.apache.calcite.rel.logical.LogicalCorrelate
-
Creates a LogicalCorrelate.
- create(RelNode, RelNode, RexLiteral, ImmutableIntList, ImmutableIntList, JoinRelType) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableMergeJoin
- create(RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Static method in class org.apache.calcite.rel.logical.LogicalJoin
-
Creates a LogicalJoin.
- create(RelNode, RelNode, 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, RexNode, JoinRelType, Set<String>) - Static method in class org.apache.calcite.rel.logical.LogicalJoin
-
Deprecated.
- create(RelNode, RelNode, RexNode, JoinRelType, Set<String>, boolean, ImmutableList<RelDataTypeField>) - Static method in class org.apache.calcite.rel.logical.LogicalJoin
-
Deprecated.
- create(RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableSemiJoin
-
Creates an EnumerableSemiJoin.
- create(RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList) - Static method in class org.apache.calcite.rel.core.SemiJoin
-
Creates a SemiJoin.
- create(RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList, Set<CorrelationId>, JoinRelType) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableJoin
-
Creates an EnumerableJoin.
- create(RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList, JoinRelType, Set<String>) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableJoin
-
Deprecated.
- create(RelNode, RelDataType, RexNode, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, List<RexNode>, RelCollation, RexNode) - Static method in class org.apache.calcite.rel.logical.LogicalMatch
-
Creates a LogicalMatch.
- 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, ImmutableSet<CorrelationId>) - Static method in class org.apache.calcite.rel.logical.LogicalFilter
-
Creates a LogicalFilter.
- create(RelNode, RexNode, RexNode) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableLimit
-
Creates an EnumerableLimit.
- 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, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Static method in class org.apache.calcite.rel.logical.LogicalAggregate
-
Creates a LogicalAggregate.
- create(RelDataTypeFactory, RexCall, List<RelCollation>) - Static method in class org.apache.calcite.rex.RexCallBinding
-
Creates a binding of the appropriate type.
- create(RelDataType, List<? extends RexNode>, RexNode, List<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(Resources.PropertyAccessor, Class<T>) - Static method in class org.apache.calcite.runtime.Resources
-
Creates an instance of the resource object that can access properties but not resources.
- create(Path) - Static method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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.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(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.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.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.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, RelDataType) - Method in class org.apache.calcite.adapter.druid.DruidTableFactory
- 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(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
-
Creates an AggregateCall, inferring its type if
type
is null. - create(SqlAggFunction, boolean, boolean, List<Integer>, int, RelCollation, RelDataType, String) - Static method in class org.apache.calcite.rel.core.AggregateCall
-
Creates an AggregateCall.
- 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(SqlIdentifier, SqlIdentifier, SqlNodeList, SqlNodeList, SqlLiteral, SqlNode, SqlNode, SqlLiteral, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlWindow
- create(SqlNode, RexNode) - Static method in class org.apache.calcite.rex.RexWindowBound
-
Creates window bound.
- create(SqlValidatorScope, int, SqlValidatorNamespace, SqlIdentifier) - Static method in class org.apache.calcite.sql.validate.SqlQualified
- 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(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(Source, Map<String, Object>) - Static method in class org.apache.calcite.adapter.file.FileTable
-
Creates a FileTable.
- create_(RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Static method in class org.apache.calcite.rel.logical.LogicalAggregate
- CREATE_ENRICHER - org.apache.calcite.util.BuiltInMethod
- CREATE_EXCEPTION - org.apache.calcite.runtime.Resources.Validation
-
Checks that it is possible to create an exception.
- CREATE_FOREIGN_SCHEMA - org.apache.calcite.sql.SqlKind
-
CREATE FOREIGN SCHEMA
DDL statement. - CREATE_FUNCTION - org.apache.calcite.sql.SqlKind
-
CREATE FUNCTION
DDL statement. - CREATE_INDEX - org.apache.calcite.sql.SqlKind
-
CREATE INDEX
DDL statement. - CREATE_MATERIALIZATION - org.apache.calcite.runtime.Hook
-
Called when materialization is created.
- CREATE_MATERIALIZATIONS - org.apache.calcite.config.CalciteConnectionProperty
-
Whether Calcite should create materializations.
- CREATE_MATERIALIZED_VIEW - org.apache.calcite.sql.SqlKind
-
CREATE MATERIALIZED VIEW
DDL statement. - CREATE_RDD - org.apache.calcite.adapter.spark.SparkMethod
- CREATE_SCHEMA - org.apache.calcite.sql.SqlKind
-
CREATE SCHEMA
DDL statement. - CREATE_SEQUENCE - org.apache.calcite.sql.SqlKind
-
CREATE SEQUENCE
DDL statement. - CREATE_TABLE - org.apache.calcite.sql.SqlKind
-
CREATE TABLE
DDL statement. - CREATE_TYPE - org.apache.calcite.sql.SqlKind
-
CREATE TYPE
DDL statement. - CREATE_VIEW - org.apache.calcite.sql.SqlKind
-
CREATE VIEW
DDL statement. - createAggImpl(SqlToRelConverter.Blackboard, SqlToRelConverter.AggConverter, SqlNodeList, SqlNodeList, SqlNode, List<SqlNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- createAggregate(RelNode, boolean, ImmutableBitSet, ImmutableList<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.adapter.pig.PigRelFactories.PigAggregateFactory
- createAggregate(RelNode, boolean, ImmutableBitSet, ImmutableList<ImmutableBitSet>, List<AggregateCall>) - Method in interface org.apache.calcite.rel.core.RelFactories.AggregateFactory
-
Creates an aggregate.
- createAggregate(RelNode, boolean, ImmutableBitSet, ImmutableList<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.rel.core.RelFactories.AggregateFactoryImpl
- createAggregate(SqlToRelConverter.Blackboard, ImmutableBitSet, ImmutableList<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Creates an Aggregate.
- createAggregateCallWithBinding(RelDataTypeFactory, SqlAggFunction, RelDataType, Aggregate, AggregateCall, int, int) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
- createAll(Class<?>) - Static method in class org.apache.calcite.schema.impl.ScalarFunctionImpl
-
Creates
ScalarFunction
for each method in a given class. - 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.
- createAllPossibleExpressions(RexBuilder, RexNode, ImmutableBitSet, Map<RexInputRef, Set<RexNode>>, Map<RexInputRef, RexNode>) - Static method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
- 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
- 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(SqlParserPos, List<? extends SqlNode>) - Method in class org.apache.calcite.sql.SqlOperator
-
Creates a call to this operand with a list of operands.
- createCall(SqlParserPos, SqlNode...) - Method in interface org.apache.calcite.sql.SqlJdbcFunctionCall.MakeCall
-
Creates and return a
SqlCall
. - createCall(SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall.PermutingMakeCall
- 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 operand with an array of operands.
- createCall(SqlIdentifier, SqlParserPos, SqlFunctionCategory, SqlLiteral, Iterable<? extends SqlNode>) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Creates a call.
- createCall(SqlIdentifier, SqlParserPos, SqlFunctionCategory, SqlLiteral, SqlNode[]) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Creates a call.
- 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.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.SqlJsonValueFunction
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.fun.SqlTrimFunction
- 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.SqlOperator
-
Creates a call to this operand 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.SqlWindow.SqlWindowOperator
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.SqlWith.SqlWithOperator
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.calcite.sql.SqlWithItem.SqlWithItemOperator
- createCall(SqlNodeList) - Method in class org.apache.calcite.sql.SqlOperator
-
Creates a call to this operand with a list of operands contained in a
SqlNodeList
. - createCall(SqlNodeList, SqlNodeList, SqlNode, SqlNode, SqlNodeList, SqlNode, SqlNodeList, SqlNodeList, SqlNode, SqlNode, SqlParserPos) - Method in class org.apache.calcite.sql.SqlSelectOperator
-
Creates a call to the
SELECT
operator. - createCaseExpression(RexInputRef, RexLiteral, RexNode) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationRexShuttle
- 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.
- createCatalogReader() - Method in class org.apache.calcite.prepare.PlannerImpl
- 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.
- 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
- createCloneTable(QueryProvider, QueryableTable, String) - 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.
- createContext() - Method in interface org.apache.calcite.interpreter.Compiler
- createContext() - Method in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
- createConvertletTable() - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Factory method for default convertlet table.
- createCopyHook() - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- 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, CorrelationId, ImmutableBitSet, SemiJoinType) - Method in interface org.apache.calcite.rel.core.RelFactories.CorrelateFactory
-
Creates a correlate.
- createCorrelate(RelNode, RelNode, CorrelationId, ImmutableBitSet, SemiJoinType) - Method in class org.apache.calcite.rel.core.RelFactories.CorrelateFactoryImpl
- createCredentials(Map<String, Object>) - Method in class org.apache.calcite.adapter.mongodb.MongoSchemaFactory
- 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)
. - createCursor(ColumnMetaData.AvaticaType, Iterable) - Method in class org.apache.calcite.jdbc.CalciteResultSet
- createDataContext(Connection, SchemaPlus) - Static method in class org.apache.calcite.schema.Schemas
- createDataContext(Map<String, Object>, CalciteSchema) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- 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
-
Infers the return type of a decimal multiplication.
- createDecimalProduct(RelDataType, RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
-
Infers the return type of a decimal multiplication.
- createDecimalQuotient(RelDataType, RelDataType) - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Infers the return type of a decimal division.
- createDecimalQuotient(RelDataType, RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
-
Rules: Let p1, s1 be the precision and scale of the first operand Let p2, s2 be the precision and scale of the second operand Let p, s be the precision and scale of the result Let d be the number of whole digits in the result Then the result type is a decimal with: d = p1 - s1 + s2 s < max(6, s1 + p2 + 1) p = d + s p and s are capped at their maximum values
- createDefault(String) - Static method in class org.apache.calcite.adapter.druid.TimeExtractionFunction
-
Creates the default time format extraction function.
- createDerivedColumnOrigins(Set<RelColumnOrigin>) - Method in class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- 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.
- createDoublePrecisionType() - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- createDriverVersion() - Method in class org.apache.calcite.adapter.splunk.SplunkDriver
- createDriverVersion() - Method in class org.apache.calcite.jdbc.Driver
- createEdge(LatticeSuggester.TableRef, LatticeSuggester.TableRef) - Method in class org.apache.calcite.materialize.LatticeSuggester.StepRef.Factory
- createEdge(LatticeSuggester.TableRef, LatticeSuggester.TableRef, Object...) - Method in class org.apache.calcite.materialize.LatticeSuggester.StepRef.Factory
- createEdge(LatticeTable, LatticeTable) - Method in class org.apache.calcite.materialize.Step.Factory
- createEdge(LatticeTable, LatticeTable, Object...) - Method in class org.apache.calcite.materialize.Step.Factory
- 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.
- createEmptyResultSet(Class<E>) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- 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. - createEnumerable(Compiler, TableScan, Enumerable<Row>, ImmutableIntList, List<RexNode>, ImmutableIntList) - Static method in class org.apache.calcite.interpreter.TableScanNode
- 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 a Exchange.
- createExchange(RelNode, RelDistribution) - Method in class org.apache.calcite.rel.core.RelFactories.ExchangeFactoryImpl
- 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. - createExpressions(RexBuilder, RexNode, ImmutableBitSet, Map<RexInputRef, Set<RexNode>>, Map<RexInputRef, RexNode>, Set<RexNode>) - Static method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
- 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.
- createFilter(SubstitutionVisitor.UnifyRuleCall, MutableFilter, MutableFilter) - Method in class org.apache.calcite.plan.SubstitutionVisitor.FilterToFilterUnifyRule
- 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) - Method in class org.apache.calcite.adapter.pig.PigRelFactories.PigFilterFactory
- 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
-
Creates a filter.
- createFilter(RelNode, RexNode) - Method in class org.apache.calcite.rel.core.RelFactories.FilterFactoryImpl
- createFilter(RelNode, RexNode, RelFactories.FilterFactory) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createFilterable(Compiler, TableScan, ImmutableList<RexNode>, ImmutableIntList, FilterableTable) - Static method in class org.apache.calcite.interpreter.TableScanNode
- 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.
- createFunctionMap() - Method in class org.apache.calcite.adapter.java.ReflectiveSchema
- 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.
- createGraphFromExpression(List<RexNode>) - Method in class org.apache.calcite.rel.rules.ProjectToWindowRule.WindowedAggRelSplitter
- createGroupExpr() - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.GroupAnalyzer
- createHandler() - Static method in class org.apache.calcite.jdbc.CalcitePrepare.Dummy
- 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(Method) - Static method in class org.apache.calcite.schema.impl.ScalarFunctionImpl
- createImplementor(Method) - Static method in class org.apache.calcite.schema.impl.TableFunctionImpl
- createImplementor(NotNullImplementor, NullPolicy, boolean) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- createInsertBlackboard(RelOptTable, RexNode, List<String>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Creates a blackboard for translating the expressions of generated columns in an INSERT statement.
- 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, RexNode, Set<CorrelationId>, JoinRelType, boolean) - Method in class org.apache.calcite.adapter.pig.PigRelFactories.PigJoinFactory
- createJoin(RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType, boolean) - Method in interface org.apache.calcite.rel.core.RelFactories.JoinFactory
-
Creates a join.
- createJoin(RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType, boolean) - Method in class org.apache.calcite.rel.core.RelFactories.JoinFactoryImpl
- createJoin(RelNode, RelNode, RexNode, JoinRelType, Set<String>, boolean) - Method in class org.apache.calcite.adapter.pig.PigRelFactories.PigJoinFactory
- createJoin(RelNode, RelNode, RexNode, JoinRelType, Set<String>, boolean) - Method in interface org.apache.calcite.rel.core.RelFactories.JoinFactory
-
Deprecated.
- createJoin(RelNode, RelNode, RexNode, JoinRelType, Set<String>, boolean) - Method in class org.apache.calcite.rel.core.RelFactories.JoinFactoryImpl
- createJoin(SqlToRelConverter.Blackboard, RelNode, RelNode, RexNode, JoinRelType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- createJoinSubtree(RelMetadataQuery, RelBuilder, LoptMultiJoin, LoptJoinTree, LoptJoinTree, RexNode, JoinRelType, List<RexNode>, boolean, boolean) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Creates a LogicalJoin given left and right operands and a join condition.
- 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.rel.core.Join
-
Deprecated.
- 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.
- createLeftCall(SqlOperator, List<SqlNode>) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- 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
- createMatch(RelNode, RexNode, RelDataType, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, List<RexNode>, RelCollation, RexNode) - Method in interface org.apache.calcite.rel.core.RelFactories.MatchFactory
-
Creates a
Match
. - createMatch(RelNode, RexNode, RelDataType, boolean, boolean, Map<String, RexNode>, Map<String, RexNode>, RexNode, Map<String, ? extends SortedSet<String>>, boolean, List<RexNode>, RelCollation, RexNode) - Method in class org.apache.calcite.rel.core.RelFactories.MatchFactoryImpl
- createMatchRecognizeNameSpace(SqlMatchRecognize, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- createMaterializations() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- 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.
- 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.
- createModify(RelOptTable, RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Creates a relational expression to modify a table or modifiable view.
- 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".
- createName(int) - Static method in class org.apache.calcite.rex.RexLocalRef
- 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.
- createOrdering(RelMetadataQuery, RelBuilder, LoptMultiJoin, LoptSemiJoinOptimizer, int) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Generates a join tree with a specific factor as the first factor in the join tree
- createOverCall(SqlAggFunction, List<SqlNode>, SqlWindow) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- createParser(String) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Factory method for default SQL parser.
- createParser(String, SqlParser.ConfigBuilder) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Factory method for SQL parser with a given configuration.
- createParserConfig() - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Factory method for SQL parser configuration.
- createPaths(LatticeSpace) - Method in class org.apache.calcite.materialize.LatticeRootNode
- createPathsRecurse(LatticeSpace, List<Step>, List<Path>) - Method in class org.apache.calcite.materialize.LatticeNode
- createPdxType(PdxInstance) - Method in class org.apache.calcite.adapter.geode.util.JavaTypeFactoryExtImpl
- createPdxType2(PdxInstance) - Method in class org.apache.calcite.adapter.geode.util.JavaTypeFactoryExtImpl
- 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.
- createPlanner(HepProgram) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- createPlannerFactories() - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Creates a collection of planner factories.
- createPolicyMap() - Static method in class org.apache.calcite.plan.Strong
- createPreceding(SqlNode, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlWindow
- createPrepareContext() - Method in interface org.apache.calcite.jdbc.CalciteConnection
-
Creates a context for preparing a statement for execution.
- createPrepareContext() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerStatementImpl
- createPrepareContext() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- 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
- createProgram(Filter) - Method in class org.apache.calcite.rel.rules.FilterMergeRule
-
Creates a RexProgram corresponding to a LogicalFilter
- createProgramForLevel(int, int, RelDataType, RexNode[], int[], int[], int[], int, RelDataType) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter
-
Creates a program containing the expressions for a given level.
- 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<String>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createProject(RelNode, List<? extends RexNode>, List<String>) - Method in interface org.apache.calcite.rel.core.RelFactories.ProjectFactory
-
Creates a project.
- createProject(RelNode, List<? extends RexNode>, List<String>) - Method in class org.apache.calcite.rel.core.RelFactories.ProjectFactoryImpl
- createProject(RelNode, List<? extends RexNode>, List<String>, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createProject(RelNode, List<? extends RexNode>, List<String>, boolean, RelBuilder) - 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<Pair<RexNode, 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
- createProjectableFilterable(Compiler, TableScan, ImmutableList<RexNode>, ImmutableIntList, ProjectableFilterableTable) - Static method in class org.apache.calcite.interpreter.TableScanNode
- 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
- 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.
- createProjectWithAdditionalExprs(RelNode, List<Pair<RexNode, String>>) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Projects all
input
output fields plus the additional expressions. - createQuery(String, String, String, List<String>) - Method in class org.apache.calcite.adapter.splunk.SplunkTable.SplunkTableQueryable
- createQuery(Expression, Class<T>) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- 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 class org.apache.calcite.jdbc.CalciteConnectionImpl
- 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
- createQueryable(Compiler, TableScan, ImmutableList<RexNode>, ImmutableIntList, QueryableTable) - Static method in class org.apache.calcite.interpreter.TableScanNode
- 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.
- 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
- createRelDataType(Object) - Static method in class org.apache.calcite.adapter.geode.util.GeodeUtils
- createRename(RelNode, List<String>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createRenameRel(RelDataType, RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- createReplacementJoin(RelBuilder, LoptMultiJoin, LoptSemiJoinOptimizer, LoptJoinTree, int, int, ImmutableIntList, Integer[], List<RexNode>) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Creates a replacement join, projecting either dummy columns or replacement keys from the factor that doesn't actually need to be joined.
- createReplacementSemiJoin(RelBuilder, LoptMultiJoin, LoptSemiJoinOptimizer, LoptJoinTree, int, List<RexNode>) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
In the event that a dimension table does not need to be joined because of a semijoin, this method creates a join tree that consists of a projection on top of an existing join tree.
- createResultSet(Map<String, Object>, List<ColumnMetaData>, Meta.CursorFactory, Meta.Frame) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- createResultSet(Enumerable<E>, Class, String...) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- createRexBuilder() - Method in class org.apache.calcite.prepare.PlannerImpl
- 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.
- createRows(Compiler, ImmutableList<ImmutableList<RexLiteral>>) - Method in class org.apache.calcite.interpreter.ValuesNode
- createSample(SqlSampleSpec, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Creates a literal which represents a sample specification.
- createScan(RelOptCluster, RelOptTable) - Method in class org.apache.calcite.adapter.pig.PigRelFactories.PigTableScanFactory
- createScan(RelOptCluster, RelOptTable) - Method in interface org.apache.calcite.rel.core.RelFactories.TableScanFactory
-
Creates a
TableScan
. - createScan(RelOptCluster, RelOptTable) - Method in class org.apache.calcite.rel.core.RelFactories.TableScanFactoryImpl
- createScannable(Compiler, TableScan, ImmutableList<RexNode>, ImmutableIntList, ScannableTable) - Static method in class org.apache.calcite.interpreter.TableScanNode
- createSchema(SqlParserPos, boolean, boolean, SqlIdentifier) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a CREATE SCHEMA.
- createSelectDistinct(RelBuilder, Aggregate, List<Integer>, int, Map<Integer, Integer>) - Method in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
-
Given an
Aggregate
and the ordinals of the arguments to a particular call to an aggregate function, creates a 'select distinct' relational expression which projects the group columns and those arguments but nothing else. - 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
-
Creates a semi-join.
- createSemiJoin(RelNode, RelNode, RexNode) - Method in class org.apache.calcite.rel.core.RelFactories.SemiJoinFactoryImpl
- createSet() - Method in interface org.apache.calcite.sql.validate.SqlNameMatcher
-
Creates a set that has the same case-sensitivity as this matcher.
- createSet() - Method in class org.apache.calcite.sql.validate.SqlNameMatchers.BaseMatcher
- createSetOp(SqlKind, List<RelNode>, boolean) - Method in interface org.apache.calcite.rel.core.RelFactories.SetOpFactory
-
Creates a set operation.
- createSetOp(SqlKind, List<RelNode>, boolean) - Method in class org.apache.calcite.rel.core.RelFactories.SetOpFactoryImpl
- 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.
- 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(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() - Method in class org.apache.calcite.runtime.TrustAllSslSocketFactory
- createSocket(String, int) - Method in class org.apache.calcite.runtime.SocketFactoryImpl
- createSocket(String, int) - Method in class org.apache.calcite.runtime.TrustAllSslSocketFactory
- createSocket(String, int, InetAddress, int) - Method in class org.apache.calcite.runtime.SocketFactoryImpl
- createSocket(String, int, InetAddress, int) - Method in class org.apache.calcite.runtime.TrustAllSslSocketFactory
- createSocket(InetAddress, int) - Method in class org.apache.calcite.runtime.SocketFactoryImpl
- createSocket(InetAddress, int) - Method in class org.apache.calcite.runtime.TrustAllSslSocketFactory
- createSocket(InetAddress, int, InetAddress, int) - Method in class org.apache.calcite.runtime.SocketFactoryImpl
- createSocket(InetAddress, int, InetAddress, int) - Method in class org.apache.calcite.runtime.TrustAllSslSocketFactory
- createSort(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in interface org.apache.calcite.rel.core.RelFactories.SortFactory
-
Deprecated.
- createSort(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.rel.core.RelFactories.SortFactoryImpl
-
Deprecated.
- createSort(RelNode, RelCollation, RexNode, RexNode) - Method in interface org.apache.calcite.rel.core.RelFactories.SortFactory
-
Creates a sort.
- createSort(RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.rel.core.RelFactories.SortFactoryImpl
- createSortExchange(RelNode, RelDistribution, RelCollation) - Method in interface org.apache.calcite.rel.core.RelFactories.SortExchangeFactory
-
Creates a
SortExchange
. - createSortExchange(RelNode, RelDistribution, RelCollation) - Method in class org.apache.calcite.rel.core.RelFactories.SortExchangeFactoryImpl
- createSource(RelOptTable, RelNode, ModifiableView, RelDataType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Wraps a relational expression in the projects and filters implied by a
ModifiableView
. - 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
- 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(CalcitePrepare.Context, CalciteCatalogReader) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- createSqlValidator(Prepare.CatalogReader) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- createSqlWindowBound(RexWindowBound) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- createSqlWriter(SqlDialect, StringBuilder, IntFunction<SqlNode>) - Method in class org.apache.calcite.materialize.Lattice
-
Creates a context to which SQL can be generated.
- createSSLSocketFactory() - Static method in class org.apache.calcite.runtime.TrustAllSslSocketFactory
-
Creates an "accept-all" SSLSocketFactory - ssl sockets will accept ANY certificate sent to them - thus effectively just securing the communications.
- createStarTable() - Method in class org.apache.calcite.materialize.Lattice
- createStatement(int, int, int) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- 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<String>) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- createStructType(RelDataTypeFactory, List<? extends RexNode>, List<String>, SqlValidatorUtil.Suggester) - Static method in class org.apache.calcite.rex.RexUtil
-
Creates a record type with specified field names.
- 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, viz:
CASE value
WHEN whenList[0] THEN thenList[0]
WHEN whenList[1] THEN thenList[1]
...
ELSE elseClause
END - 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
- createSyntheticType(RelRecordType) - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl
-
Creates a synthetic Java class whose fields have the same names and relational types.
- 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(SqlParserPos, boolean, boolean, SqlIdentifier, SqlNodeList, SqlNode) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a CREATE TABLE.
- createTable(Source) - Method in class org.apache.calcite.adapter.csv.CsvSchema
-
Creates different sub-type of table based on the "flavor" attribute.
- createTableMap() - Method in class org.apache.calcite.adapter.csv.CsvSchema
- createTableMap() - Method in class org.apache.calcite.adapter.java.ReflectiveSchema
- createTableRequiresColumnList() - Method in interface org.apache.calcite.runtime.CalciteResource
- createTableRequiresColumnTypes(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- createTables(Iterable<String>) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchema
- createTableSample(boolean, float) - Static method in class org.apache.calcite.sql.SqlSampleSpec
-
Creates a table sample without repeatability.
- createTableSample(boolean, float, int) - Static method in class org.apache.calcite.sql.SqlSampleSpec
-
Creates a table sample with repeatability.
- createTargetRowType(SqlValidatorTable, SqlNodeList, boolean) - 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
- createTimestamp(Calendar, int, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Deprecated.
- createTimestamp(TimestampString, int, SqlParserPos) - Static method in class org.apache.calcite.sql.SqlLiteral
- createTopProject(RelBuilder, LoptMultiJoin, LoptJoinTree, List<String>) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Creates the topmost projection that will sit on top of the selected join ordering.
- createToRelContext() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- 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.
- 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.AbstractMaterializedViewRule
-
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.
- createUnion(RelBuilder, RexBuilder, RelNode, RelNode, RelNode) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewAggregateRule
- createUnion(RelBuilder, RexBuilder, RelNode, RelNode, RelNode) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewJoinRule
- 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
- createValueGenerator(Iterable<RelDecorrelator.CorRef>, int, SortedMap<RelDecorrelator.CorDef, Integer>) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Create RelNode tree that produces a list of correlated variables.
- createValues(RelOptCluster, RelDataType, List<ImmutableList<RexLiteral>>) - Method in interface org.apache.calcite.rel.core.RelFactories.ValuesFactory
-
Creates a Values.
- createValues(RelOptCluster, RelDataType, List<ImmutableList<RexLiteral>>) - Method in class org.apache.calcite.rel.core.RelFactories.ValuesFactoryImpl
- createValuesRel - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- createValuesRel - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- createView(SqlParserPos, boolean, SqlIdentifier, SqlNodeList, SqlNode) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates a CREATE VIEW.
- createWithCharsetAndCollation(Charset, SqlCollation) - Method in class org.apache.calcite.sql.type.BasicSqlType
-
Constructs a type with charset and collation.
- createWithNullability(boolean) - Method in class org.apache.calcite.sql.type.BasicSqlType
-
Constructs a type with nullablity.
- CROSS - org.apache.calcite.sql.JoinType
-
Cross join (also known as Cartesian product).
- crossJoinDisallowsCondition() - Method in interface org.apache.calcite.runtime.CalciteResource
- CSV - org.apache.calcite.adapter.os.SqlShell.Format
- CsvContentListener(Queue<String>) - Constructor for class org.apache.calcite.adapter.csv.CsvStreamReader.CsvContentListener
- CsvEnumerator<E> - Class in org.apache.calcite.adapter.csv
-
Enumerator that reads from a CSV file.
- CsvEnumerator(Source, AtomicBoolean, boolean, String[], CsvEnumerator.RowConverter<E>) - Constructor for class org.apache.calcite.adapter.csv.CsvEnumerator
- CsvEnumerator(Source, AtomicBoolean, List<CsvFieldType>) - Constructor for class org.apache.calcite.adapter.csv.CsvEnumerator
- CsvEnumerator(Source, AtomicBoolean, List<CsvFieldType>, int[]) - Constructor for class org.apache.calcite.adapter.csv.CsvEnumerator
- CsvEnumerator.ArrayRowConverter - Class in org.apache.calcite.adapter.csv
-
Array row converter.
- CsvEnumerator.RowConverter<E> - Class in org.apache.calcite.adapter.csv
-
Row converter.
- CsvEnumerator.SingleColumnRowConverter - Class in org.apache.calcite.adapter.csv
-
Single column row converter.
- CsvFieldType - Enum in org.apache.calcite.adapter.csv
-
Type of a field in a CSV file.
- CsvFieldType(Class, String) - Constructor for enum org.apache.calcite.adapter.csv.CsvFieldType
- CsvFieldType(Primitive) - Constructor for enum org.apache.calcite.adapter.csv.CsvFieldType
- 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(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.csv.CsvProjectTableScanRule
-
Creates a CsvProjectTableScanRule.
- csvReader - Variable in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.SplunkResultEnumerator
- CsvScannableTable - Class in org.apache.calcite.adapter.csv
-
Table based on a CSV file.
- CsvScannableTable(Source, RelProtoDataType) - Constructor for class org.apache.calcite.adapter.csv.CsvScannableTable
-
Creates a CsvScannableTable.
- 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
. - CsvSchemaFactory() - Constructor for class org.apache.calcite.adapter.csv.CsvSchemaFactory
- CsvStreamReader - Class in org.apache.calcite.adapter.csv
-
Extension to
CSVReader
that can read newly appended file content. - CsvStreamReader(Source) - Constructor for class org.apache.calcite.adapter.csv.CsvStreamReader
- CsvStreamReader(Source, char, char, char, int, boolean, boolean) - Constructor for class org.apache.calcite.adapter.csv.CsvStreamReader
-
Creates a CsvStreamReader with supplied separator and quote char.
- CsvStreamReader.CsvContentListener - Class in org.apache.calcite.adapter.csv
-
Watches for content being appended to a CSV file.
- CsvStreamScannableTable - Class in org.apache.calcite.adapter.csv
-
Table based on a CSV file.
- CsvStreamScannableTable(Source, RelProtoDataType) - Constructor for class org.apache.calcite.adapter.csv.CsvStreamScannableTable
-
Creates a CsvScannableTable.
- CsvStreamTableFactory - Class in org.apache.calcite.adapter.csv
-
Factory that creates a
CsvTranslatableTable
. - CsvStreamTableFactory() - Constructor for class org.apache.calcite.adapter.csv.CsvStreamTableFactory
- csvTable - Variable in class org.apache.calcite.adapter.csv.CsvTableScan
- CsvTable - Class in org.apache.calcite.adapter.csv
-
Base class for table that reads CSV files.
- CsvTable(Source, RelProtoDataType) - Constructor for class org.apache.calcite.adapter.csv.CsvTable
-
Creates a CsvTable.
- CsvTable.Flavor - Enum in org.apache.calcite.adapter.csv
-
Various degrees of table "intelligence".
- CsvTableFactory - Class in org.apache.calcite.adapter.csv
-
Factory that creates a
CsvTranslatableTable
. - CsvTableFactory() - Constructor for class org.apache.calcite.adapter.csv.CsvTableFactory
- CsvTableScan - Class in org.apache.calcite.adapter.csv
-
Relational expression representing a scan of a CSV file.
- CsvTableScan(RelOptCluster, RelOptTable, CsvTranslatableTable, int[]) - Constructor for class org.apache.calcite.adapter.csv.CsvTableScan
- CsvTranslatableTable - Class in org.apache.calcite.adapter.csv
-
Table based on a CSV file.
- CsvTranslatableTable(Source, RelProtoDataType) - Constructor for class org.apache.calcite.adapter.csv.CsvTranslatableTable
-
Creates a CsvTable.
- cube(List<ImmutableBitSet>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Computes the cube of bit sets.
- CUBE - org.apache.calcite.rel.core.Aggregate.Group
- CUBE - 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 - 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 - org.apache.calcite.util.BuiltInMethod
- CUMULATIVE_MEMORY_WITHIN_PHASE - org.apache.calcite.util.BuiltInMethod
- CUMULATIVE_MEMORY_WITHIN_PHASE_SPLIT - org.apache.calcite.util.BuiltInMethod
- cumulativeCostHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- 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 - Variable in class org.apache.calcite.adapter.cassandra.CassandraEnumerator
- current - Variable in class org.apache.calcite.adapter.csv.CsvEnumerator
- current - Variable in class org.apache.calcite.adapter.file.FileEnumerator
- current - Variable in class org.apache.calcite.adapter.geode.rel.GeodeEnumerator
- current - Variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleEnumerator
- current - Variable in class org.apache.calcite.adapter.mongodb.MongoEnumerator
- current - Variable in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.SplunkResultEnumerator
- current - Variable in class org.apache.calcite.linq4j.Linq4j.IterableEnumerator
- current - Variable in class org.apache.calcite.util.Util.FilteringIterator
- current() - Method in class org.apache.calcite.adapter.cassandra.CassandraEnumerator
-
Produce the next row from the results
- current() - Method in class org.apache.calcite.adapter.clone.ArrayTable.Content.ArrayEnumerator
- current() - Method in class org.apache.calcite.adapter.clone.ArrayTable.Content.ObjectEnumerator
- current() - Method in class org.apache.calcite.adapter.csv.CsvEnumerator
- current() - Method in class org.apache.calcite.adapter.csv.JsonEnumerator
- current() - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl.BlockingQueueEnumerator
- current() - Method in class org.apache.calcite.adapter.file.FileEnumerator
- current() - Method in class org.apache.calcite.adapter.geode.rel.GeodeEnumerator
-
Produces the next row from the results.
- current() - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleEnumerator
- current() - Method in class org.apache.calcite.adapter.mongodb.MongoEnumerator
- current() - Method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.SplunkResultEnumerator
- current() - Method in class org.apache.calcite.linq4j.DelegatingEnumerator
- current() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.CastingEnumerator
- current() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- current() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.SkipWhileEnumerator
- current() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileEnumerator
- current() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileLongEnumerator
- current() - Method in interface org.apache.calcite.linq4j.Enumerator
-
Gets the current element in the collection.
- current() - Method in class org.apache.calcite.linq4j.Linq4j.CartesianProductListEnumerator
- current() - Method in class org.apache.calcite.linq4j.Linq4j.IterableEnumerator
- current() - Method in class org.apache.calcite.linq4j.Linq4j.ListEnumerator
- current() - Method in class org.apache.calcite.linq4j.Linq4j.SingletonEnumerator
- current() - Method in class org.apache.calcite.linq4j.Linq4j.SingletonNullEnumerator
- 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() - Method in class org.apache.calcite.runtime.ResultSetEnumerable.ResultSetEnumerator
- current() - Method in class org.apache.calcite.runtime.SqlFunctions.ProductComparableListEnumerator
- CURRENT_CATALOG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CURRENT_CATALOG
function. - CURRENT_DATE - org.apache.calcite.util.BuiltInMethod
- CURRENT_DATE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CURRENT_DATE
function. - 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 - org.apache.calcite.sql.SqlWindow.Bound
- CURRENT_SCHEMA - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CURRENT_SCHEMA
function. - CURRENT_TIME - org.apache.calcite.runtime.Hook
-
Called to get the current time.
- CURRENT_TIME - org.apache.calcite.util.BuiltInMethod
- CURRENT_TIME - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CURRENT_TIME [(precision)]
function. - CURRENT_TIMESTAMP - org.apache.calcite.DataContext.Variable
-
The time at which the current statement started executing.
- CURRENT_TIMESTAMP - org.apache.calcite.util.BuiltInMethod
- CURRENT_TIMESTAMP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CURRENT_TIMESTAMP [(precision)]
function. - CURRENT_USER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
CURRENT_USER
function. - CURRENT_VALUE - 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
- currentCount - Variable in class org.apache.calcite.rex.RexUtil.CnfHelper
- currentDate(DataContext) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
CURRENT_DATE
function. - currentIndent - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- currentLevel - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter.HighestUsageFinder
- currentLocatorHost - Static variable in class org.apache.calcite.adapter.geode.util.GeodeUtils
- currentLocatorPort - Static variable in class org.apache.calcite.adapter.geode.util.GeodeUtils
- currentMutableSchema(String) - Method in class org.apache.calcite.model.ModelHandler
- currentNullables() - Method in interface org.apache.calcite.adapter.enumerable.NestedBlockBuilder
-
Returns the current nullability state of rex nodes.
- currentNullables() - Method in class org.apache.calcite.adapter.enumerable.NestedBlockBuilderImpl
-
Returns the current nullability state of rex nodes.
- currentPosition() - Method in interface org.apache.calcite.adapter.enumerable.WinAggAddContext
-
Returns current position inside for-loop of window aggregate.
- currentProgram - Variable in class org.apache.calcite.plan.hep.HepPlanner
- currentRel - Variable in class org.apache.calcite.plan.hep.HepRelVertex
-
Wrapped rel currently chosen for implementation of expression.
- currentRel - Variable in class org.apache.calcite.sql2rel.RelDecorrelator
- currentRel - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.DecorrelateRexShuttle
- currentRel - Variable in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- currentRowField(int, SqlTypeName) - Method in class org.apache.calcite.adapter.cassandra.CassandraEnumerator
-
Get a field for the current row from the underlying object.
- currentRowFollowingError() - Method in interface org.apache.calcite.runtime.CalciteResource
- currentRowPrecedingError() - Method in interface org.apache.calcite.runtime.CalciteResource
- currentSchema() - Method in class org.apache.calcite.model.ModelHandler
- currentSchemaName() - Method in class org.apache.calcite.model.ModelHandler
- currentSchemaPath() - Method in class org.apache.calcite.model.ModelHandler
- 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. - cursor - Variable in class org.apache.calcite.adapter.mongodb.MongoEnumerator
- cursor - Variable in class org.apache.calcite.sql.parser.SqlParserUtil.StringAndPos
- cursor - Variable in class org.apache.calcite.util.ChunkList.ChunkListIterator
-
Offset within current chunk of the next element to return.
- CURSOR - org.apache.calcite.sql.SqlKind
-
CURSOR constructor, for example,
select * from TABLE(udx(CURSOR(select ...), x, y, z))
- CURSOR - org.apache.calcite.sql.type.SqlTypeFamily
- CURSOR - 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.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
- cursors - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- cursorScopes - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Maps a
SqlSelect
node that is the argument to a CURSOR constructor to the scope of the result of that select node - cursorSet - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Set of select expressions used as cursor definitions.
- CURVE - org.apache.calcite.runtime.GeoFunctions.Type
- CUSTOM - org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Records must be represented as objects.
- CUSTOM - org.apache.calcite.adapter.enumerable.JavaRowFormat
- CUSTOM - org.apache.calcite.model.JsonSchema.Type
- CUSTOM - org.apache.calcite.plan.Strong.Policy
-
This kind of expression has its own particular rules about whether it is null.
- CUSTOM_NICE - org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Consumer would prefer that records are represented as objects, but can accommodate records represented as arrays.
- CustomColumnResolvingTable - Interface in org.apache.calcite.schema
-
Extension to
Table
that specifies a custom way to resolve column names. - 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 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 org.apache.calcite.sql.validate.CyclicDefinitionException
-
Creates CyclicDefinitionException.
- CyclicMetadataException - Exception in org.apache.calcite.rel.metadata
-
Exception that indicates that a cycle has been detected while computing metadata.
- CyclicMetadataException() - Constructor for exception org.apache.calcite.rel.metadata.CyclicMetadataException
-
Creates a CyclicMetadataException.
D
- DATA_CONTEXT_GET - org.apache.calcite.util.BuiltInMethod
- DATA_CONTEXT_GET_QUERY_PROVIDER - org.apache.calcite.util.BuiltInMethod
- DATA_CONTEXT_GET_ROOT_SCHEMA - org.apache.calcite.util.BuiltInMethod
- databaseMajorVersion - Variable in class org.apache.calcite.sql.SqlDialect.ContextImpl
- databaseMajorVersion() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- databaseMajorVersion() - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- DatabaseMetaDataInvocationHandler(String, String) - Constructor for class org.apache.calcite.sql.SqlUtil.DatabaseMetaDataInvocationHandler
- databaseMinorVersion - Variable in class org.apache.calcite.sql.SqlDialect.ContextImpl
- databaseMinorVersion() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- databaseMinorVersion() - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- databaseProduct - Variable in class org.apache.calcite.sql.SqlDialect.ContextImpl
- databaseProduct - Variable in class org.apache.calcite.sql.SqlDialect
- databaseProduct() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- databaseProduct() - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- DatabaseProduct(String, String, NullCollation) - Constructor for enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- databaseProductName - Variable in class org.apache.calcite.sql.SqlDialect.ContextImpl
- databaseProductName - Variable in class org.apache.calcite.sql.SqlUtil.DatabaseMetaDataInvocationHandler
- databaseProductName() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- databaseProductName() - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- databaseVersion - Variable in class org.apache.calcite.sql.SqlDialect.ContextImpl
- databaseVersion() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- databaseVersion() - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- DatabaseWrapper() - Constructor for enum org.apache.calcite.chinook.ConnectionFactory.DatabaseWrapper
- dataContext - Variable in class org.apache.calcite.interpreter.AggregateNode
- dataContext - Variable in class org.apache.calcite.interpreter.InterpretableRel.InterpreterImplementor
- dataContext - Variable in class org.apache.calcite.interpreter.Interpreter
- dataContext - Variable in class org.apache.calcite.rex.RexExecutable
- dataContext - Variable in class org.apache.calcite.rex.RexExecutorImpl
- 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)
. - DataContextImpl(CalciteConnectionImpl, Map<String, Object>, CalciteSchema) - Constructor for class org.apache.calcite.jdbc.CalciteConnectionImpl.DataContextImpl
- DataContextInputGetter(RelDataType, RelDataTypeFactory) - Constructor for class org.apache.calcite.rex.RexExecutorImpl.DataContextInputGetter
- dataSet - Variable in class org.apache.calcite.adapter.clone.ArrayTable.Column
- dataSet - Variable in class org.apache.calcite.adapter.clone.ArrayTable.Content.ObjectEnumerator
- datasetStack - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Stack of names of datasets requested by the
TABLE(SAMPLE(<datasetName>, <query>))
construct. - dataSource - Variable in class org.apache.calcite.adapter.druid.DruidQuery.ScanQuery
- dataSource - Variable in class org.apache.calcite.adapter.druid.DruidTable
- dataSource - Variable in class org.apache.calcite.adapter.jdbc.JdbcSchema
- dataSource - Variable in class org.apache.calcite.runtime.ResultSetEnumerable
- dataSource(String, String, String, String) - Static method in class org.apache.calcite.adapter.jdbc.JdbcSchema
-
Creates a JDBC data source with the given specification.
- dataSource(List<String>) - Static method in class org.apache.calcite.adapter.jdbc.JdbcUtils.DataSourcePool
- DataSourcePool() - Constructor for class org.apache.calcite.adapter.jdbc.JdbcUtils.DataSourcePool
- 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
- Datatype(String) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping.Datatype
- dataTypeSystem - Variable in class org.apache.calcite.sql.SqlDialect.ContextImpl
- dataTypeSystem - Variable in class org.apache.calcite.sql.SqlDialect
- dataTypeSystem() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- dataTypeSystem() - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- date - Variable in class org.apache.calcite.sql.parser.SqlParserUtil.Format
- DATE - org.apache.calcite.adapter.csv.CsvFieldType
- DATE - org.apache.calcite.adapter.file.FileFieldType
- DATE - org.apache.calcite.sql.type.SqlTypeFamily
- DATE - org.apache.calcite.sql.type.SqlTypeName
- DATE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is Date.
- DATE_FORMATTER - Static variable in class org.apache.calcite.adapter.druid.DruidJsonFilter
- DATE_TO_INT - org.apache.calcite.util.BuiltInMethod
- DATE_TO_INT_OPTIONAL - org.apache.calcite.util.BuiltInMethod
- dateLiteralOutOfRange(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- dateMethod - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.FloorImplementor
- 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() - Constructor for class org.apache.calcite.rel.rules.DateRangeRules
- DateRangeRules.ExtractFinder - Class in org.apache.calcite.rel.rules
-
Visitor that searches for calls to
EXTRACT
,FLOOR
orCEIL
, building a list of distinct time units. - DateRangeRules.ExtractShuttle - Class in org.apache.calcite.rel.rules
-
Walks over an expression, replacing calls to
EXTRACT
,FLOOR
andCEIL
with date ranges. - DateRangeRules.FilterDateRangeRule - Class in org.apache.calcite.rel.rules
-
Rule that converts EXTRACT, FLOOR and CEIL in a
Filter
into a date range. - 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.
- DateString(String, boolean) - Constructor for class org.apache.calcite.util.DateString
-
Internal constructor, no validation.
- DATETIME - org.apache.calcite.sql.type.SqlTypeFamily
- DATETIME - Static variable in class org.apache.calcite.sql.type.OperandTypes
- DATETIME_INTERVAL - 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_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- DatetimeArithmeticImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.DatetimeArithmeticImplementor
- dateTimeFormatString(SqlTypeName) - Static method in class org.apache.calcite.adapter.druid.DruidSqlCastConverter
- dateTimeLiteral(RexBuilder, Calendar, RexNode) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- DateTimeStringUtils - Class in org.apache.calcite.util
-
Utility methods to manipulate String representation of DateTime values.
- DateTimeStringUtils() - Constructor for class org.apache.calcite.util.DateTimeStringUtils
- DAY - org.apache.calcite.adapter.druid.Granularity.Type
- DAY_INTERVAL_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- 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. - DAYOFYEAR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
DAYOFYEAR
operator. - DAYS_IN_TEN_YEARS - Static variable in class org.apache.calcite.adapter.druid.DruidQuery
- DB2 - 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.
- 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.
- debug(String, Object...) - Method in class org.apache.calcite.util.trace.CalciteLogger
- 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 - Static variable in class org.apache.calcite.example.maze.Maze
- DEBUG - Static variable in class org.apache.calcite.plan.SubstitutionVisitor
- DEBUG - Static variable in class org.apache.calcite.prepare.CalcitePrepareImpl
- DEBUG - Static variable in class org.apache.calcite.util.PartiallyOrderedSet
-
Whether to check internal consistency all the time.
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
Debugging information.
- DECIMAL - org.apache.calcite.sql.type.SqlTypeName
- DECIMAL_FORMAT - Static variable in class org.apache.calcite.util.trace.CalciteTimingTracer
- 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 product 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
. - decimalFormat(String) - Static method in class org.apache.calcite.util.NumberUtil
-
Creates a format.
- DecimalShuttle(RexBuilder) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule.DecimalShuttle
- Declaration - 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.
- declareAndResetState(JavaTypeFactory, BlockBuilder, EnumerableRel.Result, int, List<AggImpState>, PhysType, List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindow
- 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.EnumerableAggregate
- declaringClass - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- declName - Variable in class org.apache.calcite.sql.SqlWindow
-
The name of the window being declared.
- declString() - Method in class org.apache.calcite.linq4j.tree.ParameterExpression
- declString(Type) - Method in class org.apache.calcite.linq4j.tree.ParameterExpression
- DECODE - org.apache.calcite.sql.SqlKind
-
The "DECODE" function (Oracle).
- DECODE - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
The "DECODE(v, v1, result1, [v2, result2, ...], resultN)" function.
- DECODE_MAP - Static variable in class org.apache.calcite.util.NlsString
- DECODE_RETURN_TYPE - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
Return type inference for
DECODE
. - decodeIntervalOrDecimal(RexNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Retrieves an interval or decimal node's integer representation
- decodeList(CharSequence, char) - Static method in class org.apache.calcite.adapter.splunk.util.StringUtils
- decodeValue(RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Retrieves a decimal node's integer representation
- decompose(Set<RexNode>, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Tries to decompose the RexNode which is a RexCall into non-literal RexNodes.
- 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
- decorrelateInputWithValueGenerator(RelNode, RelDecorrelator.Frame) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- DecorrelateProgram() - Constructor for class org.apache.calcite.tools.Programs.DecorrelateProgram
- 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(Sort) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Rewrite Sort.
- decorrelateRel(Values) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Rewrites a
Values
. - decorrelateRel(LogicalAggregate) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Rewrites a
LogicalAggregate
. - decorrelateRel(LogicalCorrelate) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Rewrite Correlate into a left outer join.
- decorrelateRel(LogicalFilter) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Rewrite LogicalFilter.
- decorrelateRel(LogicalJoin) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Rewrite LogicalJoin.
- decorrelateRel(LogicalProject) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Rewrite LogicalProject.
- decorrelateRel(RelNode) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Fallback if none of the other
decorrelateRel
methods match. - DecorrelateRexShuttle(RelNode, Map<RelNode, RelDecorrelator.Frame>, RelDecorrelator.CorelMap) - Constructor for class org.apache.calcite.sql2rel.RelDecorrelator.DecorrelateRexShuttle
- decorrelationEnabled - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- decorrelationEnabled - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- DECREASING - org.apache.calcite.sql.validate.SqlMonotonicity
- decrement(Calendar, TimeUnitRange) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- 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 - 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
- deduceModality(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Return the intended modality of a SELECT or set-op.
- deduceRowType(JavaTypeFactory, Source, List<CsvFieldType>) - Static method in class org.apache.calcite.adapter.csv.CsvEnumerator
-
Deduces the names and types of a table's columns by reading the first line of a CSV file.
- deduceRowType(JavaTypeFactory, Source, List<CsvFieldType>, Boolean) - Static method in class org.apache.calcite.adapter.csv.CsvEnumerator
-
Deduces the names and types of a table's columns by reading the first line of a CSV file.
- deduceType(List<ParameterExpression>, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- deduceType(RelDataTypeFactory, TimeUnit, RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.fun.SqlTimestampAddFunction
- 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.
- 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.
- DeduplicateCorrelateVariables(RexBuilder, CorrelationId, ImmutableSet<CorrelationId>) - Constructor for class org.apache.calcite.sql2rel.DeduplicateCorrelateVariables
-
Creates a DeduplicateCorrelateVariables.
- DeduplicateCorrelateVariables.DeduplicateCorrelateVariablesShuttle - Class in org.apache.calcite.sql2rel
-
Replaces alternative names of correlation variable to its canonical name.
- DeduplicateCorrelateVariablesShuttle(RexBuilder, CorrelationId, ImmutableSet<CorrelationId>, DeduplicateCorrelateVariables) - Constructor for class org.apache.calcite.sql2rel.DeduplicateCorrelateVariables.DeduplicateCorrelateVariablesShuttle
- dedupRex - Variable in class org.apache.calcite.sql2rel.DeduplicateCorrelateVariables
- deep - Variable in class org.apache.calcite.rex.RexVisitorImpl
- deep() - Method in class org.apache.calcite.rel.mutable.MutableRel
- DeepCopier(SqlValidatorScope) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- def - Variable in class org.apache.calcite.interpreter.AggregateNode.ScalarAccumulator
- def - Variable in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider.Key
- def() - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorRef
- 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.MaxRowCount
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A default value.
- DEFAULT - org.apache.calcite.schema.ColumnStrategy
-
Column has a default value.
- DEFAULT - org.apache.calcite.sql.SqlJsonValueEmptyOrErrorBehavior
- DEFAULT - org.apache.calcite.sql.SqlKind
-
DEFAULT operator
- DEFAULT - org.apache.calcite.sql.validate.SqlConformanceEnum
-
Calcite's default SQL behavior.
- DEFAULT - Static variable in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- DEFAULT - Static variable in interface org.apache.calcite.rel.type.RelDataTypeSystem
-
Default type system.
- DEFAULT - Static variable in class org.apache.calcite.runtime.TrustAllSslSocketFactory
- 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.Db2SqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.DerbySqlDialect
- DEFAULT - Static variable in class org.apache.calcite.sql.dialect.FirebirdSqlDialect
- 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.RedshiftSqlDialect
- 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 interface org.apache.calcite.sql.validate.SqlConformance
-
Deprecated.
- DEFAULT - Static variable in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Default configuration.
- 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_BEAN - Static variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Bean holding the default property values.
- DEFAULT_CALL - Static variable in class org.apache.calcite.sql.SqlCallBinding
- DEFAULT_CASSANDRA_PORT - Static variable in class org.apache.calcite.adapter.cassandra.CassandraSchema
- DEFAULT_CHARSET - Static variable in class org.apache.calcite.util.Util
- DEFAULT_CHILD_FACTORY - Static variable in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
- 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_FETCH_SIZE - Static variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- DEFAULT_FILTER_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_IDENTIFIER_MAX_LENGTH - Static variable in class org.apache.calcite.sql.parser.SqlParser
- 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_MONITOR_DELAY - Static variable in class org.apache.calcite.adapter.csv.CsvStreamReader
-
The default file monitor delay.
- DEFAULT_NULL_COLLATION - 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_RESPONSE_TIMESTAMP_COLUMN - Static variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- DEFAULT_RULES - Static variable in class org.apache.calcite.plan.SubstitutionVisitor
- DEFAULT_RULES - Static variable in class org.apache.calcite.prepare.CalcitePrepareImpl
- DEFAULT_SEMI_JOIN_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_SET_OP_FACTORY - Static variable in class org.apache.calcite.rel.core.RelFactories
- DEFAULT_SKIP_LINES - Static variable in class org.apache.calcite.adapter.csv.CsvStreamReader
-
The default line to start reading.
- 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_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
-
The string property "saffron.default.charset" is the name of the default character set.
- defaultCollation() - Method in interface org.apache.calcite.util.SaffronProperties
-
The string property "saffron.default.collation.name" is the name of the default collation.
- defaultCollationStrength() - Method in interface org.apache.calcite.util.SaffronProperties
-
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.
- DefaultDirectedGraph.VertexInfo<V,E> - Class in org.apache.calcite.util.graph
-
Information about an edge.
- 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
- defaultExpander - Variable in class org.apache.calcite.rel.rules.ReduceDecimalsRule.ExpanderMap
- 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.linq4j.DefaultQueryable
- defaultIfEmpty() - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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 interface org.apache.calcite.linq4j.ExtendedQueryable
-
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>) - 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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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.
- 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) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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.
- 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.
- defaultMeasureSet - Variable in class org.apache.calcite.materialize.Lattice.Builder
- defaultNationalCharset() - Method in interface org.apache.calcite.util.SaffronProperties
-
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
- defaultNullCollation() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- 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.
- DefaultQueryable<T> - Class in org.apache.calcite.linq4j
-
Implementation of the
Queryable
interface that implements the extension methods by calling into theExtensions
class. - DefaultQueryable() - Constructor for class org.apache.calcite.linq4j.DefaultQueryable
-
Creates a DefaultQueryable using a factory that records events.
- DefaultQueryable(QueryableFactory<T>) - Constructor for class org.apache.calcite.linq4j.DefaultQueryable
-
Creates a DefaultQueryable using a particular factory.
- 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.
- 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 - Variable in class org.apache.calcite.prepare.PlannerImpl
- defaultSchema - Variable in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- defaultSchema - Variable in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- defaultSchema(SchemaPlus) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- DefaultTableFactory() - Constructor for class org.apache.calcite.materialize.MaterializationService.DefaultTableFactory
- defaultUnknownAs - Variable in class org.apache.calcite.rex.RexSimplify
-
How to treat UNKNOWN values, if one of the deprecated
simplify
methods without anunknownAs
argument is called. - defaultValue - Variable in enum org.apache.calcite.config.CalciteConnectionProperty
- 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 - Variable in class org.apache.calcite.runtime.Resources.BooleanProp
- defaultValue - Variable in class org.apache.calcite.runtime.Resources.DoubleProp
- defaultValue - Variable in class org.apache.calcite.runtime.Resources.IntProp
- defaultValue - Variable in class org.apache.calcite.runtime.Resources.StringProp
- defaultValue() - Method in enum org.apache.calcite.config.CalciteConnectionProperty
- defaultValue() - Method in class org.apache.calcite.runtime.Resources.BooleanProp
- defaultValue() - Method in class org.apache.calcite.runtime.Resources.DoubleProp
- defaultValue() - Method in class org.apache.calcite.runtime.Resources.IntProp
- defaultValue() - Method in class org.apache.calcite.runtime.Resources.StringProp
- DeferredLookup(SqlToRelConverter.Blackboard, String) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.DeferredLookup
- DeferringRuleCall(VolcanoPlanner, RelOptRuleOperand) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlanner.DeferringRuleCall
- defineBinary(SqlOperator, ExpressionType, NullPolicy, String) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable
- defineEscape(char, String) - Method in class org.apache.calcite.util.XmlOutput.StringEscaper
-
Map character "from" to escape sequence "to"
- defineImplementor(SqlOperator, NullPolicy, NotNullImplementor, boolean) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable
- 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.
- defineMethod(SqlOperator, Method, NullPolicy) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable
- defineMethod(SqlOperator, String, NullPolicy) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable
- defineMethodReflective(SqlOperator, Method, NullPolicy) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable
- 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
- defineUnary(SqlOperator, ExpressionType, NullPolicy) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable
- 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 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- dejsonize(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- delegate - Variable in class org.apache.calcite.adapter.elasticsearch.Scrolling.AutoClosingIterator
- delegate - Variable in class org.apache.calcite.linq4j.DelegatingEnumerator
- delegate - Variable in class org.apache.calcite.sql.ExplicitOperatorBinding
- delegate - Variable in class org.apache.calcite.sql.validate.AggVisitor
- delegate - Variable in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- 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.
- 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.
- DelegatingScope(SqlValidatorScope) - Constructor for class org.apache.calcite.sql.validate.DelegatingScope
-
Creates a
DelegatingScope
. - 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 - org.apache.calcite.rel.core.TableModify.Operation
- DELETE - org.apache.calcite.sql.SqlAccessEnum
- DELETE - org.apache.calcite.sql.SqlKind
-
DELETE statement
- DeleteNamespace(SqlValidatorImpl, SqlDelete, SqlNode, SqlValidatorScope) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.DeleteNamespace
- 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(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaAggregateTransposeRule
-
Creates a DeltaAggregateTransposeRule.
- DeltaFilterTransposeRule(RelBuilderFactory) - 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(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaJoinTransposeRule
-
Creates a DeltaJoinTransposeRule.
- DeltaProjectTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaProjectTransposeRule
-
Creates a DeltaProjectTransposeRule.
- DeltaSortTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaSortTransposeRule
-
Creates a DeltaSortTransposeRule.
- DeltaTableScanRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaTableScanRule
-
Creates a DeltaTableScanRule.
- DeltaTableScanToEmptyRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaTableScanToEmptyRule
-
Creates a DeltaTableScanToEmptyRule.
- DeltaUnionTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.stream.StreamRules.DeltaUnionTransposeRule
-
Creates a DeltaUnionTransposeRule.
- Demo - Class in org.apache.calcite
-
Demo.
- Demo() - Constructor for class org.apache.calcite.Demo
- DENSE_RANK - 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. - DenseRankImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.DenseRankImplementor
- Department(int, String, List<StatementTest.Employee>) - Constructor for class org.apache.calcite.benchmarks.StatementTest.Department
- dependencies - Variable in class org.apache.calcite.profile.ProfilerImpl.Space
- dependencies - Variable in class org.apache.calcite.profile.SimpleProfiler.Space
- dependentColumn - Variable in class org.apache.calcite.profile.Profiler.FunctionalDependency
- dependents - Variable in class org.apache.calcite.profile.ProfilerImpl.Space
- dependents - Variable in class org.apache.calcite.profile.SimpleProfiler.Space
- 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 class org.apache.calcite.sql.SqlExplain
- depth - Variable in exception org.apache.calcite.sql.validate.CyclicDefinitionException
- Depth() - Constructor for enum org.apache.calcite.sql.SqlExplain.Depth
- DEPTH_FIRST - org.apache.calcite.plan.hep.HepMatchOrder
-
Match in depth-first order.
- depthFirstApply(Iterator<HepRelVertex>, Collection<RelOptRule>, boolean, int) - Method in class org.apache.calcite.plan.hep.HepPlanner
- 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.benchmarks.StatementTest.Department
- deptno - Variable in class org.apache.calcite.benchmarks.StatementTest.Employee
- depts - Variable in class org.apache.calcite.benchmarks.StatementTest.HrSchema
- deque - Variable in class org.apache.calcite.profile.ProfilerImpl.SurpriseQueue
- deque - Variable in class org.apache.calcite.util.graph.BreadthFirstIterator
- DERBY - 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
. - deriveAlias(LatticeSuggester.MutableMeasure, LatticeSuggester.DerivedColRef) - Static method in class org.apache.calcite.materialize.LatticeSuggester
-
Derives the alias of an expression that is the argument to a measure.
- deriveAlias(RelNode) - Static method in class org.apache.calcite.tools.RelBuilder.Frame
- 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
- deriveAlias(SqlNode, Collection<String>, int) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- deriveAliasFromOrdinal(int) - Static method in class org.apache.calcite.sql.SqlUtil
- deriveAndCollectTypes(SqlValidator, SqlValidatorScope, List<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
- deriveCollectRowType(SingleRel, String) - Static method in class org.apache.calcite.rel.core.Collect
-
Derives the output type of a collect relational expression.
- 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.
- DerivedColRef(Iterable<LatticeSuggester.TableRef>, RexNode, String) - Constructor for class org.apache.calcite.materialize.LatticeSuggester.DerivedColRef
- DerivedColumn(int, String, RexNode, List<String>) - Constructor for class org.apache.calcite.materialize.Lattice.DerivedColumn
- derivedColumnsByName - Variable in class org.apache.calcite.materialize.Lattice.Builder
- deriveFieldName(RexNode, int) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter
- 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.rel.core.Join
-
Deprecated.
- 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.
- deriveKey() - Method in class org.apache.calcite.runtime.Resources.Element
- deriveNaturalJoinColumnList(SqlNameMatcher, RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Derives the list of column names suitable for NATURAL JOIN.
- 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.FileTableScan
- deriveRowType() - Method in class org.apache.calcite.adapter.geode.rel.GeodeTableScan
- 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.SemiJoin
- 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. - 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
- deriveType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.SqlDataTypeSpec
-
Does not throw an error if the type is not built-in.
- deriveType(RelDataTypeFactory, boolean) - Method in class org.apache.calcite.sql.SqlDataTypeSpec
-
Converts this type specification to a
RelDataType
. - deriveType(SqlValidator) - Method in class org.apache.calcite.sql.SqlDataTypeSpec
-
Throws an error if the type is not found.
- 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.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.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.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.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.SqlWithinGroupOperator
- deriveType(SqlValidator, SqlValidatorScope, SqlCall, boolean) - Method in class org.apache.calcite.sql.SqlFunction
- 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
- deriveTypeImpl(SqlValidatorScope, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Derives the type of a node, never null.
- DeriveTypeVisitor(SqlValidatorScope) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.DeriveTypeVisitor
- deriveUncollectRowType(RelNode, boolean) - 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 - Variable in class org.apache.calcite.rel.AbstractRelNode
-
Description, consists of id plus digest.
- desc - Variable in class org.apache.calcite.util.Benchmark.Statistician
- desc(RelFieldCollation.Direction) - Static method in class org.apache.calcite.sql2rel.SqlToRelConverter
- desc(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Converts a sort expression to descending.
- DESC - 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(E, boolean) - Method in class org.apache.calcite.util.PartiallyOrderedSet
- descendants(MutableRel) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- descendantsRecurse(List<MutableRel>, MutableRel) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- DESCENDING - org.apache.calcite.rel.RelFieldCollation.Direction
-
Descending direction: A value is always followed by a lesser or equal value.
- DESCENDING - org.apache.calcite.sql.SqlKind
-
DESC in ORDER 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 - org.apache.calcite.piglet.Ast.Op
- DESCRIBE_SCHEMA - org.apache.calcite.sql.SqlKind
-
DESCRIBE SCHEMA statement
- DESCRIBE_TABLE - org.apache.calcite.sql.SqlKind
-
DESCRIBE TABLE statement
- DescribeStmt(SqlParserPos, Ast.Identifier) - Constructor for class org.apache.calcite.piglet.Ast.DescribeStmt
- description - Variable in class org.apache.calcite.plan.RelOptRule
-
Description of rule, must be unique within planner.
- description - Variable in class org.apache.calcite.util.PartiallyOrderedSet.TopBottomNode
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.AggregationsDeserializer
- destdir - Variable in class org.apache.calcite.util.javac.JaninoCompiler.JaninoCompilerArgs
- destDir - Variable in class org.apache.calcite.util.javac.JaninoCompiler.AccountingClassLoader
- destFields - Variable in class org.apache.calcite.plan.RelOptUtil.RexInputConverter
- detailLevel - Variable in class org.apache.calcite.prepare.Prepare.PreparedExplain
- detailLevel - Variable in class org.apache.calcite.rel.externalize.RelWriterImpl
- detailLevel - Variable in class org.apache.calcite.sql.SqlExplain
- Deterministic - Annotation Type in org.apache.calcite.linq4j.function
-
Specifies that function is deterministic (i.e.
- DETERMINISTIC_CLASSES - Static variable in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
- 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.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.Context
- dialect - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor
- dialect - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- dialect - Variable in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- dialect - Variable in class org.apache.calcite.sql.util.SqlBuilder
- dialect - Variable in class org.apache.calcite.sql.util.SqlString
- dialectDoesNotSupportFeature(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- DialectPool() - Constructor for class org.apache.calcite.adapter.jdbc.JdbcUtils.DialectPool
- difference(RelTraitSet) - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns a list of traits that are in
traitSet
but not in this RelTraitSet. - differentCollations(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- 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.plan.volcano.VolcanoRuleMatch
- digest - Variable in class org.apache.calcite.rel.AbstractRelNode
-
A short description of this relational expression's type, inputs, and other properties.
- digest - Variable in class org.apache.calcite.rel.core.Window.Group
- digest - Variable in class org.apache.calcite.rel.type.RelDataTypeImpl
- digest - Variable in class org.apache.calcite.rex.RexNode
- digest - Variable in class org.apache.calcite.rex.RexTableInputRef.RelTableRef
- digest - Variable in class org.apache.calcite.rex.RexWindow
- 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.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.MutableSemiJoin
- 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 - org.apache.calcite.sql.SqlExplainLevel
-
Display only attributes which contribute to an expression's digest.
- digits3(long, int) - Static method in class org.apache.calcite.util.Util
- dimension - Variable in class org.apache.calcite.adapter.druid.DefaultDimensionSpec
- dimension - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonBound
- dimension - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonInFilter
- dimension - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonSelector
- dimension - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonCollation
- dimension - Variable in class org.apache.calcite.adapter.druid.ExtractionDimensionSpec
- dimension - Variable in class org.apache.calcite.linq4j.tree.NewArrayExpression
- dimensionListBuilder - Variable in class org.apache.calcite.materialize.Lattice.TileBuilder
- dimensionOrder - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonCollation
- 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 - 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.adapter.druid.DruidQuery.JsonCollation
- direction - Variable in class org.apache.calcite.rel.RelFieldCollation
-
Direction of sorting.
- direction(RelFieldCollation) - Method in class org.apache.calcite.adapter.mongodb.MongoSort
- direction(RelFieldCollation.Direction) - Method in class org.apache.calcite.adapter.geode.rel.GeodeSort
- Direction() - Constructor for enum org.apache.calcite.example.maze.Maze.Direction
- Direction() - Constructor for enum org.apache.calcite.piglet.Ast.Direction
- Direction(String) - Constructor for enum org.apache.calcite.rel.RelFieldCollation.Direction
- 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
- directoryFile - Variable in class org.apache.calcite.adapter.csv.CsvSchema
- DirectProvenance(RelNode) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlanner.DirectProvenance
- 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.linq4j.tree.Types
- discard(Object) - Static method in class org.apache.calcite.util.Util
-
Does nothing with its argument.
- discoverTables - Variable in class org.apache.calcite.adapter.druid.DruidSchema
- 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.interpreter.Interpreter.CompilerImpl
- dispatcher - Variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- dispatcher - Variable in class org.apache.calcite.sql2rel.RelDecorrelator
- dispatcher - Variable in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener.RewriteRelVisitor
- 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. - display(PrintWriter, int) - Method in class org.apache.calcite.util.XmlOutput.XMLAttrVector
- displayIndent(PrintWriter, int) - Method in class org.apache.calcite.util.XmlOutput
-
Private helper function to display a degree of indentation
- distanceRecurse(Map<PartiallyOrderedSet.Node, Integer>, PartiallyOrderedSet.Node<E>, int) - Method in class org.apache.calcite.util.PartiallyOrderedSet
- distinct - Variable in class org.apache.calcite.materialize.Lattice.Measure
- distinct - Variable in class org.apache.calcite.materialize.LatticeSuggester.MutableMeasure
- distinct - Variable in class org.apache.calcite.rel.core.AggregateCall
- distinct - Variable in class org.apache.calcite.rel.core.Window.RexWinAggCall
-
Whether to eliminate duplicates before applying aggregate function.
- distinct - Variable in class org.apache.calcite.rex.RexOver
- distinct - Variable in class org.apache.calcite.sql.validate.AggChecker
- distinct - Variable in class org.apache.calcite.sql.validate.AggregatingSelectScope
- distinct - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.HistogramShuttle
- distinct - Variable in class org.apache.calcite.tools.RelBuilder.AggCallImpl
- distinct() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- distinct() - Method in class org.apache.calcite.linq4j.DefaultQueryable
- distinct() - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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 interface org.apache.calcite.linq4j.ExtendedQueryable
-
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.AggCallImpl
- distinct() - Method in class org.apache.calcite.tools.RelBuilder.AggCallImpl2
- 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(boolean) - Method in class org.apache.calcite.tools.RelBuilder.AggCallImpl
- distinct(boolean) - Method in class org.apache.calcite.tools.RelBuilder.AggCallImpl2
- 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.linq4j.DefaultQueryable
- distinct(EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- distinct(PigRelBuilder.Partitioner, int) - Method in class org.apache.calcite.tools.PigRelBuilder
-
Removes duplicate tuples in a relation.
- DISTINCT - org.apache.calcite.piglet.Ast.Op
- DISTINCT - org.apache.calcite.sql.SqlSelectKeyword
- DISTINCT - org.apache.calcite.sql.type.SqlTypeName
- DISTINCT - org.apache.calcite.util.BuiltInMethod
- DISTINCT_FIELD_SUFFIX - Static variable in class org.apache.calcite.adapter.pig.PigAggregate
- DISTINCT_ROW_COUNT - org.apache.calcite.util.BuiltInMethod
- DISTINCT2 - org.apache.calcite.util.BuiltInMethod
- distinctify(SqlToRelConverter.Blackboard, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Having translated 'SELECT ...
- 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.
- distinctRowCountHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- DistinctStmt(SqlParserPos, Ast.Identifier, Ast.Identifier) - Constructor for class org.apache.calcite.piglet.Ast.DistinctStmt
- distinctVariables(boolean) - Method in class org.apache.calcite.linq4j.tree.BlockStatement
- distribution - Variable in class org.apache.calcite.rel.core.Exchange
- distribution - Variable in class org.apache.calcite.rel.mutable.MutableExchange
- distribution() - Method in class org.apache.calcite.profile.ProfilerImpl.Space
-
Returns the distribution created from this space, or null if no distribution has been registered yet.
- distribution() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Distribution
-
Determines how the rows are distributed.
- distribution(HepRelVertex, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdDistribution
- 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(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 - org.apache.calcite.util.BuiltInMethod
- distributionHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- distributionList - Variable in class org.apache.calcite.profile.Profiler.Profile
- distributionMap - Variable in class org.apache.calcite.profile.Profiler.Profile
- distributions - Variable in class org.apache.calcite.profile.ProfilerImpl.Run
- 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
- 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(RexBuilder, RexNode, BigDecimal) - Static method in class org.apache.calcite.sql2rel.StandardConvertletTable
- divide(Mapping, Mapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Divides one mapping by another.
- Divide - org.apache.calcite.linq4j.tree.ExpressionType
-
A division operation, such as (a / b), for numeric operands.
- DIVIDE - org.apache.calcite.sql.SqlKind
-
The 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 - 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
- divideBy(RelOptCost) - Method in class org.apache.calcite.plan.volcano.VolcanoCost
- divideInt(RexBuilder, RexNode, RexNode) - Static method in class org.apache.calcite.sql2rel.StandardConvertletTable
- 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
- DnfHelper(RexBuilder) - Constructor for class org.apache.calcite.rex.RexUtil.DnfHelper
- doesConverterApply(ConverterRule, HepRelVertex) - Method in class org.apache.calcite.plan.hep.HepPlanner
- done - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.BlockingQueueEnumerator
- done - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- done - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileEnumerator
- done - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileLongEnumerator
- 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.
- doneQueue - Variable in class org.apache.calcite.profile.ProfilerImpl.Run
-
Combinations of columns that we have computed but whose successors have not yet been computed.
- doRewrite(RelBuilder, Aggregate, int, List<Integer>, int, List<RexInputRef>) - Method in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
-
Converts all distinct aggregate calls to a given set of arguments.
- dot(RexNode, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an access to a field by ordinal.
- dot(RexNode, String) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an access to a field by name.
- DOT - org.apache.calcite.piglet.Ast.Op
- DOT - 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 - org.apache.calcite.adapter.csv.CsvFieldType
- DOUBLE - org.apache.calcite.adapter.druid.DruidType
- DOUBLE - org.apache.calcite.adapter.file.FileFieldType
- DOUBLE - org.apache.calcite.linq4j.tree.Primitive
- DOUBLE - 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_FORMAT - Static variable in class org.apache.calcite.runtime.SqlFunctions
- DOUBLE_FORMATTER - Static variable in class org.apache.calcite.util.NumberUtil
- DOUBLE_MAX - Static variable in class org.apache.calcite.linq4j.Extensions
- DOUBLE_MIN - Static variable in class org.apache.calcite.linq4j.Extensions
- 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_QUOTE - Static variable in class org.apache.calcite.util.StackWriter
- DOUBLE_SUM - Static variable in class org.apache.calcite.linq4j.Extensions
- DoubleFunction1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function that takes one parameter and returns a native
double
value. - DoubleProp(Resources.PropertyAccessor, Method) - Constructor for class org.apache.calcite.runtime.Resources.DoubleProp
- DoubleSum() - Constructor for class org.apache.calcite.interpreter.AggregateNode.DoubleSum
- doubleValue() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.LiteralExpression
- doubleValue(Resources.DoubleProp) - Method in enum org.apache.calcite.runtime.Resources.EmptyPropertyAccessor
- doubleValue(Resources.DoubleProp) - Method in class org.apache.calcite.runtime.Resources.PropertiesAccessor
- doubleValue(Resources.DoubleProp) - Method in interface org.apache.calcite.runtime.Resources.PropertyAccessor
- doubleValue(Resources.DoubleProp, double) - Method in enum org.apache.calcite.runtime.Resources.EmptyPropertyAccessor
- doubleValue(Resources.DoubleProp, double) - Method in class org.apache.calcite.runtime.Resources.PropertiesAccessor
- doubleValue(Resources.DoubleProp, double) - Method in interface org.apache.calcite.runtime.Resources.PropertyAccessor
- DOWN - org.apache.calcite.example.maze.Maze.Direction
- DQID - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
-
double-quoted identifier, e.g.
- Driver - Class in org.apache.calcite.jdbc
-
Calcite JDBC driver.
- Driver() - Constructor for class org.apache.calcite.jdbc.Driver
- DRIVER - Static variable in class org.apache.calcite.jdbc.CalciteMetaImpl
- DRIVER_URL - Static variable in class org.apache.calcite.chinook.CalciteConnectionProvider
- DROP_FUNCTION - org.apache.calcite.sql.SqlKind
-
DROP FUNCTION
DDL statement. - DROP_INDEX - org.apache.calcite.sql.SqlKind
-
DROP INDEX
DDL statement. - DROP_MATERIALIZED_VIEW - org.apache.calcite.sql.SqlKind
-
DROP MATERIALIZED VIEW
DDL statement. - DROP_SCHEMA - org.apache.calcite.sql.SqlKind
-
DROP SCHEMA
DDL statement. - DROP_SEQUENCE - org.apache.calcite.sql.SqlKind
-
DROP SEQUENCE
DDL statement. - DROP_TABLE - org.apache.calcite.sql.SqlKind
-
DROP TABLE
DDL statement. - DROP_TYPE - org.apache.calcite.sql.SqlKind
-
DROP TYPE
DDL statement. - DROP_VIEW - 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_FETCH - 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_QUERY_FETCH - Static variable in class org.apache.calcite.adapter.druid.DruidQuery
- DruidAggregateExtractProjectRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidAggregateExtractProjectRule
-
Creates a DruidAggregateExtractProjectRule.
- DruidAggregateFilterTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidAggregateFilterTransposeRule
-
Creates a DruidAggregateFilterTransposeRule.
- DruidAggregateProjectRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidAggregateProjectRule
-
Creates a DruidAggregateProjectRule.
- DruidAggregateRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidAggregateRule
-
Creates a DruidAggregateRule.
- DruidConnection - Interface in org.apache.calcite.adapter.druid
-
Connection to Druid.
- DruidConnectionImpl - Class in org.apache.calcite.adapter.druid
-
Implementation of
DruidConnection
. - DruidConnectionImpl(String, String) - Constructor for class org.apache.calcite.adapter.druid.DruidConnectionImpl
- DruidConnectionImpl.BlockingQueueEnumerator<E> - Class in org.apache.calcite.adapter.druid
-
An
Enumerator
that gets its rows from aBlockingQueue
. - DruidConnectionImpl.JsonAggregator - Class in org.apache.calcite.adapter.druid
-
Element of the "aggregators" collection in the result of a "segmentMetadata" call, populated by Jackson.
- DruidConnectionImpl.JsonColumn - Class in org.apache.calcite.adapter.druid
-
Element of the "columns" collection in the result of a "segmentMetadata" call, populated by Jackson.
- DruidConnectionImpl.JsonSegmentMetadata - Class in org.apache.calcite.adapter.druid
-
Result of a "segmentMetadata" call, populated by Jackson.
- DruidConnectionImpl.Page - Class in org.apache.calcite.adapter.druid
-
Progress through a large fetch.
- DruidConnectionImpl.RunnableQueueSink - Interface in org.apache.calcite.adapter.druid
-
A
Sink
that is alsoRunnable
. - DruidDateTimeUtils - Class in org.apache.calcite.adapter.druid
-
Utilities for generating intervals from RexNode.
- DruidDateTimeUtils() - Constructor for class org.apache.calcite.adapter.druid.DruidDateTimeUtils
- DruidExpressions - Class in org.apache.calcite.adapter.druid
-
Expression utility class to transform Calcite expressions to Druid expressions when possible.
- DruidExpressions() - Constructor for class org.apache.calcite.adapter.druid.DruidExpressions
- DruidFilterAggregateTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidFilterAggregateTransposeRule
-
Creates a DruidFilterAggregateTransposeRule.
- DruidFilterProjectTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidFilterProjectTransposeRule
-
Creates a DruidFilterProjectTransposeRule.
- DruidFilterRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidFilterRule
-
Creates a DruidFilterRule.
- druidFunctionName - Variable in class org.apache.calcite.adapter.druid.DirectOperatorConversion
- DruidHavingFilterRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidHavingFilterRule
- DruidJson - Interface in org.apache.calcite.adapter.druid
-
Object that knows how to write itself to a
JsonGenerator
. - DruidJsonFilter - Class in org.apache.calcite.adapter.druid
-
Filter element of a Druid "groupBy" or "topN" query.
- DruidJsonFilter(DruidJsonFilter.Type) - Constructor for class org.apache.calcite.adapter.druid.DruidJsonFilter
- DruidJsonFilter.JsonBound - Class in org.apache.calcite.adapter.druid
-
Bound filter.
- DruidJsonFilter.JsonCompositeFilter - Class in org.apache.calcite.adapter.druid
-
Filter that combines other filters using a boolean operator.
- DruidJsonFilter.JsonDimHavingFilter - Class in org.apache.calcite.adapter.druid
-
Druid Having Filter spec
- DruidJsonFilter.JsonExpressionFilter - Class in org.apache.calcite.adapter.druid
-
Druid Expression filter.
- DruidJsonFilter.JsonInFilter - Class in org.apache.calcite.adapter.druid
-
IN filter.
- DruidJsonFilter.JsonSelector - Class in org.apache.calcite.adapter.druid
-
Equality filter.
- DruidJsonFilter.Type - Enum in org.apache.calcite.adapter.druid
-
Supported filter types
- druidOperator - Variable in class org.apache.calcite.adapter.druid.BinaryOperatorConversion
- druidOperator - Variable in class org.apache.calcite.adapter.druid.UnaryPrefixOperatorConversion
- druidOperator - Variable in class org.apache.calcite.adapter.druid.UnarySuffixOperatorConversion
- druidOperatorName - Variable in class org.apache.calcite.adapter.druid.NaryOperatorConverter
- DruidPostAggregationProjectRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidPostAggregationProjectRule
-
Creates a DruidPostAggregationProjectRule.
- DruidProjectFilterTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidProjectFilterTransposeRule
-
Creates a DruidProjectFilterTransposeRule.
- DruidProjectRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidProjectRule
-
Creates a DruidProjectRule.
- DruidProjectSortTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidProjectSortTransposeRule
-
Creates a DruidProjectSortTransposeRule.
- 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.DruidQueryNode - Class in org.apache.calcite.adapter.druid
-
Interpreter node that executes a Druid query and sends the results to a
Sink
. - DruidQuery.JsonAggregation - Class in org.apache.calcite.adapter.druid
-
Aggregation element of a Druid "groupBy" or "topN" query.
- DruidQuery.JsonCardinalityAggregation - Class in org.apache.calcite.adapter.druid
-
Aggregation element that calls the "cardinality" function.
- DruidQuery.JsonCollation - Class in org.apache.calcite.adapter.druid
-
Collation element of a Druid "groupBy" query.
- DruidQuery.JsonExpressionPostAgg - Class in org.apache.calcite.adapter.druid
-
Druid Json Expression post aggregate.
- DruidQuery.JsonFilteredAggregation - Class in org.apache.calcite.adapter.druid
-
Aggregation element that contains a filter
- DruidQuery.JsonLimit - Class in org.apache.calcite.adapter.druid
-
Collation element of a Druid "groupBy" query.
- DruidQuery.JsonPostAggregation - Class in org.apache.calcite.adapter.druid
-
Post-Aggregator Post aggregator abstract writer
- DruidQuery.QuerySpec - Class in org.apache.calcite.adapter.druid
-
Druid query specification.
- DruidQuery.ScanQuery - Class in org.apache.calcite.adapter.druid
-
Druid Scan Query Body
- DruidQueryNode(Compiler, DruidQuery) - Constructor for class org.apache.calcite.adapter.druid.DruidQuery.DruidQueryNode
- DruidRules - Class in org.apache.calcite.adapter.druid
-
Rules and relational operators for
DruidQuery
. - DruidRules() - Constructor for class org.apache.calcite.adapter.druid.DruidRules
- DruidRules.DruidAggregateExtractProjectRule - Class in org.apache.calcite.adapter.druid
-
Rule to extract a
Project
fromAggregate
on top ofDruidQuery
based on the fields used in the aggregate. - DruidRules.DruidAggregateFilterTransposeRule - Class in org.apache.calcite.adapter.druid
- DruidRules.DruidAggregateProjectRule - Class in org.apache.calcite.adapter.druid
- DruidRules.DruidAggregateRule - Class in org.apache.calcite.adapter.druid
-
Rule to push an
Aggregate
into aDruidQuery
. - DruidRules.DruidFilterAggregateTransposeRule - Class in org.apache.calcite.adapter.druid
- DruidRules.DruidFilterProjectTransposeRule - Class in org.apache.calcite.adapter.druid
- DruidRules.DruidFilterRule - Class in org.apache.calcite.adapter.druid
-
Rule to push a
Filter
into aDruidQuery
. - DruidRules.DruidHavingFilterRule - Class in org.apache.calcite.adapter.druid
-
Rule to Push a Having
Filter
into aDruidQuery
- DruidRules.DruidPostAggregationProjectRule - Class in org.apache.calcite.adapter.druid
-
Rule to push a
Project
into aDruidQuery
as a Post aggregator. - DruidRules.DruidProjectFilterTransposeRule - Class in org.apache.calcite.adapter.druid
- DruidRules.DruidProjectRule - Class in org.apache.calcite.adapter.druid
-
Rule to push a
Project
into aDruidQuery
. - DruidRules.DruidProjectSortTransposeRule - Class in org.apache.calcite.adapter.druid
- DruidRules.DruidSortProjectTransposeRule - Class in org.apache.calcite.adapter.druid
- DruidRules.DruidSortRule - Class in org.apache.calcite.adapter.druid
-
Rule to push a
Sort
into aDruidQuery
. - 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
- DruidSortProjectTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.druid.DruidRules.DruidSortProjectTransposeRule
-
Creates a DruidSortProjectTransposeRule.
- DruidSortRule(RelBuilderFactory) - 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 cast
- DruidSqlCastConverter() - Constructor for class org.apache.calcite.adapter.druid.DruidSqlCastConverter
- DruidSqlOperatorConverter - Interface in org.apache.calcite.adapter.druid
-
Defines how to convert RexNode with a given calcite SQL operator to Druid expressions
- druidTable - Variable in class org.apache.calcite.adapter.druid.DruidQuery
- 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.
- DruidTable.MapRelProtoDataType - Class in org.apache.calcite.adapter.druid
-
Creates a
RelDataType
from a map of field names and types. - DruidTableFactory - Class in org.apache.calcite.adapter.druid
-
Implementation of
TableFactory
for Druid. - DruidTableFactory() - Constructor for class org.apache.calcite.adapter.druid.DruidTableFactory
- druidType() - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonAggregator
- DruidType - Enum in org.apache.calcite.adapter.druid
-
Druid type.
- DruidType(SqlTypeName) - Constructor for enum org.apache.calcite.adapter.druid.DruidType
- 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
- DUMB_FILTER_ON_JOIN - Static variable in class org.apache.calcite.rel.rules.FilterJoinRule
-
Dumber version of
FilterJoinRule.FILTER_ON_JOIN
. - dummy - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- Dummy() - Constructor for class org.apache.calcite.jdbc.CalcitePrepare.Dummy
- DUMMY - Static variable in class org.apache.calcite.linq4j.Linq4j
- DUMMY - Static variable in class org.apache.calcite.rel.metadata.MetadataFactoryImpl
- DUMMY - Static variable in class org.apache.calcite.sql.SqlDialect
-
Deprecated.Use
AnsiSqlDialect.DEFAULT
instead. - DUMMY - Static variable in class org.apache.calcite.util.NameSet
- DUMMY - Static variable in class org.apache.calcite.util.Util.FilteringIterator
- DummyDataContext(CalciteConnection, SchemaPlus) - Constructor for class org.apache.calcite.schema.Schemas.DummyDataContext
- 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.
- DummyTrustManager() - Constructor for class org.apache.calcite.runtime.TrustAllSslSocketFactory.DummyTrustManager
- dump() - Method in class org.apache.calcite.plan.volcano.RuleQueue
- dump(PrintWriter) - Method in class org.apache.calcite.plan.volcano.RuleQueue
- 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 - org.apache.calcite.piglet.Ast.Op
- dumpGraph() - Method in class org.apache.calcite.plan.hep.HepPlanner
- 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.
- 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
- DuplicatingSink(List<ArrayDeque<Row>>) - Constructor for class org.apache.calcite.interpreter.Interpreter.DuplicatingSink
- dupWindowSpec() - Method in interface org.apache.calcite.runtime.CalciteResource
- durations - Variable in class org.apache.calcite.util.Benchmark.Statistician
- DuTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "du" ("disk usage") command to compute file sizes.
- DuTableFunction() - Constructor for class org.apache.calcite.adapter.os.DuTableFunction
- DYADIC_STRING_SUM_PRECISION - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the same type as the input types but with the combined length of the two first types if types are of char type the type with the highest coercibility will be used result is varying if either input is; otherwise fixed
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A dynamic operation.
- DYNAMIC_HANDLER - Static variable in class org.apache.calcite.util.trace.CalciteTrace
- DYNAMIC_PARAM - org.apache.calcite.sql.SqlKind
-
A dynamic parameter.
- DYNAMIC_STAR - 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
- dynamicFunction - Variable in class org.apache.calcite.linq4j.tree.FunctionExpression
- 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.
- dynamicParameterCount - Variable in class org.apache.calcite.sql.SqlExplain
- dynamicParameters - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- dynamicParameters - Variable in class org.apache.calcite.sql.util.SqlString
- dynamicParamIllegal() - Method in interface org.apache.calcite.runtime.CalciteResource
- dynamicParamSqlNodes - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- 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.
E
- e - Variable in class org.apache.calcite.linq4j.Linq4j.SingletonEnumerator
- 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.materialize.LatticeSuggester.DerivedColRef
- e - Variable in class org.apache.calcite.rex.RexAnalyzer
- e - Variable in class org.apache.calcite.util.Holder
- e - Variable in class org.apache.calcite.util.PartiallyOrderedSet.Node
- earliest - Variable in class org.apache.calcite.adapter.splunk.SplunkQuery
- earliest - Variable in class org.apache.calcite.adapter.splunk.SplunkTableScan
- Edge(Lattice.Vertex, Lattice.Vertex) - Constructor for class org.apache.calcite.materialize.Lattice.Edge
- Edge(RelNode, int) - Constructor for class org.apache.calcite.interpreter.Interpreter.Edge
- Edge(RexNode, ImmutableBitSet, ImmutableBitSet) - Constructor for class org.apache.calcite.rel.rules.LoptMultiJoin.Edge
- Edge(RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef) - Constructor for class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.Edge
- edgeFactory - Variable in class org.apache.calcite.util.graph.DefaultDirectedGraph
- edges - Variable in class org.apache.calcite.util.graph.DefaultDirectedGraph
- edgeSet() - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- edgeSet() - Method in interface org.apache.calcite.util.graph.DirectedGraph
- ELASTICSEARCH_QUERYABLE_FIND - org.apache.calcite.adapter.elasticsearch.ElasticsearchMethod
- ElasticsearchAggregate - Class in org.apache.calcite.adapter.elasticsearch
-
Implementation of
Aggregate
relational expression for ElasticSearch. - ElasticsearchAggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchAggregate
-
Creates a ElasticsearchAggregate
- ElasticsearchAggregateRule() - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.ElasticsearchAggregateRule
- ElasticsearchConstants - Interface in org.apache.calcite.adapter.elasticsearch
-
Internal constants referenced in this package.
- ElasticsearchConverterRule(Class<? extends RelNode>, RelTrait, Convention, String) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.ElasticsearchConverterRule
- ElasticsearchEnumerators - Class in org.apache.calcite.adapter.elasticsearch
-
Util functions which convert
ElasticsearchJson.SearchHit
into calcite specific return type (map, object[], list etc.) - ElasticsearchEnumerators() - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchEnumerators
- elasticsearchFieldNames(RelDataType) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules
- ElasticsearchFilter - Class in org.apache.calcite.adapter.elasticsearch
-
Implementation of a
Filter
relational expression in Elasticsearch. - ElasticsearchFilter(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter
- ElasticsearchFilter.PredicateAnalyzerTranslator - Class in org.apache.calcite.adapter.elasticsearch
-
New version of translator which uses visitor pattern and allow to process more complex (boolean) predicates.
- ElasticsearchFilter.Translator - Class in org.apache.calcite.adapter.elasticsearch
-
Translates
RexNode
expressions into Elasticsearch expression strings. - ElasticsearchFilterRule() - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.ElasticsearchFilterRule
- ElasticsearchJson - Class in org.apache.calcite.adapter.elasticsearch
-
Internal objects (and deserializers) used to parse Elasticsearch results (which are in JSON format).
- ElasticsearchJson() - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson
- ElasticsearchJson.Aggregation - Interface in org.apache.calcite.adapter.elasticsearch
-
Identifies all aggregations
- ElasticsearchJson.Aggregations - Class in org.apache.calcite.adapter.elasticsearch
-
ElasticsearchJson.Aggregation
container. - ElasticsearchJson.AggregationsDeserializer - Class in org.apache.calcite.adapter.elasticsearch
-
Allows to de-serialize nested aggregation structures.
- ElasticsearchJson.Bucket - Class in org.apache.calcite.adapter.elasticsearch
-
A bucket represents a criteria to which all documents that fall in it adhere to.
- ElasticsearchJson.GroupValue - Class in org.apache.calcite.adapter.elasticsearch
-
Distinguishes from
ElasticsearchJson.MultiValue
. - ElasticsearchJson.HasAggregations - Interface in org.apache.calcite.adapter.elasticsearch
-
Allows traversing aggregations tree
- ElasticsearchJson.MultiBucketsAggregation - Class in org.apache.calcite.adapter.elasticsearch
-
An aggregation that returns multiple buckets
- ElasticsearchJson.MultiValue - Class in org.apache.calcite.adapter.elasticsearch
-
Multi value aggregatoin like Stats
- ElasticsearchJson.Result - Class in org.apache.calcite.adapter.elasticsearch
-
Response from Elastic
- ElasticsearchJson.RowKey - Class in org.apache.calcite.adapter.elasticsearch
-
Identifies a calcite row (as in relational algebra)
- ElasticsearchJson.SearchHit - Class in org.apache.calcite.adapter.elasticsearch
-
Concrete result record which matched the query.
- ElasticsearchJson.SearchHits - Class in org.apache.calcite.adapter.elasticsearch
-
Similar to
SearchHits
in ES. - ElasticsearchMapping - Class in org.apache.calcite.adapter.elasticsearch
-
Stores Elasticsearch mapping information for particular index/type.
- ElasticsearchMapping(String, String, Map<String, String>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping
- ElasticsearchMapping.Datatype - Class in org.apache.calcite.adapter.elasticsearch
-
Represents elastic data-type, like
long
,keyword
,date
etc. - ElasticsearchMethod - Enum in org.apache.calcite.adapter.elasticsearch
-
Builtin methods in the Elasticsearch adapter.
- ElasticsearchMethod(Class, String, Class...) - Constructor for enum org.apache.calcite.adapter.elasticsearch.ElasticsearchMethod
- ElasticsearchProject - Class in org.apache.calcite.adapter.elasticsearch
-
Implementation of
Project
relational expression in Elasticsearch. - ElasticsearchProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchProject
- ElasticsearchProjectRule() - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.ElasticsearchProjectRule
- ElasticsearchQueryable(QueryProvider, SchemaPlus, ElasticsearchTable, String) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable.ElasticsearchQueryable
- 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. - ElasticsearchRules - Class in org.apache.calcite.adapter.elasticsearch
-
Rules and relational operators for
ELASTICSEARCH
calling convention. - ElasticsearchRules() - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules
- ElasticsearchRules.ElasticsearchAggregateRule - Class in org.apache.calcite.adapter.elasticsearch
-
Rule to convert an
LogicalAggregate
to anElasticsearchAggregate
. - ElasticsearchRules.ElasticsearchConverterRule - Class in org.apache.calcite.adapter.elasticsearch
-
Base class for planner rules that convert a relational expression to Elasticsearch calling convention.
- ElasticsearchRules.ElasticsearchFilterRule - Class in org.apache.calcite.adapter.elasticsearch
-
Rule to convert a
LogicalFilter
to anElasticsearchFilter
. - ElasticsearchRules.ElasticsearchProjectRule - Class in org.apache.calcite.adapter.elasticsearch
-
Rule to convert a
LogicalProject
to anElasticsearchProject
. - ElasticsearchRules.ElasticsearchSortRule - Class in org.apache.calcite.adapter.elasticsearch
-
Rule to convert a
Sort
to anElasticsearchSort
. - ElasticsearchRules.RexToElasticsearchTranslator - Class in org.apache.calcite.adapter.elasticsearch
-
Translator from
RexNode
to strings in Elasticsearch's expression language. - ElasticsearchSchema - Class in org.apache.calcite.adapter.elasticsearch
-
Schema mapped onto an index of ELASTICSEARCH types.
- ElasticsearchSchema(RestClient, ObjectMapper, String) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchema
-
Allows schema to be instantiated from existing elastic search client.
- ElasticsearchSchema(RestClient, ObjectMapper, String, String) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchema
- ElasticsearchSchema(RestClient, ObjectMapper, String, String, int) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchema
- 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(ElasticsearchSearchResult.SearchHits, long) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult
-
Constructor for this instance.
- 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. - ElasticsearchSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchSort
- ElasticsearchSortRule() - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.ElasticsearchSortRule
- elasticsearchTable - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
- elasticsearchTable - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTableScan
- ElasticsearchTable - Class in org.apache.calcite.adapter.elasticsearch
-
Table based on an Elasticsearch type.
- ElasticsearchTable(ElasticsearchTransport) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
-
Creates an ElasticsearchTable.
- 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.
- ElasticsearchTableScan(RelOptCluster, RelTraitSet, RelOptTable, ElasticsearchTable, RelDataType) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchTableScan
-
Creates an ElasticsearchTableScan.
- ElasticsearchToEnumerableConverter - Class in org.apache.calcite.adapter.elasticsearch
-
Relational expression representing a scan of a table in an Elasticsearch data source.
- ElasticsearchToEnumerableConverter(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchToEnumerableConverter
- ElasticsearchToEnumerableConverterRule - Class in org.apache.calcite.adapter.elasticsearch
-
Rule to convert a relational expression from
ElasticsearchRel.CONVENTION
toEnumerableConvention
. - ElasticsearchToEnumerableConverterRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchToEnumerableConverterRule
-
Creates an ElasticsearchToEnumerableConverterRule.
- ElasticsearchTransport - Class in org.apache.calcite.adapter.elasticsearch
-
Set of predefined functions for REST interaction with elastic search API.
- ElasticsearchTransport(RestClient, ObjectMapper, String, String, int) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- ElasticsearchTransport.HttpFunction - Class in org.apache.calcite.adapter.elasticsearch
-
Basic rest operations interacting with elastic cluster.
- ElasticsearchTransport.JsonParserFn<T> - Class in org.apache.calcite.adapter.elasticsearch
-
Parses HTTP response into some class using jackson API.
- ElasticsearchVersion - Enum in org.apache.calcite.adapter.elasticsearch
-
Identifies current ES version at runtime.
- ElasticsearchVersion() - Constructor for enum org.apache.calcite.adapter.elasticsearch.ElasticsearchVersion
- element - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.Wrapped
- element(Object[], int) - Static method in class org.apache.calcite.util.ChunkList
- element(List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ELEMENT function.
- Element(Method) - Constructor for class org.apache.calcite.runtime.Resources.Element
- ELEMENT - 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(int) - Method in class org.apache.calcite.linq4j.Linq4j.ListEnumerable
- 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
- elementAt(Queryable<T>, int) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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
- elementAtOrDefault(Queryable<T>, int) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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
- elements - Variable in class org.apache.calcite.linq4j.Ord.OrdArrayList
- elements - Variable in class org.apache.calcite.linq4j.Ord.OrdList
- elements - Variable in class org.apache.calcite.util.ImmutableNullableList
- elements - Variable in class org.apache.calcite.util.UnmodifiableArrayList
- elementType - Variable in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
- elementType - Variable in class org.apache.calcite.adapter.java.AbstractQueryableTable
- elementType - Variable in class org.apache.calcite.adapter.java.ReflectiveSchema.ReflectiveTable
- elementType - Variable in class org.apache.calcite.linq4j.BaseQueryable
- elementType - Variable in class org.apache.calcite.linq4j.EnumerableQueryable
- elementType - Variable in class org.apache.calcite.rel.core.TableFunctionScan
- elementType - Variable in class org.apache.calcite.rel.mutable.MutableTableFunctionScan
- elementType - Variable in class org.apache.calcite.sql.type.ArraySqlType
- elementType - Variable in class org.apache.calcite.sql.type.MultisetSqlType
- ELEVEN - org.apache.calcite.util.mapping.MappingType
- elseArgs(int) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- elseExpr - Variable in class org.apache.calcite.sql.fun.SqlCase
- empid - Variable in class org.apache.calcite.benchmarks.StatementTest.Employee
- Employee(int, int, String, float, Integer) - Constructor for class org.apache.calcite.benchmarks.StatementTest.Employee
- employees - Variable in class org.apache.calcite.benchmarks.StatementTest.Department
- emps - Variable in class org.apache.calcite.benchmarks.StatementTest.HrSchema
- empties - Variable in class org.apache.calcite.util.graph.TopologicalOrderIterator
- empty - Variable in class org.apache.calcite.interpreter.AggregateNode.UdaAccumulator
- 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() - 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(RexBuilder) - Static method in class org.apache.calcite.prepare.CalcitePrepareImpl.EmptyScalarTranslator
- EMPTY - org.apache.calcite.plan.RelOptUtil.Side
- EMPTY - org.apache.calcite.sql.SqlJsonEmptyOrError
- EMPTY - Static variable in class org.apache.calcite.plan.RelOptPredicateList
- EMPTY - Static variable in class org.apache.calcite.plan.volcano.VolcanoPlanner.Provenance
- EMPTY - Static variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- 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.schema.Schemas.PathImpl
- 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 - Static variable in class org.apache.calcite.util.ImmutableBitSet
- EMPTY - Static variable in class org.apache.calcite.util.ImmutableIntList
- EMPTY_ARRAY - org.apache.calcite.sql.SqlJsonQueryEmptyOrErrorBehavior
- EMPTY_ARRAY - Static variable in class org.apache.calcite.sql.SqlNode
- EMPTY_ARRAY - Static variable in class org.apache.calcite.util.ImmutableIntList
- 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 - org.apache.calcite.util.BuiltInMethod
- EMPTY_ENUMERABLE - Static variable in class org.apache.calcite.linq4j.Linq4j
- EMPTY_ENUMERATOR - Static variable in class org.apache.calcite.linq4j.Linq4j
- EMPTY_LIST - Static variable in class org.apache.calcite.plan.RelOptPredicateList
- EMPTY_LIST - Static variable in class org.apache.calcite.rel.metadata.RelMdPredicates
- EMPTY_LONGS - Static variable in class org.apache.calcite.util.ImmutableBitSet
- EMPTY_OBJECT - org.apache.calcite.sql.SqlJsonQueryEmptyOrErrorBehavior
- EMPTY_STATEMENT - Static variable in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- EMPTY_TRAITS - Static variable in class org.apache.calcite.plan.RelTraitSet
- emptyContext() - Static method in class org.apache.calcite.sql.SqlDialect
-
Creates an empty context.
- EmptyContext() - Constructor for class org.apache.calcite.plan.Contexts.EmptyContext
- 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. - EmptyImmutableIntList() - Constructor for class org.apache.calcite.util.ImmutableIntList.EmptyImmutableIntList
- EmptyPath() - Constructor for class org.apache.calcite.sql.validate.SqlValidatorScope.EmptyPath
- EmptyPropertyAccessor() - Constructor for enum org.apache.calcite.runtime.Resources.EmptyPropertyAccessor
- emptyResultOfJsonQueryFuncNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- emptyResultOfJsonValueFuncNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- EmptyScalarTranslator(RexBuilder) - Constructor for class org.apache.calcite.prepare.CalcitePrepareImpl.EmptyScalarTranslator
- EmptyScope - Class in org.apache.calcite.sql.validate
-
Deviant implementation of
SqlValidatorScope
for the top of the scope stack. - EmptyScope(SqlValidatorImpl) - Constructor for class org.apache.calcite.sql.validate.EmptyScope
- emptyStructType - Variable in class org.apache.calcite.sql.advise.SqlAdvisorValidator
- emptyTag(String, XmlOutput.XMLAttrVector) - Method in class org.apache.calcite.util.XmlOutput
-
Writes an empty tag to the stream.
- emptyTraitSet - Variable in class org.apache.calcite.plan.RelOptCluster
- 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
- emulateNullDirection - Variable in class org.apache.calcite.sql.dialect.HiveSqlDialect
- 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.MysqlSqlDialect
- 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(long, boolean) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema.AbstractCached
- enable(long, boolean) - Method in interface org.apache.calcite.jdbc.CachingCalciteSchema.Cached
-
Called when CalciteSchema caching is enabled or disabled.
- ENABLE_BINDABLE - 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.prepare.CalcitePrepareImpl
-
Whether to enable the collation trait.
- ENABLE_ENUMERABLE - Static variable in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Whether the enumerable convention is enabled.
- ENABLE_HISTOGRAM_AGG - Static variable in class org.apache.calcite.sql2rel.SqlToRelConverter.HistogramShuttle
-
Whether to convert calls to MIN(x) to HISTOGRAM_MIN(HISTOGRAM(x)).
- ENABLE_STREAM - Static variable in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Whether the streaming is enabled.
- 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 class org.apache.calcite.jdbc.CalcitePrepare.Dummy.TrivialSparkHandler
- 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.
- enclosingNode - Variable in class org.apache.calcite.sql.validate.AbstractNamespace
- encodeIntervalOrDecimal(RexNode, RelDataType, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Casts a decimal's integer representation to a decimal node.
- encodeList(List<? extends CharSequence>, char) - Static method in class org.apache.calcite.adapter.splunk.util.StringUtils
- encodeValue(RexNode, RelDataType) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Casts a decimal's integer representation to a decimal node.
- encodeValue(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.util.ChunkList.ChunkListIterator
-
Offset of the first unoccupied location in the current chunk.
- end() - Method in interface org.apache.calcite.interpreter.AggregateNode.Accumulator
- end() - Method in class org.apache.calcite.interpreter.AggregateNode.CountAccumulator
- end() - Method in class org.apache.calcite.interpreter.AggregateNode.FilterAccumulator
- end() - Method in class org.apache.calcite.interpreter.AggregateNode.ScalarAccumulator
- end() - Method in class org.apache.calcite.interpreter.AggregateNode.UdaAccumulator
- end() - Method in class org.apache.calcite.interpreter.Interpreter.DuplicatingSink
- end() - Method in class org.apache.calcite.interpreter.Interpreter.ListSink
- end() - Method in interface org.apache.calcite.interpreter.Sink
- end() - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
-
Decreases the indentation level.
- end(String) - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
- end(Row.RowBuilder) - Method in class org.apache.calcite.interpreter.AggregateNode.AccumulatorList
- end(Sink) - Method in class org.apache.calcite.interpreter.AggregateNode.Grouping
- end(RexNode, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- 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 - org.apache.calcite.adapter.enumerable.WinAggImplementor.SeekType
-
End of window.
- endBeginTag(String) - Method in class org.apache.calcite.util.XmlOutput
- endCol - Variable in class org.apache.calcite.materialize.LatticeNode
- endCol - Variable in class org.apache.calcite.materialize.MutableNode
- endColumnNum - Variable in class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
- endColumnNumber - Variable in class org.apache.calcite.sql.parser.SqlParserPos
- endContext - Variable in class org.apache.calcite.interpreter.AggregateNode.ScalarAccumulatorDef
- 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.
- endGroup - Variable in class org.apache.calcite.plan.hep.HepInstruction.BeginGroup
- EndGroup() - Constructor for class org.apache.calcite.plan.hep.HepInstruction.EndGroup
- endIndex - Variable in class org.apache.calcite.adapter.enumerable.impl.WinAggResetContextImpl
- 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.
- endLineNum - Variable in class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
- endLineNumber - Variable in class org.apache.calcite.sql.parser.SqlParserPos
- 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
- endPosColumn - Variable in exception org.apache.calcite.runtime.CalciteContextException
- endPosLine - Variable in exception org.apache.calcite.runtime.CalciteContextException
- endsAfter(SqlParserPos) - Method in class org.apache.calcite.sql.parser.SqlParserPos
- endScalar - Variable in class org.apache.calcite.interpreter.AggregateNode.ScalarAccumulatorDef
- endTag(String) - Method in class org.apache.calcite.util.XmlOutput
-
Completes a tag.
- enforce(Type, Expression) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
- enrich(PreparedStatement) - Method in interface org.apache.calcite.runtime.ResultSetEnumerable.PreparedStatementEnricher
- ensure(PlannerImpl.State) - Method in class org.apache.calcite.prepare.PlannerImpl
-
Makes sure that the state is at least the given state.
- 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, VolcanoRuleCall) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- ensureReservedAndKeyWords() - Method in class org.apache.calcite.sql.advise.SqlAdvisor
- ensureRootConverters() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Ensures that the subset that is the root relational expression contains converters to all other subsets in its equivalence set.
- ensureScale(RexNode, int, int) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Ensures a value is of a required scale.
- ensureSize(int) - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter.Indent
- ensureSqlType(RelDataType, RexNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Ensures that an expression has a given
SqlTypeName
, applying a cast if necessary. - ensureType(RelDataType, RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Ensures expression is interpreted as a specified type.
- ensureType(RelDataType, RexNode, boolean) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Ensures expression is interpreted as a specified type.
- ensureType(RelDataType, RexNode, boolean) - Method in class org.apache.calcite.rex.RexBuilder
-
Ensures expression is interpreted as a specified type.
- entityNumber - Variable in class org.apache.calcite.rex.RexTableInputRef.RelTableRef
- Entry(CalciteSchema, String) - Constructor for class org.apache.calcite.jdbc.CalciteSchema.Entry
- entrySet() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.WrapMap
- entrySet() - Method in class org.apache.calcite.linq4j.LookupImpl
- entrySet() - Method in class org.apache.calcite.util.CompositeMap
- ENUM_CONSTANTS - Static variable in class org.apache.calcite.util.Util
-
Maps classes to the map of their enum values.
- 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.adapter.enumerable.EnumerableInterpretable.EnumerableNode
- enumerable - Variable in class org.apache.calcite.adapter.java.ReflectiveSchema.ReflectiveTable
- enumerable - Variable in class org.apache.calcite.linq4j.EnumerableQueryable
- enumerable(QueryType, String, List<String>, ExecutorService) - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
-
Executes a request and returns the resulting rows as an
Enumerable
, running the parser in a thread provided byservice
. - enumerable(Meta.StatementHandle, CalcitePrepare.CalciteSignature<T>) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- 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.Interpreter.CompilerImpl
- 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_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
- ENUMERABLE_CORRELATE_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_ENUMERATOR - org.apache.calcite.util.BuiltInMethod
- 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 - org.apache.calcite.util.BuiltInMethod
- ENUMERABLE_INTERSECT_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_JOIN_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_LIMIT_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_MERGE_JOIN_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_MINUS_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_PROJECT_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_PROJECT_TO_CALC_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_RULES - Static variable in class org.apache.calcite.prepare.CalcitePrepareImpl
- ENUMERABLE_SEMI_JOIN_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_SORT_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_TABLE_FUNCTION_SCAN_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_TABLE_MODIFICATION_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_TABLE_SCAN_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_TO_LIST - org.apache.calcite.util.BuiltInMethod
- ENUMERABLE_UNCOLLECT_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_UNION_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_VALUES_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- ENUMERABLE_WINDOW_RULE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- 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
- EnumerableAggregate.AggContextImpl - Class in org.apache.calcite.adapter.enumerable
-
An implementation of
AggContext
. - EnumerableAggregateRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert a
LogicalAggregate
to anEnumerableAggregate
. - EnumerableAggregateRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableAggregateRule
- 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.
- EnumerableCalcRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert a
LogicalCalc
to anEnumerableCalc
. - EnumerableCalcRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableCalcRule
- 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
- EnumerableCollectRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert an
Collect
to anEnumerableCollect
. - EnumerableCollectRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableCollectRule
- EnumerableConvention - Enum in org.apache.calcite.adapter.enumerable
-
Family of calling conventions that return results as an
Enumerable
. - EnumerableConvention() - Constructor for enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- EnumerableCorrelate - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Correlate
inenumerable calling convention
. - EnumerableCorrelate(RelOptCluster, RelTraitSet, RelNode, RelNode, CorrelationId, ImmutableBitSet, SemiJoinType) - 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(RelBuilderFactory) - 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
- EnumerableDefaults.CastingEnumerator<T> - Class in org.apache.calcite.linq4j
-
Enumerator that casts each value.
- EnumerableDefaults.LookupResultEnumerable<TResult,TKey,TAccumulate> - Class in org.apache.calcite.linq4j
-
Reads a populated map, applying a selector function.
- EnumerableDefaults.MergeJoinEnumerator<TResult,TSource,TInner,TKey extends java.lang.Comparable<TKey>> - Class in org.apache.calcite.linq4j
-
Enumerator that performs a merge join on its sorted inputs.
- EnumerableDefaults.SkipWhileEnumerator<TSource> - Class in org.apache.calcite.linq4j
-
Enumerator that implements skip-while.
- EnumerableDefaults.TakeWhileEnumerator<TSource> - Class in org.apache.calcite.linq4j
-
Enumerable that implements take-while.
- EnumerableDefaults.TakeWhileLongEnumerator<TSource> - Class in org.apache.calcite.linq4j
-
Enumerable that implements take-while.
- EnumerableDefaults.WrapMap<K,V> - Class in org.apache.calcite.linq4j
-
Map that wraps each value.
- EnumerableDefaults.Wrapped<T> - Class in org.apache.calcite.linq4j
-
Value wrapped with a comparer.
- enumerableEnumerator - Variable in class org.apache.calcite.linq4j.Linq4j.CompositeEnumerable
- 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.
- EnumerableFilterRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert a
LogicalFilter
to anEnumerableFilter
. - EnumerableFilterRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableFilterRule
- EnumerableFilterToCalcRule - Class in org.apache.calcite.adapter.enumerable
-
Variant of
FilterToCalcRule
forenumerable calling convention
. - EnumerableFilterToCalcRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableFilterToCalcRule
-
Creates an EnumerableFilterToCalcRule.
- 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
- EnumerableInterpretable.EnumerableNode - Class in org.apache.calcite.adapter.enumerable
-
Interpreter node that reads from an
Enumerable
. - 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(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableInterpreterRule
-
Creates an 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
- EnumerableIntersectRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert a
LogicalIntersect
to anEnumerableIntersect
. - EnumerableIntersectRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableIntersectRule
- EnumerableJoin - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Join
inenumerable calling convention
. - EnumerableJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableJoin
-
Creates an EnumerableJoin.
- EnumerableJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList, JoinRelType, Set<String>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableJoin
-
Deprecated.
- EnumerableJoinRule - Class in org.apache.calcite.adapter.enumerable
-
Planner rule that converts a
LogicalJoin
relational expressionenumerable calling convention
. - EnumerableJoinRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableJoinRule
- 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() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableLimitRule
- EnumerableMergeJoin - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Join
inenumerable calling convention
using a merge algorithm. - EnumerableMergeJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableMergeJoin
- EnumerableMergeJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList, JoinRelType, Set<String>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableMergeJoin
-
Deprecated.
- EnumerableMergeJoinRule - Class in org.apache.calcite.adapter.enumerable
-
Planner rule that converts a
LogicalJoin
relational expressionenumerable calling convention
. - EnumerableMergeJoinRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableMergeJoinRule
- 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
- EnumerableMinusRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert an
LogicalMinus
to anEnumerableMinus
. - EnumerableMinusRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableMinusRule
- EnumerableNode(Enumerable<Object[]>, Compiler, EnumerableInterpretable) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableInterpretable.EnumerableNode
- EnumerableOrderedQueryable<T> - Class in org.apache.calcite.linq4j
-
Implementation of
OrderedQueryable
by anEnumerable
. - EnumerableOrderedQueryable(Enumerable<T>, Class<T>, QueryProvider, Expression) - Constructor for class org.apache.calcite.linq4j.EnumerableOrderedQueryable
- 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.
- EnumerableProjectRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert a
LogicalProject
to anEnumerableProject
. - EnumerableProjectRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableProjectRule
- EnumerableProjectToCalcRule - Class in org.apache.calcite.adapter.enumerable
-
Variant of
ProjectToCalcRule
forenumerable calling convention
. - EnumerableProjectToCalcRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableProjectToCalcRule
-
Creates an EnumerableProjectToCalcRule.
- EnumerableQueryable<T> - Class in org.apache.calcite.linq4j
-
Implementation of
Queryable
by aEnumerable
. - EnumerableQueryable(QueryProvider, Class<T>, Expression, Enumerable<T>) - Constructor for class org.apache.calcite.linq4j.EnumerableQueryable
- 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.
- 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
- EnumerableRelImplementor.TypeFinder - Class in org.apache.calcite.adapter.enumerable
-
Visitor that finds types in an
Expression
tree. - EnumerableRelImplementor.TypeRegistrar - Class in org.apache.calcite.adapter.enumerable
-
Adds a declaration of each synthetic type found in a code block.
- EnumerableRules - Class in org.apache.calcite.adapter.enumerable
-
Rules and relational operators for the
enumerable calling convention
. - EnumerableRules() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableRules
- Enumerables - Class in org.apache.calcite.runtime
-
Utilities for processing
Enumerable
collections. - Enumerables() - Constructor for class org.apache.calcite.runtime.Enumerables
- EnumerableSemiJoin - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
SemiJoin
inenumerable calling convention
. - EnumerableSemiJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableSemiJoin
-
Creates an EnumerableSemiJoin.
- EnumerableSemiJoinRule - Class in org.apache.calcite.adapter.enumerable
-
Planner rule that converts a
SemiJoin
relational expressionenumerable calling convention
. - EnumerableSemiJoinRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableSemiJoinRule
- 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.
- EnumerableSortRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert an
Sort
to anEnumerableSort
. - EnumerableSortRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableSortRule
- 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
-
Planner rule that converts a
LogicalTableFunctionScan
relational expressionenumerable calling convention
. - EnumerableTableFunctionScanRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableTableFunctionScanRule
-
Deprecated.
- EnumerableTableFunctionScanRule(RelBuilderFactory) - 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
relational expressionenumerable calling convention
. - EnumerableTableModifyRule(RelBuilderFactory) - 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
LogicalTableFunctionScan
relational expressionenumerable calling convention
. - EnumerableTableScanRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableTableScanRule
-
Deprecated.
- EnumerableTableScanRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableTableScanRule
-
Creates an EnumerableTableScanRule.
- EnumerableThetaJoin - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Join
inenumerable calling convention
that allows conditions that are not just=
(equals). - EnumerableThetaJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableThetaJoin
-
Creates an EnumerableThetaJoin.
- EnumerableThetaJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, Set<String>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableThetaJoin
-
Deprecated.
- EnumerableToBindableConverterRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableBindable.EnumerableToBindableConverterRule
-
Creates an 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
- EnumerableToSparkConverterRule - Class in org.apache.calcite.adapter.spark
-
Rule to convert a relational expression from
JdbcConvention
toSpark convention
. - EnumerableToSparkConverterRule() - Constructor for class org.apache.calcite.adapter.spark.SparkRules.EnumerableToSparkConverterRule
- EnumerableToSparkConverterRule(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.spark.EnumerableToSparkConverterRule
-
Creates an EnumerableToSparkConverterRule.
- 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.
- EnumerableUncollectRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert an
Uncollect
to anEnumerableUncollect
. - EnumerableUncollectRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableUncollectRule
- 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
- EnumerableUnionRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert an
LogicalUnion
to anEnumerableUnion
. - EnumerableUnionRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableUnionRule
- EnumerableValues - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
Values
inenumerable calling convention
. - EnumerableValues(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, RelTraitSet) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableValues
-
Creates an EnumerableValues.
- EnumerableValuesRule - Class in org.apache.calcite.adapter.enumerable
-
Planner rule that converts a
LogicalValues
relational expressionenumerable calling convention
. - EnumerableValuesRule(RelBuilderFactory) - 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
. - EnumerableWindow(RelOptCluster, RelTraitSet, RelNode, List<RexLiteral>, RelDataType, List<Window.Group>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableWindow
-
Creates an EnumerableWindowRel.
- EnumerableWindow.WindowRelInputGetter - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
RexToLixTranslator.InputGetter
suitable for generating implementations of windowed aggregate functions. - EnumerableWindowRule - Class in org.apache.calcite.adapter.enumerable
-
Rule to convert a
LogicalWindow
to anEnumerableWindow
. - EnumerableWindowRule() - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableWindowRule
- enumerator - Variable in class org.apache.calcite.adapter.csv.JsonEnumerator
- enumerator - Variable in class org.apache.calcite.interpreter.Interpreter.EnumeratorSource
- enumerator - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.CastingEnumerator
- enumerator - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.SkipWhileEnumerator
- enumerator - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileEnumerator
- enumerator - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileLongEnumerator
- enumerator - Variable in class org.apache.calcite.linq4j.Linq4j.EnumeratorIterator
- enumerator - Variable in class org.apache.calcite.linq4j.TransformedEnumerator
- enumerator - Variable in class org.apache.calcite.runtime.EnumeratorCursor
- enumerator - Variable in class org.apache.calcite.runtime.ObjectEnumeratorCursor
- enumerator() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- enumerator() - Method in class org.apache.calcite.adapter.clone.ArrayTable.Content
- 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.jdbc.JdbcTable.JdbcTableQueryable
- enumerator() - Method in class org.apache.calcite.adapter.mongodb.MongoTable.MongoQueryable
- enumerator() - Method in class org.apache.calcite.adapter.os.Processes.ProcessLinesEnumerator
- enumerator() - Method in class org.apache.calcite.adapter.os.Processes.SeparatedLinesEnumerable
- enumerator() - Method in class org.apache.calcite.adapter.splunk.SplunkQuery
- enumerator() - Method in class org.apache.calcite.adapter.splunk.SplunkTable.SplunkTableQueryable
- 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.EnumerableQueryable
- enumerator() - Method in class org.apache.calcite.linq4j.GroupingImpl
- enumerator() - Method in class org.apache.calcite.linq4j.Linq4j.CompositeEnumerable
- enumerator() - Method in class org.apache.calcite.linq4j.Linq4j.ListEnumerable
- enumerator() - Method in class org.apache.calcite.linq4j.LookupImpl
- 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.util.IntegerIntervalSet
- enumerator(Collection<? extends V>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Adapter that converts a collection into an enumerator.
- enumerator(Set<Integer>) - Method in class org.apache.calcite.example.maze.Maze
-
Generates a list of lines representing the maze in text form.
- enumerator(CalciteMetaImpl) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl.MetadataTable
- Enumerator<T> - Interface in org.apache.calcite.linq4j
-
Supports a simple iteration over a collection.
- ENUMERATOR_CLOSE - org.apache.calcite.util.BuiltInMethod
- ENUMERATOR_CURRENT - org.apache.calcite.util.BuiltInMethod
- ENUMERATOR_MOVE_NEXT - org.apache.calcite.util.BuiltInMethod
- ENUMERATOR_RESET - org.apache.calcite.util.BuiltInMethod
- enumeratorBasedOnPreparedStatement() - Method in class org.apache.calcite.runtime.ResultSetEnumerable
- enumeratorBasedOnStatement() - Method in class org.apache.calcite.runtime.ResultSetEnumerable
- 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 a
EnumeratorCursor
- enumeratorIterator(Enumerator<T>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Adapter that converts an enumerator into an iterator.
- EnumeratorIterator(Enumerator<T>) - Constructor for class org.apache.calcite.linq4j.Linq4j.EnumeratorIterator
- enumerators - Variable in class org.apache.calcite.linq4j.CartesianProductEnumerator
- EnumeratorSource(Enumerator<Row>) - Constructor for class org.apache.calcite.interpreter.Interpreter.EnumeratorSource
- EnumUtils - Class in org.apache.calcite.adapter.enumerable
-
Utilities for generating programs in the Enumerable (functional) style.
- EnumUtils() - Constructor for class org.apache.calcite.adapter.enumerable.EnumUtils
- 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.
- envelope(Geometry) - Static method in class org.apache.calcite.runtime.GeoFunctions
- environment - Variable in class org.apache.calcite.rex.RexInterpreter
- EnvironmentFairy - Class in org.apache.calcite.chinook
-
Fairy simulates environment around Calcite.
- EnvironmentFairy() - Constructor for class org.apache.calcite.chinook.EnvironmentFairy
- EnvironmentFairy.User - Enum in org.apache.calcite.chinook
-
Who is emulated to being logged in?
- EPSILON - Static variable in class org.apache.calcite.plan.RelOptUtil
- 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, RelDataType, String, RelDataType, Litmus) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns whether two types are equal using '='.
- eq(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
=
operator applied to BigDecimal values (neither may be null). - eq(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.OptimizeShuttle
-
Treats two expressions equal even if they represent different null types
- eq(RexBuilder, RexNode, RexNode) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- eq(RexNode, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- EQ - 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). - eqMap - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
- eqMap - Variable in class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
- equal(Object[], Object[]) - Method in class org.apache.calcite.linq4j.function.Functions.ArrayEqualityComparer
- equal(Object, Object) - Method in class org.apache.calcite.linq4j.function.Functions.IdentityEqualityComparer
- equal(Object, Object) - Static method in class org.apache.calcite.runtime.Resources
-
Returns whether two objects are equal or are both null.
- equal(Object, Object) - Static method in class org.apache.calcite.runtime.Utilities
-
Deprecated.Use
Objects.equals(java.lang.Object, java.lang.Object)
. - 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(T, T) - Method in class org.apache.calcite.linq4j.function.Functions.SelectorEqualityComparer
- Equal - org.apache.calcite.linq4j.tree.ExpressionType
-
A node that represents an equality comparison, such as
a == b
in Java. - equalDeep(List<SqlNode>, List<SqlNode>, Litmus) - Static method in class org.apache.calcite.sql.SqlNode
-
Returns whether two lists of operands are equal.
- 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.
- equalityPredicates - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- equals(Object) - Method in class org.apache.calcite.adapter.druid.DruidQuery.QuerySpec
- equals(Object) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Aggregations
- equals(Object) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.RowKey
- equals(Object) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
- 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.EnumerableDefaults.Wrapped
- equals(Object) - Method in class org.apache.calcite.linq4j.GroupingImpl
- 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.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.LatticeSuggester.StepRef
- equals(Object) - Method in class org.apache.calcite.materialize.LatticeSuggester.TableRef
- equals(Object) - Method in class org.apache.calcite.materialize.LatticeTable
- equals(Object) - Method in class org.apache.calcite.materialize.MaterializationActor.QueryKey
- equals(Object) - Method in class org.apache.calcite.materialize.MaterializationKey
- equals(Object) - Method in class org.apache.calcite.materialize.Path
- equals(Object) - Method in class org.apache.calcite.materialize.Step
- equals(Object) - Method in class org.apache.calcite.materialize.TileKey
- equals(Object) - Method in class org.apache.calcite.plan.hep.HepRelMetadataProvider
- equals(Object) - Method in class org.apache.calcite.plan.RelCompositeTrait
- 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.VolcanoCost
- equals(Object) - Method in class org.apache.calcite.plan.volcano.VolcanoRelMetadataProvider
- 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.profile.ProfilerImpl.Space
- equals(Object) - Method in class org.apache.calcite.profile.SimpleProfiler.Space
- 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.Window.Group
- equals(Object) - Method in class org.apache.calcite.rel.core.Window.RexWinAggCall
- equals(Object) - Method in class org.apache.calcite.rel.logical.LogicalWindow.WindowKey
- 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.JaninoRelMetadataProvider.Key
- 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.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.MutableSemiJoin
- 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.RelDistributions.RelDistributionImpl
- equals(Object) - Method in class org.apache.calcite.rel.RelFieldCollation
- equals(Object) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.Key
- 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.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.RexRangeRef
- 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.rex.RexWindowBound.RexWindowBoundBounded
- equals(Object) - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundCurrentRow
- equals(Object) - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundUnbounded
- equals(Object) - Method in class org.apache.calcite.runtime.ConsList
- equals(Object) - Method in class org.apache.calcite.runtime.FlatLists.ComparableEmptyList
- 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.Resources.Inst
- equals(Object) - Method in class org.apache.calcite.schema.impl.LongSchemaVersion
- equals(Object) - Method in class org.apache.calcite.schema.Schemas.PathImpl
- equals(Object) - Method in class org.apache.calcite.sql.parser.SqlParserPos
- 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.SqlOperator
- 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.sql2rel.RelDecorrelator.CorDef
- equals(Object) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMap
- equals(Object) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorRef
- equals(Object) - Method in class org.apache.calcite.tools.RuleSets.ListRuleSet
- 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.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, Object) - Static method in class org.apache.calcite.rex.RexLiteral
- equals(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- equals(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- equals(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- 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(RelOptCost) - Method in class org.apache.calcite.plan.volcano.VolcanoCost
- 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 - org.apache.calcite.sql.SqlKind
-
The 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.
- 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.
- 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.
- 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.
- equiColumns - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.Edge
- EquiJoin - Class in org.apache.calcite.rel.core
-
Base class for any join whose condition is based on column equality.
- EquiJoin - Class in org.apache.calcite.rel.rules
-
Deprecated.
- EquiJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.rel.core.EquiJoin
-
Creates an EquiJoin.
- 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.
- EquiJoinInfo(ImmutableIntList, ImmutableIntList) - Constructor for class org.apache.calcite.rel.core.JoinInfo.EquiJoinInfo
- equiv(E, E) - Method in class org.apache.calcite.util.EquivalenceSet
-
Marks two elements as equivalent.
- equivalence - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- equivalence - Variable in class org.apache.calcite.util.BitSets.Closure
- equivalence - Variable in class org.apache.calcite.util.ImmutableBitSet.Closure
- equivalenceClass - Variable in class org.apache.calcite.plan.RelOptListener.RelEquivalenceEvent
- EquivalenceClasses() - Constructor for class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.EquivalenceClasses
- EquivalenceFinder() - Constructor for class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference.EquivalenceFinder
- EquivalenceSet<E extends java.lang.Comparable<E>> - Class in org.apache.calcite.util
-
Set of elements organized into equivalence classes.
- EquivalenceSet() - Constructor for class org.apache.calcite.util.EquivalenceSet
- equivalents - Variable in class org.apache.calcite.plan.SubstitutionVisitor
- equivalentSet - Variable in class org.apache.calcite.plan.volcano.RelSet
-
Set to the superseding set when this is found to be equivalent to another set.
- EquivConvertlet(SqlOperator) - Constructor for class org.apache.calcite.rex.RexSqlStandardConvertletTable.EquivConvertlet
- equivRoot(RelSet) - Static method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- err - Variable in class org.apache.calcite.adapter.os.SqlShell
- ERROR - org.apache.calcite.sql.SqlJsonEmptyOrError
- ERROR - org.apache.calcite.sql.SqlJsonExistsErrorBehavior
- ERROR - org.apache.calcite.sql.SqlJsonQueryEmptyOrErrorBehavior
- ERROR - org.apache.calcite.sql.SqlJsonValueEmptyOrErrorBehavior
- errorMessage - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonColumn
- errorMsg - Variable in class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
- ES2 - org.apache.calcite.adapter.elasticsearch.ElasticsearchVersion
- ES5 - org.apache.calcite.adapter.elasticsearch.ElasticsearchVersion
- ES6 - org.apache.calcite.adapter.elasticsearch.ElasticsearchVersion
- ES7 - org.apache.calcite.adapter.elasticsearch.ElasticsearchVersion
- escape(String) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- ESCAPE - 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.
- escapeForQuoting(String) - Static method in class org.apache.calcite.util.XmlOutput
- escapeString(String) - Method in class org.apache.calcite.util.XmlOutput.StringEscaper
-
Apply an immutable transformation to the given string.
- escapeString(StringBuilder, String) - Static method in class org.apache.calcite.linq4j.tree.ConstantExpression
- estimateFilteredRows(RelNode, RexNode) - Static method in class org.apache.calcite.rel.core.Filter
-
Deprecated.
- estimateFilteredRows(RelNode, RexNode, RelMetadataQuery) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
- 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
- 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.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.SemiJoin
- 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.
- estimateSpace() - Method in class org.apache.calcite.materialize.TileSuggester.AttributeImpl
- eval() - Method in class org.apache.calcite.chinook.ChosenCustomerEmail
- 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.PsTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.StdinTableFunction
- eval(boolean) - Static method in class org.apache.calcite.adapter.os.VmstatTableFunction
- eval(String) - Static method in class org.apache.calcite.adapter.os.FilesTableFunction
-
Evaluates the function.
- eval(String, String) - Method in class org.apache.calcite.chinook.StringConcatFunction
- 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) - Method in class org.apache.calcite.linq4j.tree.Evaluator
- 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.
- evaluateIntervalLiteralAsDay(RelDataTypeSystem, int, String, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Validates an INTERVAL literal against a DAY interval qualifier.
- evaluateIntervalLiteralAsDayToHour(RelDataTypeSystem, int, String, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Validates an INTERVAL literal against a DAY TO HOUR interval qualifier.
- evaluateIntervalLiteralAsDayToMinute(RelDataTypeSystem, int, String, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Validates an INTERVAL literal against a DAY TO MINUTE interval qualifier.
- evaluateIntervalLiteralAsDayToSecond(RelDataTypeSystem, int, String, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Validates an INTERVAL literal against a DAY TO SECOND interval qualifier.
- evaluateIntervalLiteralAsHour(RelDataTypeSystem, int, String, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Validates an INTERVAL literal against an HOUR interval qualifier.
- evaluateIntervalLiteralAsHourToMinute(RelDataTypeSystem, int, String, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Validates an INTERVAL literal against an HOUR TO MINUTE interval qualifier.
- evaluateIntervalLiteralAsHourToSecond(RelDataTypeSystem, int, String, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Validates an INTERVAL literal against an HOUR TO SECOND interval qualifier.
- evaluateIntervalLiteralAsMinute(RelDataTypeSystem, int, String, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Validates an INTERVAL literal against an MINUTE interval qualifier.
- evaluateIntervalLiteralAsMinuteToSecond(RelDataTypeSystem, int, String, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Validates an INTERVAL literal against an MINUTE TO SECOND interval qualifier.
- evaluateIntervalLiteralAsMonth(RelDataTypeSystem, int, String, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Validates an INTERVAL literal against a MONTH interval qualifier.
- evaluateIntervalLiteralAsSecond(RelDataTypeSystem, int, String, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Validates an INTERVAL literal against an SECOND interval qualifier.
- evaluateIntervalLiteralAsYear(RelDataTypeSystem, int, String, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Validates an INTERVAL literal against a YEAR interval qualifier.
- evaluateIntervalLiteralAsYearToMonth(RelDataTypeSystem, int, String, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Validates an INTERVAL literal against a YEAR TO MONTH interval qualifier.
- Evaluator - Class in org.apache.calcite.linq4j.tree
-
Holds context for evaluating expressions.
- Evaluator() - Constructor for class org.apache.calcite.linq4j.tree.Evaluator
- EVEN_QUOTES - org.apache.calcite.runtime.Resources.Validation
-
Checks that every message contains even number of quotes.
- evolve - Variable in class org.apache.calcite.materialize.LatticeSuggester
-
Whether to try to extend an existing lattice when adding a lattice.
- evolveLattice - Variable in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- evolveLattice - Variable in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- evolveLattice(boolean) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- ex() - Method in class org.apache.calcite.runtime.Resources.ExInst
- ex(Throwable) - Method in class org.apache.calcite.runtime.Resources.ExInstWithCause
- exact - Variable in class org.apache.calcite.piglet.Ast.NumericLiteral
- EXACT_NUMERIC - 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
- exc - Variable in class org.apache.calcite.runtime.SqlFunctions.PathContext
- except(Enumerable<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- except(Enumerable<T>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- except(Enumerable<T>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- except(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- except(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- except(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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.
- except(Enumerable<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Produces the set difference of two sequences by using the default equality comparer to compare values.
- 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.
- 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. - 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. - except(Enumerable<TSource>, EqualityComparer<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Produces the set difference of two sequences by using the specified
EqualityComparer<TSource>
to compare values. - 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.
- except(Queryable<T>, Enumerable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- except(Queryable<T>, Enumerable<T>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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. - except(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- except(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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 - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- EXCEPT - org.apache.calcite.sql.SqlKind
-
Except
- EXCEPT - 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
- 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 - org.apache.calcite.rel.mutable.MutableRelType
- exchangeFactory - Variable in class org.apache.calcite.tools.RelBuilder
- ExchangeFactoryImpl() - Constructor for class org.apache.calcite.rel.core.RelFactories.ExchangeFactoryImpl
- 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 - 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 - 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.rel.rules.CalcRelSplitter
- execute() - Method in class org.apache.calcite.rex.RexExecutable
- 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.SqlCreateForeignSchema
- execute(CalcitePrepare.Context) - Method in class org.apache.calcite.sql.ddl.SqlCreateMaterializedView
- execute(CalcitePrepare.Context) - Method in class org.apache.calcite.sql.ddl.SqlCreateSchema
- execute(CalcitePrepare.Context) - Method in class org.apache.calcite.sql.ddl.SqlCreateTable
- execute(CalcitePrepare.Context) - Method in class org.apache.calcite.sql.ddl.SqlCreateType
- execute(CalcitePrepare.Context) - Method in class org.apache.calcite.sql.ddl.SqlCreateView
- execute(CalcitePrepare.Context) - Method in class org.apache.calcite.sql.ddl.SqlDropMaterializedView
- execute(CalcitePrepare.Context) - Method in class org.apache.calcite.sql.ddl.SqlDropObject
- execute(CalcitePrepare.Context) - Method in class org.apache.calcite.sql.ddl.SqlDropSchema
- execute(CalcitePrepare.Context) - Method in interface org.apache.calcite.sql.SqlExecutableStatement
- execute(Expression, Class<T>) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- 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 class org.apache.calcite.jdbc.CalciteConnectionImpl
- 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(HepPlanner) - Method in class org.apache.calcite.plan.hep.HepInstruction.BeginGroup
- execute(HepPlanner) - Method in class org.apache.calcite.plan.hep.HepInstruction.CommonRelSubExprRules
- execute(HepPlanner) - Method in class org.apache.calcite.plan.hep.HepInstruction.ConverterRules
- execute(HepPlanner) - Method in class org.apache.calcite.plan.hep.HepInstruction.EndGroup
- execute(HepPlanner) - Method in class org.apache.calcite.plan.hep.HepInstruction
- execute(HepPlanner) - Method in class org.apache.calcite.plan.hep.HepInstruction.MatchLimit
- execute(HepPlanner) - Method in class org.apache.calcite.plan.hep.HepInstruction.MatchOrder
- execute(HepPlanner) - Method in class org.apache.calcite.plan.hep.HepInstruction.RuleClass
- execute(HepPlanner) - Method in class org.apache.calcite.plan.hep.HepInstruction.RuleCollection
- execute(HepPlanner) - Method in class org.apache.calcite.plan.hep.HepInstruction.RuleInstance
- execute(HepPlanner) - Method in class org.apache.calcite.plan.hep.HepInstruction.Subprogram
- 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
- executeInstruction(HepInstruction.BeginGroup) - Method in class org.apache.calcite.plan.hep.HepPlanner
- executeInstruction(HepInstruction.CommonRelSubExprRules) - Method in class org.apache.calcite.plan.hep.HepPlanner
- executeInstruction(HepInstruction.ConverterRules) - Method in class org.apache.calcite.plan.hep.HepPlanner
- executeInstruction(HepInstruction.EndGroup) - Method in class org.apache.calcite.plan.hep.HepPlanner
- executeInstruction(HepInstruction.MatchLimit) - Method in class org.apache.calcite.plan.hep.HepPlanner
- executeInstruction(HepInstruction.MatchOrder) - Method in class org.apache.calcite.plan.hep.HepPlanner
- executeInstruction(HepInstruction.RuleClass<?>) - Method in class org.apache.calcite.plan.hep.HepPlanner
- executeInstruction(HepInstruction.RuleCollection) - Method in class org.apache.calcite.plan.hep.HepPlanner
- executeInstruction(HepInstruction.RuleInstance) - Method in class org.apache.calcite.plan.hep.HepPlanner
- executeInstruction(HepInstruction.Subprogram) - Method in class org.apache.calcite.plan.hep.HepPlanner
- executeMethod(String, String, CharSequence, Map<String, String>, int, int) - Static method in class org.apache.calcite.runtime.HttpUtils
- executeProgram(HepProgram) - Method in class org.apache.calcite.plan.hep.HepPlanner
- executeQuery(StatementTest.HrConnection) - Method in class org.apache.calcite.benchmarks.StatementTest
- executeQuery(Queryable<T>) - Method in class org.apache.calcite.adapter.jdbc.JdbcQueryProvider
- executeQuery(Queryable<T>) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- 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.plan.AbstractRelOptPlanner
- executor - Variable in class org.apache.calcite.plan.RexImplicationChecker
- executor - Variable in class org.apache.calcite.prepare.PlannerImpl
- executor - Variable in class org.apache.calcite.rex.RexSimplify
- executor - Variable in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- executor - Variable in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- 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.
- ExInst(String, Locale, Method, Object...) - Constructor for class org.apache.calcite.runtime.Resources.ExInst
- ExInstWithCause(String, Locale, Method, Object...) - Constructor for class org.apache.calcite.runtime.Resources.ExInstWithCause
- existingWindowName(String) - Method in class org.apache.calcite.sql.validate.SelectScope
- exists() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- exists() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- exists() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- 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(RelNode) - Static method in class org.apache.calcite.rex.RexSubQuery
-
Creates an EXISTS sub-query.
- Exists(RelNode, boolean, boolean) - Constructor for class org.apache.calcite.plan.RelOptUtil.Exists
- EXISTS - org.apache.calcite.plan.RelOptUtil.SubQueryType
- EXISTS - org.apache.calcite.sql.SqlKind
-
The "EXISTS" operator.
- EXISTS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- existsQuery(String) - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A filter to filter only documents where a field exists in them.
- ExistsQueryBuilder(String) - Constructor for class org.apache.calcite.adapter.elasticsearch.QueryBuilders.ExistsQueryBuilder
- 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(SqlWriter) - Method in class org.apache.calcite.sql.ddl.SqlAttributeDefinition
- exp(SqlWriter) - Method in class org.apache.calcite.sql.ddl.SqlColumnDeclaration
- EXP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- expand - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- expand - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- expand(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.BinaryArithmeticExpander
- expand(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.CaseExpander
- expand(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.CastArgAsTypeExpander
- expand(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.CastExpander
- expand(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.CeilExpander
- expand(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.FloorExpander
- expand(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.PassThroughExpander
- expand(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.ReinterpretExpander
- 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
- expandAvg(SqlNode, RelDataType, SqlRexContext) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable.AvgVarianceConvertlet
- expandColumnReferences - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- expandComparison(RexCall, List<RexNode>) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.BinaryArithmeticExpander
- ExpandConversionRule(RelBuilderFactory) - Constructor for class org.apache.calcite.plan.volcano.AbstractConverter.ExpandConversionRule
-
Creates an ExpandConversionRule.
- expandCovariance(SqlNode, SqlNode, SqlNode, RelDataType, SqlRexContext, boolean) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable.RegrCovarianceConvertlet
- expandDivide(RexCall, List<RexNode>) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.BinaryArithmeticExpander
- expandDynamicStar(SqlIdentifier, SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.Expander
- expanded - Variable in class org.apache.calcite.sql.SqlBasicCall
- expandedSelectList - Variable in class org.apache.calcite.sql.validate.SelectScope
- Expander(SqlValidatorImpl, SqlValidatorScope) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.Expander
- expanderMap - Variable in class org.apache.calcite.rel.rules.ReduceDecimalsRule.DecimalShuttle
- ExpanderMap(RexBuilder) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule.ExpanderMap
- expandGroupByOrHavingExpr(SqlNode, SqlValidatorScope, SqlSelect, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- expandIdentifiers - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- expandingScanFactory(RelOptTable.ViewExpander, RelFactories.TableScanFactory) - Static method in class org.apache.calcite.rel.core.RelFactories
-
Creates a
RelFactories.TableScanFactory
that uses aRelOptTable.ViewExpander
to handleTranslatableTable
instances, and falls back to a default factory for other tables. - expandingScanFactory(RelFactories.TableScanFactory) - Static method in class org.apache.calcite.rel.core.RelFactories
-
Creates a
RelFactories.TableScanFactory
that can expandTranslatableTable
instances, but explodes on views. - 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).
- expandMod(RexCall, List<RexNode>) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.BinaryArithmeticExpander
- 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
- expandPlusMinus(RexCall, List<RexNode>) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.BinaryArithmeticExpander
- expandRegrSzz(SqlNode, SqlNode, RelDataType, SqlRexContext, boolean) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable.RegrCovarianceConvertlet
- expandSelectItem(SqlNode, SqlSelect, RelDataType, List<SqlNode>, Set<String>, List<Map.Entry<String, RelDataType>>, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
If
selectItem
is "*" or "TABLE.*", expands it and returns true; otherwise writes the unexpanded item. - expandStar(List<SqlNode>, Set<String>, List<Map.Entry<String, RelDataType>>, boolean, SelectScope, SqlNode) - 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
- expandTimes(RexCall, List<RexNode>) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.BinaryArithmeticExpander
- expandVariance(SqlNode, RelDataType, SqlRexContext, boolean, boolean) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable.AvgVarianceConvertlet
- expandView(RelOptTable.ToRelContext, RelDataType, String) - Method in class org.apache.calcite.schema.impl.ViewTable
- 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.
- expansionDepth - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- ExpansionShuttle(List<RexNode>) - Constructor for class org.apache.calcite.rex.RexProgram.ExpansionShuttle
- expect(JsonParser, JsonToken) - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- expect(JsonToken, JsonToken) - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- expectedBoolean() - Method in interface org.apache.calcite.runtime.CalciteResource
- expectedCardinality - Variable in class org.apache.calcite.profile.Profiler.Distribution
- expectedCardinality - Variable in class org.apache.calcite.profile.ProfilerImpl.Space
- expectedCardinality(double, ImmutableBitSet) - Method in class org.apache.calcite.profile.ProfilerImpl.Run
-
Estimates the cardinality of a collection of columns represented by
columnOrdinals
, drawing on existing distributions. - expectedCharacter() - Method in interface org.apache.calcite.runtime.CalciteResource
- expectedTokenSequences - Variable in exception org.apache.calcite.sql.parser.SqlParseException
- expectObjectField(JsonParser, String) - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- expectScalarField(JsonParser, String) - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- 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 - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- explain - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- 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 - org.apache.calcite.sql.SqlKind
-
EXPLAIN statement
- 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 - org.apache.calcite.util.BuiltInMethod
- explainCalc(RelWriter) - Method in class org.apache.calcite.rex.RexProgram
-
Writes an explanation of the expressions in this program to a plan writer.
- explainGeneric(RelNode, List<Pair<String, Object>>) - Method in class org.apache.calcite.rel.externalize.RelXmlWriter
-
Generates generic XML (sometimes called 'element-oriented XML').
- explainInputs(List<RelNode>) - Method in class org.apache.calcite.rel.externalize.RelJsonWriter
- explainInputs(List<RelNode>) - Method in class org.apache.calcite.rel.externalize.RelWriterImpl
- explainParamCount - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- explainSpecific(RelNode, List<Pair<String, Object>>) - Method in class org.apache.calcite.rel.externalize.RelXmlWriter
-
Generates specific XML (sometimes called 'attribute-oriented XML').
- 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.EnumerableLimit
- explainTerms(RelWriter) - Method in class org.apache.calcite.adapter.file.FileTableScan
- explainTerms(RelWriter) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcCalc
- 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.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.Sample
- explainTerms(RelWriter) - Method in class org.apache.calcite.rel.core.SetOp
- 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.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.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
- explainVisibilityHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- explicandum - Variable in class org.apache.calcite.sql.SqlExplain
- 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 - org.apache.calcite.sql.SqlCollation.Coercibility
-
Strongest coercibility.
- EXPLICIT_TABLE - 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.
- ExplicitOperandTypeInference - Class in org.apache.calcite.sql.type
-
ExplicitOperandTypeInferences implements
SqlOperandTypeInference
by explicitly supplying a type for each parameter. - ExplicitOperandTypeInference(ImmutableList<RelDataType>) - Constructor for class org.apache.calcite.sql.type.ExplicitOperandTypeInference
- 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
- ExplicitOperatorBinding(SqlOperatorBinding, RelDataTypeFactory, SqlOperator, 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.
- expList - Variable in class org.apache.calcite.piglet.Ast.ForeachNestedStmt
- expList - Variable in class org.apache.calcite.piglet.Ast.ForeachStmt
- EXPPLAN_ATTRIBUTES - org.apache.calcite.sql.SqlExplainLevel
-
Display only attributes which contribute to the plan output.
- expr - Variable in class org.apache.calcite.rex.RexFieldAccess
- expr - Variable in class org.apache.calcite.sql.ddl.SqlCreateTable.ColumnDef
- expr - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.SubQuery
- EXPR_SUGGESTER - Static variable in class org.apache.calcite.sql.validate.SqlValidatorUtil
- ExprContext() - Constructor for enum org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext
- exprConverter - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- expressAsLiteral(PredicateAnalyzer.Expression) - Static method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor
-
Try to convert a generic expression into a literal expression.
- expression - Variable in class org.apache.calcite.adapter.clone.ListTable
- expression - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonExpressionFilter
- expression - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonAggregation
- expression - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonExpressionPostAgg
- expression - Variable in class org.apache.calcite.adapter.druid.VirtualColumn.Builder
- expression - Variable in class org.apache.calcite.adapter.druid.VirtualColumn
- expression - Variable in class org.apache.calcite.adapter.jdbc.JdbcConvention
- expression - Variable in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcTableModify
- expression - Variable in class org.apache.calcite.linq4j.BaseQueryable
- expression - Variable in class org.apache.calcite.linq4j.EnumerableQueryable
- 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.SqlAttributeDefinition
- expression - Variable in class org.apache.calcite.sql.ddl.SqlCheckConstraint
- expression - Variable in class org.apache.calcite.sql.ddl.SqlColumnDeclaration
- 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 - org.apache.calcite.adapter.druid.DruidJsonFilter.Type
- EXPRESSION - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category consisting of all expression operators.
- EXPRESSION_LINEAGE - org.apache.calcite.util.BuiltInMethod
- EXPRESSION_REDUCER - org.apache.calcite.runtime.Hook
-
Called when a constant expression is being reduced.
- EXPRESSION_TYPES - Static variable in class org.apache.calcite.adapter.druid.DruidExpressions
-
Type mapping between Calcite SQL family types and native Druid expression types
- 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
- expressionForReuse - Variable in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Contains final-fine-to-reuse-declarations.
- expressionFunction - Variable in class org.apache.calcite.prepare.RelOptTableImpl
- expressionLineageHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- expressionList - Variable in class org.apache.calcite.linq4j.tree.ConditionalExpression
- expressionList - Variable in class org.apache.calcite.linq4j.tree.ConditionalStatement
- ExpressionNormalizer(boolean) - Constructor for class org.apache.calcite.rex.RexUtil.ExpressionNormalizer
- ExpressionNotAnalyzableException - Exception in org.apache.calcite.adapter.elasticsearch
-
Thrown when
RelNode
expression can't be processed (or converted into ES query) - ExpressionNotAnalyzableException(String, Throwable) - Constructor for exception org.apache.calcite.adapter.elasticsearch.ExpressionNotAnalyzableException
- ExpressionNotAnalyzableException(String, Throwable) - Constructor for exception org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.ExpressionNotAnalyzableException
- 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() - Constructor for class org.apache.calcite.linq4j.tree.Expressions
- Expressions.FluentArrayList<T> - Class in org.apache.calcite.linq4j.tree
-
Fluent array list.
- Expressions.FluentList<T> - Interface in org.apache.calcite.linq4j.tree
-
Fluent list.
- Expressions.PropertyInfo - Interface in org.apache.calcite.linq4j.tree
-
Property info.
- Expressions.RuntimeVariablesExpression - Interface in org.apache.calcite.linq4j.tree
-
Runtime variables expression.
- Expressions.SymbolDocumentInfo - Interface in org.apache.calcite.linq4j.tree
-
Symbol document info.
- expressionType - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.BinaryImplementor
- expressionType - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.UnaryImplementor
- ExpressionType - Enum in org.apache.calcite.linq4j.tree
-
Analogous to LINQ's System.Linq.Expressions.ExpressionType.
- ExpressionType() - Constructor for enum org.apache.calcite.linq4j.tree.ExpressionType
- ExpressionType(String, boolean, int, boolean) - Constructor for enum org.apache.calcite.linq4j.tree.ExpressionType
- ExpressionType(String, String, boolean, int, boolean) - Constructor for enum org.apache.calcite.linq4j.tree.ExpressionType
- ExpressionType(String, String, boolean, int, boolean, boolean) - Constructor for enum org.apache.calcite.linq4j.tree.ExpressionType
- ExpressionVisitor - Interface in org.apache.calcite.linq4j.tree
-
Represents a visitor or rewriter for expression trees.
- ExpressionWriter - Class in org.apache.calcite.linq4j.tree
-
Converts an expression to Java code.
- ExpressionWriter() - Constructor for class org.apache.calcite.linq4j.tree.ExpressionWriter
- ExpressionWriter(boolean) - Constructor for class org.apache.calcite.linq4j.tree.ExpressionWriter
- ExpressionWriter.Indent - Class in org.apache.calcite.linq4j.tree
-
Helps generate strings of spaces, to indent text.
- exprFields - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- exprInverseOrdinals - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter.InputToCommonExprConverter
- exprLevels - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter.InputToCommonExprConverter
- exprLevels - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter.MaxInputFinder
- exprList - Variable in class org.apache.calcite.rex.RexProgramBuilder
- exprList(SqlImplementor.Context, List<? extends RexNode>) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- exprMap - Variable in class org.apache.calcite.rex.RexProgramBuilder
- exprNullableMap - Variable in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- exprs - Variable in class org.apache.calcite.rex.RexProgram.ExpansionShuttle
- exprs - Variable in class org.apache.calcite.rex.RexProgram
-
First stage of expression evaluation.
- 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.
- ExprsItr(ImmutableBitSet) - Constructor for class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference.ExprsItr
- exprsLineage - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.NodeLineage
- exprsLineageLosslessCasts - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.NodeLineage
- exps - Variable in class org.apache.calcite.rel.core.Project
- 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, RelProtoDataType, ImmutableIntList) - Method in class org.apache.calcite.schema.impl.ModifiableViewTable
- extend(SqlNodeList) - Method in class org.apache.calcite.sql.validate.TableNamespace
-
Creates a TableNamespace based on the same table as this one, but with extended fields.
- EXTEND - 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 class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Extended instance of the rule that can push down aggregate functions.
- EXTENDED_RULES - Static variable in class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor
- ExtendedEnumerable<TSource> - Interface in org.apache.calcite.linq4j
-
Extension methods in
Enumerable
. - ExtendedExpander(SqlValidatorImpl, SqlValidatorScope, SqlSelect, SqlNode, boolean) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.ExtendedExpander
- extendedFields - Variable in class org.apache.calcite.sql.validate.TableNamespace
- ExtendedOrderedEnumerable<T> - Interface in org.apache.calcite.linq4j
-
Extension methods for
OrderedEnumerable
. - ExtendedOrderedQueryable<T> - Interface in org.apache.calcite.linq4j
-
Extension methods for
OrderedQueryable
. - ExtendedQueryable<TSource> - Interface in org.apache.calcite.linq4j
-
Extension methods in Queryable.
- 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 - 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.
- Extensions() - Constructor for class org.apache.calcite.linq4j.Extensions
- 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.
- extract(RexCall, List<Comparable>) - Method in class org.apache.calcite.rex.RexInterpreter
- EXTRACT - org.apache.calcite.sql.SqlKind
-
The "EXTRACT" function.
- EXTRACT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
EXTRACT
operator. - EXTRACT_COLUMN_NAME_PREFIX - Static variable in class org.apache.calcite.adapter.druid.DruidQuery
- EXTRACT_UNIT_MAP - Static variable in class org.apache.calcite.adapter.druid.ExtractOperatorConversion
- extractColumnName(RexNode, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
- ExtractFinder() - Constructor for class org.apache.calcite.rel.rules.DateRangeRules.ExtractFinder
- extractGranularity(RexNode, String) - Static method in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
-
Infers granularity from a time unit.
- ExtractImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.ExtractImplementor
- extractInputRefs(RexNode) - Static method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
- 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 - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonBound
- extractionFunction - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonInFilter
- extractionFunction - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonSelector
- extractionFunction - Variable in class org.apache.calcite.adapter.druid.ExtractionDimensionSpec
- ExtractionFunction - Interface in org.apache.calcite.adapter.druid
-
Interface for Druid extraction functions.
- ExtractOperatorConversion - Class in org.apache.calcite.adapter.druid
-
Time extract operator conversion for expressions like EXTRACT(timeUnit FROM arg) Unit can be SECOND, MINUTE, HOUR, DAY (day of month), DOW (day of week), DOY (day of year), WEEK (week of week year), MONTH (1 through 12), QUARTER (1 through 4), or YEAR
- ExtractOperatorConversion() - Constructor for class org.apache.calcite.adapter.druid.ExtractOperatorConversion
- extractPossibleMapping(List<Set<RexTableInputRef>>, List<Set<RexTableInputRef>>) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
Given the source and target equivalence classes, it extracts the possible mappings from each source equivalence class to each target equivalence class.
- extractRange(TimeUnitRange, SqlKind, Calendar) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- extractRanges(RexNode, boolean) - Static method in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
- extractReferences(RexBuilder, RelNode) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
If the node is an Aggregate, it returns a list of references to the grouping columns.
- ExtractShuttle(RexBuilder, TimeUnitRange, Map<RexNode, RangeSet<Calendar>>, ImmutableSortedSet<TimeUnitRange>, String) - Constructor for class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- extractTimestampField(JsonParser) - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- extractTimeUnits(RexNode) - Static method in class org.apache.calcite.rel.rules.DateRangeRules
-
Tests whether an expression contains one or more calls to the
EXTRACT
function, and if so, returns the time units used. - extraExprList - Variable in class org.apache.calcite.sql.validate.AggregatingSelectScope.Resolved
- extraExprs - Variable in class org.apache.calcite.sql.validate.AggChecker
- extraExprs - Variable in class org.apache.calcite.sql.validate.SqlValidatorUtil.GroupAnalyzer
-
Extra expressions, computed from the input as extra GROUP BY expressions.
- extraFields - Variable in class org.apache.calcite.plan.RelOptUtil.InputFinder
- extraIndent - Variable in class org.apache.calcite.plan.RelOptUtil.TypeDumper
- extraIndent - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
-
Indent of sub-frame with respect to this one.
- extraNodes - Variable in class org.apache.calcite.tools.RelBuilder.Registrar
- ExtraOperand(String) - Constructor for enum org.apache.calcite.model.ModelHandler.ExtraOperand
- 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 - Variable in class org.apache.calcite.sql2rel.AuxiliaryConverter.Impl
- 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.
- factor - Variable in class org.apache.calcite.adapter.enumerable.EnumerableInterpreter
- factorBitmap(ImmutableBitSet) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Sets the bitmap indicating which factors a filter references based on which fields it references
- FactorCostComparator() - Constructor for class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer.FactorCostComparator
- factorCostOrdering - Variable in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
- factors - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin.Edge
- factors - Variable in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.Vertex
- factorsRefByFactor - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Bitmap indicating which factors each factor references in join filters that correspond to comparisons
- factorsRefByJoinFilter - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
For each join filter, associates a bitmap indicating all factors referenced by the filter
- factorTree - Variable in class org.apache.calcite.rel.rules.LoptJoinTree
- factorWeights - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Weights of each factor combination
- factory - Variable in class org.apache.calcite.interpreter.AggregateNode.UdaAccumulator
- factory - Variable in class org.apache.calcite.linq4j.DefaultQueryable
- 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.rel.rules.LoptMultiJoin
-
Type factory
- factory() - Static method in class org.apache.calcite.util.graph.DefaultEdge
- factory(List<Pair<ColumnMetaData.Rep, Integer>>) - Static method in class org.apache.calcite.adapter.jdbc.JdbcUtils.ObjectArrayRowBuilder
- 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.adapter.jdbc.JdbcSchema.Factory
- Factory() - Constructor for class org.apache.calcite.materialize.LatticeSuggester.StepRef.Factory
- Factory() - Constructor for class org.apache.calcite.materialize.Step.Factory
- Factory() - Constructor for class org.apache.calcite.plan.RelOptCostImpl.Factory
- Factory() - Constructor for class org.apache.calcite.plan.volcano.VolcanoCost.Factory
- Factory() - Constructor for class org.apache.calcite.schema.impl.AbstractSchema.Factory
- FACTORY - Static variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping.Datatype
- FACTORY - Static variable in class org.apache.calcite.materialize.Lattice.Edge
- FACTORY - Static variable in class org.apache.calcite.materialize.ProfilerLatticeStatisticProvider
- FACTORY - Static variable in class org.apache.calcite.materialize.SqlLatticeStatisticProvider
- FACTORY - Static variable in class org.apache.calcite.plan.RelOptCostImpl
- FACTORY - Static variable in class org.apache.calcite.plan.volcano.VolcanoCost
- 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 interface org.apache.calcite.util.Litmus
-
Called when test fails.
- failCount - Variable in class org.apache.calcite.rex.RexChecker
- failedToAccessField(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- FakeUtil() - Constructor for class org.apache.calcite.sql.SqlDialect.FakeUtil
- FALSE - org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
If one of the arguments is null, the function returns false.
- FALSE - 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 - org.apache.calcite.rex.RexInterpreter.Truthy
- FALSE - 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 - 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.linq4j.tree.Primitive
- family - Variable in class org.apache.calcite.sql.type.ObjectSqlType
- family - Variable in enum org.apache.calcite.sql.type.SqlTypeName
- 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.
- FamilyOperandTypeChecker(List<SqlTypeFamily>, Predicate<Integer>) - Constructor for class org.apache.calcite.sql.type.FamilyOperandTypeChecker
-
Package private.
- fastBailOut - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
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
- FemLocalIndex() - Constructor for class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer.FemLocalIndex
- fetch - Variable in class org.apache.calcite.adapter.cassandra.CassandraLimit
- fetch - Variable in class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
- fetch - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
-
Number of records to return.
- 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 - Variable in class org.apache.calcite.sql.SqlSelect
- fetch(long) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
- fetch(Meta.StatementHandle, long, int) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- FETCH - org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- FETCH - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
FETCH clause.
- fetchAndCreateMapping() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
-
Build index mapping returning new instance of
ElasticsearchMapping
. - fetchLimit - Variable in class org.apache.calcite.adapter.druid.DruidQuery.ScanQuery
- 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.
- fetchPreferredAlbums() - Method in class org.apache.calcite.chinook.PreferredAlbumsTableFactory
- fetchPreferredGenres() - Method in class org.apache.calcite.chinook.PreferredGenresTableFactory
- fetchSize - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchema
-
Default batch size to be used during scrolling.
- fetchSize - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
-
Default batch size
- fetchSize - Variable in class org.apache.calcite.adapter.elasticsearch.Scrolling
- field - Variable in class org.apache.calcite.adapter.java.ReflectiveSchema.FieldTable
- field - Variable in class org.apache.calcite.linq4j.tree.MemberExpression
- field - Variable in class org.apache.calcite.linq4j.tree.ReflectedPseudoField
- field - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.SimpleContext
- field - Variable in class org.apache.calcite.rel.type.RelDataTypeImpl.Slot
- field - Variable in class org.apache.calcite.rex.RexFieldAccess
- field - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.CorDef
- field - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.CorRef
- 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.materialize.LatticeTable
- 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.JoinContext
- 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, int, boolean) - Method in class org.apache.calcite.tools.RelBuilder
-
As
RelBuilder.field(int, int, int)
, but ifalias
is true, the method may apply an alias to make sure that the field has the same name as in the input frame. - 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.SqlValidatorImpl.Permute
- 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(BlockBuilder, int, Type) - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindow.WindowRelInputGetter
- 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(BlockBuilder, int, Type) - Method in class org.apache.calcite.rex.RexExecutorImpl.DataContextInputGetter
- field(Expression, int, Type, Type) - Method in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
-
Returns a reference to a particular field.
- 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, 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(Expression, PseudoField) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberExpression that represents accessing a 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 class org.apache.calcite.sql.validate.SqlNameMatchers.BaseMatcher
- field(RelDataType, String) - Method in interface org.apache.calcite.sql.validate.SqlValidatorCatalogReader
- field(RexNode, String) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns a reference to a given field of a record-valued expression.
- field(RelBuilder, int, int) - Method in class org.apache.calcite.rel.rules.SubQueryRemoveRule
-
Returns a reference to a particular field, by offset, across several inputs on a
RelBuilder
's stack. - Field(ImmutableSet<String>, RelDataTypeField) - Constructor for class org.apache.calcite.tools.RelBuilder.Field
- FIELD_ACCESS - org.apache.calcite.sql.SqlKind
-
The field access operator, ".".
- FIELD_PREFIX - Static variable in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
- FIELD_SCHEMA - org.apache.calcite.piglet.Ast.Op
- FieldAccessFinder() - Constructor for class org.apache.calcite.rex.RexUtil.FieldAccessFinder
- fieldAccessList - Variable in class org.apache.calcite.rex.RexUtil.FieldAccessFinder
- fieldBitmap(RexNode) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- 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
- fieldClasses - Variable in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- fieldClasses(JavaTypeFactory) - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- fieldCollations - Variable in class org.apache.calcite.rel.RelCollationImpl
- fieldConfigs - Variable in class org.apache.calcite.adapter.file.FileRowConverter
- fieldCount - Variable in class org.apache.calcite.interpreter.ValuesNode
- fieldCount - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- 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
- FieldDef(String, FileFieldType, Map<String, Object>, int) - Constructor for class org.apache.calcite.adapter.file.FileRowConverter.FieldDef
- fieldExceedsPrecisionException(SqlParserPos, int, BigDecimal, TimeUnit, int) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- fieldExists(String) - Method in class org.apache.calcite.sql.validate.AbstractNamespace
- fieldExists(String) - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- fieldExists(String) - Method in class org.apache.calcite.sql.validate.FieldNamespace
- fieldExists(String) - Method in interface org.apache.calcite.sql.validate.SqlValidatorNamespace
-
Returns whether this namespace has a field of a given name.
- fieldExpression(ParameterExpression, int, PhysType, JavaRowFormat) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
- fieldExpressions(Expression) - Method in class org.apache.calcite.prepare.LixToRelTranslator
- fieldExps - Variable in class org.apache.calcite.rel.core.Sort
- fieldIndex - Variable in class org.apache.calcite.adapter.csv.CsvEnumerator.SingleColumnRowConverter
- fieldIndex - Variable in class org.apache.calcite.rel.RelFieldCollation
-
0-based index of field being sorted.
- FieldInfoBuilder(RelDataTypeFactory) - Constructor for class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- fieldList - Variable in class org.apache.calcite.adapter.splunk.SplunkQuery
- fieldList - Variable in class org.apache.calcite.adapter.splunk.SplunkTableScan
- 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.adapter.druid.DruidConnectionImpl.JsonAggregator
- fieldName - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonAggregation
- fieldName - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.ExistsQueryBuilder
- fieldName - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- fieldName - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RegexpQueryBuilder
- fieldName - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.TermQueryBuilder
- fieldName - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.TermsQueryBuilder
- fieldName - Variable in class org.apache.calcite.linq4j.tree.ArrayLengthRecordField
- fieldName - Variable in class org.apache.calcite.rel.core.Collect
- fieldName - Variable in class org.apache.calcite.rel.mutable.MutableCollect
- fieldName(int) - Method in class org.apache.calcite.adapter.geode.rel.GeodeSort
- fieldNames - Variable in class org.apache.calcite.adapter.cassandra.CassandraFilter.Translator
- fieldNames - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonCardinalityAggregation
- fieldNames - Variable in class org.apache.calcite.adapter.druid.DruidQuery.QuerySpec
- fieldNames - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
- fieldNames - Variable in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
- fieldNames - Variable in class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
- fieldNames - Variable in class org.apache.calcite.adapter.pig.PigTable
- fieldNames - Variable in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.CountingSearchResultListener
- fieldNames - Variable in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.SplunkResultEnumerator
- fieldNames(RelDataType) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchAggregate
- fieldNames(RelDataType) - Method in class org.apache.calcite.adapter.geode.rel.GeodeAggregate
- FieldNamespace - Class in org.apache.calcite.sql.validate
-
Implementation of
SqlValidatorNamespace
for a field of a record. - FieldNamespace(SqlValidatorImpl, RelDataType) - Constructor for class org.apache.calcite.sql.validate.FieldNamespace
-
Creates a FieldNamespace.
- 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
- fieldOffset - Variable in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.LeafVertex
- 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
- fieldReferences(Expression, List<Integer>) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- fieldRelation(Field) - Method in class org.apache.calcite.adapter.java.ReflectiveSchema
-
Returns a table based on a particular field of this schema.
- fieldRowTypes(RelDataType, List<? extends RexNode>, List<Integer>) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
- fields - Variable in class org.apache.calcite.adapter.csv.CsvEnumerator.ArrayRowConverter
- fields - Variable in class org.apache.calcite.adapter.csv.CsvTableScan
- fields - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonCompositeFilter
- fields - Variable in class org.apache.calcite.adapter.druid.DruidTable.MapRelProtoDataType
- fields - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHit
- fields - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHit
- fields - Variable in class org.apache.calcite.adapter.file.FileEnumerator
- fields - Variable in class org.apache.calcite.adapter.file.FileRowConverter
- fields - Variable in class org.apache.calcite.adapter.file.FileTableScan
- fields - Variable in class org.apache.calcite.adapter.java.ReflectiveSchema.FieldSelector
- fields - Variable in class org.apache.calcite.jdbc.JavaTypeFactoryImpl.SyntheticRecordType
- fields - Variable in class org.apache.calcite.piglet.Ast.OrderStmt
- fields - Variable in class org.apache.calcite.rel.RelRoot
- fields - Variable in class org.apache.calcite.rel.type.RelDataTypeHolder
- fields - Variable in class org.apache.calcite.rel.type.RelRecordType.SerializableRelRecordType
- fields - Variable in class org.apache.calcite.rex.RexPermuteInputsShuttle
- fields - Variable in class org.apache.calcite.tools.RelBuilder.Frame
- fields() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHit
- fields() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHit
- fields() - Method in class org.apache.calcite.tools.RelBuilder
-
Returns references to the fields of the top input.
- fields() - Method in class org.apache.calcite.tools.RelBuilder.Frame
- 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(RelNode[]) - Static method in class org.apache.calcite.rex.RexPermuteInputsShuttle
- fields(RelBuilder, int) - Static method in class org.apache.calcite.rel.rules.SubQueryRemoveRule
-
Returns a list of expressions that project the first
fieldCount
fields of the top input on aRelBuilder
's stack. - fields(Mappings.TargetMapping) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns references to fields identified by a mapping.
- FIELDS - Static variable in interface org.apache.calcite.adapter.elasticsearch.ElasticsearchConstants
- 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
- fieldSchemaList - Variable in class org.apache.calcite.piglet.Ast.Schema
- fieldSchemaList - Variable in class org.apache.calcite.piglet.Ast.TupleType
- FieldSelector(Class) - Constructor for class org.apache.calcite.adapter.java.ReflectiveSchema.FieldSelector
- fieldsOf(Class) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- fieldsRefByJoinFilter - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
For each join filter, associates a bitmap indicating all fields referenced by the filter
- FieldTable(Field, Type, Enumerable<T>) - Constructor for class org.apache.calcite.adapter.java.ReflectiveSchema.FieldTable
- FieldTable(Field, Type, Enumerable<T>, Statistic) - Constructor for class org.apache.calcite.adapter.java.ReflectiveSchema.FieldTable
- fieldType - Variable in class org.apache.calcite.adapter.csv.CsvEnumerator.SingleColumnRowConverter
- fieldType(Field) - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl
-
Returns the type of a field.
- fieldTypes - Variable in class org.apache.calcite.adapter.cassandra.CassandraEnumerator
- fieldTypes - Variable in class org.apache.calcite.adapter.csv.CsvEnumerator.ArrayRowConverter
- fieldTypes - Variable in class org.apache.calcite.adapter.csv.CsvTable
- fieldTypes - Variable in class org.apache.calcite.adapter.geode.rel.GeodeEnumerator
- fieldTypes(JavaTypeFactory, List<? extends RelDataType>) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
- file - Variable in class org.apache.calcite.util.Sources.FileSource
- file() - Method in interface org.apache.calcite.util.Source
- file() - Method in class org.apache.calcite.util.Sources.FileSource
- file(File, String) - Static method in class org.apache.calcite.util.Sources
- FILE - 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.
- FileEnumerator - Class in org.apache.calcite.adapter.file
-
Wraps
FileReader
andFileRowConverter
, enumerates tr DOM elements as table rows. - FileEnumerator(Iterator<Elements>, FileRowConverter) - Constructor for class org.apache.calcite.adapter.file.FileEnumerator
- FileEnumerator(Iterator<Elements>, FileRowConverter, int[]) - Constructor for class org.apache.calcite.adapter.file.FileEnumerator
- FileFieldType - Enum in org.apache.calcite.adapter.file
-
Type of a field in a Web (HTML) table.
- FileFieldType(Primitive) - Constructor for enum org.apache.calcite.adapter.file.FileFieldType
- FileFieldType(Primitive, Class) - Constructor for enum org.apache.calcite.adapter.file.FileFieldType
- fileNameList - Variable in class org.apache.calcite.util.javac.JavaCompilerArgs
- filePath - Variable in class org.apache.calcite.adapter.pig.PigTable
- fileReader - Variable in class org.apache.calcite.adapter.file.FileRowConverter
- 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) - Constructor for class org.apache.calcite.adapter.file.FileReader
- FileReader(Source, String, Integer) - Constructor for class org.apache.calcite.adapter.file.FileReader
- FileReader.FileReaderIterator - Class in org.apache.calcite.adapter.file
-
Iterates over HTML tables, returning an Elements per row.
- FileReaderException - Exception in org.apache.calcite.adapter.file
-
Indicates that the FileReader failed.
- FileReaderException(String) - Constructor for exception org.apache.calcite.adapter.file.FileReaderException
- FileReaderException(String, Throwable) - Constructor for exception org.apache.calcite.adapter.file.FileReaderException
- FileReaderIterator(Elements) - Constructor for class org.apache.calcite.adapter.file.FileReader.FileReaderIterator
- FileRowConverter - Class in org.apache.calcite.adapter.file
-
FileRowConverter.
- FileRowConverter(FileReader, List<Map<String, Object>>) - Constructor for class org.apache.calcite.adapter.file.FileRowConverter
-
Creates a FileRowConverter.
- FileRowConverter.CellReader - Class in org.apache.calcite.adapter.file
-
Parses an an HTML table cell.
- FileRowConverter.FieldDef - Class in org.apache.calcite.adapter.file
-
Responsible for managing field (column) definition, and for converting an Element to a java data type.
- FileSchema - Class in org.apache.calcite.adapter.file
-
Schema mapped onto a set of URLs / HTML tables.
- FileSchema(SchemaPlus, String, File, List<Map<String, Object>>) - Constructor for class org.apache.calcite.adapter.file.FileSchema
-
Creates an HTML tables schema.
- FileSchemaFactory - Class in org.apache.calcite.adapter.file
-
Factory that creates a
FileSchema
. - FileSchemaFactory() - Constructor for class org.apache.calcite.adapter.file.FileSchemaFactory
- FileSource(File) - Constructor for class org.apache.calcite.util.Sources.FileSource
- FileSource(URL) - Constructor for class org.apache.calcite.util.Sources.FileSource
- FilesTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "find" command to find files under a particular path.
- FilesTableFunction() - Constructor for class org.apache.calcite.adapter.os.FilesTableFunction
- FileTable - Class in org.apache.calcite.adapter.file
-
Table implementation wrapping a URL / HTML table.
- FileTable(Source, String, Integer, RelProtoDataType, List<Map<String, Object>>) - Constructor for class org.apache.calcite.adapter.file.FileTable
-
Creates a FileTable.
- FileTableScan - Class in org.apache.calcite.adapter.file
-
Relational expression representing a scan of an HTML table.
- FileTableScan(RelOptCluster, RelOptTable, FileTable, int[]) - Constructor for class org.apache.calcite.adapter.file.FileTableScan
- FileType() - Constructor for enum org.apache.calcite.sql.ddl.SqlDdlNodes.FileType
- fillInStackTrace() - Method in exception org.apache.calcite.util.ControlFlowException
- fillIntervalValueArray(int, BigDecimal, BigDecimal) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- fillIntervalValueArray(int, BigDecimal, BigDecimal, BigDecimal, BigDecimal, BigDecimal) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- filter - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonDimHavingFilter
- filter - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonFilteredAggregation
- filter - Variable in class org.apache.calcite.rel.core.Aggregate.AggCallBinding
- filter - Variable in class org.apache.calcite.tools.RelBuilder.AggCallImpl
- 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 RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Filter
of a list of predicates. - filter(Iterable<E>, Predicate<E>) - Static method in class org.apache.calcite.util.Util
-
Filters an iterable.
- filter(Collection<?>, Class<E>) - Static method in class org.apache.calcite.util.Util
- filter(Iterator<E>, Predicate<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(QueryBuilders.QueryBuilder) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.BoolQueryBuilder
- 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.AggCallImpl
- filter(RexNode) - Method in class org.apache.calcite.tools.RelBuilder.AggCallImpl2
- filter(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Filter
of an array of predicates. - 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, 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 - org.apache.calcite.piglet.Ast.Op
- FILTER - org.apache.calcite.rel.mutable.MutableRelType
- FILTER - org.apache.calcite.sql.SqlKind
-
FILTER operator
- FILTER - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- FILTER - Static variable in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- FILTER - Static variable in class org.apache.calcite.rel.rules.SubQueryRemoveRule
- 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_FACTORY - Static variable in interface org.apache.calcite.adapter.enumerable.EnumerableRel
- FILTER_INSTANCE - Static variable in class org.apache.calcite.rel.rules.DateRangeRules
- FILTER_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts a
LogicalFilter
to empty if its child is empty. - FILTER_INSTANCE - Static variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Singleton rule that reduces constants inside a
LogicalFilter
. - FILTER_INSTANCE - Static variable in class org.apache.calcite.rel.rules.ValuesReduceRule
-
Instance of this rule that applies to the pattern Filter(Values).
- FILTER_ON_JOIN - Static variable in class org.apache.calcite.rel.rules.FilterJoinRule
-
Rule that pushes predicates from a Filter into the Join below them.
- 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.rel.rules.DateRangeRules
- 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
- FILTERABLE - org.apache.calcite.adapter.csv.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
- FilterAccumulator(AggregateNode.Accumulator, int) - Constructor for class org.apache.calcite.interpreter.AggregateNode.FilterAccumulator
- filterAggregateTransposeRule - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewAggregateRule
-
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
-
Creates a FilterAggregateTransposeRule.
- FilterAggregateTransposeRule(RelOptRuleOperand, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterAggregateTransposeRule
- filterArg - Variable in class org.apache.calcite.interpreter.AggregateNode.FilterAccumulator
- 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
-
Planner rule that merges a
LogicalFilter
and aLogicalCalc
. - FilterCalcMergeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterCalcMergeRule
-
Creates a FilterCalcMergeRule.
- filterClauses - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.BoolQueryBuilder
- FilterCorrelateRule - Class in org.apache.calcite.rel.rules
- FilterCorrelateRule(RelFactories.FilterFactory, RelFactories.ProjectFactory) - Constructor for class org.apache.calcite.rel.rules.FilterCorrelateRule
-
Deprecated.
- FilterCorrelateRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterCorrelateRule
-
Creates a FilterCorrelateRule.
- FilterDateRangeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.DateRangeRules.FilterDateRangeRule
- filterFactory - Variable in class org.apache.calcite.tools.RelBuilder
- FilterFactoryImpl() - Constructor for class org.apache.calcite.rel.core.RelFactories.FilterFactoryImpl
- FilteringIterator(Iterator<? extends T>, Predicate<T>) - Constructor for class org.apache.calcite.util.Util.FilteringIterator
- 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
- FilterJoinRule - 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(RelOptRuleOperand, String, boolean, RelFactories.FilterFactory, RelFactories.ProjectFactory) - Constructor for class org.apache.calcite.rel.rules.FilterJoinRule
-
Deprecated.
- FilterJoinRule(RelOptRuleOperand, String, boolean, RelFactories.FilterFactory, RelFactories.ProjectFactory, FilterJoinRule.Predicate) - Constructor for class org.apache.calcite.rel.rules.FilterJoinRule
-
Deprecated.
- FilterJoinRule(RelOptRuleOperand, String, boolean, RelBuilderFactory, FilterJoinRule.Predicate) - Constructor for class org.apache.calcite.rel.rules.FilterJoinRule
-
Creates a FilterProjectTransposeRule with an explicit root operand and factories.
- 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.JoinConditionPushRule - Class in org.apache.calcite.rel.rules
-
Rule that pushes parts of the join condition to its inputs.
- 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.
- filterList - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.AggregateFinder
- 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(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterMergeRule
-
Creates a FilterMergeRule.
- FilterMultiJoinMergeRule - Class in org.apache.calcite.rel.rules
- FilterMultiJoinMergeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterMultiJoinMergeRule
-
Creates a FilterMultiJoinMergeRule.
- 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
- FilterOnProjectRule(RelBuilderFactory) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.FilterOnProjectRule
-
Creates a FilterOnProjectRule.
- filterOperatorRoutinesByKind(Iterator<SqlOperator>, SqlKind) - Static method in class org.apache.calcite.sql.SqlUtil
- filterProjectTransposeRule - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewAggregateRule
-
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
-
Creates a FilterProjectTransposeRule.
- 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
-
Creates a FilterProjectTransposeRule.
- FilterProjectTransposeRule(RelOptRuleOperand, boolean, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterProjectTransposeRule
- FilterReduceExpressionsRule(Class<? extends Filter>, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.FilterReduceExpressionsRule
- FilterReduceExpressionsRule(Class<? extends Filter>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.FilterReduceExpressionsRule
-
Deprecated.
- 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
-
Creates a FilterRemoveIsNotDistinctFromRule.
- FilterRemoveIsNotDistinctFromRule.RemoveIsNotDistinctFromRexShuttle - Class in org.apache.calcite.rel.rules
-
Shuttle that removes 'x IS NOT DISTINCT FROM y' and converts it to 'CASE WHEN x IS NULL THEN y IS NULL WHEN y IS NULL THEN x IS NULL ELSE x = y END'.
- filterRoutinesByParameterCount(Iterator<SqlOperator>, List<RelDataType>) - Static method in class org.apache.calcite.sql.SqlUtil
- filterRoutinesByParameterType(SqlSyntax, Iterator<SqlOperator>, List<RelDataType>, List<String>) - Static method in class org.apache.calcite.sql.SqlUtil
- filterRoutinesByTypePrecedence(SqlSyntax, Iterator<SqlOperator>, List<RelDataType>) - Static method in class org.apache.calcite.sql.SqlUtil
- filters - Variable in class org.apache.calcite.interpreter.Bindables.BindableTableScan
- FilterSetOpTransposeRule - Class in org.apache.calcite.rel.rules
- FilterSetOpTransposeRule(RelFactories.FilterFactory) - Constructor for class org.apache.calcite.rel.rules.FilterSetOpTransposeRule
-
Deprecated.
- FilterSetOpTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterSetOpTransposeRule
-
Creates a FilterSetOpTransposeRule.
- 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(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterTableFunctionTransposeRule
-
Creates a FilterTableFunctionTransposeRule.
- 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
-
Creates a FilterTableScanRule.
- FilterToCalcRule - Class in org.apache.calcite.rel.rules
-
Planner rule that converts a
LogicalFilter
to aLogicalCalc
. - FilterToCalcRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.FilterToCalcRule
-
Creates a FilterToCalcRule.
- FilterToFilterUnifyRule() - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.FilterToFilterUnifyRule
- FilterToFilterUnifyRule1() - Constructor for class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor.FilterToFilterUnifyRule1
- FilterToProjectUnifyRule() - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.FilterToProjectUnifyRule
- FilterToProjectUnifyRule1() - Constructor for class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor.FilterToProjectUnifyRule1
- filterValues - Variable in class org.apache.calcite.adapter.csv.CsvEnumerator
- FINAL - org.apache.calcite.sql.SqlKind
-
Special functions in MATCH_RECOGNIZE.
- FINAL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
FINAL
function to be used withinMATCH_RECOGNIZE
. - find(ImmutableList<Lattice.Measure>, Pair<SqlAggFunction, List<Integer>>) - Static method in class org.apache.calcite.rel.rules.AggregateStarTableRule
- find(MongoDatabase, String, String, List<Map.Entry<String, Class>>) - Method in class org.apache.calcite.adapter.mongodb.MongoTable
-
Executes a "find" operation on the underlying collection.
- find(Class<? extends RelNode>, Method) - Method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider.Space
-
Finds an implementation of a method for
relNodeClass
or its nearest base class. - 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>>, Long, Long) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable.ElasticsearchQueryable
-
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>>, Long, Long) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
-
Executes a "find" operation on the underlying type.
- 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(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(RexNode) - Static method in class org.apache.calcite.rex.RexUtil.SubQueryFinder
- findAgg(List<SqlNode>) - Method in class org.apache.calcite.sql.validate.AggFinder
- findAgg(SqlNode) - Method in class org.apache.calcite.sql.validate.AggFinder
-
Finds an aggregate.
- findAliases(Collection<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- findAliases(Collection<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.EmptyScope
- 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. - findAll(Iterable<SqlNode>) - Method in class org.apache.calcite.sql.validate.AggFinder
-
Creates a copy of this finder that has the same parameters as this, then returns the list of all aggregates found.
- findAllColumnNames(List<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- findAllColumnNames(List<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.EmptyScope
- 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.EmptyScope
- 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
- findAllValidFunctionNames(List<String>, SqlValidator, Collection<SqlMoniker>, SqlParserPos) - Static method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- findAllValidUdfNames(List<String>, SqlValidator, Collection<SqlMoniker>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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)
. - findBestOrderings(RelMetadataQuery, RelBuilder, LoptMultiJoin, LoptSemiJoinOptimizer, RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Generates N optimal join orderings.
- findChild(List<String>, SqlNameMatcher) - Method in class org.apache.calcite.sql.validate.ListScope
- findChild(Step) - Method in class org.apache.calcite.materialize.MutableNode
- findChildren(E) - Method in class org.apache.calcite.util.PartiallyOrderedSet
- findClause(SqlSimpleParser.TokenType) - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Query
- findCohort(List<Set<Integer>>, int) - Static method in class org.apache.calcite.rel.rules.CalcRelSplitter
-
Finds the cohort that contains the given integer, or returns null.
- findCorrelationEquivalent(RelDecorrelator.CorRef, RexNode) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Finds a
RexInputRef
that is equivalent to aRelDecorrelator.CorRef
, and if found, throws aUtil.FoundOne
. - findCycles() - Method in class org.apache.calcite.util.graph.CycleDetector
- findCycles() - Method in class org.apache.calcite.util.graph.TopologicalOrderIterator
- 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.
- finder - Variable in class org.apache.calcite.sql2rel.CorrelationReferenceFinder.MyRexVisitor
- Finder() - Constructor for class org.apache.calcite.rex.RexOver.Finder
- FINDER - Static variable in class org.apache.calcite.rex.RexOver
- findExprInLists(RexNode, List<RexNode>, int, List<RexNode>, int) - Method in class org.apache.calcite.rel.rules.PushProjector.RefAndExprConverter
-
Looks for a matching RexNode from among two lists of RexNodes and returns the offset into the list corresponding to the match, adjusted by an amount, depending on whether the match was from the first or second list.
- 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
- findIndex(RelTraitDef) - Method in class org.apache.calcite.plan.RelTraitSet
-
Finds the index of a trait of a given type in this set.
- findLocalIpAddress() - Static method in class org.apache.calcite.adapter.spark.HttpServer
- 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.
- findMatch(Lattice, MutableNode) - Method in class org.apache.calcite.materialize.LatticeSuggester
-
Returns the best match for a lattice.
- findMethod(Class<?>, String) - Static method in class org.apache.calcite.schema.impl.ReflectiveFunctionBase
-
Finds a method in a given class by name.
- findMethod(Class<?>, String, Class...) - Static method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- findOperatorCall(SqlOperator, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a given node contains a RexCall with a specified operator
- findParents(E) - Method in class org.apache.calcite.util.PartiallyOrderedSet
- findParentsChildren(E, Deque<PartiallyOrderedSet.Node<E>>, boolean) - Method in class org.apache.calcite.util.PartiallyOrderedSet
- findPaths(V, V, List<List<V>>) - Method in class org.apache.calcite.util.graph.Graphs.FrozenGraph
- findPathsExcluding(V, V, List<List<V>>, Set<V>, List<V>) - Method in class org.apache.calcite.util.graph.Graphs.FrozenGraph
-
Finds all paths from "from" to "to" of length 2 or greater, such that the intermediate nodes are not contained in "excludedNodes".
- findPos(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Looks for one or two carets in a SQL string, and if present, converts them into a parser position.
- findProvider(List<Pair<String, MetadataHandler>>, Class<?>) - Static method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- findQualifyingTableName(String, SqlNode) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- findQualifyingTableName(String, SqlNode) - Method in class org.apache.calcite.sql.validate.EmptyScope
- 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.EmptyScope
- 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>, List<RexNode>) - 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
- findReference(LogicalProject, LogicalWindow) - Method in class org.apache.calcite.rel.rules.ProjectWindowTransposeRule
- findRel(int) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.LookupContext
-
Returns the relational expression with a given offset, and the ordinal in the combined row of its first field.
- findRemovableOuterJoins(RelMetadataQuery, LoptMultiJoin) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Locates all null generating factors whose outer join can be removed.
- findRemovableSelfJoins(RelMetadataQuery, LoptMultiJoin) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Locates pairs of joins that are self-joins where the join can be removed because the join condition between the two factors is an equality join on unique keys.
- findSemiJoinIndexByCost(RelNode, List<Integer>, List<Integer>, List<Integer>) - Method in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer.LcsIndexOptimizer
- findSemiJoinIndexByCost(LoptMultiJoin, List<RexNode>, int, int) - Method in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
-
Given a list of possible filters on a fact table, determine if there is an index that can be used, provided all the fact table keys originate from the same underlying table.
- findSubQueries(SqlToRelConverter.Blackboard, SqlNode, RelOptUtil.Logic, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Builds a list of all
IN
orEXISTS
operators inside SQL parse tree. - findTable(String) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Given a table alias, find the corresponding
Table
associated with it - findTable(CalciteSchema, String, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- findTableColumnPair(SqlIdentifier, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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.
- findValue(RexNode) - Static method in class org.apache.calcite.rex.RexLiteral
- finish() - Method in class org.apache.calcite.profile.ProfilerImpl.Collector
- finish() - Method in class org.apache.calcite.profile.ProfilerImpl.CompositeCollector
- finish() - Method in class org.apache.calcite.profile.ProfilerImpl.HllCollector
- finish() - Method in class org.apache.calcite.profile.ProfilerImpl.SingletonCollector
- FiniteAbstractMapping() - Constructor for class org.apache.calcite.util.mapping.Mappings.FiniteAbstractMapping
- fire - Variable in class org.apache.calcite.benchmarks.PreconditionTest
- FIREBIRD - 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.
- fireRule(RelOptRuleCall) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Fires a rule, taking care of tracing and listener notification.
- fireRules(RelNode, boolean) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Fires all rules matched by a relational expression.
- first - Variable in class org.apache.calcite.linq4j.CartesianProductEnumerator
- first - Variable in class org.apache.calcite.runtime.ConsList
- first - Variable in class org.apache.calcite.util.ChunkList
- first - Variable in class org.apache.calcite.util.Pair.AdjacentIterator
- first - Variable in class org.apache.calcite.util.Pair.FirstAndIterator
- first - Variable in class org.apache.calcite.util.PrecedenceClimbingParser
- first - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Result
- 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(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(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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- first(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- first(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- first(FunctionExpression<Predicate1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Returns the first element of a sequence that satisfies a specified condition.
- 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 - org.apache.calcite.config.NullCollation
-
Nulls first for DESC and ASC.
- FIRST - org.apache.calcite.rel.RelFieldCollation.NullDirection
- FIRST - org.apache.calcite.sql.SqlKind
- FIRST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
FIRST
function to be used withinMATCH_RECOGNIZE
. - FIRST_ID - Static variable in class org.apache.calcite.chinook.PreferredAlbumsTableFactory
- FIRST_ID - Static variable in class org.apache.calcite.chinook.PreferredGenresTableFactory
- 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 - 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<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.
- FirstAndIterator(Iterator<E>, E) - Constructor for class org.apache.calcite.util.Pair.FirstAndIterator
- firstCall - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference.ExprsItr
- 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.
- firstLastCount - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternValidator
- FirstLastValueImplementor(WinAggImplementor.SeekType) - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.FirstLastValueImplementor
- firstLeftRef - Variable in class org.apache.calcite.rel.rules.PushProjector.RefAndExprConverter
- 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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- firstOrDefault(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- firstOrDefault(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- firstOrDefault(FunctionExpression<Predicate1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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
- firstRightRef - Variable in class org.apache.calcite.rel.rules.PushProjector.RefAndExprConverter
- firstSet(boolean[]) - Static method in class org.apache.calcite.rel.rules.CalcRelSplitter
-
Returns the index of the first set bit in an array.
- FirstValueImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.FirstValueImplementor
- fix(List<RexNode>, int, int) - Static method in class org.apache.calcite.plan.RelOptUtil
- Fixer() - Constructor for class org.apache.calcite.materialize.Lattice.Builder.Fixer
- FixNullabilityShuttle(RexBuilder, List<RelDataType>) - Constructor for class org.apache.calcite.rex.RexUtil.FixNullabilityShuttle
- fixUp(MutableNode) - Method in class org.apache.calcite.materialize.Lattice.Builder.Fixer
- 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.
- fixUpInputs(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- flag - Variable in class org.apache.calcite.sql.fun.SqlBetweenOperator
- flag - Variable in class org.apache.calcite.sql2rel.StandardConvertletTable.TrimConvertlet
- Flag() - Constructor for enum org.apache.calcite.sql.fun.SqlBetweenOperator.Flag
- Flag(int, int) - Constructor for enum org.apache.calcite.sql.fun.SqlTrimFunction.Flag
- Flags() - Constructor for class org.apache.calcite.rel.core.Project.Flags
-
Deprecated.
- FLAT - org.apache.calcite.runtime.GeoFunctions.CapStyle
- FLAT_MAP_FUNCTION_CALL - org.apache.calcite.adapter.spark.SparkMethod
- FLAT_PRODUCT - org.apache.calcite.util.BuiltInMethod
- Flat1List(T) - Constructor for class org.apache.calcite.runtime.FlatLists.Flat1List
- Flat2List(T, T) - Constructor for class org.apache.calcite.runtime.FlatLists.Flat2List
- Flat3List(T, T, T) - Constructor for class org.apache.calcite.runtime.FlatLists.Flat3List
- Flat4List(T, T, T, T) - Constructor for class org.apache.calcite.runtime.FlatLists.Flat4List
- Flat5List(T, T, T, T, T) - Constructor for class org.apache.calcite.runtime.FlatLists.Flat5List
- Flat6List(T, T, T, T, T, T) - Constructor for class org.apache.calcite.runtime.FlatLists.Flat6List
- flatElements - Variable in class org.apache.calcite.runtime.SqlFunctions.ProductComparableListEnumerator
- flatList_(T[], boolean) - Static method in class org.apache.calcite.runtime.FlatLists
-
Creates a memory-, CPU- and cache-efficient comparable immutable list, optionally copying the list.
- flatListNotComparable(T[]) - Static method in class org.apache.calcite.runtime.FlatLists
-
Creates a memory-, CPU- and cache-efficient immutable list, always copying the list.
- FlatLists - Class in org.apache.calcite.runtime
-
Space-efficient, comparable, immutable lists.
- FlatLists() - Constructor for class org.apache.calcite.runtime.FlatLists
- FlatLists.AbstractFlatList<T> - Class in org.apache.calcite.runtime
-
Base class for flat lists.
- FlatLists.ComparableEmptyList<T> - Class in org.apache.calcite.runtime
-
Empty list that implements the
Comparable
interface. - FlatLists.ComparableList<T> - Interface in org.apache.calcite.runtime
-
List that is also comparable.
- FlatLists.ComparableListImpl<T extends java.lang.Comparable<T>> - Class in org.apache.calcite.runtime
-
Wrapper around a list that makes it implement the
Comparable
interface using lexical ordering. - 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
- FlatProductInputType() - Constructor for enum org.apache.calcite.runtime.SqlFunctions.FlatProductInputType
- flatten(Iterator<ElasticsearchJson.Result>) - Static method in class org.apache.calcite.adapter.elasticsearch.Scrolling
-
Combines lazily multiple
ElasticsearchJson.Result
into a single iterator ofElasticsearchJson.SearchHit
. - 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<MutableNode>) - Method in class org.apache.calcite.materialize.MutableNode
-
Populates a flattened list of mutable nodes.
- flatten(List<RelNode>, int, int[], List<Pair<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(SqlNode) - Static method in class org.apache.calcite.sql.SqlUtil
- flatten(SqlNode, ArrayList<SqlNode>) - Static method in class org.apache.calcite.sql.SqlUtil
- flattenAnd(Iterable<? extends RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Flattens a list of AND nodes.
- flattenComparison(RexBuilder, SqlOperator, List<RexNode>) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener.RewriteRexShuttle
- flattened - Variable in class org.apache.calcite.rel.core.TableModify
- flattened - Variable in class org.apache.calcite.rel.mutable.MutableTableModify
- flattenedRootType - Variable in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- flattenFields(RelDataTypeFactory, RelDataType, List<RelDataTypeField>, int[]) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- flattenInputs(List<RelDataTypeField>, RexNode, List<Pair<RexNode, String>>) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
-
Generates expressions that reference the flattened input fields from a given row type.
- flattenNullLiteral(RelDataType, List<Pair<RexNode, String>>) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- flattenOperands(RelOptRuleOperand) - Method in class org.apache.calcite.plan.RelOptRule
-
Creates a flattened list of this operand and its descendants in prefix order.
- flattenOr(Iterable<? extends RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Flattens a list of OR nodes.
- flattenProjection(RelStructuredTypeFlattener.RewriteRexShuttle, RexNode, String, List<Pair<RexNode, String>>) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- flattenProjections(RelStructuredTypeFlattener.RewriteRexShuttle, List<? extends RexNode>, List<String>, String, List<Pair<RexNode, String>>) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- 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.
- flattenRecurse(List<RelOptRuleOperand>, RelOptRuleOperand) - Method in class org.apache.calcite.plan.RelOptRule
-
Adds the operand and its descendants to the list in prefix order.
- flattenRecurse(List<RexNode>, List<? extends RexNode>, SqlOperator) - Static method in class org.apache.calcite.rex.RexUtil
- flattenRel(RelStructuredTypeFlattener) - Method in interface org.apache.calcite.sql2rel.RelStructuredTypeFlattener.SelfFlatteningRel
- flattenTo(ImmutableList.Builder<LatticeNode>) - Method in class org.apache.calcite.materialize.LatticeNode
- flattenTypes(RelOptPlanner, RelNode, boolean) - Method in class org.apache.calcite.adapter.spark.SparkHandlerImpl
- flattenTypes(RelOptPlanner, RelNode, boolean) - Method in class org.apache.calcite.jdbc.CalcitePrepare.Dummy.TrivialSparkHandler
- 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 - Variable in class org.apache.calcite.adapter.csv.CsvSchema
- flavor - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.AdjustProjectForCountAggregateRule
- flavor(Type) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Returns whether this type is a primitive, box or other type.
- Flavor() - Constructor for enum org.apache.calcite.adapter.csv.CsvTable.Flavor
- Flavor() - Constructor for enum org.apache.calcite.linq4j.tree.Primitive.Flavor
- FlightRecorderProfiler - Class in org.apache.calcite.benchmarks
-
Captures Flight Recorder log.
- FlightRecorderProfiler() - Constructor for class org.apache.calcite.benchmarks.FlightRecorderProfiler
- FLOAT - org.apache.calcite.adapter.csv.CsvFieldType
- FLOAT - org.apache.calcite.adapter.druid.DruidType
- FLOAT - org.apache.calcite.adapter.file.FileFieldType
- FLOAT - org.apache.calcite.linq4j.tree.Primitive
- FLOAT - org.apache.calcite.sql.type.SqlTypeName
- FLOAT_FORMATTER - Static variable in class org.apache.calcite.util.NumberUtil
- FLOAT_MAX - Static variable in class org.apache.calcite.linq4j.Extensions
- FLOAT_MIN - Static variable in class org.apache.calcite.linq4j.Extensions
- FLOAT_SUM - Static variable in class org.apache.calcite.linq4j.Extensions
- FloatFunction1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function that takes one parameter and returns a native
float
value. - 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(Calendar, TimeUnitRange) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
-
Computes floor of a calendar to a given time unit.
- FLOOR - org.apache.calcite.sql.SqlKind
-
The "FLOOR" function
- FLOOR - org.apache.calcite.util.BuiltInMethod
- FLOOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
FLOOR
function. - FLOOR_COLUMN_NAME_PREFIX - Static variable in class org.apache.calcite.adapter.druid.DruidQuery
- FLOOR_DIV - org.apache.calcite.util.BuiltInMethod
- FLOOR_MOD - org.apache.calcite.util.BuiltInMethod
- FloorCeilConvertlet() - Constructor for class org.apache.calcite.sql2rel.StandardConvertletTable.FloorCeilConvertlet
- FloorExpander(RexBuilder) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule.FloorExpander
- FloorImplementor(String, Method, Method) - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.FloorImplementor
- floorKey(String) - Method in class org.apache.calcite.util.CaseInsensitiveComparator
- 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
- floorRange(TimeUnitRange, SqlKind, Calendar) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- FluentArrayList() - Constructor for class org.apache.calcite.linq4j.tree.Expressions.FluentArrayList
- FluentArrayList(Collection<? extends T>) - Constructor for class org.apache.calcite.linq4j.tree.Expressions.FluentArrayList
- FLYWEIGHT_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Use sharing to support large numbers of fine-grained objects efficiently.
- fn - Variable in class org.apache.calcite.linq4j.function.Functions.GeneratingList
- FNL25_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether issue FNL-25 is fixed.
- FNL3_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether issue Fnl-3 is fixed.
- foldAnd(List<Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Combines a list of expressions using AND.
- foldOr(List<Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Combines a list of expressions using OR.
- FOLLOWING - org.apache.calcite.sql.SqlKind
-
The "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
- FooCompiler() - Constructor for class org.apache.calcite.interpreter.Interpreter.FooCompiler
- For - org.apache.calcite.linq4j.tree.ExpressionType
- 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.
- forAggregation(JavaTypeFactory, BlockBuilder, RexToLixTranslator.InputGetter, SqlConformance) - Static method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Creates a translator for translating aggregate functions.
- FORBIDDEN - 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 - Variable in class org.apache.calcite.rel.rules.ProjectMergeRule
-
Whether to always merge projects.
- FORCE_DECORRELATE - 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
- 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(StatementTest.HrConnection) - Method in class org.apache.calcite.benchmarks.StatementTest
- FOREACH - org.apache.calcite.piglet.Ast.Op
- FOREACH_NESTED - org.apache.calcite.piglet.Ast.Op
- ForeachNestedStmt(SqlParserPos, Ast.Identifier, Ast.Identifier, List<Ast.Stmt>, List<Ast.Node>, Ast.Schema) - Constructor for class org.apache.calcite.piglet.Ast.ForeachNestedStmt
- ForeachStmt(SqlParserPos, Ast.Identifier, Ast.Identifier, List<Ast.Node>, Ast.Schema) - Constructor for class org.apache.calcite.piglet.Ast.ForeachStmt
- foreign - Variable in class org.apache.calcite.sql.ddl.SqlDropSchema
- FOREIGN_KEY - org.apache.calcite.sql.SqlKind
-
FOREIGN KEY
constraint. - FOREIGN_TABLE - org.apache.calcite.schema.Schema.TableType
-
Foreign table.
- forgetAllocation(ClosableAllocation) - Method in class org.apache.calcite.util.CompoundClosableAllocation
-
Forgets an allocation without closing it.
- format - Variable in class org.apache.calcite.adapter.druid.TimeExtractionFunction
- format - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- format - Variable in class org.apache.calcite.adapter.enumerable.EnumerableRel.Result
- format - Variable in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- format - Variable in class org.apache.calcite.prepare.Prepare.PreparedExplain
- format - Variable in class org.apache.calcite.sql.SqlExplain
- format() - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
- format(String) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- 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() - Constructor for enum org.apache.calcite.adapter.os.SqlShell.Format
- Format() - Constructor for class org.apache.calcite.sql.parser.SqlParserUtil.Format
- 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.
- forProgram(RexProgram, RexBuilder, boolean) - Static method in class org.apache.calcite.rex.RexProgramBuilder
-
Creates a program builder and initializes it from an existing program.
- 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
- forward1(RelSet, RelSet) - Static method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Moves forward one link, checking for a cycle.
- forward2(RelSet, RelSet) - Static method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Moves forward two links, checking for a cycle at each.
- ForwardRefFinder(RelDataType) - Constructor for class org.apache.calcite.rex.RexUtil.ForwardRefFinder
- found(SqlCall) - Method in class org.apache.calcite.sql.validate.AggFinder.AggIterable
- found(SqlCall) - Method in class org.apache.calcite.sql.validate.AggFinder
- found(SqlCall) - Method in class org.apache.calcite.sql.validate.AggVisitor
- 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 org.apache.calcite.util.Util.FoundOne
- FOURTEEN - org.apache.calcite.util.mapping.MappingType
- 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
- fractionalSecondPrecision - Variable in class org.apache.calcite.sql.SqlIntervalQualifier
- frame - Variable in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- frame - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- frame(LatticeSuggester.Query, RelNode) - Method in class org.apache.calcite.materialize.LatticeSuggester
- Frame(int, List<LatticeSuggester.Hop>, List<LatticeSuggester.MutableMeasure>, Collection<LatticeSuggester.TableRef>) - Constructor for class org.apache.calcite.materialize.LatticeSuggester.Frame
- Frame(int, List<LatticeSuggester.Hop>, List<LatticeSuggester.MutableMeasure>, List<LatticeSuggester.Frame>) - Constructor for class org.apache.calcite.materialize.LatticeSuggester.Frame
- Frame(int, RelNode) - Constructor for class org.apache.calcite.rel.rel2sql.RelToSqlConverter.Frame
- Frame(RelNode) - Constructor for class org.apache.calcite.tools.RelBuilder.Frame
- Frame(RelNode, ImmutableList<RelBuilder.Field>) - Constructor for class org.apache.calcite.tools.RelBuilder.Frame
- Frame(RelNode, RelNode, SortedMap<RelDecorrelator.CorDef, Integer>, Map<Integer, Integer>) - Constructor for class org.apache.calcite.sql2rel.RelDecorrelator.Frame
- FRAME_TYPE - Static variable in class org.apache.calcite.sql.fun.SqlBetweenOperator
- FRAME_TYPE - Static variable in class org.apache.calcite.sql.fun.SqlCaseOperator
- FRAME_TYPE - Static variable in class org.apache.calcite.sql.SqlJoin.SqlJoinOperator
- FrameImpl(SqlWriter.FrameType, String, String, String, int, boolean, boolean, int, boolean, boolean, boolean) - Constructor for class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- frameRowCount - Variable in class org.apache.calcite.adapter.enumerable.impl.WinAggResetContextImpl
- frameType - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- FrameTypeEnum() - Constructor for enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Creates a list type.
- FrameTypeEnum(boolean) - Constructor for enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Creates a list type.
- 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() - Constructor for class org.apache.calcite.tools.Frameworks
- 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
-
Piece of code to be run in a context where a planner and statement are available.
- Frameworks.StdFrameworkConfig - Class in org.apache.calcite.tools
-
An implementation of
FrameworkConfig
that uses standard Calcite classes to provide basic planner functionality. - freeze(int, int[]) - Method in class org.apache.calcite.adapter.clone.ColumnLoader.ValueSet
-
Freezes the contents of this value set into a column, optionally re-ordering if
sources
is specified. - freeze(ColumnLoader.ValueSet, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- freeze(ColumnLoader.ValueSet, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ByteStringDictionary
- freeze(ColumnLoader.ValueSet, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.Constant
- freeze(ColumnLoader.ValueSet, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectArray
- freeze(ColumnLoader.ValueSet, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectDictionary
- freeze(ColumnLoader.ValueSet, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveArray
- freeze(ColumnLoader.ValueSet, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveDictionary
- freeze(ColumnLoader.ValueSet, int[]) - Method in interface org.apache.calcite.adapter.clone.ArrayTable.Representation
-
Converts a value set into a compact representation.
- freeze(ColumnLoader.ValueSet, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.StringDictionary
- frequency(Iterable<String>, String) - Method in interface org.apache.calcite.sql.validate.SqlNameMatcher
-
Returns how many times a string occurs in a collection.
- frequency(Iterable<String>, String) - Method in class org.apache.calcite.sql.validate.SqlNameMatchers.BaseMatcher
- 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
- FRG282_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether issue FRG-282: Support precision in TIME and TIMESTAMP data types is fixed.
- FRG296_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether issue FRG-296: SUBSTRING(string FROM regexp FOR regexp) is fixed.
- FRG327_FIXED - Static variable in class org.apache.calcite.util.Bug
- 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 - Variable in class org.apache.calcite.sql.SqlSelect
- from(int) - Static method in class org.apache.calcite.sql.type.SqlOperandCountRanges
- from(Object, boolean) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- from(PlannerImpl) - Method in enum org.apache.calcite.prepare.PlannerImpl.State
-
Moves planner's state to this state.
- from(SchemaPlus) - Static method in class org.apache.calcite.jdbc.CalciteSchema
- FROM - org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- FROM - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- FROM_BIT_SET - Static variable in class org.apache.calcite.util.ImmutableBitSet
-
Deprecated.
- FROM_LIST - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
FROM clause (containing various kinds of JOIN).
- FROM_OPERAND - Static variable in class org.apache.calcite.sql.SqlSelect
- fromAliasDuplicate(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- 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.TimeString
-
Creates a TimeString from a Calendar.
- fromCaseOperands(RexBuilder, List<RexNode>) - Static method in class org.apache.calcite.rex.RexSimplify.CaseBranch
-
Given "CASE WHEN p1 THEN v1 ...
- fromColumn(String) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- fromDaysSinceEpoch(int) - Static method in class org.apache.calcite.util.DateString
-
Creates a DateString that is a given number of days since the epoch.
- fromInternal(Class<?>[], List<Expression>) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
- fromInternal(Type) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
- fromInternal(Expression, Class<?>) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
-
Converts from internal representation to JDBC representation used by arguments of user-defined functions.
- fromJdbcString(RelDataType, SqlTypeName, String) - Static method in class org.apache.calcite.rex.RexLiteral
-
Converts a Jdbc string into a RexLiteral.
- 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
- fromMutables(List<MutableRel>, RelBuilder) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- fromString(String) - Static method in enum org.apache.calcite.adapter.elasticsearch.ElasticsearchVersion
- fromTo(String, int, int) - Static method in class org.apache.calcite.rex.RexSlot.SelfPopulatingList
- FrozenGraph(DefaultDirectedGraph<V, E>, Map<Pair<V, V>, List<V>>) - Constructor for class org.apache.calcite.util.graph.Graphs.FrozenGraph
-
Creates a frozen graph as a copy of another graph.
- FULL - org.apache.calcite.rel.core.JoinRelType
- FULL - org.apache.calcite.sql.JoinType
-
Full outer join.
- fullClassName - Variable in class org.apache.calcite.util.javac.JaninoCompiler.JaninoCompilerArgs
- FULLY_QUALIFIED - 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.EmptyScope
- 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 interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Converts an identifier into a fully-qualified identifier.
- fun(Class<T>, T) - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- fun(Class<T>, T) - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- FUN - org.apache.calcite.config.CalciteConnectionProperty
-
Collection of built-in functions and operators.
- FUN_CALL - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Function call or datatype declaration.
- FUN_DECL - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Function declaration.
- funcNeedsOrderBy() - Method in interface org.apache.calcite.runtime.CalciteResource
- function - Variable in class org.apache.calcite.jdbc.CalciteSchema.FunctionEntryImpl
- 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 - Variable in class org.apache.calcite.util.Benchmark
- function - Variable in class org.apache.calcite.util.Util.TransformingList
- 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 - org.apache.calcite.sql.SqlFunctionCategory.Property
- FUNCTION - org.apache.calcite.sql.SqlSyntax
-
Function syntax, as in "Foo(x, y)".
- FUNCTION - org.apache.calcite.sql.validate.SqlMonikerType
- FUNCTION - org.apache.calcite.util.mapping.MappingType
- FUNCTION - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category consisting of regular and special functions.
- FUNCTION_ID - org.apache.calcite.sql.SqlSyntax
-
Function syntax which takes no parentheses if there are no arguments, for example "CURRENTTIME".
- FUNCTION_RESULT_TYPES - Static variable in class org.apache.calcite.linq4j.function.Functions
- FUNCTION_STAR - 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 - org.apache.calcite.util.BuiltInMethod
- Function1<T0,R> - Interface in org.apache.calcite.linq4j.function
-
Function with one parameter.
- FUNCTION1_APPLY - org.apache.calcite.util.BuiltInMethod
- FUNCTION1_CLASSES - Static variable in class org.apache.calcite.linq4j.function.Functions
- Function2<T0,T1,R> - Interface in org.apache.calcite.linq4j.function
-
Function with two parameters.
- functionalDependencies - Variable in class org.apache.calcite.profile.ProfilerImpl.Run
- FunctionalDependency(SortedSet<Profiler.Column>, Profiler.Column) - Constructor for class org.apache.calcite.profile.Profiler.FunctionalDependency
- 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.
- 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>, F, BlockStatement, List<ParameterExpression>) - 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.adapter.java.ReflectiveSchema
- functionMap - Variable in class org.apache.calcite.jdbc.CalciteSchema
- FunctionMappingIter(Mappings.FunctionMapping) - Constructor for class org.apache.calcite.util.mapping.Mappings.FunctionMappingIter
- functionMatchRecognizeOnly(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- functionNames - Variable in class org.apache.calcite.jdbc.CalciteSchema
- FunctionParameter - Interface in org.apache.calcite.schema
-
Parameter to a
Function
. - FunctionParamInfo() - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.FunctionParamInfo
- functionQuantifier - Variable in class org.apache.calcite.sql.SqlBasicCall
- functionQuantifierNotAllowed(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- functionResultType(FunctionExpression<Function1<P0, R>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
- functions - Variable in class org.apache.calcite.model.JsonMapSchema
-
Functions in this schema.
- Functions - Class in org.apache.calcite.linq4j.function
-
Utilities relating to functions.
- Functions() - Constructor for class org.apache.calcite.linq4j.function.Functions
- Functions.ArrayEqualityComparer - Class in org.apache.calcite.linq4j.function
-
Array equality comparer.
- Functions.GeneratingList<E> - Class in org.apache.calcite.linq4j.function
-
List that generates each element using a function.
- Functions.IdentityEqualityComparer - Class in org.apache.calcite.linq4j.function
-
Identity equality comparer.
- Functions.Ignore<R,T0,T1> - Class in org.apache.calcite.linq4j.function
-
Ignore.
- Functions.NullsFirstComparator - Class in org.apache.calcite.linq4j.function
-
Nulls first comparator.
- Functions.NullsFirstReverseComparator - Class in org.apache.calcite.linq4j.function
-
Nulls first reverse comparator.
- Functions.NullsLastComparator - Class in org.apache.calcite.linq4j.function
-
Nulls last comparator.
- Functions.NullsLastReverseComparator - Class in org.apache.calcite.linq4j.function
-
Nulls last reverse comparator.
- Functions.SelectorEqualityComparer<T,T2> - Class in org.apache.calcite.linq4j.function
-
Selector equality comparer.
- functionUndefined(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- FUSION - org.apache.calcite.sql.SqlKind
-
The
FUSION
aggregate function. - FUSION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The FUSION operator.
- FusionImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.FusionImplementor
- fynally - Variable in class org.apache.calcite.linq4j.tree.TryStatement
G
- g - Variable in class org.apache.calcite.materialize.LatticeSpace
- g - Variable in class org.apache.calcite.runtime.GeoFunctions.SimpleGeom
- g() - Method in interface org.apache.calcite.runtime.GeoFunctions.Geom
- g() - Method in class org.apache.calcite.runtime.GeoFunctions.MapGeom
- g() - Method in class org.apache.calcite.runtime.GeoFunctions.SimpleGeom
- gatherConstraint(Class<C>, RexNode, RexNode, Map<RexNode, C>, Set<RexNode>, RexBuilder) - Static method in class org.apache.calcite.rex.RexUtil
- gatherConstraints(Class<C>, RexNode, Map<RexNode, C>, Set<RexNode>, RexBuilder) - Static method in class org.apache.calcite.rex.RexUtil
- gatherExpr(RexNode) - Method in class org.apache.calcite.rex.RexProgram
- gatherLattices(CalciteSchema, List<CalciteSchema.LatticeEntry>) - Static method in class org.apache.calcite.schema.Schemas
- 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.
- gcd(Type...) - Static method in class org.apache.calcite.linq4j.tree.Types
-
Returns the most restrictive type that is assignable from all given types.
- ge(boolean, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≥
operator applied to boolean values. - ge(String, 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(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≥
operator applied to ByteString values. - ge(RexBuilder, RexNode, RexNode) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- 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). - Genealogist(Predicate<SqlNode>, Predicate<SqlNode>) - Constructor for class org.apache.calcite.sql.SqlUtil.Genealogist
- generate(int, int, int) - Static method in class org.apache.calcite.example.maze.MazeTable
-
Table function that generates a maze.
- generate(int, Function1<Integer, 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. - 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
- generateAggregateSql(Aggregate, List<String>) - Method in class org.apache.calcite.materialize.TileSuggester.SchemaImpl
- generateBranch(boolean, RexSimplify, RexSimplify.CaseBranch) - Method in class org.apache.calcite.rex.RexSimplify
-
If boolean is true, simplify cond in input branch and return new branch.
- generateBytecodes(String) - Method in class org.apache.calcite.util.javac.JaninoCompiler.AccountingClassLoader
- 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
- 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_CLASS_NAME - Static variable in class org.apache.calcite.rex.RexExecutable
- generatedCorRels - Variable in class org.apache.calcite.sql2rel.RelDecorrelator
- generatedRelList - Variable in class org.apache.calcite.plan.volcano.VolcanoRuleCall
-
List of
RelNode
generated by this call. - generateEquivalenceClasses(RexBuilder, AbstractMaterializedViewRule.EquivalenceClasses, AbstractMaterializedViewRule.EquivalenceClasses) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
Given the equi-column predicates of the source and the target and the computed equivalence classes, it extracts possible mappings between the equivalence classes.
- generateGet(EnumerableRelImplementor, PhysType, BlockBuilder, ParameterExpression, int, Expression, Expression, SqlDialect.CalendarPolicy) - Method in class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverter
- generateMapping(RexBuilder, RexSimplify, RelMetadataQuery, RelNode, RelNode, ImmutableBitSet, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, AbstractMaterializedViewRule.EquivalenceClasses, List<RexNode>) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewAggregateRule
-
Mapping from node expressions to target expressions.
- generateMissingNames() - Method in class org.apache.calcite.rex.RexProgramBuilder
- 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.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.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.
- generateSql() - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- generateSql(SqlDialect) - Method in class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverter
- generateSql(SqlDialect) - Method in class org.apache.calcite.adapter.spark.JdbcToSparkConverter
- generateSwapColumnTableReferencesLineage(RexBuilder, RelMetadataQuery, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, AbstractMaterializedViewRule.EquivalenceClasses, List<RexNode>) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
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>, AbstractMaterializedViewRule.EquivalenceClasses, List<RexNode>) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
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>) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
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.ArraySqlType
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.sql.type.BasicSqlType
- 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
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl.UnknownSqlType
- generateUnionRewriting - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
Whether to generate rewritings containing union if the query results are contained within the view results.
- GeneratingList(int, Function1<Integer, E>) - Constructor for class org.apache.calcite.linq4j.function.Functions.GeneratingList
- generationStrategy(RelOptTable, int) - Method in class org.apache.calcite.schema.impl.ModifiableViewTable.ModifiableViewTableInitializerExpressionFactory
- 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
- generic - Variable in class org.apache.calcite.rel.externalize.RelXmlWriter
- generics - Variable in class org.apache.calcite.linq4j.tree.ExpressionWriter
- GEO - org.apache.calcite.sql.type.SqlTypeFamily
- GEODE_QUERY_METHOD - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeToEnumerableConverter
-
Reference to the method
GeodeTable.GeodeQueryable.query(java.util.List<java.util.Map.Entry<java.lang.String, java.lang.Class>>, java.util.List<java.util.Map.Entry<java.lang.String, java.lang.String>>, java.util.List<java.util.Map.Entry<java.lang.String, java.lang.String>>, java.util.List<java.lang.String>, java.util.List<java.lang.String>, java.util.List<java.lang.String>, java.lang.Long)
, used in theExpression
. - 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
-
Creates a GeodeAggregate.
- GeodeAggregateRule() - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeAggregateRule
- GeodeConverterRule(Class<? extends RelNode>, String) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeConverterRule
- GeodeEnumerator - Class in org.apache.calcite.adapter.geode.rel
-
Enumerator that reads from a Geode Regions.
- GeodeEnumerator(SelectResults, RelProtoDataType) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeEnumerator
-
Creates a GeodeEnumerator.
- geodeFieldNames(RelDataType) - Static method in class org.apache.calcite.adapter.geode.rel.GeodeRules
- GeodeFilter - Class in org.apache.calcite.adapter.geode.rel
-
Implementation of
Filter
relational expression in Geode. - GeodeFilter(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeFilter
- GeodeFilter.Translator - Class in org.apache.calcite.adapter.geode.rel
-
Translates
RexNode
expressions into Geode expression strings. - GeodeFilterRule() - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeRules.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. - GeodeProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeProject
- GeodeProjectRule() - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeProjectRule
- 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() - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeRules
- GeodeRules.GeodeAggregateRule - Class in org.apache.calcite.adapter.geode.rel
-
Rule to convert
Aggregate
to aGeodeAggregate
. - GeodeRules.GeodeConverterRule - Class in org.apache.calcite.adapter.geode.rel
-
Base class for planner rules that convert a relational expression to Geode calling convention.
- GeodeRules.GeodeFilterRule - Class in org.apache.calcite.adapter.geode.rel
-
Rule to convert a
LogicalFilter
to aGeodeFilter
. - GeodeRules.GeodeProjectRule - Class in org.apache.calcite.adapter.geode.rel
-
Rule to convert a
LogicalProject
to aGeodeProject
. - GeodeRules.GeodeSortLimitRule - Class in org.apache.calcite.adapter.geode.rel
- GeodeRules.RexToGeodeTranslator - Class in org.apache.calcite.adapter.geode.rel
-
Translator from
RexNode
to strings in Geode's expression language. - GeodeSchema - Class in org.apache.calcite.adapter.geode.rel
-
Schema mapped onto a Geode Region.
- GeodeSchema(String, int, Iterable<String>, String) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeSchema
- 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. - GeodeSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeSort
-
Creates a GeodeSort.
- GeodeSortLimitRule(Predicate<Sort>) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeSortLimitRule
- geodeTable - Variable in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- geodeTable - Variable in class org.apache.calcite.adapter.geode.rel.GeodeTableScan
- GeodeTable - Class in org.apache.calcite.adapter.geode.rel
-
Table based on a Geode Region
- GeodeTable(Region<?, ?>) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeTable
- 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.
- GeodeTableScan(RelOptCluster, RelTraitSet, RelOptTable, GeodeTable, RelDataType) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeTableScan
-
Creates a GeodeTableScan.
- 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() - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeToEnumerableConverterRule
- GeodeUtils - Class in org.apache.calcite.adapter.geode.util
-
Utilities for the Geode adapter.
- GeodeUtils() - Constructor for class org.apache.calcite.adapter.geode.util.GeodeUtils
- GeoFunctions - Class in org.apache.calcite.runtime
-
Helper methods to implement Geo-spatial functions in generated code.
- GeoFunctions() - Constructor for class org.apache.calcite.runtime.GeoFunctions
- GeoFunctions.CapStyle - Enum in org.apache.calcite.runtime
-
How the "buffer" command terminates the end of a line.
- GeoFunctions.Geom - Interface in org.apache.calcite.runtime
-
Geometry.
- GeoFunctions.JoinStyle - Enum in org.apache.calcite.runtime
-
How the "buffer" command decorates junctions between line segments.
- GeoFunctions.MapGeom - Class in org.apache.calcite.runtime
-
Sub-class of geometry that has a spatial reference.
- GeoFunctions.SimpleGeom - Class in org.apache.calcite.runtime
-
Sub-class of geometry that has no spatial reference.
- GeoFunctions.Type - Enum in org.apache.calcite.runtime
-
Geometry types, with the names and codes assigned by OGC.
- GEOMCOLLECTION - org.apache.calcite.runtime.GeoFunctions.Type
- Geometry - org.apache.calcite.runtime.GeoFunctions.Type
- GEOMETRY - org.apache.calcite.sql.type.SqlTypeName
- GEOMETRY - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- geometryDisabled() - Method in interface org.apache.calcite.runtime.CalciteResource
- get() - Method in class org.apache.calcite.adapter.os.Processes.ProcessFactory
- get() - Method in class org.apache.calcite.interpreter.AggregateNode.ScalarAccumulatorDef
- get() - Method in class org.apache.calcite.interpreter.AggregateNode.UdaAccumulatorFactory
- get() - Method in class org.apache.calcite.runtime.Resources.BooleanProp
-
Returns the value of this boolean property.
- get() - Method in class org.apache.calcite.runtime.Resources.DoubleProp
-
Returns the value of this double property.
- get() - Method in class org.apache.calcite.runtime.Resources.IntProp
-
Returns the value of this integer property.
- get() - Method in class org.apache.calcite.runtime.Resources.StringProp
-
Returns the value of this String property.
- get() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.ValidationError
- get() - Method in class org.apache.calcite.util.Holder
-
Gets the value.
- get(boolean) - Method in class org.apache.calcite.runtime.Resources.BooleanProp
-
Returns the value of this boolean property, returning the given default value if the property is not set.
- get(double) - Method in class org.apache.calcite.runtime.Resources.DoubleProp
-
Returns the value of this double property, returning the given default value if the property is not set.
- get(int) - Method in interface org.apache.calcite.example.maze.Maze.CellContent
- get(int) - Method in class org.apache.calcite.linq4j.function.Functions.GeneratingList
- get(int) - Method in class org.apache.calcite.linq4j.Ord.OrdArrayList
- get(int) - Method in class org.apache.calcite.linq4j.Ord.OrdList
- 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.ComparableEmptyList
- get(int) - Method in class org.apache.calcite.runtime.FlatLists.ComparableListImpl
- 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.runtime.Resources.IntProp
-
Returns the value of this integer property, returning the given default value if the property is not set.
- get(int) - Method in class org.apache.calcite.schema.Schemas.PathImpl
- 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
-
Returns the value of the bit with the specified index.
- get(int) - Method in class org.apache.calcite.util.ImmutableIntList.AbstractIndexedListIterator
- 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.PrecedenceClimbingParser.TokenList
- get(int) - Method in class org.apache.calcite.util.UnmodifiableArrayList
- get(int) - Method in class org.apache.calcite.util.Util.TransformingList
- 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(long) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema.AbstractCached
- get(long) - Method in interface org.apache.calcite.jdbc.CachingCalciteSchema.Cached
-
Returns the value; uses cached value if valid.
- get(Object) - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl.RecordFieldImpl
- get(Object) - Method in class org.apache.calcite.linq4j.EnumerableDefaults.WrapMap
- get(Object) - Method in class org.apache.calcite.linq4j.LookupImpl
- 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 class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Aggregations
-
Returns the aggregation that is associated with the specified name.
- get(String) - Method in interface org.apache.calcite.DataContext
-
Returns a context variable.
- get(String) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.DataContextImpl
- get(String) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.SlimDataContext
- 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.runtime.Resources.StringProp
-
Returns the value of this String property, returning the given default value if the property is not set.
- get(String) - Method in class org.apache.calcite.schema.Schemas.DummyDataContext
- get(String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter.Bean
- get(String) - Static method in enum org.apache.calcite.sql.type.SqlTypeName
-
Looks up a type name from its name.
- get(String, String, String, String) - Method in class org.apache.calcite.adapter.jdbc.JdbcUtils.DataSourcePool
- get(DatabaseMetaData) - Method in interface org.apache.calcite.sql.dialect.JethroDataSqlDialect.JethroInfoCache
- get(DatabaseMetaData) - Method in class org.apache.calcite.sql.dialect.JethroDataSqlDialect.JethroInfoCacheImpl
- 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(Map<K, V>, List<String>, List<String>) - Method in class org.apache.calcite.sql.validate.SqlNameMatchers.BaseMatcher
- 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(SqlDialectFactory, DataSource) - Method in class org.apache.calcite.adapter.jdbc.JdbcUtils.DialectPool
- get(SqlOperator) - 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_COMPLETION_HINTS - Static variable in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction
- GET_COMPLETION_HINTS - Static variable in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction2
- 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 - org.apache.calcite.adapter.spark.SparkMethod
- getAbstractMethod() - Method in class org.apache.calcite.linq4j.tree.FunctionExpression
- getAbstractMethodName() - Method in class org.apache.calcite.linq4j.tree.FunctionExpression
- getAcceptedIssuers() - Method in class org.apache.calcite.runtime.TrustAllSslSocketFactory.DummyTrustManager
- getAccumulator(AggregateCall, boolean) - Method in class org.apache.calcite.interpreter.AggregateNode
- 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.
- getActualTypeArguments() - Method in class org.apache.calcite.linq4j.tree.Types.ParameterizedTypeImpl
- getAdjustedIndex(int, ImmutableBitSet, int) - Method in class org.apache.calcite.rel.rules.ProjectWindowTransposeRule
- 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
- getAgg(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
If there is at least one call to an aggregate function, returns the first.
- getAggCall(SqlCall) - Static method in class org.apache.calcite.sql.SqlFilterOperator
- getAggCallList() - Method in class org.apache.calcite.rel.core.Aggregate
-
Returns a list of calls to aggregate functions.
- getAggCalls() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- 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.
- getAggregations() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Bucket
- getAggregations() - Method in interface org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.HasAggregations
- getAlias() - Method in class org.apache.calcite.sql.SqlDelete
- getAlias() - Method in class org.apache.calcite.sql.SqlMerge
- getAlias() - Method in class org.apache.calcite.sql.SqlUpdate
- getAlias() - Method in class org.apache.calcite.tools.PigRelBuilder
- getAlias(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.
- getAliasContext(RexCorrelVariable) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.BaseContext
- getAliasContext(RexCorrelVariable) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- 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.
- getAllDefaultType() - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- 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
- 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.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.AssignableOperandTypeChecker
- getAllowedSignatures(SqlOperator, String) - Method in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- getAllowedSignatures(SqlOperator, String) - Method in class org.apache.calcite.sql.type.FamilyOperandTypeChecker
- 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.OperandTypes.PeriodOperandTypeChecker
- 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
-
Extract predicates for an Aggregate.
- getAllPredicates(Exchange, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Extract predicates for an Exchange.
- getAllPredicates(Filter, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Add the Filter condition to the list obtained from the input.
- 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
-
Extract predicates for a project.
- getAllPredicates(Sort, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Extract predicates for a Sort.
- getAllPredicates(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Extract predicates for a table scan.
- getAllPredicates(Union, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdAllPredicates
-
Extract predicates for a Union.
- 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
- getAncestorAttributes() - Method in class org.apache.calcite.materialize.TileSuggester.AttributeImpl
- 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
- getArg(Map<Object, Object>, int) - Method in class org.apache.calcite.util.Template
-
Returns the value of the
ordinal
th argument. - getArgCountMismatchMsg(int...) - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall.PermutingMakeCall
- getArgList() - Method in class org.apache.calcite.rel.core.AggregateCall
-
Returns the ordinals of the arguments to this call.
- getArgNames(String, AggregateCall) - Method in class org.apache.calcite.adapter.pig.PigAggregate
- getArgs() - Method in class org.apache.calcite.adapter.splunk.SplunkQuery
- getArgs() - Method in class org.apache.calcite.util.javac.JaninoCompiler
- getArgs() - Method in interface org.apache.calcite.util.javac.JavaCompiler
- getArgType(RexCall, int) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.CastArgAsDoubleExpander
- getArgType(RexCall, int) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.CastArgAsTypeExpander
- getArrayBindable(ClassDeclaration, String, int) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableInterpretable
- getAsByteArray() - Method in class org.apache.calcite.util.BitString
- getAtomicLong(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- getAttributes() - Method in class org.apache.calcite.materialize.TileSuggester.SchemaImpl
- 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. - getBaseRowType() - Method in class org.apache.calcite.sql.validate.TableNamespace
-
Gets the data-type of all columns in a table (for a view table: including columns of the underlying table)
- getBean() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Returns an object which encapsulates each property as a get/set method.
- getBest() - Method in class org.apache.calcite.plan.volcano.RelSubset
- getBestNextFactor(RelMetadataQuery, LoptMultiJoin, BitSet, BitSet, LoptSemiJoinOptimizer, LoptJoinTree, List<RexNode>) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Determines the best factor to be added next into a join tree.
- getBestTable(Document) - Method in class org.apache.calcite.adapter.file.FileReader
- getBindable(Meta.CursorFactory) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparedExplain
- getBindable(Meta.CursorFactory) - Method in interface org.apache.calcite.prepare.Prepare.PreparedResult
-
Executes the prepared result.
- getBindable(ClassDeclaration, String, int) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableInterpretable
- 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
- getBlockBuilderWinAggFrameResultContextFunction(JavaTypeFactory, SqlConformance, EnumerableRel.Result, List<Expression>, Expression, Expression, ParameterExpression, Expression, Expression, Expression, Expression, Expression, Expression, Expression, DeclarationStatement, PhysType) - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindow
- getBoolean() - Method in interface org.apache.calcite.linq4j.tree.Primitive.Source
- getBoolean(String, boolean) - Method in interface org.apache.calcite.rel.RelInput
- getBooleanProperty(String) - Static method in class org.apache.calcite.util.Util
-
Returns the value of a system property as a boolean.
- getBooleanProperty(String, boolean) - Static method in class org.apache.calcite.util.Util
-
Returns the value of a system property as a boolean, returning a given default value if the property is not specified.
- getBoxingClass(Class) - Static method in class org.apache.calcite.util.ReflectUtil
-
Gets the Java boxing class for a primitive class.
- getBuf() - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
- 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.
- getCalciteConnection() - Method in class org.apache.calcite.jdbc.CalciteResultSet
- getCalendarFormat(SqlTypeName) - Static method in class org.apache.calcite.rex.RexLiteral
- getCalendarPolicy() - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- getCalendarPolicy() - Method in class org.apache.calcite.sql.SqlDialect
- 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.
- getCancelFlag(Meta.StatementHandle) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- getCandidateColumnName() - Method in class org.apache.calcite.materialize.TileSuggester.AttributeImpl
- getCastedSqlNode(SqlNode, RelDataType, SqlParserPos, RexNode) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable.AvgVarianceConvertlet
- getCastedSqlNode(SqlNode, RelDataType, SqlParserPos, RexNode) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable.RegrCovarianceConvertlet
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
- getCastSpec(RelDataType) - Method in class org.apache.calcite.sql.SqlDialect
- 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 org.apache.calcite.sql.parser.SqlParseException
- getCeilSqlFunction(TimeUnitRange) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.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
- 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.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. - getCharsetName() - Method in class org.apache.calcite.util.NlsString
- getCharSetName() - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- getChecker(RelDataType) - Method in class org.apache.calcite.sql.fun.SqlDotOperator
- getChecker(RelDataType) - Method in class org.apache.calcite.sql.fun.SqlItemOperator
- getChildExps() - Method in class org.apache.calcite.rel.AbstractRelNode
- getChildExps() - Method in class org.apache.calcite.rel.core.Filter
- getChildExps() - Method in class org.apache.calcite.rel.core.Join
- getChildExps() - Method in class org.apache.calcite.rel.core.Project
- getChildExps() - Method in class org.apache.calcite.rel.core.Sort
- getChildExps() - Method in class org.apache.calcite.rel.core.TableFunctionScan
- getChildExps() - Method in interface org.apache.calcite.rel.RelNode
-
Deprecated.use #accept(org.apache.calcite.rex.RexShuttle)
- getChildExps() - Method in class org.apache.calcite.rel.rules.MultiJoin
- getChildFactors(LoptJoinTree, ImmutableBitSet.Builder) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Deprecated.
- getChildNames() - Method in class org.apache.calcite.sql.validate.ListScope
-
Returns an immutable list of child names.
- 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
- getClassExpressionFunction(CalciteSchema.TableEntry, Table) - Static method in class org.apache.calcite.prepare.RelOptTableImpl
- getClassExpressionFunction(SchemaPlus, String, Table) - Static method in class org.apache.calcite.prepare.RelOptTableImpl
- 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
- getClassName(RelDataType) - Static method in class org.apache.calcite.prepare.CalcitePrepareImpl
- getClassTracer(Class) - Static method in class org.apache.calcite.adapter.splunk.util.StringUtils
- getClientCache() - Method in class org.apache.calcite.adapter.geode.rel.GeodeTable.GeodeQueryable
- 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
- 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.
- getCohorts() - Method in class org.apache.calcite.rel.rules.ProjectToWindowRule.WindowedAggRelSplitter
- 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.sql.SqlCharStringLiteral
- 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
- 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.rel.AbstractRelNode
-
Deprecated.
- getCollationList() - Method in class org.apache.calcite.rel.core.Sort
- getCollationList() - Method in class org.apache.calcite.rel.core.TableScan
- getCollationList() - Method in interface org.apache.calcite.rel.RelNode
-
Deprecated.
- 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.
- getCollection() - Method in class org.apache.calcite.linq4j.Linq4j.CollectionEnumerable
- getCollectionsTypeName() - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- 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.rel.rules.LoptMultiJoin.RemovableSelfJoin
- 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
- getColumnMappings(SqlOperator) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- getColumnMetaDataList(JavaTypeFactory, RelDataType, RelDataType, List<List<String>>) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- getColumnMonotonicities() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- getColumnNum() - Method in class org.apache.calcite.sql.parser.SqlParserPos
- getColumnOrigin(RelNode, int) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Determines the origin of a column, provided the column maps to a single column that isn't derived.
- 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(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(SetOp, 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(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
- getColumnReferenceExpansion() - Method in interface org.apache.calcite.sql.validate.SqlValidator
- getColumnReferenceExpansion() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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
- getCompact() - Method in class org.apache.calcite.util.XmlOutput
- getComparability() - Method in interface org.apache.calcite.rel.type.RelDataType
- getComparability() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getComparability() - Method in class org.apache.calcite.sql.type.ObjectSqlType
- getComparables(RexNode) - Static method in class org.apache.calcite.rex.RexAnalyzer
- 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.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.SqlMultisetQueryConstructor
- getComponentType(RelDataTypeFactory, List<RelDataType>) - Method in class org.apache.calcite.sql.fun.SqlMultisetValueConstructor
- getComponentTypeN(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- getComponentTypes(RelDataTypeFactory, List<RelDataType>) - Method in class org.apache.calcite.sql.fun.SqlMapValueConstructor
- 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
- getConcatenatedFieldNameAndTypeForPigSchema(PigRel.Implementor, RelDataTypeField) - Method in class org.apache.calcite.adapter.pig.PigTableScan
- 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
- getCondition() - Method in class org.apache.calcite.sql.SqlUpdate
-
Gets the filter condition for rows to be updated.
- 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
- getConformance() - Method in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- getConformance() - Method in class org.apache.calcite.adapter.spark.SparkToEnumerableConverter.SparkImplementorImpl
- getConformance() - Method in interface org.apache.calcite.plan.RelImplementor
-
Returns the desired SQL conformance.
- getConformance() - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns the dialect of SQL (SQL:2003, etc.) this validator recognizes.
- getConformance() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getConnection() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteQueryable
- getConnection() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerStatementImpl
- getConnection() - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- getConnection() - Method in class org.apache.calcite.jdbc.CalcitePreparedStatement
- 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.AssignableOperandTypeChecker
- getConsistency() - Method in class org.apache.calcite.sql.type.ComparableOperandTypeChecker
- getConsistency() - Method in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- getConsistency() - Method in class org.apache.calcite.sql.type.FamilyOperandTypeChecker
- getConsistency() - Method in class org.apache.calcite.sql.type.LiteralOperandTypeChecker
- getConsistency() - Method in class org.apache.calcite.sql.type.MultisetOperandTypeChecker
- getConsistency() - Method in class org.apache.calcite.sql.type.OperandTypes.PeriodOperandTypeChecker
- getConsistency() - Method in class org.apache.calcite.sql.type.SameOperandTypeChecker
- getConsistency() - Method in class org.apache.calcite.sql.type.SetopOperandTypeChecker
- 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.
- getConstructor(Class<C>) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
- getConstructor(String) - Method in class org.apache.calcite.rel.externalize.RelJson
- 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() - Method in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- getContext(RelOptCluster) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- 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
. - getConversionData(RelOptPlanner) - Method in class org.apache.calcite.plan.ConventionTraitDef
- getConvertletTable() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns the convertlet table that should be used when converting from SQL to row expressions
- getConvertletTable() - Method in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- getCopyJoinFieldRefCountsMap() - Method in class org.apache.calcite.rel.rules.MultiJoin
- getCorRel(RelDecorrelator.CorRef) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- getCorrelationId() - Method in class org.apache.calcite.rel.core.Correlate
-
Returns the correlating expressions.
- getCorrelationUse(SqlToRelConverter.Blackboard, RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- 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
- 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.
- getCostFactory() - Method in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- getCpu() - Method in interface org.apache.calcite.plan.RelOptCost
- getCpu() - Method in class org.apache.calcite.plan.RelOptCostImpl
- getCpu() - Method in class org.apache.calcite.plan.volcano.VolcanoCost
- 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
- 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
- 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.Interpreter.CompilerImpl
- getDataContext() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.ContextImpl
- getDataContext() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.Context
- getDataSource() - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getDatatype(Dialect) - Method in class org.apache.calcite.materialize.TileSuggester.AttributeImpl
- getDate() - Method in class org.apache.calcite.sql.SqlDateLiteral
-
Converts this literal to a
DateString
. - getDateFormatter() - Static method in class org.apache.calcite.adapter.druid.DruidJsonFilter
- getDay() - Method in class org.apache.calcite.util.DateString
- getDaysSinceEpoch() - Method in class org.apache.calcite.util.DateString
-
Returns the number of days since the epoch.
- getDeclaringClass() - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl.RecordFieldImpl
- 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.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.RelMdMaxRowCount
- 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.RelMdPercentageOriginalRows
- 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
- 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.rel.RelCollationTraitDef
- getDefault() - Method in class org.apache.calcite.rel.RelDistributionTraitDef
- getDefault() - Static method in class org.apache.calcite.runtime.SocketFactoryImpl
- getDefault() - Static method in class org.apache.calcite.runtime.TrustAllSslSocketFactory
- getDefaultCharset() - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
- 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 ofSaffronProperties.defaultCharset()
- getDefaultNullCollation() - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns how NULL values should be collated if an ORDER BY item does not contain NULLS FIRST or NULLS LAST.
- getDefaultNullCollation() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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 -1 if precision is either unsupported or must be specified explicitly.
- getDefaultPrecision(SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- getDefaultScale() - Method in enum org.apache.calcite.sql.type.SqlTypeName
- getDefaultSchema() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns the default schema that should be checked before looking at the root schema.
- getDefaultSchema() - Method in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- getDefaultSchemaPath() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.ContextImpl
- getDefaultSchemaPath() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.Context
- getDefaultSSLSocketFactory() - Static method in class org.apache.calcite.runtime.TrustAllSslSocketFactory
- getDefaultValue(Type) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- 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.
- 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 class org.apache.calcite.benchmarks.FlightRecorderProfiler
- getDescription() - Method in interface org.apache.calcite.plan.RelOptNode
-
Returns a string which describes the relational expression and, unlike
RelOptNode.getDigest()
, also includes the identity. - getDescription() - Method in class org.apache.calcite.rel.AbstractRelNode
- 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
- getDetailLevel() - Method in class org.apache.calcite.sql.SqlExplain
- getDialect() - Method in class org.apache.calcite.materialize.TileSuggester.SchemaImpl
- 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 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.rel.AbstractRelNode
- 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
- getDimensions() - Method in class org.apache.calcite.materialize.TileSuggester.SchemaImpl
- getDirection() - Method in class org.apache.calcite.rel.RelFieldCollation
- getDirection() - Method in class org.apache.calcite.rex.RexFieldCollation
- getDistinctCalls(PigRel.Implementor) - Method in class org.apache.calcite.adapter.pig.PigAggregate
-
A agg function call like
COUNT(DISTINCT COL)
in Pig is achieved via two statements in a FOREACH that follows a GROUP statement:TABLE = GROUP TABLE ALL;
TABLE = FOREACH TABLE {
COL.DISTINCT = DISTINCT COL;
GENERATE COUNT(COL.DISTINCT) AS C;
} - 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(SemiJoin, 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(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.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(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
- getDriver() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- getDruidTable() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getDruidType() - Method in class org.apache.calcite.adapter.druid.ComplexMetric
- getDurationSeconds(IterationParams) - Method in class org.apache.calcite.benchmarks.FlightRecorderProfiler
- 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
- 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.
- 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.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.BindableJoin
- 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.jdbc.CalciteMetaImpl.MetadataTable
- getElementType() - Method in class org.apache.calcite.linq4j.BaseQueryable
- getElementType() - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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 interface org.apache.calcite.schema.QueryableTable
-
Returns the element type of the collection that will implement this table.
- getElementType() - Method in class org.apache.calcite.sql.ddl.SqlCreateTable.MutableArrayTable
- getElementType(Class) - Static method in class org.apache.calcite.adapter.java.ReflectiveSchema
-
Deduces the element type of a collection; same logic as
ReflectiveSchema.toEnumerable(java.lang.Object)
- 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<Object>) - Method in class org.apache.calcite.schema.impl.TableFunctionImpl
- getElementType(List<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<Object>) - Method in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction
- getElementType(List<Object>) - Method in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction2
- getElementType(RelDataTypeFactory, List<SqlNode>) - 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.
- getElseOperand() - Method in class org.apache.calcite.sql.fun.SqlCase
- 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.AbstractNamespace
- 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
- getEndColumnNum() - Method in class org.apache.calcite.sql.parser.SqlParserPos
- getEndLineNum() - Method in class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
- getEndLineNum() - Method in class org.apache.calcite.sql.parser.SqlParserPos
- getEndPosColumn() - Method in exception org.apache.calcite.runtime.CalciteContextException
- getEndPosLine() - Method in exception org.apache.calcite.runtime.CalciteContextException
- 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.
- getEnumValue(SqlNode) - Method in class org.apache.calcite.sql.fun.SqlJsonArrayFunction
- getEnumValue(SqlNode) - Method in class org.apache.calcite.sql.fun.SqlJsonObjectFunction
- getEnumValue(SqlNode) - Method in class org.apache.calcite.sql.fun.SqlJsonQueryFunction
- 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.AbstractMaterializedViewRule.EquivalenceClasses
- getEquivalenceClassesMap() - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.EquivalenceClasses
- getExceptionClass(Type) - Static method in class org.apache.calcite.runtime.Resources.ExInstWithCause
- getExecutable(RexBuilder, List<RexNode>, RelDataType) - 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.
- getExecutor() - Method in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- getExpandedSelectList() - Method in class org.apache.calcite.sql.validate.SelectScope
- getExpander(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.DecimalShuttle
-
Returns a
ReduceDecimalsRule.RexExpander
for a call - getExpander(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.ExpanderMap
- 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 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 org.apache.calcite.sql.parser.SqlParseException
-
Returns the expected token sequences.
- getExplicandum() - Method in class org.apache.calcite.sql.SqlExplain
- 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.EnumerableQueryable
- 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.schema.impl.AbstractTableQueryable
- 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(String) - Method in interface org.apache.calcite.rel.RelInput
-
Returns an expression.
- getExpression(PhysType) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
- getExpression(RexNode) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableLimit
- getExpression(SchemaPlus, String) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getExpression(SchemaPlus, String) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.RootSchema
- getExpression(SchemaPlus, String) - Method in class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- getExpression(SchemaPlus, String) - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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.csv.CsvTranslatableTable
- getExpression(SchemaPlus, String, Class) - Method in class org.apache.calcite.adapter.java.AbstractQueryableTable
- getExpression(SchemaPlus, String, Class) - Method in class org.apache.calcite.adapter.java.ReflectiveSchema.FieldTable
- 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.sql.ddl.SqlCreateTable.MutableArrayTable
- getExpressionLineage(HepRelVertex, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
- 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(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(Sort, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage
-
Expression lineage from Sort.
- 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(RelDataTypeFactory, 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
- getFactor(TimeUnit) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- getFactorsRefByFactor(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- getFactorsRefByJoinFilter(RexNode) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- getFactorTree() - Method in class org.apache.calcite.rel.rules.LoptJoinTree
- getFactorWeights() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- getFactory() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- 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.
- getFactRowCount() - Method in class org.apache.calcite.materialize.TileSuggester.StatisticsProviderImpl
- 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.sql.type.AbstractSqlType
- getFamily() - Method in class org.apache.calcite.sql.type.ArraySqlType
- 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.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, Class) - Static method in class org.apache.calcite.linq4j.tree.Types
- getField(String, Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- getFieldAccess(CorrelationId) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.DeferredLookup
- 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.RelDataTypeHolder
- getFieldCount() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getFieldIndex() - Method in class org.apache.calcite.rel.RelFieldCollation
- getFieldList() - Method in class org.apache.calcite.rel.type.DynamicRecordTypeImpl
- getFieldList() - Method in class org.apache.calcite.rel.type.RelCrossType
- 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.RelDataTypeHolder
- getFieldList() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getFieldList(List<RelDataType>) - Static method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
-
Returns a list of the fields in a list of types.
- 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.RelDataTypeHolder
- getFieldNames() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getFieldOrigin(SqlNode, int) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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
- getFieldOrInsert(String, boolean) - Method in class org.apache.calcite.rel.type.RelDataTypeHolder
-
Get field if exists, otherwise inserts a new field.
- getFieldRecurse(List<RelDataTypeImpl.Slot>, RelDataType, int, String, boolean) - Static method in class org.apache.calcite.rel.type.RelDataTypeImpl
- getFieldReference() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- getFieldsRefByJoinFilter(RexNode) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- 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.
- getFieldType(RelNode, int) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
- 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.
- 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(SqlOperator, List<RexNode>, StringBuilder, List<String>) - Method in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- getFilterRefs(List<AggregateCall>) - Static method in class org.apache.calcite.adapter.druid.DruidRules.DruidAggregateProjectRule
- 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.AbstractMaterializedViewRule.MaterializedViewAggregateRule
-
Get floor function datetime.
- 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.
- getFractionalSecondPrecision(RelDataTypeSystem) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- getFractionalSecondPrecisionPreservingDefault() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- getFrame() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- getFrame(RelNode, boolean) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- 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
- 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
- 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.
- 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.jdbc.CalciteSchema.SchemaPlusImpl
- getFunctionNames() - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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.jdbc.CalciteSchema.SchemaPlusImpl
- getFunctions(String) - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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.
- getFunctionsFrom(List<String>) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- getFunctionType() - Method in class org.apache.calcite.sql.SqlFunction
- 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.
- getGranularity() - Method in class org.apache.calcite.adapter.druid.TimeExtractionFunction
- getGraphIterator(HepRelVertex) - Method in class org.apache.calcite.plan.hep.HepPlanner
- 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
- getGroupExprs() - Method in class org.apache.calcite.sql.validate.AggregatingSelectScope
-
Returns the expressions that are in the GROUP BY clause (or the SELECT DISTINCT clause, if distinct) and that can therefore be referenced without being wrapped in aggregate functions.
- 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
- 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
- getHeadings() - Method in class org.apache.calcite.adapter.file.FileReader
- getHistogramOp(SqlAggFunction) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.HistogramShuttle
-
Returns the histogram operator corresponding to a given aggregate function.
- getHour() - Method in class org.apache.calcite.util.TimeString
- 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
- 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
- getIdentifierQuoteString(DatabaseMetaData) - Method in class org.apache.calcite.sql.SqlDialectFactoryImpl
- 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.
- getImplementor(SqlTypeName) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.ItemImplementor
- 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.cassandra.CassandraFilter.Translator
-
Infer the implicit correlation from the unrestricted clustering keys.
- getImplicitSubSchema(String, boolean) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema
- 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. - getImplicitSubSchema(String, boolean) - Method in class org.apache.calcite.jdbc.SimpleCalciteSchema
- getImplicitTable(String, boolean) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema
- 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. - getImplicitTable(String, boolean) - Method in class org.apache.calcite.jdbc.SimpleCalciteSchema
- getImplicitTableBasedOnNullaryFunction(String, boolean) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema
- 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. - getImplicitTableBasedOnNullaryFunction(String, boolean) - Method in class org.apache.calcite.jdbc.SimpleCalciteSchema
- getImplicitType(String, boolean) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema
- 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. - getImplicitType(String, boolean) - Method in class org.apache.calcite.jdbc.SimpleCalciteSchema
- getImportance() - Method in class org.apache.calcite.plan.volcano.VolcanoRuleMatch
-
Returns the importance of this rule.
- getImportance(RelSet) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Computes the importance of a set (which is that of its most important subset).
- getImportance(RelSubset) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Returns the importance of an equivalence class of relational expressions.
- getIndentation() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- getIndentation() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- getIndentation() - Method in interface org.apache.calcite.sql.SqlWriter
-
Returns the offset for each level of indentation.
- getIndex() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchema
- 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
- 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
-
Returns the number of indicator fields.
- 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
- getInitializerFactory(SqlValidatorTable) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- getInnerSelect(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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.MutableSingleRel
- 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. - getInput(RelNode, int) - Method in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
- getInputFieldName(int) - Method in class org.apache.calcite.adapter.pig.PigAggregate
- getInputFieldNameForAggCall(String, AggregateCall, int) - Method in class org.apache.calcite.adapter.pig.PigAggregate
- 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 rowtype 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.MutableBiRel
- getInputs() - Method in class org.apache.calcite.rel.mutable.MutableLeafRel
- getInputs() - Method in class org.apache.calcite.rel.mutable.MutableMultiRel
- getInputs() - Method in class org.apache.calcite.rel.mutable.MutableRel
- getInputs() - Method in class org.apache.calcite.rel.mutable.MutableSingleRel
- 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
- getInstance() - Static method in class org.apache.calcite.chinook.ChinookAvaticaServer.CalciteChinookMetaFactory
- getInstance() - Static method in class org.apache.calcite.chinook.ChinookAvaticaServer.RawChinookMetaFactory
- 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
. - getInSubQueryThreshold() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- getInt() - Method in interface org.apache.calcite.linq4j.tree.Primitive.Source
- getInt(int) - Method in class org.apache.calcite.util.ImmutableIntList
- getInt(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- getInt(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ByteStringDictionary
- getInt(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.Constant
- getInt(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectArray
- getInt(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectDictionary
- getInt(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveArray
- getInt(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveDictionary
- getInt(Object, int) - Method in interface org.apache.calcite.adapter.clone.ArrayTable.Representation
- getInt(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.StringDictionary
- 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
- getInterval() - Method in class org.apache.calcite.rel.core.Match
- getInterval() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getIntervalCostMultiplier() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- 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.sql.SqlIntervalLiteral.IntervalValue
- getIntervalQualifier() - Method in class org.apache.calcite.sql.type.IntervalSqlType
- getIntervalSign(String) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- 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, 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
- getIo() - Method in class org.apache.calcite.plan.RelOptCostImpl
- getIo() - Method in class org.apache.calcite.plan.volcano.VolcanoCost
- 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
- 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
- getJdbcKeywords() - Method in interface org.apache.calcite.sql.parser.SqlAbstractParserImpl.Metadata
-
Returns comma-separated list of JDBC keywords.
- getJdbcKeywords() - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
- 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
- getJdbcTableType() - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- getJdbcTableType() - Method in class org.apache.calcite.jdbc.CalciteMetaImpl.MetadataTable
- 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.ddl.SqlCreateMaterializedView.MaterializedViewTable
- 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
- getJoinFieldRefCounts(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- getJoinFieldRefCountsMap() - Method in class org.apache.calcite.rel.rules.MultiJoin
- 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
- getJoinFilterFactorBitmap(RexNode, boolean) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns a bitmap representing the factors referenced in a join filter
- getJoinFilters() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- 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
- getJoinRemovalSemiJoin(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- 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
- 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
- getJsonAggregation(String, AggregateCall, RexNode, String, String, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
- getKey() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor.SwapResult
- getKey() - Method in interface org.apache.calcite.linq4j.Grouping
-
Gets the key of this Grouping.
- getKey() - Method in class org.apache.calcite.linq4j.GroupingImpl
- 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.util.Pair
- getKeyFields() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable
- getKeyFields(String, boolean) - Method in class org.apache.calcite.adapter.cassandra.CassandraSchema
-
Get all primary key columns from the underlying CQL table
- getKeys() - Method in interface org.apache.calcite.rel.RelDistribution
-
Returns the ordinals of the key columns.
- getKeys() - Method in class org.apache.calcite.rel.RelDistributions.RelDistributionImpl
- getKeys() - Method in class org.apache.calcite.runtime.Resources.ShadowResourceBundle
- getKeyspace() - Method in class org.apache.calcite.adapter.cassandra.CassandraSchema
- 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.RelDataTypeImpl
- getKeyType() - Method in class org.apache.calcite.sql.type.MapSqlType
- 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.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.SqlJoin
- 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
- getLabel() - Method in class org.apache.calcite.materialize.TileSuggester.AttributeImpl
- getLabel() - Method in class org.apache.calcite.materialize.TileSuggester.TableImpl
- 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.MutableBiRel
- 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
- getLeftFactor() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin.RemovableSelfJoin
- getLeftKeys() - Method in class org.apache.calcite.rel.core.EquiJoin
- getLeftNodeDisjunctions(RexNode, List<RexNode>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
- getLeftNodeFieldName(RexNode) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
-
Get the field name for the left node to use for IN SET query
- getLeftNodeFieldNameForNode(RexNode) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
- 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
- getLineNum() - Method in class org.apache.calcite.sql.parser.SqlParserPos
- getList() - Method in class org.apache.calcite.sql.SqlNodeList
- getList(List<Pair<String, Object>>, String) - Method in class org.apache.calcite.rel.externalize.RelJsonWriter
- getListener() - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- getListForType(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeExplicitPrecedenceList
- getListPosition(SqlTypeName, List<SqlTypeName>) - Static method in class org.apache.calcite.sql.type.SqlTypeExplicitPrecedenceList
- 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
- getLiteralAsString(RexLiteral) - Method in class org.apache.calcite.adapter.pig.PigFilter
-
TODO: do proper literal to string conversion + escaping
- getLoadTime(List<Attribute>) - Method in class org.apache.calcite.materialize.TileSuggester.StatisticsProviderImpl
- getLocalDateString() - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
- getLocale() - Method in class org.apache.calcite.sql.parser.SqlParserUtil.ParsedCollation
- 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
- getLong(int, int, long, long[], int) - Static method in class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- getLong(int, long[], int) - Static method in class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- 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
- getMapConvertedNonCorrSubqs() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- 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.InverseMapping
- 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.PartialFunctionImpl
- 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
- getMatchedClass() - Method in class org.apache.calcite.plan.RelOptRuleOperand
- 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.
- getMax() - Method in class org.apache.calcite.sql.type.SqlOperandCountRanges.RangeImpl
- 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
-
Returns the maximum precision of a NUMERIC or DECIMAL type.
- 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
-
Returns the maximum scale of a NUMERIC or DECIMAL type.
- 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 -1 if precision/length are not applicable for this type.
- getMaxPrecision(SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- 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(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(Sort, 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
- 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 of a given type.
- getMaxScale(SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeSystemImpl
- getMaxUnscaled(int) - Static method in class org.apache.calcite.util.NumberUtil
- getMaxUsingLevelOrdinals() - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.HighestUsageFinder
- getMaxValue(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Determines the maximum unscaled value of a numeric type
- getMeasureList() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getMeasures() - Method in class org.apache.calcite.materialize.TileSuggester.SchemaImpl
- getMeasures() - Method in class org.apache.calcite.rel.core.Match
- 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 org.apache.calcite.runtime.CalciteContextException
- getMessage() - Method in class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
- getMessages(Throwable) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- getMetadata() - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Returns metadata about this parser: keywords, etc.
- getMetadata() - Method in class org.apache.calcite.sql.parser.SqlParser
-
Get the parser metadata.
- getMetadataFactory() - Method in class org.apache.calcite.plan.RelOptCluster
- 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)
. - getMethod(String, String, Class...) - Static method in class org.apache.calcite.linq4j.Linq4j
- getMethod(SqlTypeName, boolean, boolean) - Method in class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverter
- getMethod2(SqlTypeName) - Method in class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverter
- getMetricName() - Method in class org.apache.calcite.adapter.druid.ComplexMetric
- getMetricType() - Method in class org.apache.calcite.adapter.druid.ComplexMetric
- getMillisInSecond() - Method in class org.apache.calcite.util.TimestampString
- getMillisInSecond() - Method in class org.apache.calcite.util.TimeString
- 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.
- getMin() - Method in class org.apache.calcite.sql.type.SqlOperandCountRanges.RangeImpl
- getMinMaxKind() - Method in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
-
Deprecated.
- getMinPrecision() - Method in enum org.apache.calcite.sql.type.SqlTypeName
-
Returns the minimum precision (or length) allowed for this type, or -1 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(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(Sort, 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
-
Returns the minimum scale (or fractional second precision in the case of intervals) allowed for this type, or -1 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
. - getMinute() - Method in class org.apache.calcite.util.TimeString
- getMinValue(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Determines 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 interface org.apache.calcite.schema.ModifiableTable
-
Returns the modifiable collection.
- getModifiableCollection() - Method in class org.apache.calcite.sql.ddl.SqlCreateTable.MutableArrayTable
- 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.jdbc.JavaTypeFactoryImpl.RecordFieldImpl
- 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
- getMongoDb() - Method in class org.apache.calcite.adapter.mongodb.MongoTable.MongoQueryable
- getMonotonicExprs() - Method in class org.apache.calcite.sql.validate.AbstractNamespace
- 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.AbstractNamespace
- 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.sql.validate.TableNamespace
- 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.EmptyScope
- 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.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.
- getMonth() - Method in class org.apache.calcite.util.DateString
- getMultiJoinFields() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns array of fields contained within the multi-join
- getMultiJoinRel() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- getMutableClone() - Method in class org.apache.calcite.util.XmlOutput.StringEscaper
-
Create a mutable escaper from an existing escaper, which may already be immutable.
- getMutableRootSchema() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.ContextImpl
- 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 interface org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Aggregation
- getName() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Bucket
- getName() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.MultiBucketsAggregation
- getName() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.MultiValue
- getName() - Method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- getName() - Method in class org.apache.calcite.adapter.file.FileRowConverter.FieldDef
- 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.CalciteSchema.SchemaPlusImpl
- getName() - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl.RecordFieldImpl
- 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.prepare.RelOptTableImpl.MySchemaPlus
- 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.fun.SqlBetweenOperator
- 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
- 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.
- getNameForJdbcType(int) - Static method in enum org.apache.calcite.sql.type.SqlTypeName
-
Gets the SqlTypeName corresponding to a JDBC type.
- getNamespace(SqlIdentifier, DelegatingScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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
- getNamespace(SqlNode, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getNewColumnMapping(Table, ImmutableIntList, List<RelDataTypeField>, RelDataTypeFactory) - Static method in class org.apache.calcite.schema.impl.ModifiableViewTable
-
Creates a mapping from the view index to the index in the underlying table.
- 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.
- getNewForOldInputMapping(RelNode) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
-
Returns a mapping between old and new fields.
- getNewForOldInputRef(RelNode, Map<RelNode, RelDecorrelator.Frame>, RexInputRef) - Static method in class org.apache.calcite.sql2rel.RelDecorrelator
- getNewForOldRel(RelNode) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- getNextLine() - Method in class org.apache.calcite.adapter.csv.CsvStreamReader
-
Reads the next line from the file.
- getNlsString() - Method in class org.apache.calcite.sql.SqlCharStringLiteral
- 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.CatalogScope
- getNode() - Method in class org.apache.calcite.sql.validate.CollectNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.CollectScope
- getNode() - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.EmptyScope
- getNode() - Method in class org.apache.calcite.sql.validate.FieldNamespace
- 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.JoinNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.JoinScope
- 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.OrderByScope
- getNode() - Method in class org.apache.calcite.sql.validate.OverScope
- getNode() - Method in class org.apache.calcite.sql.validate.ParameterNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.ProcedureNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.SchemaNamespace
- 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.SqlValidatorImpl.DeleteNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.InsertNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.MergeNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.UpdateNamespace
- 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.TableNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.TableScope
- getNode() - Method in class org.apache.calcite.sql.validate.UnnestNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.WithItemNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.WithNamespace
- getNode() - Method in class org.apache.calcite.sql.validate.WithScope
- getNode() - Method in exception 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(HepRelVertex, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- 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(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(Minus, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Project, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(SemiJoin, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- getNodeTypes(Sort, 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(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.NodeTypes.getNodeTypes()
statistic. - getNodeTypes(RelNode, Class<? extends RelNode>, RelMetadataQuery) - Static method in class org.apache.calcite.rel.metadata.RelMdNodeTypes
- 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
- 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.RexImpTable.CountWinImplementor
- getNotNullState(WinAggContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.RowNumberImplementor
- getNotNullState(WinAggContext) - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- getNthExpr(SqlNode, int, int) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Locates the n'th expression in an INSERT or UPDATE query.
- 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.
- getNullCollation(DatabaseMetaData) - Method in class org.apache.calcite.sql.SqlDialectFactoryImpl
- getNullDirection() - Method in class org.apache.calcite.rex.RexFieldCollation
- getNullPolicy(Method) - Static method in class org.apache.calcite.schema.impl.ScalarFunctionImpl
- getNumColumns() - Method in interface org.apache.calcite.rel.RelReferentialConstraint
-
Returns the number of columns in the keys.
- getNumColumns() - Method in class org.apache.calcite.rel.RelReferentialConstraintImpl
- getNumericFunctions() - Static method in class org.apache.calcite.sql.SqlJdbcFunctionCall
- getNumericJavaClassName(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Deprecated.
- getNumericLimit(int, int, boolean, SqlTypeName.Limit, boolean) - Method in enum org.apache.calcite.sql.type.SqlTypeName
- getNumFieldsInJoinFactor(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- getNumJoinFactors() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- getNumTotalFields() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- 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
- getObject(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- getObject(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ByteStringDictionary
- getObject(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.Constant
- getObject(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectArray
- getObject(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectDictionary
- getObject(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveArray
- getObject(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveDictionary
- getObject(Object, int) - Method in interface org.apache.calcite.adapter.clone.ArrayTable.Representation
- getObject(Object, int) - Method in class org.apache.calcite.adapter.clone.ArrayTable.StringDictionary
- getObjectPath() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.ContextImpl
- getObjectPath() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.Context
-
Returns the path of the object being analyzed, or null.
- getObjects(JsonBuilder, NavigableSet<Profiler.Column>) - Static method in class org.apache.calcite.profile.Profiler.FunctionalDependency
- 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.rex.RexWindowBound.RexWindowBoundBounded
- 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
- 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.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.SqlJsonObjectFunction
- 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.SqlSubstringFunction
- 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.type.AssignableOperandTypeChecker
- getOperandCountRange() - Method in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- getOperandCountRange() - Method in class org.apache.calcite.sql.type.FamilyOperandTypeChecker
- getOperandCountRange() - Method in class org.apache.calcite.sql.type.LiteralOperandTypeChecker
- getOperandCountRange() - Method in class org.apache.calcite.sql.type.MultisetOperandTypeChecker
- getOperandCountRange() - Method in class org.apache.calcite.sql.type.OperandTypes.PeriodOperandTypeChecker
- 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
- 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.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.fun.SqlCase
- getOperandList() - Method in class org.apache.calcite.sql.SqlBasicCall
- getOperandList() - Method in class org.apache.calcite.sql.SqlCall
- 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.SqlInsert
- getOperandList() - Method in class org.apache.calcite.sql.SqlJoin
- 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.SqlSelect
- getOperandList() - Method in class org.apache.calcite.sql.SqlSetOption
- 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.
- 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
- getOperands() - Method in class org.apache.calcite.sql.SqlBasicCall
- 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.EmptyScope
- 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.
- 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.rex.RexCallBinding.RexCastCallBinding
- 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.SqlOperator
- 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.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.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.SqlInsert
- getOperator() - Method in interface org.apache.calcite.sql.SqlJdbcFunctionCall.MakeCall
- 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.SqlMatchRecognize
- getOperator() - Method in class org.apache.calcite.sql.SqlMerge
- getOperator() - Method in class org.apache.calcite.sql.SqlOperatorBinding
- getOperator() - Method in class org.apache.calcite.sql.SqlOrderBy
- 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.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
- 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.util.ChainedSqlOperatorTable
- getOperatorList() - Method in class org.apache.calcite.sql.util.ListSqlOperatorTable
- 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() - Method in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- getOpTab() - Method in class org.apache.calcite.rex.RexBuilder
-
Returns this RexBuilder's operator table
- getOrAdd(List<RelTrait>) - Method in class org.apache.calcite.plan.RelTraitSet.Cache
- getOrCreateSubset(RelOptCluster, RelTraitSet) - Method in class org.apache.calcite.plan.volcano.RelSet
- getOrderKey() - Method in class org.apache.calcite.rex.RexWindowBound
-
Returns relative sort offset when known at compile time.
- getOrderKey() - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundCurrentRow
- getOrderKey() - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundUnbounded
- 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.EmptyScope
- 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.
- getOriginalRelName() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.DeferredLookup
- getOriginalSql() - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Returns the SQL text.
- getOriginalStatement() - Method in exception org.apache.calcite.runtime.CalciteContextException
- getOriginColumnOrdinal() - Method in class org.apache.calcite.rel.metadata.RelColumnOrigin
- getOriginTable() - Method in class org.apache.calcite.rel.metadata.RelColumnOrigin
- getOrUnbound(RexNode) - Method in class org.apache.calcite.rex.RexInterpreter
- 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
- getOuterJoinConditions() - Method in class org.apache.calcite.rel.rules.MultiJoin
- getOuterJoinFactors(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- 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
- getOwnerType() - Method in class org.apache.calcite.linq4j.tree.Types.ParameterizedTypeImpl
- 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.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(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 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
- 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.
- getParameterTypes(RelDataTypeFactory) - Method in class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
- getParamNames() - Method in class org.apache.calcite.sql.SqlFunction
-
Returns a list of parameter names.
- 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
- getParamTypes() - Method in class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
- getParent() - Method in class org.apache.calcite.materialize.TileSuggester.TableImpl
- 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.RelSet
- 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
- getParents() - Method in class org.apache.calcite.plan.volcano.RelSubset
-
Returns the collection of RelNodes one of whose inputs is in this subset.
- 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 class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- getParentSchema() - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- getParentSchema() - Method in interface org.apache.calcite.schema.SchemaPlus
-
Returns the parent schema, or null if this schema has no parent.
- getParentSubsets(VolcanoPlanner) - Method in class org.apache.calcite.plan.volcano.RelSubset
-
Returns the collection of distinct subsets that contain a RelNode one of whose inputs is in this subset.
- 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.
- getParserConfig() - Method in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- getParserMetadata() - Method in class org.apache.calcite.sql.advise.SqlAdvisor
-
Returns the underlying Parser metadata.
- 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, List<? extends RexNode>) - Static method in class org.apache.calcite.rel.core.Project
-
Returns a partial mapping of a set of project expressions.
- getPartitionIterator(BlockBuilder, Expression, PhysType, Window.Group, Expression) - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindow
- 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).
- getPath() - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns the default path resolving functions from this schema.
- getPathMap() - Method in class org.apache.calcite.plan.ConventionTraitDef.ConversionData
- getPaths(Convention, Convention) - Method in class org.apache.calcite.plan.ConventionTraitDef.ConversionData
- getPaths(V, V) - Method in class org.apache.calcite.util.graph.Graphs.FrozenGraph
-
Returns an iterator of all paths between two nodes, shortest first.
- getPattern() - Method in class org.apache.calcite.rel.core.Match
- getPattern() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- 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(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
- 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.
- getPhaseRuleMappingInitializer() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- getPhysicalRowType() - Method in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
-
Returns the physical row type of this prepared statement.
- getPigAggregateCall(String, AggregateCall) - Method in class org.apache.calcite.adapter.pig.PigAggregate
- getPigAggregateCalls(PigRel.Implementor) - Method in class org.apache.calcite.adapter.pig.PigAggregate
- getPigAggregateStatement(PigRel.Implementor) - Method in class org.apache.calcite.adapter.pig.PigAggregate
-
Generates a GROUP BY statement, followed by an optional FOREACH statement for all aggregate functions used.
- getPigFilterStatement(PigRel.Implementor) - Method in class org.apache.calcite.adapter.pig.PigFilter
-
Generates Pig Latin filtering statements, for example
- getPigForEachGenerate(PigRel.Implementor) - Method in class org.apache.calcite.adapter.pig.PigAggregate
-
Generates a FOREACH statement containing invocation of aggregate functions and projection of grouped fields.
- getPigGenerateCall(PigRel.Implementor) - Method in class org.apache.calcite.adapter.pig.PigAggregate
- getPigGroupBy(PigRel.Implementor) - Method in class org.apache.calcite.adapter.pig.PigAggregate
-
Generates the GROUP BY statement, e.g.
- getPigJoinStatement(PigRel.Implementor) - Method in class org.apache.calcite.adapter.pig.PigJoin
-
Constructs a Pig JOIN statement in the form of
- getPigJoinType() - Method in class org.apache.calcite.adapter.pig.PigJoin
-
Get a string representation of the type of join for use in a Pig script.
- getPigRelationAlias(RelNode) - Method in class org.apache.calcite.adapter.pig.PigRel.Implementor
- getPigTable(String) - Method in class org.apache.calcite.adapter.pig.PigTableScan
- 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.
- getPlannerTracer() - Static method in class org.apache.calcite.util.trace.CalciteTrace
-
The "org.apache.calcite.plan.RelOptPlanner" tracer prints the query optimization process.
- 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(SemiJoin, 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(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. - getPos() - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
- getPos() - Method in exception 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 org.apache.calcite.runtime.CalciteContextException
- getPosLine() - Method in exception org.apache.calcite.runtime.CalciteContextException
- getPostJoinFilter() - Method in class org.apache.calcite.rel.rules.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
- getPrecedenceList() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- 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.sql.SqlDataTypeSpec
- getPrecision() - Method in class org.apache.calcite.sql.type.BasicSqlType
- getPrecision() - Method in class org.apache.calcite.sql.type.IntervalSqlType
- getPrecision(RelDataType) - Static method in class org.apache.calcite.prepare.CalcitePrepareImpl
- getPredicates() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Predicates
-
Derives the predicates that hold on rows emitted from a relational expression.
- getPredicates(HepRelVertex, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
- getPredicates(RelSubset, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
- getPredicates(Aggregate, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for an Aggregate.
- 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(Join, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
- getPredicates(Project, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for a project.
- getPredicates(Sort, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Infers predicates for a Sort.
- 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(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. - getPreExprs() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- getPreferredCasing(String) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
-
Returns casing which is preferred for replacement.
- getPrimitive(RelDataTypeField) - Method in class org.apache.calcite.adapter.druid.DruidQuery.DruidQueryNode
- 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
- 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.
- getPrograms() - Method in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- 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, LogicalProject, boolean) - Method in class org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule
- getProjectFields(List<RexNode>) - Method in class org.apache.calcite.adapter.csv.CsvProjectTableScanRule
- 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
- getProjFields(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- getProperties() - Method in interface org.apache.calcite.jdbc.CalciteConnection
-
Returns an instance of the connection properties.
- getProperties() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- getProperties() - Method in class org.apache.calcite.runtime.Resources.Inst
- getPropertyNames() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter.Bean
- getProvider() - Method in class org.apache.calcite.linq4j.BaseQueryable
- getProvider() - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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. - 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(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
-
Constructs a qualified name for an optimizer table reference.
- getQuery() - Method in class org.apache.calcite.plan.RelOptCluster
-
Deprecated.
- getQuery() - Method in class org.apache.calcite.rel.AbstractRelNode
- getQuery() - Method in interface org.apache.calcite.rel.RelNode
-
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.jdbc.CalciteConnectionImpl.DataContextImpl
- getQueryProvider() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.SlimDataContext
- getQueryProvider() - Method in class org.apache.calcite.plan.VisitorDataContext
- getQueryProvider() - Method in class org.apache.calcite.schema.Schemas.DummyDataContext
- 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
- getQueryTypeCostMultiplier() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getRank(DirectedGraph<Integer, DefaultEdge>) - Method in class org.apache.calcite.rel.rules.ProjectToWindowRule.WindowedAggRelSplitter
- 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
- getRawType() - Method in class org.apache.calcite.linq4j.tree.Types.ParameterizedTypeImpl
- getRecordField(String, Types.RecordType) - Static method in class org.apache.calcite.linq4j.tree.Types
- getRecordFields() - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl.SyntheticRecordType
- getRecordFields() - Method in interface org.apache.calcite.linq4j.tree.Types.RecordType
- getReference() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.NamedFieldExpression
- 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.
- getRefName() - Method in class org.apache.calcite.sql.SqlWindow
- getRegrCountRexNode(Aggregate, AggregateCall, List<AggregateCall>, Map<AggregateCall, RexNode>, ImmutableIntList, ImmutableList<RelDataType>, int) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
- getRel() - Method in class org.apache.calcite.plan.RelOptListener.RelEvent
- getRelBuilderFactory() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns the factory to create
RelBuilder
, never null. - getRelBuilderFactory() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- getRelDataType(String, boolean) - Method in class org.apache.calcite.adapter.cassandra.CassandraSchema
- getRelDataType(String, String, String) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- getRelDataType(DatabaseMetaData, String, String, String) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- 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
- getRelMetadataTimestamp(RelNode) - Method in class org.apache.calcite.plan.hep.HepPlanner
- getRelMetadataTimestamp(RelNode) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Gets a timestamp for a given rel's metadata.
- getRelMetadataTimestamp(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- 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
- getRelOptTable(SqlValidatorNamespace, Prepare.CatalogReader, String, boolean[]) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Converts a
SqlValidatorScope
into aRelOptTable
. - getRelOptTable(TableNamespace, Prepare.CatalogReader, String, boolean[], List<RelDataTypeField>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
- getRelRunner() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.ContextImpl
- 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.
- getRelsFromAllSubsets() - Method in class org.apache.calcite.plan.volcano.RelSet
- 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.
- getRemaining(RexBuilder) - Method in class org.apache.calcite.rel.core.JoinInfo.EquiJoinInfo
- getRemaining(RexBuilder) - Method in class org.apache.calcite.rel.core.JoinInfo
- getRemaining(RexBuilder) - Method in class org.apache.calcite.rel.core.JoinInfo.NonEquiJoinInfo
- 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
-
Return an array of SQL reserved and keywords
- getReservedAndKeyWordsSet() - Method in class org.apache.calcite.sql.advise.SqlAdvisor
- getResultCount() - Method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.CountingSearchResultListener
- getResults() - Method in class org.apache.calcite.plan.hep.HepRuleCall
- getResultSet() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerStatementImpl
- getResultSet() - Method in interface org.apache.calcite.server.CalciteServerStatement
- 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) - Method in class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
- getReturnType(RelDataTypeFactory, SqlOperatorBinding) - Method in class org.apache.calcite.schema.impl.ScalarFunctionImpl
- getReturnTypeInference() - Method in class org.apache.calcite.sql.SqlOperator
- 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.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. - getRexShuttle(MutableProject) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
-
Builds a shuttle that stores a list of expressions, and can map incoming expressions to references to them.
- getRight() - Method in class org.apache.calcite.rel.BiRel
- getRight() - Method in class org.apache.calcite.rel.mutable.MutableBiRel
- 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
- 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.
- getRightFactor() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin.RemovableSelfJoin
- getRightKeys() - Method in class org.apache.calcite.rel.core.EquiJoin
- getRightPrec() - Method in class org.apache.calcite.sql.SqlOperator
- getRollup(SqlAggFunction) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
- getRollup(SqlAggFunction) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewAggregateRule
-
Get rollup aggregation function.
- 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
- getRootExpression() - Method in class org.apache.calcite.adapter.enumerable.JavaRelImplementor
-
Returns the expression used to access
DataContext
. - getRootField(RexInputRef) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- getRootName() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.NamedFieldExpression
- 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 class org.apache.calcite.jdbc.CalciteConnectionImpl.ContextImpl
- getRootSchema() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.DataContextImpl
- getRootSchema() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- getRootSchema() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.SlimDataContext
- 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 class org.apache.calcite.schema.Schemas.DummyDataContext
- getRootSchema() - Method in interface org.apache.calcite.sql.validate.SqlValidatorCatalogReader
-
Returns the root namespace for name resolution.
- getRowCollationKey(BlockBuilder, PhysType, Window.Group, int) - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindow
- 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(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(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(List<Attribute>) - Method in class org.apache.calcite.materialize.TileSuggester.StatisticsProviderImpl
- 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(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(SemiJoin, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdRowCount
- getRowCount(Sort, 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
- getRows() - Method in interface org.apache.calcite.plan.RelOptCost
- getRows() - Method in class org.apache.calcite.plan.RelOptCostImpl
- getRows() - Method in class org.apache.calcite.plan.volcano.VolcanoCost
- getRows() - Method in class org.apache.calcite.rel.AbstractRelNode
- getRows() - Method in interface org.apache.calcite.rel.RelNode
-
Deprecated.Call
RelMetadataQuery.getRowCount(RelNode)
; if you wish to override the default row count formula, override theRelNode.estimateRowCount(RelMetadataQuery)
method. - 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.AbstractNamespace
- getRowType() - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- getRowType() - Method in class org.apache.calcite.sql.validate.DelegatingSqlValidatorTable
- getRowType() - Method in class org.apache.calcite.sql.validate.ParameterNamespace
- 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(String) - Method in interface org.apache.calcite.rel.RelInput
- getRowType(String, String) - Method in interface org.apache.calcite.rel.RelInput
- getRowType(JavaTypeFactory) - Method in class org.apache.calcite.adapter.file.FileRowConverter
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.clone.ArrayTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.clone.ListTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.csv.CsvStreamScannableTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.csv.CsvTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.csv.JsonTable
- 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.FileTable
- 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.java.ReflectiveSchema.ReflectiveTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- 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.splunk.SplunkTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.tpcds.TpcdsSchema.TpcdsQueryableTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.tpch.TpchSchema.TpchQueryableTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.example.maze.MazeTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl.MetadataTable
- 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.ddl.SqlCreateTable.MutableArrayTable
- getRowType(RelDataTypeFactory, List<Object>) - Method in class org.apache.calcite.schema.impl.TableFunctionImpl
- getRowType(RelDataTypeFactory, List<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<Object>) - Method in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction
- getRowType(RelDataTypeFactory, List<Object>) - Method in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction2
- getRowType(RelDataTypeFactory, List<SqlNode>) - Method in class org.apache.calcite.sql.validate.SqlUserDefinedTableFunction
-
Returns the record type of the table yielded by this function when applied to given arguments.
- getRowTypeSansSystemColumns() - Method in class org.apache.calcite.sql.validate.AbstractNamespace
- 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.
- 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.hep.HepPlanner
- getRules() - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Returns the list of all registered rules.
- getRules() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- getRules() - Method in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- getRules() - Method in class org.apache.calcite.sql.type.CompositeSingleOperandTypeChecker
- getSamplePercentage() - Method in class org.apache.calcite.sql.SqlSampleSpec.SqlTableSampleSpec
-
Returns sampling percentage.
- getSamplingParameters() - Method in class org.apache.calcite.rel.core.Sample
-
Retrieve the sampling parameters for this Sample.
- getSamplingParameters(RelInput) - Static method in class org.apache.calcite.rel.core.Sample
- getSamplingPercentage() - Method in class org.apache.calcite.plan.RelOptSamplingParameters
-
Returns the sampling percentage.
- getScalar(ClassDeclaration, String) - Static method in class org.apache.calcite.interpreter.JaninoRexCompiler
- 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.sql.SqlDataTypeSpec
- 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
- getScale(RelDataType) - Static method in class org.apache.calcite.prepare.CalcitePrepareImpl
- 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. - getSchemaForPigStatement(PigRel.Implementor) - Method in class org.apache.calcite.adapter.pig.PigTableScan
- 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 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.
- 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
- getSearchResultEnumerator(String, Map<String, String>, List<String>) - Method in class org.apache.calcite.adapter.splunk.SplunkDriver.MockSplunkConnection
- getSearchResultEnumerator(String, Map<String, String>, List<String>) - Method in class org.apache.calcite.adapter.splunk.SplunkDriver.WrappingSplunkConnection
- 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
- getSearchResults(String, Map<String, String>, List<String>, SearchResultListener) - Method in class org.apache.calcite.adapter.splunk.SplunkDriver.MockSplunkConnection
- getSearchResults(String, Map<String, String>, List<String>, SearchResultListener) - Method in class org.apache.calcite.adapter.splunk.SplunkDriver.WrappingSplunkConnection
- getSearchResults_(String, Map<String, String>, List<String>, SearchResultListener) - Method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- getSecond() - Method in class org.apache.calcite.util.TimeString
- getSelectedTable(Document, String) - Method in class org.apache.calcite.adapter.file.FileReader
- getSelectivity(Aggregate, 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(Project, RelMetadataQuery, RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdSelectivity
- getSelectivity(SemiJoin, 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(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
- getSelectListItem(SqlNode, int) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns the
i
th select-list item of a query. - getSelectorFilter(String, String, ExtractionFunction) - Static method in class org.apache.calcite.adapter.druid.DruidJsonFilter
- 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.
- getSemiJoinRowCount(RelMetadataQuery, RelNode, RelNode, JoinRelType, RexNode) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Returns an estimate of the number of rows returned by a
SemiJoin
. - getSession() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- getSet() - Method in class org.apache.calcite.plan.volcano.RelSubset
- 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
- getShortestPath(Convention, Convention) - Method in class org.apache.calcite.plan.ConventionTraitDef.ConversionData
- getShortestPath(V, V) - Method in class org.apache.calcite.util.graph.Graphs.FrozenGraph
-
Returns the shortest path between two points, null if there is no path.
- getSign() - Method in class org.apache.calcite.sql.SqlIntervalLiteral.IntervalValue
- getSignature() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerStatementImpl
- getSignature() - Method in class org.apache.calcite.jdbc.CalciteResultSet
- 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.SqlJsonArrayFunction
- getSignatureTemplate(int) - Method in class org.apache.calcite.sql.fun.SqlJsonExistsFunction
- 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.SqlJsonValueFunction
- 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.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
- getSimpleFactors(RelMetadataQuery, LoptMultiJoin) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Retrieves join factors that correspond to simple table references.
- getSimpleName() - Method in class org.apache.calcite.plan.ConventionTraitDef
- getSimpleName() - Method in class org.apache.calcite.plan.RelTraitDef
- 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
- getSingleFilterCondition(PigRel.Implementor, String, RexCall) - Method in class org.apache.calcite.adapter.pig.PigFilter
- getSingleFilterCondition(PigRel.Implementor, RexNode) - Method in class org.apache.calcite.adapter.pig.PigFilter
- getSource() - Method in class org.apache.calcite.materialize.Lattice.Edge
- getSource() - Method in class org.apache.calcite.rex.RexExecutable
- getSource() - Method in class org.apache.calcite.sql.SqlInsert
- getSource(int) - Method in class org.apache.calcite.util.mapping.Mappings.AbstractMapping
- getSource(int) - Method in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
- getSource(int) - Method in class org.apache.calcite.util.mapping.Mappings.InverseMapping
- getSource(int) - Method in class org.apache.calcite.util.mapping.Mappings.OverridingSourceMapping
- getSource(int) - Method in interface org.apache.calcite.util.mapping.Mappings.SourceMapping
- getSource(int) - Method in class org.apache.calcite.util.mapping.Mappings.SurjectionWithInverse
- 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.InverseMapping
- getSourceCount() - Method in class org.apache.calcite.util.mapping.Mappings.PartialFunctionImpl
- 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
- 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
- getSourceOpt(int) - Method in class org.apache.calcite.util.mapping.Mappings.InverseMapping
- getSourceOpt(int) - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- getSourceOpt(int) - Method in interface org.apache.calcite.util.mapping.Mappings.SourceMapping
- getSourceOpt(int) - Method in interface org.apache.calcite.util.mapping.Mappings.TargetMapping
- 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.
- getSourceString() - Method in class org.apache.calcite.util.SourceStringReader
-
Returns the source string.
- getSourceTableRef() - Method in class org.apache.calcite.sql.SqlMerge
- getSpace(List<Attribute>) - Method in class org.apache.calcite.materialize.TileSuggester.StatisticsProviderImpl
- 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.
- getSql92ReservedWords() - Static method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Returns immutable set of all reserved words defined by SQL-92.
- getSqlAdvisor() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.DataContextImpl
- 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.sql.SqlFunction
- 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
. - getSqlToRelConverterConfig() - Method in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- 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
- getSqlTypeName() - Method in class org.apache.calcite.rel.type.RelRecordType
- 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
- 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
- getStartLineNum() - Method in class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
- 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 class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerImpl
- 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.
- getStatementType(Prepare.PreparedResult) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Deduces the broad type of statement for a prepare result.
- getStatementType(SqlKind) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Deduces the broad type of statement.
- 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.FirstLastValueImplementor
- getStateType(AggContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.GroupingImplementor
- getStateType(AggContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.JsonArrayAggImplementor
- getStateType(AggContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.JsonObjectAggImplementor
- getStateType(AggContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.LeadLagImplementor
- getStateType(AggContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.NthValueImplementor
- getStateType(AggContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.NtileImplementor
- getStateType(AggContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.SingleValueImplementor
- getStateType(AggContext) - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- getStatistic() - Method in class org.apache.calcite.adapter.clone.ArrayTable
- getStatistic() - Method in class org.apache.calcite.adapter.clone.ListTable
- getStatistic() - Method in class org.apache.calcite.adapter.file.FileTable
- getStatistic() - Method in class org.apache.calcite.adapter.java.ReflectiveSchema.FieldTable
- getStatistic() - Method in class org.apache.calcite.adapter.java.ReflectiveSchema.ReflectiveTable
- getStatistic() - Method in class org.apache.calcite.adapter.tpcds.TpcdsSchema.TpcdsQueryableTable
- 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.
- 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.
- getStatisticProvider() - Method in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- getStatisticsProvider() - Method in class org.apache.calcite.materialize.TileSuggester.SchemaImpl
- 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
float
value. - getString(List<String>) - Static method in class org.apache.calcite.sql.SqlIdentifier
-
Converts a list of strings to a qualified identifier.
- getString(RelDataType) - Method in class org.apache.calcite.sql.validate.AliasNamespace
- 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.
- 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
- getSubQuery(SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- 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.jdbc.CalciteSchema.SchemaPlusImpl
- getSubSchema(String) - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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.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.jdbc.CalciteSchema.SchemaPlusImpl
- getSubSchemaNames() - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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(RelTraitSet) - Method in class org.apache.calcite.plan.volcano.RelSet
- 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
- getSubset(RelNode, RelTraitSet, boolean) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- getSubsetList() - Method in class org.apache.calcite.sql.SqlMatchRecognize
- getSubsets() - Method in class org.apache.calcite.rel.core.Match
- getSubtype() - Method in class org.apache.calcite.sql.fun.SqlAvgAggFunction
-
Deprecated.
- getSubtype() - Method in class org.apache.calcite.sql.fun.SqlCovarAggFunction
-
Deprecated.
- getSumAggregatedRexNode(Aggregate, AggregateCall, List<AggregateCall>, Map<AggregateCall, RexNode>, RexBuilder, int, int) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
- getSumAggregatedRexNodeWithBinding(Aggregate, AggregateCall, List<AggregateCall>, Map<AggregateCall, RexNode>, RelDataType, int, int) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
- 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.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.fun.SqlDatetimePlusOperator
- getSyntax() - Method in class org.apache.calcite.sql.fun.SqlDatetimeSubtractionOperator
- getSyntax() - Method in class org.apache.calcite.sql.fun.SqlRandFunction
- getSyntax() - Method in class org.apache.calcite.sql.fun.SqlRandIntegerFunction
- getSyntax() - Method in class org.apache.calcite.sql.fun.SqlRowOperator
- getSyntax() - Method in class org.apache.calcite.sql.SqlBinaryOperator
- getSyntax() - Method in class org.apache.calcite.sql.SqlFunction
- getSyntax() - Method in class org.apache.calcite.sql.SqlInfixOperator
- 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.SqlOperator
-
Returns the syntactic type of this operator, never null.
- getSyntax() - Method in class org.apache.calcite.sql.SqlOrderBy.Operator
- 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.SqlSpecialOperator
- getSyntax() - Method in class org.apache.calcite.sql.SqlWindow.SqlWindowOperator
- getSystemField(String, Class) - Static method in class org.apache.calcite.linq4j.tree.Types
- 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.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
- getTable() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- getTable() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getTable() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable.ElasticsearchQueryable
- getTable() - Method in class org.apache.calcite.adapter.file.FileReader
- getTable() - Method in class org.apache.calcite.adapter.geode.rel.GeodeTable.GeodeQueryable
- getTable() - Method in class org.apache.calcite.adapter.mongodb.MongoTable.MongoQueryable
- 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.materialize.TileSuggester.AttributeImpl
- getTable() - Method in class org.apache.calcite.plan.RelOptMaterialization.ProjectFilterTable
- 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 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.AbstractNamespace
- 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() - Method in class org.apache.calcite.sql.validate.TableNamespace
- getTable() - Method in class org.apache.calcite.sql.validate.UnnestNamespace
- 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 class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- getTable(String) - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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(RelDataTypeFactory, List<SqlNode>) - Method in class org.apache.calcite.sql.validate.SqlUserDefinedTableMacro
-
Returns the table in this UDF, or null if there is no table.
- getTableAccessMode(List<String>) - Method in class org.apache.calcite.plan.TableAccessMap
-
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.
- getTableConstructorRowType(SqlCall, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Returns null if there is no common type.
- 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. - getTableEntryFrom(CalciteSchema, String, boolean) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
- 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. - 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.file.FileSchema
- 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.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.jdbc.MetadataSchema
- getTableMap() - Method in class org.apache.calcite.schema.impl.AbstractSchema
-
Returns a map of tables in this schema by name.
- getTableMap(boolean) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- 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(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.jdbc.CalciteSchema.SchemaPlusImpl
- getTableNames() - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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.EmptyScope
- getTableNamespace(List<String>) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Deprecated.
- getTableNamespace(List<String>) - Method in class org.apache.calcite.sql.validate.WithScope
- 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
- getTableReferences() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.TableReferences
-
This provider returns the tables used by a given plan.
- getTableReferences(HepRelVertex, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
- 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(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(Sort, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
Table references from Sort.
- getTableReferences(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
TableScan table reference.
- getTableReferences(Union, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdTableReferences
-
Table references from
Union
. - 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() - Method in class org.apache.calcite.materialize.TileSuggester.SchemaImpl
- 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
- 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.materialize.Lattice.Edge
- 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
- getTarget(int) - Method in class org.apache.calcite.util.mapping.Mappings.InverseMapping
- getTarget(int) - Method in class org.apache.calcite.util.mapping.Mappings.OverridingTargetMapping
- getTarget(int) - Method in interface org.apache.calcite.util.mapping.Mappings.TargetMapping
- 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
- getTargetColumnList() - Method in class org.apache.calcite.sql.SqlUpdate
- 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.InverseMapping
- getTargetCount() - Method in class org.apache.calcite.util.mapping.Mappings.PartialFunctionImpl
- 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
- getTargetExpression(SchemaPlus, String) - Method in class org.apache.calcite.adapter.java.ReflectiveSchema
-
Returns an expression for the object wrapped by this schema (not the schema itself).
- 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
- getTargetOpt(int) - Method in class org.apache.calcite.util.mapping.Mappings.InverseMapping
- getTargetOpt(int) - Method in class org.apache.calcite.util.mapping.Mappings.PartialFunctionImpl
- getTargetOpt(int) - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- getTargetOpt(int) - Method in interface org.apache.calcite.util.mapping.Mappings.SourceMapping
- getTargetOpt(int) - Method in interface org.apache.calcite.util.mapping.Mappings.TargetMapping
- 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
- getTargetTable() - Method in class org.apache.calcite.sql.SqlInsert
- getTargetTable() - Method in class org.apache.calcite.sql.SqlMerge
- getTargetTable() - Method in class org.apache.calcite.sql.SqlUpdate
- getTargetTable(SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- getter - Variable in class org.apache.calcite.adapter.mongodb.MongoEnumerator
- getter(List<Map.Entry<String, Class>>) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchEnumerators
- getter(List<Map.Entry<String, Class>>) - Static method in class org.apache.calcite.adapter.mongodb.MongoEnumerator
- getterMethods - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.Bean
- 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.linq4j.DefaultQueryable
- getThis() - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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.linq4j.DefaultQueryable
- getThreadLocale() - Static method in class org.apache.calcite.runtime.Resources
-
Returns the preferred locale of the current thread, or null if the thread has not called
Resources.setThreadLocale(java.util.Locale)
. - getThreadOrDefaultLocale() - Static method in class org.apache.calcite.runtime.Resources
-
Returns the preferred locale of the current thread, or the default locale if the current thread has not called
Resources.setThreadLocale(java.util.Locale)
. - getTime() - Method in class org.apache.calcite.sql.SqlTimeLiteral
-
Converts this literal to a
TimeString
. - getTimeDateFunctions() - Static method in class org.apache.calcite.sql.SqlJdbcFunctionCall
- 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
- getTimeUnits(SqlTypeName) - Static method in class org.apache.calcite.rex.RexLiteral
-
Returns a list of the time units covered by an interval type such as HOUR TO SECOND.
- getTimeZone() - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- getTimeZoneExpression(EnumerableRelImplementor) - Method in class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverter
- getTokenImages() - Method in exception org.apache.calcite.sql.parser.SqlParseException
-
Returns the token images.
- getTokens() - Method in interface org.apache.calcite.sql.parser.SqlAbstractParserImpl.Metadata
-
Returns a list of all tokens in alphabetical order.
- getTokens() - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
- getTokenVal(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- getTopNode() - Method in class org.apache.calcite.adapter.druid.DruidQuery
- getTotalByteCodeSize() - Method in class org.apache.calcite.util.javac.JaninoCompiler.AccountingClassLoader
- 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
- 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 class org.apache.calcite.plan.RelCompositeTrait
- 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
- getTraitDef() - Method in class org.apache.calcite.rel.RelDistributions.RelDistributionImpl
- getTraitDefs() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns a list of trait definitions.
- getTraitDefs() - Method in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- 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
- 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 class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- getType() - Method in class org.apache.calcite.adapter.clone.ArrayTable.ByteStringDictionary
- getType() - Method in class org.apache.calcite.adapter.clone.ArrayTable.Constant
- getType() - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectArray
- getType() - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectDictionary
- getType() - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveArray
- getType() - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveDictionary
- getType() - Method in interface org.apache.calcite.adapter.clone.ArrayTable.Representation
-
Returns the representation type.
- getType() - Method in class org.apache.calcite.adapter.clone.ArrayTable.StringDictionary
- getType() - Method in enum org.apache.calcite.adapter.druid.Granularities.AllGranularity
- getType() - Method in class org.apache.calcite.adapter.druid.Granularities.PeriodGranularity
- getType() - Method in interface org.apache.calcite.adapter.druid.Granularity
- getType() - Method in class org.apache.calcite.adapter.file.FileRowConverter.FieldDef
- 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.jdbc.JavaTypeFactoryImpl.RecordFieldImpl
- 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 class org.apache.calcite.rel.RelDistributions.RelDistributionImpl
- 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.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.AbstractNamespace
- 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.jdbc.CalciteSchema.SchemaPlusImpl
- getType(String) - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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.
- 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 class org.apache.calcite.adapter.spark.SparkToEnumerableConverter.SparkImplementorImpl
- 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 class org.apache.calcite.jdbc.CalciteConnectionImpl.ContextImpl
- getTypeFactory() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.DataContextImpl
- getTypeFactory() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- getTypeFactory() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.SlimDataContext
- 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 class org.apache.calcite.rex.RexBuilder
-
Returns this RexBuilder's type factory
- getTypeFactory() - Method in class org.apache.calcite.schema.Schemas.DummyDataContext
- getTypeFactory() - Method in class org.apache.calcite.sql.SqlOperatorBinding
- 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.AggConverter
- 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.
- getTypeFromMetaData(String) - Static method in enum org.apache.calcite.adapter.druid.DruidType
-
Returns a DruidType matching the String from a meta data query
- getTypeFromMetric(String) - Static method in enum org.apache.calcite.adapter.druid.DruidType
-
Returns a DruidType matching the given String type from a Druid metric
- getTypeInfo(Meta.ConnectionHandle) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- getTypeList(ImmutableList<RelDataType>, List<RelDataType>) - Static method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
-
Returns a list of all atomic types in a list.
- getTypeMap() - Method in class org.apache.calcite.schema.impl.AbstractSchema
-
Returns a map of types in this schema by name.
- 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
- 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)
. - getTypeName(RelDataType) - Static method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Returns the type name in string form.
- 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.jdbc.CalciteSchema.SchemaPlusImpl
- getTypeNames() - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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
- getTypeOrdinal(RelDataType) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- getTypes() - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- 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.
- getTypeSystem() - Method in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- 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). - getUniqueFilterRefs(List<AggregateCall>) - Method in class org.apache.calcite.adapter.druid.DruidRules.DruidAggregateProjectRule
-
Returns an array of unique filter references from the given list of
AggregateCall
- 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(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(Join, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUniqueKeys(Project, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUniqueKeys(SemiJoin, RelMetadataQuery, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- getUniqueKeys(SetOp, 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(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
. - 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).
- getUpdateCall() - Method in class org.apache.calcite.sql.SqlMerge
- 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
- getUsageMap(RexInputRef) - Method in class org.apache.calcite.plan.RexImplicationChecker.InputUsageFinder
- 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
- 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.AbstractNamespace
- 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.EmptyScope
- 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
- getValue() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor.SwapResult
- getValue() - Method in class org.apache.calcite.linq4j.GroupingImpl
- 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.sql.SqlLiteral
-
Returns the value of this literal.
- getValue() - Method in class org.apache.calcite.sql.SqlSetOption
- 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
- getValue(SqlNode) - Static method in class org.apache.calcite.sql.validate.SqlUserDefinedTableMacro
- 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
- 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
- getValues() - Method in class org.apache.calcite.interpreter.Row
- 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.RelDataTypeImpl
- 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.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.
- getVariablesStopped() - Method in class org.apache.calcite.rel.AbstractRelNode
- getVariablesStopped() - Method in interface org.apache.calcite.rel.RelNode
-
Deprecated.
- getVariablesUsed(RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a set of variables used by a relational expression or its descendants.
- getVertexParents(HepRelVertex) - Method in class org.apache.calcite.plan.hep.HepPlanner
-
Retrieves the parent vertices of a vertex.
- getViewExpander() - Method in interface org.apache.calcite.tools.FrameworkConfig
-
Returns a view expander.
- getViewExpander() - Method in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- getViewPath() - Method in class org.apache.calcite.schema.impl.ViewTable
-
Returns the the path of the view.
- getViewSql() - Method in class org.apache.calcite.schema.impl.ViewTable
-
Returns the view's SQL definition.
- 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
- 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
- getWindowInOver(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getWindowList() - Method in class org.apache.calcite.sql.SqlSelect
- getWithinGroupCall(SqlCall) - Static method in class org.apache.calcite.sql.SqlFilterOperator
- getWithScope(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
- getWithScope(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- getYear() - Method in class org.apache.calcite.util.DateString
- GitCommitsTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "git log" command to discover git commits.
- GitCommitsTableFunction() - Constructor for class org.apache.calcite.adapter.os.GitCommitsTableFunction
- glob - Variable in class org.apache.calcite.util.XmlOutput
- GLOBAL_TEMPORARY - org.apache.calcite.schema.Schema.TableType
-
A global temporary table.
- GLOBAL_TEMPORARY_TABLE - org.apache.calcite.schema.Schema.TableType
-
A global temporary table.
- Glossary - Interface in org.apache.calcite.util
-
A collection of terms.
- go() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.OrderExpressionExpander
- go(List<RexNode>) - Method in class org.apache.calcite.rel.core.Match.PatternVarFinder
- go(EnumerableRel.Result) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor.TypeRegistrar
- go(MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor
-
Substitutes the query with replacement whenever possible but meanwhile keeps track of all the substitutions and their original rel before replacement, so that in later processing stage, the replacement can be recovered individually to produce a list of all possible rels with substitution in different places.
- go(MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableRelVisitor
- go(RelNode) - Method in class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor
- 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.
- go(RexCall) - Method in class org.apache.calcite.rel.core.Match.AggregateFinder
- go(RexNode) - Method in class org.apache.calcite.rel.core.Match.PatternVarFinder
- go(RexNode) - Method in class org.apache.calcite.rel.rules.JoinCommuteRule.VariableReplacer
- go(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.NavigationModifier
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A "go to" expression, such as goto Label in C# or GoTo Label in Visual Basic.
- Goto - 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. - GotoExpressionKind(String) - Constructor for enum org.apache.calcite.linq4j.tree.GotoExpressionKind
- GotoStatement - Class in org.apache.calcite.linq4j.tree
-
Represents an unconditional jump.
- GotoStatement(GotoExpressionKind, LabelTarget, Expression) - Constructor for class org.apache.calcite.linq4j.tree.GotoStatement
- grab(List<RelNode>, RexNode) - Static method in class org.apache.calcite.materialize.Lattice
-
Converts an "t1.c1 = t2.c2" expression into two (input, field) pairs.
- Granularities - Class in org.apache.calcite.adapter.druid
-
Factory methods and helpers for
Granularity
. - Granularities() - Constructor for class org.apache.calcite.adapter.druid.Granularities
- Granularities.AllGranularity - Enum in org.apache.calcite.adapter.druid
-
Implementation of
Granularity
forGranularity.Type.ALL
. - Granularities.PeriodGranularity - Class in org.apache.calcite.adapter.druid
-
Implementation of
Granularity
based on a time unit. - granularity - Variable in class org.apache.calcite.adapter.druid.TimeExtractionFunction
- 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.
- graph - Variable in class org.apache.calcite.plan.hep.HepPlanner
-
Query graph, with edges directed from parent to child.
- graph - Variable in class org.apache.calcite.util.graph.BreadthFirstIterator
- graph - Variable in class org.apache.calcite.util.graph.CycleDetector
- graph - Variable in class org.apache.calcite.util.graph.Graphs.FrozenGraph
- graph - Variable in class org.apache.calcite.util.graph.TopologicalOrderIterator
- Graphs - Class in org.apache.calcite.util.graph
-
Miscellaneous graph utilities.
- Graphs() - Constructor for class org.apache.calcite.util.graph.Graphs
- Graphs.FrozenGraph<V,E extends DefaultEdge> - Class in org.apache.calcite.util.graph
-
Immutable grap.
- graphSizeLastGC - Variable in class org.apache.calcite.plan.hep.HepPlanner
- 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 - org.apache.calcite.util.BuiltInMethod
- GREATER_THAN - org.apache.calcite.sql.SqlKind
-
The greater-than operator, ">".
- GREATER_THAN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Logical greater-than operator, '
>
'. - GREATER_THAN_OR_EQUAL - org.apache.calcite.sql.SqlKind
-
The 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 - 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 - 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 - org.apache.calcite.sql.SqlKind
-
The "GREATEST" function (Oracle).
- GREATEST - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
The "GREATEST(value, value)" function.
- GreatestConvertlet() - Constructor for class org.apache.calcite.sql2rel.StandardConvertletTable.GreatestConvertlet
- group - Variable in class org.apache.calcite.plan.hep.HepProgram
- group - Variable in class org.apache.calcite.plan.hep.HepProgramBuilder
- group - Variable in class org.apache.calcite.sql.validate.AggVisitor
-
Whether to find group functions (e.g.
- 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() - Constructor for enum org.apache.calcite.rel.core.Aggregate.Group
- Group(ImmutableBitSet, boolean, RexWindowBound, RexWindowBound, RelCollation, List<Window.RexWinAggCall>) - Constructor for class org.apache.calcite.rel.core.Window.Group
- GROUP - org.apache.calcite.piglet.Ast.Op
- GROUP - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- GROUP_BY - org.apache.calcite.adapter.druid.QueryType
- GROUP_BY - org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- GROUP_BY - org.apache.calcite.util.BuiltInMethod
- GROUP_BY_LIST - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
GROUP BY list.
- GROUP_BY_MULTIPLE - org.apache.calcite.util.BuiltInMethod
- GROUP_BY2 - org.apache.calcite.util.BuiltInMethod
- GROUP_ID - org.apache.calcite.sql.SqlKind
-
The
GROUP_ID()
function. - GROUP_ID - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
GROUP_ID()
function. - GroupAnalyzer(List<SqlNode>) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorUtil.GroupAnalyzer
- groupBy - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
-
Allows bucketing documents together.
- groupBy - Variable in class org.apache.calcite.sql.SqlSelect
- 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>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- groupBy(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- groupBy(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<T, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- groupBy(FunctionExpression<Function1<TSource, TKey>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Groups the elements of a sequence according to a specified key selector function.
- groupBy(FunctionExpression<Function1<TSource, TKey>>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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<TSource, TKey>>, FunctionExpression<Function1<TSource, TElement>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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<TSource, TKey>>, FunctionExpression<Function1<TSource, TElement>>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Groups the elements of a sequence and projects the elements for each group by using a specified function.
- groupBy(FunctionExpression<Function1<TSource, TKey>>, FunctionExpression<Function1<TSource, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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<TSource, TKey>>, FunctionExpression<Function1<TSource, TElement>>, FunctionExpression<Function2<TKey, Enumerable<TElement>, TResult>>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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_(Map<TKey, TAccumulate>, Enumerable<TSource>, Function1<TSource, TKey>, Function0<TAccumulate>, Function2<TAccumulate, TSource, TAccumulate>, Function2<TKey, TAccumulate, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- groupBy_(Set<TKey>, Enumerable<TSource>, Function1<TSource, TKey>, Function1<TKey, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- groupByFields - Variable in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- 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>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- groupByK(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- groupByK(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- groupByK(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- groupByK(FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function2<TKey, Enumerable<T>, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- groupByK(FunctionExpression<Function1<TSource, TKey>>, FunctionExpression<Function2<TKey, Enumerable<TSource>, TResult>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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<TSource, TKey>>, FunctionExpression<Function2<TKey, Enumerable<TSource>, TResult>>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Groups the elements of a sequence according to a specified key selector function and creates a result value from each group and its key.
- groupByList - Variable in class org.apache.calcite.sql.validate.GroupByScope
- 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.
- groupByMultiple_(Map<TKey, TAccumulate>, 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
- GroupByScope - Class in org.apache.calcite.sql.validate
-
Represents the name-resolution context for expressions in an GROUP BY clause.
- GroupByScope(SqlValidatorScope, SqlNodeList, SqlSelect) - Constructor for class org.apache.calcite.sql.validate.GroupByScope
- groupByScopes - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Maps a
SqlSelect
node to the scope used by its GROUP BY clause. - groupCount - Variable in class org.apache.calcite.rel.core.Aggregate.AggCallBinding
- groupCount - Variable in class org.apache.calcite.sql.validate.SqlValidatorUtil.GroupAnalyzer
- groupExprList - Variable in class org.apache.calcite.sql.validate.AggregatingSelectScope.Resolved
- groupExprProjection - Variable in class org.apache.calcite.sql.validate.AggregatingSelectScope.Resolved
- groupExprProjection - Variable in class org.apache.calcite.sql.validate.SqlValidatorUtil.GroupAnalyzer
- groupExprs - Variable in class org.apache.calcite.sql.validate.AggChecker
- groupExprs - Variable in class org.apache.calcite.sql.validate.SqlValidatorUtil.GroupAnalyzer
- groupExprs - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
-
The group-by expressions, in
SqlNode
format. - groupFinder - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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 - Variable in class org.apache.calcite.interpreter.AggregateNode.Grouping
- Grouping<K,V> - Interface in org.apache.calcite.linq4j
-
Represents a collection of objects that have a common key.
- Grouping(ImmutableBitSet) - Constructor for class org.apache.calcite.interpreter.AggregateNode.Grouping
- GROUPING - 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 - 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 - 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
- GroupingImpl<K,V> - Class in org.apache.calcite.linq4j
-
Implementation of
Grouping
. - GroupingImpl(K, Collection<V>) - Constructor for class org.apache.calcite.linq4j.GroupingImpl
- GroupingImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.GroupingImplementor
- 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.linq4j.DefaultQueryable
- groupJoin(Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, Enumerable<TInner>, TResult>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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.linq4j.DefaultQueryable
- 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.linq4j.EnumerableQueryable
- groupJoin(Enumerable<TInner>, FunctionExpression<Function1<TSource, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<TSource, Enumerable<TInner>, TResult>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Correlates the elements of two sequences based on key equality and groups the results.
- groupJoin(Enumerable<TInner>, FunctionExpression<Function1<TSource, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<TSource, Enumerable<TInner>, TResult>>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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<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.prepare.QueryableRelBuilder
- 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, ImmutableList<ImmutableBitSet>) - Method in class org.apache.calcite.tools.RelBuilder
- 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.
- groupKey_(Iterable<? extends RexNode>, boolean, Iterable<? extends Iterable<? extends RexNode>>) - Method in class org.apache.calcite.tools.RelBuilder
- groupKey_(ImmutableBitSet, boolean, ImmutableList<ImmutableBitSet>) - Method in class org.apache.calcite.tools.RelBuilder
- GroupKeyImpl(ImmutableList<RexNode>, boolean, ImmutableList<ImmutableList<RexNode>>, String) - Constructor for class org.apache.calcite.tools.RelBuilder.GroupKeyImpl
- GroupOption() - Constructor for enum org.apache.calcite.tools.PigRelBuilder.GroupOption
- groups - Variable in class org.apache.calcite.interpreter.AggregateNode
- 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.logical.LogicalWindow.WindowKey
- 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.EnumerableAggregate.AggContextImpl
- GroupStmt(SqlParserPos, Ast.Identifier, Ast.Identifier, List<Ast.Node>) - Constructor for class org.apache.calcite.piglet.Ast.GroupStmt
- groupValue(ImmutableBitSet, ImmutableBitSet) - Static method in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
- GroupValue(String, Map<String, Object>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.GroupValue
- gt - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- gt(boolean, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
>
operator applied to boolean values. - gt(Object) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- gt(String, 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(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- gt(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- gt(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- gt(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
>
operator applied to ByteString values. - GT - org.apache.calcite.piglet.Ast.Op
- 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 - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- gte(Object) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- gte(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- gte(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- gte(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- GTE - org.apache.calcite.piglet.Ast.Op
- guaranteed - Variable in class org.apache.calcite.plan.hep.HepInstruction.ConverterRules
- guessDescription(String) - Static method in class org.apache.calcite.plan.RelOptRule
-
Deduces a name for a rule by taking the name of its class and returning the segment after the last '.' or '$'.
- 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.
- guessSubset() - Method in class org.apache.calcite.plan.volcano.VolcanoRuleMatch
-
Returns a guess as to which subset (that is equivalence class of relational expressions combined with a set of physical traits) the result of this rule will belong to.
- guessType(Object) - Method in class org.apache.calcite.rex.RexBuilder
H
- H2 - org.apache.calcite.sql.SqlDialect.DatabaseProduct
- 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.
- handle(String) - Method in class org.apache.calcite.adapter.csv.CsvStreamReader.CsvContentListener
- 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
- handleGetObject(String) - Method in class org.apache.calcite.runtime.Resources.ShadowResourceBundle
- handleJavaObjectEntry(List<RelDataTypeField>, Object) - Static method in class org.apache.calcite.adapter.geode.util.GeodeUtils
- handleNull(Expression, RexImpTable.NullAs) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Adapts an expression with "normal" result to one that adheres to this particular policy.
- handleNullUnboxingIfNecessary(Expression, RexImpTable.NullAs, Type) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- handleOffsetFetch(SqlNode, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- handlePdxInstanceEntry(List<RelDataTypeField>, Object) - Static method in class org.apache.calcite.adapter.geode.util.GeodeUtils
- 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
- handlerMap - Variable in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
- handlerMap - Variable in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider.Space
- handlers - Variable in enum org.apache.calcite.runtime.Hook
- handlers(MetadataDef<M>) - Method in class org.apache.calcite.plan.hep.HepRelMetadataProvider
- handlers(MetadataDef<M>) - Method in class org.apache.calcite.plan.volcano.VolcanoRelMetadataProvider
- handlers(MetadataDef<M>) - Method in class org.apache.calcite.rel.metadata.CachingRelMetadataProvider
- handlers(MetadataDef<M>) - Method in class org.apache.calcite.rel.metadata.ChainedRelMetadataProvider
- handlers(MetadataDef<M>) - Method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- handlers(MetadataDef<M>) - Method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
- handlers(MetadataDef<M>) - Method in interface org.apache.calcite.rel.metadata.RelMetadataProvider
- HANDLERS - Static variable in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
-
Cache of pre-generated handlers by provider and kind of metadata.
- handleScalarSubQuery(SqlSelect, SqlSelect, List<SqlNode>, Set<String>, List<Map.Entry<String, RelDataType>>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Processes SubQuery found in Select list.
- handleStructEntry(List<RelDataTypeField>, Object) - Static method in class org.apache.calcite.adapter.geode.util.GeodeUtils
- handleUnresolvedFunction(SqlCall, SqlFunction, 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, SqlFunction, List<RelDataType>, List<String>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- harmonize(RexToLixTranslator, List<RexNode>) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
-
Ensures that operands have identical type.
- has(Collection<RelDecorrelator.CorDef>, RelDecorrelator.CorRef) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Returns whether a
CorrelationId
is satisfied by at least one of a collection ofRelDecorrelator.CorDef
s. - hasAll(Collection<RelDecorrelator.CorRef>, Collection<RelDecorrelator.CorDef>) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Returns whether all of a collection of
RelDecorrelator.CorRef
s are satisfied by at least one of a collection ofRelDecorrelator.CorDef
s. - hasAllFactors(LoptJoinTree, BitSet) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Returns true if a join tree contains all factors required
- hasAllocations() - Method in class org.apache.calcite.util.CompoundClosableAllocation
- hasAmbiguousUnresolvedStar(RelDataType, RelDataTypeField, String) - Method in class org.apache.calcite.sql.validate.DelegatingScope
-
Returns whether
rowType
contains more than one star column. - hasAssignment() - Method in class org.apache.calcite.sql.SqlCallBinding
-
Returns whether arguments have name assignment.
- hasCollectionField(RelDataType) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
- hasCorrelation() - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMap
-
Returns whether there are any correlating variables in this statement.
- hasDefault - Variable in class org.apache.calcite.runtime.Resources.Prop
- hasDefault() - Method in class org.apache.calcite.runtime.Resources.Prop
- 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.
- hasFilter() - Method in class org.apache.calcite.rel.core.Aggregate.AggCallBinding
- hasFilter() - Method in class org.apache.calcite.rel.core.AggregateCall
-
Returns true if and only if 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.linq4j.tree.BlockStatement
-
Cache the hash code for the expression
- hash - Variable in class org.apache.calcite.linq4j.tree.ConstructorDeclaration
-
Cache the hash code for the expression
- hash - Variable in class org.apache.calcite.linq4j.tree.ForStatement
-
Cache the hash code for the expression
- hash - Variable in class org.apache.calcite.linq4j.tree.FunctionExpression
-
Cache the hash code for the expression
- hash - Variable in class org.apache.calcite.linq4j.tree.MethodCallExpression
-
Cache the hash code for the expression
- hash - Variable in class org.apache.calcite.linq4j.tree.NewArrayExpression
-
Cache the hash code for the expression
- hash - Variable in class org.apache.calcite.linq4j.tree.NewExpression
-
Cache the hash code for the expression
- 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.Use
Objects.hash(Object...)
- 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.Use
Objects.hash(Object...)
- 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 - org.apache.calcite.util.BuiltInMethod
- HASH_DISTRIBUTED - 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.
- hashArray(int, Object[]) - Static method in class org.apache.calcite.util.Util
-
Deprecated.Use
Objects.hash(Object...)
- hashCode - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.RowKey
- hashCode() - Method in class org.apache.calcite.adapter.druid.DruidQuery.QuerySpec
- hashCode() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Aggregations
- hashCode() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.RowKey
- hashCode() - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
- 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.EnumerableDefaults.Wrapped
- hashCode() - Method in class org.apache.calcite.linq4j.GroupingImpl
- 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.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.LatticeSuggester.StepRef
- hashCode() - Method in class org.apache.calcite.materialize.LatticeSuggester.TableRef
- hashCode() - Method in class org.apache.calcite.materialize.LatticeTable
- hashCode() - Method in class org.apache.calcite.materialize.MaterializationActor.QueryKey
- hashCode() - Method in class org.apache.calcite.materialize.MaterializationKey
- hashCode() - Method in class org.apache.calcite.materialize.Path
- hashCode() - Method in class org.apache.calcite.materialize.Step
- hashCode() - Method in class org.apache.calcite.materialize.TileKey
- hashCode() - Method in class org.apache.calcite.plan.hep.HepRelMetadataProvider
- hashCode() - Method in class org.apache.calcite.plan.RelCompositeTrait
- 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.VolcanoCost
- hashCode() - Method in class org.apache.calcite.plan.volcano.VolcanoRelMetadataProvider
- 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.profile.ProfilerImpl.Space
- hashCode() - Method in class org.apache.calcite.profile.SimpleProfiler.Space
- 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.Window.Group
- hashCode() - Method in class org.apache.calcite.rel.core.Window.RexWinAggCall
- hashCode() - Method in class org.apache.calcite.rel.logical.LogicalWindow.WindowKey
- 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.JaninoRelMetadataProvider.Key
- 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.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.MutableSemiJoin
- 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.RelDistributions.RelDistributionImpl
- hashCode() - Method in class org.apache.calcite.rel.RelFieldCollation
- hashCode() - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.Key
- 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.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.RexRangeRef
- 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.rex.RexWindowBound.RexWindowBoundBounded
- hashCode() - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundCurrentRow
- hashCode() - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundUnbounded
- hashCode() - Method in class org.apache.calcite.runtime.ConsList
- hashCode() - Method in class org.apache.calcite.runtime.FlatLists.ComparableEmptyList
- 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.Resources.Inst
- hashCode() - Method in class org.apache.calcite.schema.impl.LongSchemaVersion
- hashCode() - Method in class org.apache.calcite.schema.Schemas.PathImpl
- hashCode() - Method in class org.apache.calcite.sql.parser.SqlParserPos
- 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.SqlOperator
- 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.sql2rel.RelDecorrelator.CorDef
- hashCode() - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMap
- hashCode() - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorRef
- hashCode() - Method in class org.apache.calcite.tools.RuleSets.ListRuleSet
- 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.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.Use
Boolean.hashCode(boolean)
- hashCode(double) - Static method in class org.apache.calcite.runtime.Utilities
-
Deprecated.Use
Double.hashCode(double)
- hashCode(double) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- hashCode(float) - Static method in class org.apache.calcite.runtime.Utilities
-
Deprecated.Use
Float.hashCode(float)
- hashCode(long) - Static method in class org.apache.calcite.runtime.Utilities
-
Deprecated.Use
Long.hashCode(long)
- hashCode(Object) - Method in class org.apache.calcite.linq4j.function.Functions.IdentityEqualityComparer
- hashCode(Object[]) - Method in class org.apache.calcite.linq4j.function.Functions.ArrayEqualityComparer
- hashCode(T) - Method in interface org.apache.calcite.linq4j.function.EqualityComparer
- hashCode(T) - Method in class org.apache.calcite.linq4j.function.Functions.SelectorEqualityComparer
- 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
- hasLeftChild(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule
- hasMultipleValues - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonColumn
- hasNestedAggregations(LogicalAggregate) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
- hasNext - Variable in class org.apache.calcite.linq4j.Linq4j.EnumeratorIterator
- hasNext() - Method in class org.apache.calcite.adapter.elasticsearch.Scrolling.AutoClosingIterator
- hasNext() - Method in class org.apache.calcite.adapter.file.FileReader.FileReaderIterator
- hasNext() - Method in class org.apache.calcite.jdbc.CalciteMetaImpl.LimitIterator
- hasNext() - Method in class org.apache.calcite.linq4j.Linq4j.EnumeratorIterator
- hasNext() - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference.ExprsItr
- hasNext() - Method in class org.apache.calcite.util.ChunkList.ChunkListIterator
- 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
- hasNext() - Method in class org.apache.calcite.util.ImmutableIntList.AbstractIndexedListIterator
- hasNext() - Method in class org.apache.calcite.util.mapping.Mappings.FunctionMappingIter
- hasNext() - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping.MappingItr
- hasNext() - Method in class org.apache.calcite.util.Pair.AdjacentIterator
- hasNext() - Method in class org.apache.calcite.util.Pair.FirstAndIterator
- hasNext() - Method in class org.apache.calcite.util.Pair.LeftIterator
- hasNext() - Method in class org.apache.calcite.util.Pair.RightIterator
- hasNext() - Method in class org.apache.calcite.util.Pair.ZipIterator
- hasNext() - Method in class org.apache.calcite.util.Util.FilteringIterator
- hasNoAggregations() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Bucket
-
Means current bucket has no aggregations.
- hasNull(ImmutableBitSet) - Method in class org.apache.calcite.profile.SimpleProfiler.Run
- hasOrderBy() - Method in class org.apache.calcite.sql.SqlSelect
- hasOrderedCall(List<AggImpState>) - Static method in class org.apache.calcite.adapter.enumerable.EnumerableAggregate
- hasPrevious() - Method in class org.apache.calcite.util.ChunkList.ChunkListIterator
- hasPrevious() - Method in class org.apache.calcite.util.ImmutableIntList.AbstractIndexedListIterator
- hasRightChild(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinProjectTransposeRule
- hasRightChild(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule
- hasRows - Variable in class org.apache.calcite.adapter.enumerable.impl.WinAggResetContextImpl
- 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.
- hasSortedPrefix(SelectScope, SqlNodeList) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Returns whether the prefix is sorted.
- hasTimeZone - Variable in class org.apache.calcite.sql.SqlAbstractDateTimeLiteral
- hasVariable(String) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- hasWhere() - Method in class org.apache.calcite.sql.SqlSelect
- hasWithinGroupCall(SqlCall) - Static method in class org.apache.calcite.sql.SqlFilterOperator
- having - Variable in class org.apache.calcite.sql.SqlSelect
- HAVING - org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- HAVING - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- HAVING_OPERAND - Static variable in class org.apache.calcite.sql.SqlSelect
- havingExpr - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.ExtendedExpander
- 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.
- HEADER_SIZE - Static variable in class org.apache.calcite.util.ChunkList
- HEADERS - org.apache.calcite.adapter.os.SqlShell.Format
- headings - Variable in class org.apache.calcite.adapter.file.FileReader
- height - Variable in class org.apache.calcite.example.maze.Maze
- height - Variable in class org.apache.calcite.example.maze.MazeTable
- help(DataContext, BindableRel) - Static method in class org.apache.calcite.interpreter.Bindables
-
Helper method that converts a bindable relational expression into a record iterator.
- Helper() - Constructor for class org.apache.calcite.util.SaffronProperties.Helper
- 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.
- HepInstruction - Class in org.apache.calcite.plan.hep
-
HepInstruction represents one instruction in a HepProgram.
- HepInstruction() - Constructor for class org.apache.calcite.plan.hep.HepInstruction
- HepInstruction.BeginGroup - Class in org.apache.calcite.plan.hep
-
Instruction that begins a group.
- HepInstruction.CommonRelSubExprRules - Class in org.apache.calcite.plan.hep
-
Instruction that finds common relational sub-expressions.
- HepInstruction.ConverterRules - Class in org.apache.calcite.plan.hep
-
Instruction that executes converter rules.
- HepInstruction.EndGroup - Class in org.apache.calcite.plan.hep
-
Instruction that ends a group.
- HepInstruction.MatchLimit - Class in org.apache.calcite.plan.hep
-
Instruction that sets match limit.
- HepInstruction.MatchOrder - Class in org.apache.calcite.plan.hep
-
Instruction that sets match order.
- HepInstruction.RuleClass<R extends RelOptRule> - Class in org.apache.calcite.plan.hep
-
Instruction that executes all rules of a given class.
- HepInstruction.RuleCollection - Class in org.apache.calcite.plan.hep
-
Instruction that executes all rules in a given collection.
- HepInstruction.RuleInstance - Class in org.apache.calcite.plan.hep
-
Instruction that executes a given rule.
- HepInstruction.Subprogram - Class in org.apache.calcite.plan.hep
-
Instruction that executes a sub-program.
- HepMatchOrder - Enum in org.apache.calcite.plan.hep
-
HepMatchOrder specifies the order of graph traversal when looking for rule matches.
- HepMatchOrder() - Constructor for enum org.apache.calcite.plan.hep.HepMatchOrder
- 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
. - HepProgram(List<HepInstruction>) - Constructor for class org.apache.calcite.plan.hep.HepProgram
-
Creates a new empty HepProgram.
- 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.
- HepRelMetadataProvider - Class in org.apache.calcite.plan.hep
-
HepRelMetadataProvider implements the
RelMetadataProvider
interface by combining metadata from the rels inside of aHepRelVertex
. - HepRelMetadataProvider() - Constructor for class org.apache.calcite.plan.hep.HepRelMetadataProvider
- HepRelVertex - Class in org.apache.calcite.plan.hep
-
HepRelVertex wraps a real
RelNode
as a vertex in a DAG representing the entire query expression. - HepRelVertex(RelNode) - Constructor for class org.apache.calcite.plan.hep.HepRelVertex
- HepRuleCall - Class in org.apache.calcite.plan.hep
-
HepRuleCall implements
RelOptRuleCall
for aHepPlanner
. - HepRuleCall(RelOptPlanner, RelOptRuleOperand, RelNode[], Map<RelNode, List<RelNode>>, List<RelNode>) - Constructor for class org.apache.calcite.plan.hep.HepRuleCall
- 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). - HEXITS - Static variable in class org.apache.calcite.sql.SqlDialect
- HIERARCHY_TABLE - org.apache.calcite.schema.Schema.TableType
-
A hierarchy table.
- HIGH - org.apache.calcite.config.NullCollation
-
Nulls first for DESC, nulls last for ASC.
- highest() - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- HighestUsageFinder(RexNode[], int[]) - Constructor for class org.apache.calcite.rel.rules.CalcRelSplitter.HighestUsageFinder
- HINT_TOKEN - Static variable in class org.apache.calcite.sql.advise.SqlAdvisor
- hintToken - Variable in class org.apache.calcite.sql.advise.SqlSimpleParser
- hintToken - Variable in class org.apache.calcite.sql.advise.SqlSimpleParser.Tokenizer
- 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. - HistogramShuttle(List<RexNode>, ImmutableList<RexFieldCollation>, RexWindowBound, RexWindowBound, SqlWindow, boolean) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.HistogramShuttle
- history - Variable in class org.apache.calcite.model.JsonStream
-
Whether the history of the table is available.
- hits - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Result
- hits - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHits
- hits - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult
- hits - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHits
- hits() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHits
- hits() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHits
- HIVE - 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.
- HllCollector(ProfilerImpl.Space) - Constructor for class org.apache.calcite.profile.ProfilerImpl.HllCollector
- HllCompositeCollector(ProfilerImpl.Space, int[]) - Constructor for class org.apache.calcite.profile.ProfilerImpl.HllCompositeCollector
- HllSingletonCollector(ProfilerImpl.Space, int) - Constructor for class org.apache.calcite.profile.ProfilerImpl.HllSingletonCollector
- hms(int, int, int) - Static method in class org.apache.calcite.util.TimeString
-
Validates an hour-minute-second value and converts to a string.
- hms(StringBuilder, int, int, int) - Static method in class org.apache.calcite.util.DateTimeStringUtils
-
Appends hour:minute:second to a buffer; assumes they are valid.
- holder - Variable in class org.apache.calcite.rel.type.DynamicRecordTypeImpl
- 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.
- Holder(RelDataType, MutableRel) - Constructor for class org.apache.calcite.rel.mutable.Holder
- HOLDER - org.apache.calcite.rel.mutable.MutableRelType
- hook - Variable in class org.apache.calcite.adapter.cassandra.CassandraSchema
- 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() - Constructor for enum org.apache.calcite.runtime.Hook
- Hook.Closeable - Interface in org.apache.calcite.runtime
-
Removes a Hook after use.
- Hop(LatticeSuggester.BaseColRef, LatticeSuggester.BaseColRef) - Constructor for class org.apache.calcite.materialize.LatticeSuggester.Hop
- HOP - org.apache.calcite.sql.SqlKind
-
The
HOP
group function. - HOP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
HOP
group function. - HOP_END - 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_START - 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. - hops - Variable in class org.apache.calcite.materialize.LatticeSuggester.Frame
- horizontal - Variable in class org.apache.calcite.example.maze.Maze
- HOUR - org.apache.calcite.adapter.druid.Granularity.Type
- HOUR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
HOUR
operator. - HOUR_MINUTE_SECOND_PATTERN - Static variable in class org.apache.calcite.adapter.os.PsTableFunction
- hr - Variable in class org.apache.calcite.benchmarks.StatementTest.HrConnection
- HrConnection() - Constructor for class org.apache.calcite.benchmarks.StatementTest.HrConnection
- HrPreparedStatement() - Constructor for class org.apache.calcite.benchmarks.StatementTest.HrPreparedStatement
- HrSchema() - Constructor for class org.apache.calcite.benchmarks.StatementTest.HrSchema
- HSQLDB - org.apache.calcite.sql.SqlDialect.DatabaseProduct
- 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.
- HTML_ESCAPER - Static variable in class org.apache.calcite.util.XmlOutput.StringEscaper
- HttpFunction(RestClient) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport.HttpFunction
- HttpServer - Class in org.apache.calcite.adapter.spark
-
An HTTP server for static content used to allow worker nodes to access JARs.
- HttpServer(File) - Constructor for class org.apache.calcite.adapter.spark.HttpServer
- HttpUtils - Class in org.apache.calcite.runtime
-
Utilities for connecting to REST services such as Splunk via HTTP.
- HttpUtils() - Constructor for class org.apache.calcite.runtime.HttpUtils
- HUGE - Static variable in class org.apache.calcite.plan.volcano.VolcanoCost
- 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.
- HYDE - org.apache.calcite.sql.SqlWriter.SubQueryStyle
-
Julian's style of sub-query nesting.
- HYPER_UNIQUE - org.apache.calcite.adapter.druid.DruidType
I
- i - Variable in class org.apache.calcite.adapter.clone.ArrayTable.Content.ArrayEnumerator
- i - Variable in class org.apache.calcite.adapter.clone.ArrayTable.Content.ObjectEnumerator
- i - Variable in class org.apache.calcite.jdbc.CalciteMetaImpl.LimitIterator
- i - Variable in class org.apache.calcite.linq4j.Linq4j.ListEnumerator
- i - Variable in class org.apache.calcite.linq4j.Linq4j.SingletonEnumerator
- i - Variable in class org.apache.calcite.linq4j.Linq4j.SingletonNullEnumerator
- i - Variable in class org.apache.calcite.linq4j.Ord
- i - Variable in class org.apache.calcite.sql.validate.SqlValidatorScope.Step
- i - Variable in class org.apache.calcite.util.mapping.Mappings.FunctionMappingIter
- i - Variable in class org.apache.calcite.util.mapping.Mappings.PartialMapping.MappingItr
- id - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonSegmentMetadata
- id - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHit
- id - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHit
- id - Variable in class org.apache.calcite.benchmarks.StatementTest.HrConnection
- id - Variable in class org.apache.calcite.materialize.Path
- id - Variable in class org.apache.calcite.piglet.Ast.FieldSchema
- id - Variable in class org.apache.calcite.plan.RelOptRuleCall
- id - Variable in class org.apache.calcite.plan.volcano.RelSet
- id - Variable in class org.apache.calcite.rel.AbstractRelNode
-
unique id of this object -- for debugging
- id - Variable in class org.apache.calcite.rel.core.CorrelationId
- id - Variable in class org.apache.calcite.rel.rules.LoptJoinTree.Leaf
- id - Variable in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.Vertex
- 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.IdentifierNamespace
- id - Variable in class org.apache.calcite.sql.validate.SqlIdentifierMoniker
- id - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.IdInfo
- id - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.CorrelationUse
- id - Variable in class org.apache.calcite.tools.RelBuilder.Shifter
- id() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHit
-
Returns id of this hit (usually document id)
- id() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHit
-
Returns 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 - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
-
identifier, or indeed any miscellaneous sequence of characters
- ID - Static variable in interface org.apache.calcite.adapter.elasticsearch.ElasticsearchConstants
- identifier - Variable in class org.apache.calcite.sql.validate.SqlQualified
- identifier(String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- identifier(String) - Method in interface org.apache.calcite.sql.SqlWriter
-
Prints an identifier, quoting as necessary.
- 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(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 - org.apache.calcite.piglet.Ast.Op
- IDENTIFIER - org.apache.calcite.sql.SqlKind
-
Identifier
- IDENTIFIER - 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
- identifierList(List<String>) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Converts a list of names expressions to a list of single-part
SqlIdentifier
s. - identifierMaxLength - Variable in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- identifierMaxLength - Variable in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- identifierMaxLength() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- identifierMaxLength() - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- IdentifierNamespace - Class in org.apache.calcite.sql.validate
-
Namespace whose contents are defined by the type of an
identifier
. - IdentifierNamespace(SqlValidatorImpl, SqlIdentifier, SqlNodeList, SqlNode, SqlValidatorScope) - Constructor for class org.apache.calcite.sql.validate.IdentifierNamespace
-
Creates an IdentifierNamespace.
- IdentifierNamespace(SqlValidatorImpl, SqlNode, SqlNode, SqlValidatorScope) - Constructor for class org.apache.calcite.sql.validate.IdentifierNamespace
- identifierNeedsToBeQuoted(String) - Method in class org.apache.calcite.sql.SqlDialect
-
Returns whether a given identifier needs to be quoted.
- identifierQuoteString - Variable in class org.apache.calcite.sql.SqlDialect.ContextImpl
- identifierQuoteString - Variable in class org.apache.calcite.sql.SqlDialect
- identifierQuoteString - Variable in class org.apache.calcite.sql.SqlUtil.DatabaseMetaDataInvocationHandler
- identifierQuoteString() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- identifierQuoteString() - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- 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.schema.Schemas
- 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 - org.apache.calcite.util.BuiltInMethod
- IDENTITY_COMPARER - Static variable in class org.apache.calcite.linq4j.function.Functions
- IDENTITY_SELECTOR - org.apache.calcite.util.BuiltInMethod
- identityArray(int) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter
- identityComparer() - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns an
EqualityComparer
that uses object identity and hash code. - IdentityEqualityComparer() - Constructor for class org.apache.calcite.linq4j.function.Functions.IdentityEqualityComparer
- identityList(int) - Static method in class org.apache.calcite.adapter.csv.CsvEnumerator
-
Returns an array of integers {0, ..., n - 1}.
- identityList(int) - Static method in class org.apache.calcite.adapter.file.FileEnumerator
-
Returns an array of integers {0, ..., n - 1}.
- identityMap(int) - Static method in class org.apache.calcite.sql2rel.RelDecorrelator
- 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
- IdInfo(SqlValidatorScope, SqlIdentifier) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.IdInfo
- idPositions - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Maps ParsePosition strings to the
SqlIdentifier
identifier objects at these positions - IdToken(SqlSimpleParser.TokenType, String) - Constructor for class org.apache.calcite.sql.advise.SqlSimpleParser.IdToken
- 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.
- 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() - Constructor for class org.apache.calcite.linq4j.function.Functions.Ignore
- IGNORE - Static variable in interface org.apache.calcite.util.Litmus
-
Implementation of
Litmus
that returns a status code but does not throw. - IGNORE_TOKENS - Static variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.AggregationsDeserializer
- 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.
- ignoreCast - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- IGNORED - 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.
- ignorePcdata - Variable in class org.apache.calcite.util.XmlOutput
- 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.
- illegalArgumentForTableFunctionCall(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalBinaryString(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalColon() - 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
- 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
- IllegalForwardRefException() - Constructor for exception org.apache.calcite.rex.RexUtil.ForwardRefFinder.IllegalForwardRefException
- illegalFromEmpty() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalIntervalLiteral(String, String) - 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
- illegalMinusDate() - Method in interface org.apache.calcite.runtime.CalciteResource
- illegalMixingOfTypes() - 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
- IMMEDIATELY_PRECEDES - org.apache.calcite.sql.SqlKind
-
The "IMMEDIATELY PRECEDES" operator for periods.
- IMMEDIATELY_PRECEDES - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IMMEDIATELY_SUCCEEDS - org.apache.calcite.sql.SqlKind
-
The "IMMEDIATELY SUCCEEDS" operator for periods.
- IMMEDIATELY_SUCCEEDS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ImmutableBitSet - Class in org.apache.calcite.util
-
An immutable list of bits.
- ImmutableBitSet(long[]) - Constructor for class org.apache.calcite.util.ImmutableBitSet
-
Private constructor.
- ImmutableBitSet.Builder - Class in org.apache.calcite.util
-
Builder.
- ImmutableBitSet.Closure - Class in org.apache.calcite.util
-
Setup equivalence Sets for each position.
- ImmutableBitSet.Rebuilder - Class in org.apache.calcite.util
-
Refinement of
ImmutableBitSet.Builder
that remembers its originalImmutableBitSet
and tries to use it whenImmutableBitSet.Rebuilder.build()
is called. - 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. - ImmutableIntList(int...) - Constructor for class org.apache.calcite.util.ImmutableIntList
- ImmutableIntList.AbstractIndexedListIterator<E> - Class in org.apache.calcite.util
-
Extension to
UnmodifiableListIterator
that operates by index. - ImmutableIntList.EmptyImmutableIntList - Class in org.apache.calcite.util
-
Special sub-class of
ImmutableIntList
that is always empty and has only one instance. - ImmutableNullableList<E> - Class in org.apache.calcite.util
-
An immutable list that may contain null values.
- ImmutableNullableList(E[]) - Constructor for class org.apache.calcite.util.ImmutableNullableList
- ImmutableNullableList.Builder<E> - Class in org.apache.calcite.util
-
A builder for creating immutable nullable list instances.
- impatient - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
If true, and if
VolcanoPlanner.ambitious
is true, the planner waits a finite number of iterations for the cost to improve. - 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(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.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.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.EnumerableJoin
- 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.EnumerableMergeJoin
- 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.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.EnumerableSemiJoin
- 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.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.EnumerableThetaJoin
- 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.FileTableScan
- 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.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, 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, List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.BinaryImplementor
- implement(RexToLixTranslator, RexCall, List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.CastImplementor
- implement(RexToLixTranslator, RexCall, List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.DatetimeArithmeticImplementor
- implement(RexToLixTranslator, RexCall, List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.ExtractImplementor
- implement(RexToLixTranslator, RexCall, List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.FloorImplementor
- implement(RexToLixTranslator, RexCall, List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.MethodImplementor
- implement(RexToLixTranslator, RexCall, List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.MethodNameImplementor
- implement(RexToLixTranslator, RexCall, List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.NotImplementor
- implement(RexToLixTranslator, RexCall, List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.ReinterpretImplementor
- implement(RexToLixTranslator, RexCall, List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.TrimImplementor
- implement(RexToLixTranslator, RexCall, List<Expression>) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.UnaryImplementor
- implement(RexToLixTranslator, RexCall, RexImpTable.NullAs) - Method in interface org.apache.calcite.adapter.enumerable.CallImplementor
-
Implements a call.
- implement(RexToLixTranslator, RexCall, RexImpTable.NullAs) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.CaseImplementor
- implement(RexToLixTranslator, RexCall, RexImpTable.NullAs) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.CastOptimizedImplementor
- implement(RexToLixTranslator, RexCall, RexImpTable.NullAs) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.CoalesceImplementor
- implement(RexToLixTranslator, RexCall, RexImpTable.NullAs) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.IsXxxImplementor
- implement(RexToLixTranslator, RexCall, RexImpTable.NullAs) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.ItemImplementor
- implement(RexToLixTranslator, RexCall, RexImpTable.NullAs) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.SystemFunctionImplementor
- implement(RexToLixTranslator, RexCall, RexImpTable.NullAs) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.ValueConstructorImplementor
- 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(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
- 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.BindableJoin
- 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(List<AggImpState>, BlockBuilder, Function<BlockBuilder, WinAggFrameResultContext>, Function<AggImpState, List<RexNode>>, DeclarationStatement) - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindow
- 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.FirstLastValueImplementor
- implementAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.GroupingImplementor
- implementAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.JsonArrayAggImplementor
- implementAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.JsonObjectAggImplementor
- implementAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.LeadLagImplementor
- implementAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.NthValueImplementor
- implementAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.NtileImplementor
- implementAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.SingleValueImplementor
- implementAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- implementCall(RexToLixTranslator, RexCall, NotNullImplementor, RexImpTable.NullAs) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- 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.EnumerableAggregate
-
Implements the
AggregateLambdaFactory
. - implementNotNullAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.CollectImplementor
- implementNotNullAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.CountImplementor
- implementNotNullAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.FusionImplementor
- implementNotNullAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.MinMaxImplementor
- implementNotNullAdd(AggContext, AggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.SumImplementor
- 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.RexImpTable.CountWinImplementor
- implementNotNullAdd(WinAggContext, WinAggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.RankImplementor
- implementNotNullAdd(WinAggContext, WinAggAddContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.RowNumberImplementor
- implementNotNullAdd(WinAggContext, WinAggAddContext) - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- implementNotNullReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.CollectImplementor
- implementNotNullReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.FusionImplementor
- implementNotNullReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.MinMaxImplementor
- implementNotNullReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.SumImplementor
- 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.SumImplementor
- 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.RexImpTable.CountWinImplementor
- implementNotNullResult(WinAggContext, WinAggResultContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.RankImplementor
- implementNotNullResult(WinAggContext, WinAggResultContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.RowNumberImplementor
- implementNotNullResult(WinAggContext, WinAggResultContext) - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- implementNullSemantics(RexToLixTranslator, RexCall, RexImpTable.NullAs, NullPolicy, NotNullImplementor) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- implementNullSemantics0(RexToLixTranslator, RexCall, RexImpTable.NullAs, NullPolicy, boolean, NotNullImplementor) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- implementor - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- implementor - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.NotImplementor
- implementor - Variable in class org.apache.calcite.adapter.spark.SparkToEnumerableConverter.SparkImplementorImpl
- implementor - Variable in class org.apache.calcite.schema.impl.ScalarFunctionImpl
- implementor - Variable in class org.apache.calcite.schema.impl.TableFunctionImpl
- implementor() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.BaseContext
- implementor() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- 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.mongodb.MongoRel.Implementor
- Implementor() - Constructor for class org.apache.calcite.adapter.pig.PigRel.Implementor
- Implementor(RexBuilder) - Constructor for class org.apache.calcite.adapter.spark.SparkRel.Implementor
- IMPLEMENTOR - Static variable in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction
- IMPLEMENTOR - Static variable in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction2
- implementRecurse(RexToLixTranslator, List<RexNode>, RexImpTable.NullAs) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.CoalesceImplementor
- implementRecurse(RexToLixTranslator, RexCall, RexImpTable.NullAs, int) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.CaseImplementor
- 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.FirstLastValueImplementor
- implementReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.GroupingImplementor
- implementReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.JsonArrayAggImplementor
- implementReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.JsonObjectAggImplementor
- implementReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.LeadLagImplementor
- implementReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.NthValueImplementor
- implementReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.NtileImplementor
- implementReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.SingleValueImplementor
- implementReset(AggContext, AggResetContext) - Method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- implementResult(List<AggImpState>, BlockBuilder, Function<BlockBuilder, WinAggFrameResultContext>, Function<AggImpState, List<RexNode>>, boolean) - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindow
- 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.FirstLastValueImplementor
- implementResult(AggContext, AggResultContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.GroupingImplementor
- implementResult(AggContext, AggResultContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.JsonArrayAggImplementor
- implementResult(AggContext, AggResultContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.JsonObjectAggImplementor
- implementResult(AggContext, AggResultContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.LeadLagImplementor
- implementResult(AggContext, AggResultContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.NthValueImplementor
- implementResult(AggContext, AggResultContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.NtileImplementor
- implementResult(AggContext, AggResultContext) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.SingleValueImplementor
- 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
- ImplementTester(CalcRelSplitter.RelType) - Constructor for class org.apache.calcite.rel.rules.CalcRelSplitter.ImplementTester
- IMPLICIT - org.apache.calcite.sql.SqlCollation.Coercibility
- IMPLICIT - Static variable in class org.apache.calcite.sql.SqlCollation
- implicitCollation - Variable in class org.apache.calcite.adapter.cassandra.CassandraFilter
- implicitFieldCollations - Variable in class org.apache.calcite.adapter.cassandra.CassandraFilter
- implicitFieldCollations - Variable in class org.apache.calcite.adapter.cassandra.CassandraFilter.Translator
- implicitFunctionCache - Variable in class org.apache.calcite.jdbc.CachingCalciteSchema
- implicitSubSchemaCache - Variable in class org.apache.calcite.jdbc.CachingCalciteSchema
- implicitTableCache - Variable in class org.apache.calcite.jdbc.CachingCalciteSchema
- implicitTypeCache - Variable in class org.apache.calcite.jdbc.CachingCalciteSchema
- implies(RexNode, RexNode) - Method in class org.apache.calcite.plan.RexImplicationChecker
-
Checks if condition first implies (⇒) condition second.
- implies2(RexNode, RexNode) - Method in class org.apache.calcite.plan.RexImplicationChecker
-
Returns whether the predicate
first
(not a conjunction) impliessecond
. - impliesAny(RexNode, List<RexNode>) - Method in class org.apache.calcite.plan.RexImplicationChecker
-
Returns whether the predicate
first
implies (⇒) at least one predicate inseconds
. - impliesConjunction(RexNode, RexNode) - Method in class org.apache.calcite.plan.RexImplicationChecker
-
Returns whether the predicate
first
impliessecond
(both may be conjunctions). - in - Variable in class org.apache.calcite.adapter.os.SqlShell
- in() - Method in class org.apache.calcite.piglet.Ast.UnParser
- in(RelNode, ImmutableList<RexNode>) - Static method in class org.apache.calcite.rex.RexSubQuery
-
Creates an IN sub-query.
- IN - org.apache.calcite.adapter.druid.DruidJsonFilter.Type
- IN - org.apache.calcite.plan.RelOptUtil.SubQueryType
- IN - org.apache.calcite.sql.SqlKind
-
The "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 - 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
- inCharFamily(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- inCharFamily(SqlTypeName) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- inCharOrBinaryFamilies(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- includeFilter - Variable in class org.apache.calcite.util.Filterator
- includeOuter - Variable in class org.apache.calcite.rel.rules.JoinProjectTransposeRule
- 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
- INCREASING - org.apache.calcite.sql.validate.SqlMonotonicity
- increment(int, int[]) - Method in class org.apache.calcite.util.Permutation
- increment(Calendar, TimeUnitRange) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A unary increment operation, such as (a + 1) in C# and Visual Basic.
- incrementAndCheck() - Method in class org.apache.calcite.rex.RexUtil.CnfHelper
- indent - Variable in class org.apache.calcite.linq4j.tree.ExpressionWriter
- indent - Variable in class org.apache.calcite.plan.RelOptUtil.TypeDumper
- indent - Variable in class org.apache.calcite.util.XmlOutput
- indent() - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
- indent(int) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- Indent(int) - Constructor for class org.apache.calcite.linq4j.tree.ExpressionWriter.Indent
- INDENT - Static variable in class org.apache.calcite.linq4j.tree.ExpressionWriter
- 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 - Variable in class org.apache.calcite.sql.pretty.SqlFormatOptions
- indentation - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- indentation - Variable in class org.apache.calcite.util.StackWriter
- indentationDepth - Variable in class org.apache.calcite.util.StackWriter
- indentIfNeeded() - Method in class org.apache.calcite.util.StackWriter
- indentPending - Variable in class org.apache.calcite.linq4j.tree.ExpressionWriter
- indentString - Variable in class org.apache.calcite.util.XmlOutput
- index - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping
- index - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchema
- index - Variable in class org.apache.calcite.adapter.enumerable.impl.WinAggResetContextImpl
- index - Variable in class org.apache.calcite.adapter.file.FileReader
- index - Variable in class org.apache.calcite.rel.type.RelDataTypeFieldImpl
- index - Variable in class org.apache.calcite.rex.RexDynamicParam
- index - Variable in class org.apache.calcite.rex.RexSlot
- index - Variable in class org.apache.calcite.sql.SqlDynamicParam
- index() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
An index operation or an operation that accesses a property that takes arguments.
- INDEX - org.apache.calcite.schema.Schema.TableType
-
Index table.
- INDEX - Static variable in interface org.apache.calcite.adapter.elasticsearch.ElasticsearchConstants
- 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
- indexName - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
- indexName - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- 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(int, int[]) - Static method in class org.apache.calcite.rel.rules.CalcRelSplitter
-
Searches for a value in a map, and returns the position where it was found, or -1.
- 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.util.ImmutableIntList
- 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.
- indexOfLineEnd(String, int) - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Tokenizer
- 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
-
Whether there are indicator fields.
- indicator - Variable in class org.apache.calcite.tools.RelBuilder.GroupKeyImpl
- induce(ImmutableBitSet, List<ImmutableBitSet>) - Static method in enum org.apache.calcite.rel.core.Aggregate.Group
- infer(RexNode, Set<RexNode>, List<RexNode>, boolean, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- infer(AggregateFunction) - Static method in class org.apache.calcite.prepare.CalciteCatalogReader
- infer(ScalarFunction) - Static method in class org.apache.calcite.prepare.CalciteCatalogReader
- inferAlias(List<RexNode>, RexNode, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Infers the alias of an expression.
- 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.
- inferPredicates(boolean) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
-
The PullUp Strategy is sound but not complete.
- 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.SqlCastFunction
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.sql.fun.SqlDatetimePlusOperator
- 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.SqlJsonValueFunction
- 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.SqlMultisetQueryConstructor
- 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.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
- inferTypeFromOperands(RelDataTypeFactory, List<RelDataType>) - Method in class org.apache.calcite.sql.fun.SqlCaseOperator
- inferTypeFromValidator(SqlCallBinding) - Method in class org.apache.calcite.sql.fun.SqlCaseOperator
- InferTypes - Class in org.apache.calcite.sql.type
-
Strategies for inferring operand types.
- InferTypes() - Constructor for class org.apache.calcite.sql.type.InferTypes
- 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.
- inFields - Variable in class org.apache.calcite.adapter.cassandra.CassandraRules.RexToCassandraTranslator
- inFields - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.RexToElasticsearchTranslator
- inFields - Variable in class org.apache.calcite.adapter.geode.rel.GeodeRules.RexToGeodeTranslator
- inFields - Variable in class org.apache.calcite.adapter.mongodb.MongoRules.RexToMongoTranslator
- INFINITY - Static variable in class org.apache.calcite.plan.volcano.VolcanoCost
- 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 - org.apache.calcite.util.PrecedenceClimbingParser.Type
- info - Variable in class org.apache.calcite.sql.dialect.JethroDataSqlDialect
- info(String) - Method in class org.apache.calcite.util.trace.CalciteLogger
- info(String, Object...) - 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
- INFOBRIGHT - 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 - 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 - 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.
- 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.NumericComparison
- init() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
-
Called after the constructor has completed and the model has been loaded.
- init() - Method in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
-
Performs post-constructor initialization of an operator table.
- 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 - 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.RelMetadataQuery
- initialize() - Method in class org.apache.calcite.adapter.file.FileRowConverter
- initialize(boolean) - Method in class org.apache.calcite.plan.hep.HepInstruction.BeginGroup
- initialize(boolean) - Method in class org.apache.calcite.plan.hep.HepInstruction.EndGroup
- initialize(boolean) - Method in class org.apache.calcite.plan.hep.HepInstruction
- initialize(boolean) - Method in class org.apache.calcite.plan.hep.HepInstruction.RuleClass
- initialize(boolean) - Method in class org.apache.calcite.plan.hep.HepInstruction.RuleInstance
- initialize(boolean) - Method in class org.apache.calcite.plan.hep.HepInstruction.Subprogram
- initialize(boolean) - Method in class org.apache.calcite.plan.hep.HepProgram
- initialize(Map<VolcanoPlannerPhase, Set<String>>) - Method in class org.apache.calcite.plan.volcano.ChainedPhaseRuleMappingInitializer
- initialize(Map<VolcanoPlannerPhase, Set<String>>) - Method in interface org.apache.calcite.plan.volcano.VolcanoPlannerPhaseRuleMappingInitializer
-
Initializes a
VolcanoPlannerPhase
-to-rule map. - initialized - Variable in class org.apache.calcite.adapter.file.FileRowConverter
- initializeMapping() - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference.ExprsItr
- initializer - Variable in class org.apache.calcite.linq4j.tree.DeclarationStatement
- initializer - Variable in class org.apache.calcite.linq4j.tree.FieldDeclaration
- Initializer() - Constructor for class org.apache.calcite.rex.RexFieldCollation.Initializer
- InitializerContext - Interface in org.apache.calcite.sql2rel
-
Provides context for
InitializerExpressionFactory
methods. - initializerExpressionFactory - Variable in class org.apache.calcite.schema.impl.ModifiableViewTable
- initializerExpressionFactory - Variable in class org.apache.calcite.sql.ddl.SqlCreateTable.MutableArrayTable
- initializerExpressionFactory - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- InitializerExpressionFactory - Interface in org.apache.calcite.sql2rel
-
InitializerExpressionFactory supplies default values for INSERT, UPDATE, and NEW.
- initialValue - Variable in class org.apache.calcite.interpreter.AggregateNode.NumericComparison
- initialValue - Variable in class org.apache.calcite.util.TryThreadLocal
- initialValue() - Method in class org.apache.calcite.util.TryThreadLocal
- initList(SqlAbstractParserImpl, Set<String>, String) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
-
Initializes lists of keywords.
- initMethod - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- initScalar - Variable in class org.apache.calcite.interpreter.AggregateNode.ScalarAccumulatorDef
- injectImportanceBoost() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Finds RelSubsets in the plan that contain only rels of
Convention.NONE
and boosts their importance by 25%. - INJECTION - org.apache.calcite.util.mapping.MappingType
- InlineVariableVisitor(Map<ParameterExpression, Expression>) - Constructor for class org.apache.calcite.linq4j.tree.BlockBuilder.InlineVariableVisitor
- inMetadataQuery - Variable in class org.apache.calcite.plan.volcano.RelSet
-
Reentrancy flag.
- INNER - org.apache.calcite.linq4j.CorrelateJoinType
-
Inner join
- INNER - org.apache.calcite.rel.core.JoinRelType
- INNER - org.apache.calcite.sql.JoinType
-
Inner join.
- INNER - org.apache.calcite.sql.SemiJoinType
-
Inner join
- innerKeySelector - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- INOPERATIVE_VIEW - org.apache.calcite.schema.Schema.TableType
-
An inoperative view.
- inOver - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
-
Are we directly inside a windowed aggregate?
- input - Variable in class org.apache.calcite.rel.mutable.MutableSingleRel
- input - Variable in class org.apache.calcite.rel.SingleRel
- input(String, RelNode) - Method in class org.apache.calcite.rel.externalize.RelJsonWriter
- input(String, RelNode) - Method in class org.apache.calcite.rel.externalize.RelWriterImpl
- input(String, RelNode) - Method in interface org.apache.calcite.rel.RelWriter
-
Adds an input to the explanation of the current node.
- INPUT_REF - org.apache.calcite.sql.SqlKind
-
Reference to an input field.
- inputBitSet - Variable in class org.apache.calcite.plan.RelOptUtil.InputFinder
- inputCollations - Variable in class org.apache.calcite.rex.RexCallBinding
- inputExprOrdinals - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter.InputToCommonExprConverter
- inputField(List<RelNode>, RexNode) - Static method in class org.apache.calcite.materialize.Lattice
-
Converts an expression into an (input, field) pair.
- InputFinder() - Constructor for class org.apache.calcite.plan.RelOptUtil.InputFinder
- InputFinder(Set<RelDataTypeField>) - Constructor for class org.apache.calcite.plan.RelOptUtil.InputFinder
- inputGetter - Variable in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- InputGetterImpl(List<Pair<Expression, PhysType>>) - Constructor for class org.apache.calcite.adapter.enumerable.RexToLixTranslator.InputGetterImpl
- inputOffset(int, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns the number of fields in all inputs before (to the left of) the given input.
- inputPosReferenced - Variable in class org.apache.calcite.plan.RelOptUtil.InputReferencedVisitor
- InputReferenceCounter(int[]) - Constructor for class org.apache.calcite.rel.rules.JoinToMultiJoinRule.InputReferenceCounter
- InputReferencedVisitor() - Constructor for class org.apache.calcite.plan.RelOptUtil.InputReferencedVisitor
- InputRefUsage() - Constructor for class org.apache.calcite.plan.RexImplicationChecker.InputRefUsage
- inputRowType - Variable in class org.apache.calcite.rel.core.TableModify
- inputRowType - Variable in class org.apache.calcite.rex.RexProgram
- inputRowType - Variable in class org.apache.calcite.rex.RexProgramBuilder
- inputRowType - Variable in class org.apache.calcite.rex.RexUtil.ForwardRefFinder
- inputs - Variable in class org.apache.calcite.adapter.enumerable.RexToLixTranslator.InputGetterImpl
- inputs - Variable in class org.apache.calcite.plan.SubstitutionVisitor.InternalOperand
- inputs - Variable in class org.apache.calcite.rel.core.SetOp
- inputs - Variable in class org.apache.calcite.rel.core.TableFunctionScan
- inputs - Variable in class org.apache.calcite.rel.mutable.MutableMultiRel
- inputs - Variable in class org.apache.calcite.rel.rules.MultiJoin
- inputs - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- InputSpecialOpFinder(BitSet, ImmutableBitSet, ImmutableBitSet, ImmutableBitSet, PushProjector.ExprCondition, List<RexNode>, List<RexNode>) - Constructor for class org.apache.calcite.rel.rules.PushProjector.InputSpecialOpFinder
- inputSubsets(RelNode) - Static method in class org.apache.calcite.plan.volcano.RelSubset
- InputToCommonExprConverter(int[], int[], int, int[], RexNode[]) - Constructor for class org.apache.calcite.rel.rules.CalcRelSplitter.InputToCommonExprConverter
- inputTypeList - Variable in class org.apache.calcite.rex.RexChecker
- InputUsageFinder() - Constructor for class org.apache.calcite.plan.RexImplicationChecker.InputUsageFinder
- 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
- inSameFamilyOrNull(RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- insert(int, String) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Inserts the string into this character sequence.
- INSERT - org.apache.calcite.rel.core.TableModify.Operation
- INSERT - org.apache.calcite.sql.SqlAccessEnum
- INSERT - org.apache.calcite.sql.SqlKind
-
INSERT statement
- insertCall - Variable in class org.apache.calcite.sql.SqlMerge
- insertIntoAlwaysGenerated(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- InsertNamespace(SqlValidatorImpl, SqlInsert, SqlNode, SqlValidatorScope) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.InsertNamespace
- 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.
- Inst(String, Locale, Method, Object...) - Constructor for class org.apache.calcite.runtime.Resources.Inst
- instance - Static variable in class org.apache.calcite.adapter.spark.SparkHandlerImpl
- instance - Static variable in class org.apache.calcite.chinook.ChinookAvaticaServer.CalciteChinookMetaFactory
- instance - Static variable in class org.apache.calcite.chinook.ChinookAvaticaServer.RawChinookMetaFactory
- instance - Variable in class org.apache.calcite.interpreter.AggregateNode.UdaAccumulatorFactory
- instance - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
The table of contains Oracle-specific operators.
- instance - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The standard operator table.
- 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
-
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.SqlTypeAssignmentRules
-
Returns an instance that does not coerce.
- instance() - Static method in class org.apache.calcite.sql.util.SqlBasicVisitor.ArgHandlerImpl
- instance() - Static method in class org.apache.calcite.util.SaffronProperties.Helper
-
Retrieves the singleton instance of
SaffronProperties
. - instance(boolean) - Static method in class org.apache.calcite.sql.type.SqlTypeAssignmentRules
-
Returns an instance.
- instance(String, Locale, ResourceBundle) - Static method in class org.apache.calcite.runtime.Resources.ShadowResourceBundle
-
Returns the instance of the
baseName
resource bundle for the given locale. - INSTANCE - org.apache.calcite.adapter.druid.Granularities.AllGranularity
- INSTANCE - org.apache.calcite.adapter.enumerable.EnumerableConvention
- INSTANCE - org.apache.calcite.interpreter.BindableConvention
- INSTANCE - org.apache.calcite.interpreter.InterpretableConvention
- INSTANCE - org.apache.calcite.materialize.MapSqlStatisticProvider
- INSTANCE - org.apache.calcite.rel.metadata.NullSentinel
-
Placeholder for a null value.
- INSTANCE - org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- INSTANCE - org.apache.calcite.runtime.Resources.EmptyPropertyAccessor
- INSTANCE - Static variable in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraFilterRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraLimitRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraProjectRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraSortRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.cassandra.CassandraToEnumerableConverterRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.csv.CsvProjectTableScanRule
- 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.elasticsearch.ElasticsearchRules.ElasticsearchAggregateRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.ElasticsearchFilterRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.ElasticsearchProjectRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.ElasticsearchSortRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchToEnumerableConverterRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.elasticsearch.MapProjectionFieldVisitor
- INSTANCE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableBindable.EnumerableToBindableConverterRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableInterpreterRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.enumerable.RexImpTable
- INSTANCE - Static variable in exception org.apache.calcite.adapter.enumerable.RexToLixTranslator.AlwaysNull
- INSTANCE - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeAggregateRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeFilterRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeProjectRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeSortLimitRule
- 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.jdbc.JdbcUtils.DataSourcePool
- INSTANCE - Static variable in class org.apache.calcite.adapter.jdbc.JdbcUtils.DialectPool
- INSTANCE - Static variable in class org.apache.calcite.adapter.mongodb.MongoRules.MongoAggregateRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.mongodb.MongoRules.MongoFilterRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.mongodb.MongoRules.MongoProjectRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.mongodb.MongoRules.MongoSortRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.mongodb.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.PigRules.PigAggregateRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.pig.PigRules.PigFilterRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.pig.PigRules.PigJoinRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.pig.PigRules.PigProjectRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.pig.PigRules.PigTableScanRule
- 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.spark.EnumerableToSparkConverterRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.spark.SparkRules.EnumerableToSparkConverterRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.spark.SparkRules.SparkToEnumerableConverterRule
- INSTANCE - Static variable in class org.apache.calcite.adapter.splunk.SplunkTable
- INSTANCE - Static variable in class org.apache.calcite.interpreter.NoneToBindableConverterRule
- INSTANCE - Static variable in class org.apache.calcite.jdbc.MetadataSchema
- INSTANCE - Static variable in class org.apache.calcite.linq4j.function.Functions.Ignore
- INSTANCE - Static variable in class org.apache.calcite.linq4j.QueryableRecorder
- INSTANCE - Static variable in class org.apache.calcite.linq4j.tree.ConstantUntypedNull
- INSTANCE - Static variable in class org.apache.calcite.materialize.MaterializationService
- INSTANCE - Static variable in class org.apache.calcite.plan.ConventionTraitDef
- INSTANCE - Static variable in class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor.FilterToFilterUnifyRule1
- INSTANCE - Static variable in class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor.FilterToProjectUnifyRule1
- INSTANCE - Static variable in class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor.ProjectToProjectUnifyRule1
- INSTANCE - Static variable in class org.apache.calcite.plan.SubstitutionVisitor.AggregateOnProjectToAggregateUnifyRule
- INSTANCE - Static variable in class org.apache.calcite.plan.SubstitutionVisitor.AggregateToAggregateUnifyRule
- INSTANCE - Static variable in class org.apache.calcite.plan.SubstitutionVisitor.FilterOnProjectRule
- INSTANCE - Static variable in class org.apache.calcite.plan.SubstitutionVisitor.FilterToFilterUnifyRule
- INSTANCE - Static variable in class org.apache.calcite.plan.SubstitutionVisitor.FilterToProjectUnifyRule
- INSTANCE - Static variable in exception org.apache.calcite.plan.SubstitutionVisitor.MatchFailed
- INSTANCE - Static variable in class org.apache.calcite.plan.SubstitutionVisitor.ProjectToFilterUnifyRule
- INSTANCE - Static variable in class org.apache.calcite.plan.SubstitutionVisitor.ProjectToProjectUnifyRule
- INSTANCE - Static variable in class org.apache.calcite.plan.SubstitutionVisitor.ScanToProjectUnifyRule
- INSTANCE - Static variable in class org.apache.calcite.plan.SubstitutionVisitor.TrivialRule
- INSTANCE - Static variable in class org.apache.calcite.plan.volcano.AbstractConverter.ExpandConversionRule
- INSTANCE - Static variable in exception org.apache.calcite.rel.metadata.CyclicMetadataException
-
Singleton instance.
- INSTANCE - Static variable in class org.apache.calcite.rel.metadata.DefaultRelMetadataProvider
- INSTANCE - Static variable in class org.apache.calcite.rel.metadata.RelMdPercentageOriginalRows
- 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.AggregateExpandDistinctAggregatesRule
-
The default instance of the rule; operates only on logical expressions.
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.AggregateFilterTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.AggregateProjectMergeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.AggregateProjectPullUpConstantsRule
-
The singleton.
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
The singleton.
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.AggregateRemoveRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.AggregateStarTableRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.AggregateUnionAggregateRule
-
Instance that matches an
Aggregate
as either input ofUnion
. - INSTANCE - Static variable in class org.apache.calcite.rel.rules.AggregateUnionTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.AggregateValuesRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.CalcMergeRule
- INSTANCE - Static variable in exception org.apache.calcite.rel.rules.CalcRelSplitter.CannotImplement
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.CalcRemoveRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.CalcSplitRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.FilterAggregateTransposeRule
-
The default instance of
FilterAggregateTransposeRule
. - INSTANCE - Static variable in class org.apache.calcite.rel.rules.FilterCalcMergeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.FilterCorrelateRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.FilterMergeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.FilterMultiJoinMergeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.FilterProjectTransposeRule
-
The default instance of
FilterProjectTransposeRule
. - INSTANCE - Static variable in class org.apache.calcite.rel.rules.FilterRemoveIsNotDistinctFromRule
-
The singleton.
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.FilterSetOpTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.FilterTableFunctionTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.FilterTableScanRule
-
Rule that matches Filter on TableScan.
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.FilterToCalcRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.IntersectToDistinctRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.JoinAddRedundantSemiJoinRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.JoinAssociateRule
-
The singleton.
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.JoinCommuteRule
-
Instance of the rule that only swaps inner joins.
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.JoinExtractFilterRule
-
The singleton.
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.JoinPushExpressionsRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.JoinPushTransitivePredicatesRule
-
The singleton.
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.JoinToCorrelateRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.JoinToMultiJoinRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.MaterializedViewFilterScanRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.ProjectCalcMergeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.ProjectFilterTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.ProjectJoinTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.ProjectMergeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.ProjectMultiJoinMergeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.ProjectRemoveRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.ProjectSetOpTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.ProjectSortTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.ProjectTableScanRule
-
Rule that matches Project on TableScan.
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.ProjectToCalcRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.ProjectToWindowRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.ProjectWindowTransposeRule
-
The default instance of
ProjectWindowTransposeRule
. - INSTANCE - Static variable in class org.apache.calcite.rel.rules.ReduceDecimalsRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.SemiJoinFilterTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.SemiJoinJoinTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.SemiJoinProjectTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.SemiJoinRemoveRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.SortJoinTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.SortProjectTransposeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.SortRemoveConstantKeysRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.SortRemoveRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.SortUnionTransposeRule
-
Rule instance for Union implementation that does not preserve the ordering of its inputs.
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.TableScanRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.UnionEliminatorRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.UnionMergeRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.UnionPullUpConstantsRule
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.UnionToDistinctRule
- INSTANCE - Static variable in exception org.apache.calcite.rex.RexOver.OverFound
- INSTANCE - Static variable in exception org.apache.calcite.rex.RexUtil.CnfHelper.OverflowError
- INSTANCE - Static variable in class org.apache.calcite.rex.RexUtil.ConstantFinder
- INSTANCE - Static variable in class org.apache.calcite.rex.RexUtil.CorrelationFinder
- 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.sql.fun.SqlCaseOperator
- 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.SqlJdbcFunctionCall.JdbcToInternalLookupTable
-
The
singleton
instance. - 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.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.SqlWindow.SqlWindowOperator
- INSTANCE - Static variable in class org.apache.calcite.sql.SqlWith.SqlWithOperator
- INSTANCE - Static variable in class org.apache.calcite.sql.SqlWithItem.SqlWithItemOperator
- INSTANCE - Static variable in class org.apache.calcite.sql.type.JavaToSqlTypeConversionRules
- INSTANCE - Static variable in class org.apache.calcite.sql.type.SqlTypeAssignmentRules
- INSTANCE - Static variable in class org.apache.calcite.sql.util.SqlBasicVisitor.ArgHandlerImpl
- 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.SaffronProperties
- INSTANCE - Static variable in class org.apache.calcite.util.Util.OverFinder
- INSTANCE_AGGREGATE - Static variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
- INSTANCE_FILTER - Static variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
- INSTANCE_JOIN - Static variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
- INSTANCE_PROJECT_AGGREGATE - Static variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
- INSTANCE_PROJECT_FILTER - Static variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
- INSTANCE_PROJECT_JOIN - Static variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
- INSTANCE2 - Static variable in class org.apache.calcite.rel.rules.AggregateProjectPullUpConstantsRule
-
More general instance that matches any relational expression.
- INSTANCE2 - Static variable in class org.apache.calcite.rel.rules.AggregateStarTableRule
- instructions - Variable in class org.apache.calcite.plan.hep.HepProgram
- instructions - Variable in class org.apache.calcite.plan.hep.HepProgramBuilder
- inSubQueryThreshold - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- inSubQueryThreshold - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- INT - org.apache.calcite.adapter.csv.CsvFieldType
- INT - org.apache.calcite.adapter.file.FileFieldType
- INT - org.apache.calcite.linq4j.tree.Primitive
- INT_B - Static variable in class org.apache.calcite.adapter.clone.ColumnLoader
- INT_MAX - Static variable in class org.apache.calcite.rex.RexBuilder
-
The largest valid
int
value, as aBigDecimal
. - INT_MAX_VALUE_PLUS_ONE - Static variable in class org.apache.calcite.sql.SqlIntervalQualifier
- INT_MIN - Static variable in class org.apache.calcite.rex.RexBuilder
-
The smallest valid
int
value, as aBigDecimal
. - INT_S - Static variable in class org.apache.calcite.adapter.clone.ColumnLoader
- INT_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- int2(StringBuilder, int) - Static method in class org.apache.calcite.util.DateTimeStringUtils
- int4(StringBuilder, int) - Static method in class org.apache.calcite.util.DateTimeStringUtils
- int8 - Variable in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Type for the internal representation of decimals.
- inTag - Variable in class org.apache.calcite.util.XmlOutput
-
Whether we have started but not finished a start tag.
- INTEGER - org.apache.calcite.sql.type.SqlTypeFamily
- INTEGER - org.apache.calcite.sql.type.SqlTypeName
- 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_MAX - Static variable in class org.apache.calcite.linq4j.Extensions
- INTEGER_MIN - Static variable in class org.apache.calcite.linq4j.Extensions
- 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_PATTERN - Static variable in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Regular expression for integer.
- 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_SUM - Static variable in class org.apache.calcite.linq4j.Extensions
- integerFormat - Variable in class org.apache.calcite.adapter.file.FileRowConverter
-
Format for parsing integers.
- 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.
- IntegerIntervalSet(String) - Constructor for class org.apache.calcite.util.IntegerIntervalSet
- IntegerIntervalSet.Handler - Interface in org.apache.calcite.util
-
A callback.
- INTEGERS - Static variable in class org.apache.calcite.util.ChunkList
- INTERBASE - 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.
- interestingCount - Variable in class org.apache.calcite.profile.ProfilerImpl
-
The minimum number of combinations considered "interesting".
- internal(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- INTERNAL - org.apache.calcite.sql.SqlSyntax
-
Syntax of an internal operator, which does not appear in the SQL.
- INTERNAL_TO_DATE - org.apache.calcite.util.BuiltInMethod
- INTERNAL_TO_TIME - org.apache.calcite.util.BuiltInMethod
- INTERNAL_TO_TIMESTAMP - org.apache.calcite.util.BuiltInMethod
- internalExprTypeList - Variable in class org.apache.calcite.rex.RexProgram.Checker
- InternalOperand(Class<? extends MutableRel>, List<SubstitutionVisitor.Operand>) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.InternalOperand
- internalParameters - Variable in class org.apache.calcite.interpreter.InterpretableRel.InterpreterImplementor
- internalParameters - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- internalToDate(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts the internal representation of a SQL DATE (int) to the Java type used for UDF parameters (
Date
). - internalToDate(Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
As
SqlFunctions.internalToDate(int)
but allows nulls. - internalToTime(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts the internal representation of a SQL TIME (int) to the Java type used for UDF parameters (
Time
). - internalToTime(Integer) - Static method in class org.apache.calcite.runtime.SqlFunctions
- internalToTimestamp(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts the internal representation of a SQL TIMESTAMP (long) to the Java type used for UDF parameters (
Timestamp
). - internalToTimestamp(Long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- internalTypes(List<? extends RexNode>) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
- interner - Variable in class org.apache.calcite.plan.RelTraitDef
-
Cache of traits.
- InterpretableConvention - Enum in org.apache.calcite.interpreter
-
Calling convention that returns results as an
Enumerable
of object arrays. - InterpretableConvention() - Constructor for enum org.apache.calcite.interpreter.InterpretableConvention
- 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.Interpreter.CompilerImpl
- 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 class org.apache.calcite.rel.rules.FilterTableScanRule
-
Rule that matches Filter on EnumerableInterpreter on TableScan.
- INTERPRETER - Static variable in class org.apache.calcite.rel.rules.ProjectTableScanRule
-
Rule 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.
- Interpreter.CompilerImpl - Class in org.apache.calcite.interpreter
- Interpreter.DuplicatingSink - Class in org.apache.calcite.interpreter
-
Implementation of
Sink
using aArrayDeque
. - Interpreter.Edge - Class in org.apache.calcite.interpreter
-
Edge between a
RelNode
and one of its inputs. - Interpreter.EnumeratorSource - Class in org.apache.calcite.interpreter
-
A
Source
that is just backed by anEnumerator
. - Interpreter.FooCompiler - Class in org.apache.calcite.interpreter
-
Not used.
- Interpreter.ListSink - Class in org.apache.calcite.interpreter
-
Implementation of
Sink
using aArrayDeque
. - Interpreter.ListSource - Class in org.apache.calcite.interpreter
-
Implementation of
Source
using aArrayDeque
. - Interpreter.NodeInfo - Class in org.apache.calcite.interpreter
-
Information about a node registered in the data flow graph.
- Interpreter.ScalarCompiler - Interface in org.apache.calcite.interpreter
-
Converts a list of expressions to a scalar that can compute their values.
- 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
. - Interpreters() - Constructor for class org.apache.calcite.interpreter.Interpreters
- 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.linq4j.DefaultQueryable
- intersect(Enumerable<T>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- intersect(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- intersect(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- intersect(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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.
- intersect(Enumerable<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Produces the set intersection of two sequences by using the default equality comparer to compare values.
- 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.
- 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. - 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. - intersect(Enumerable<TSource>, EqualityComparer<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Produces the set intersection of two sequences by using the specified
EqualityComparer<TSource>
to compare values. - 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.
- intersect(Queryable<T>, Enumerable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- intersect(Queryable<T>, Enumerable<T>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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.
- intersect(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- intersect(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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<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 - org.apache.calcite.rel.mutable.MutableRelType
- INTERSECT - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- INTERSECT - org.apache.calcite.sql.SqlKind
-
Intersect
- INTERSECT - org.apache.calcite.util.BuiltInMethod
- 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
LogicalIntersect
to empty if any of its children are empty. - INTERSECT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.UnionMergeRule
- intersects(Geometry, Geometry, SpatialReference) - Static method in class org.apache.calcite.runtime.GeoFunctions
- 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
-
Creates an IntersectToDistinctRule.
- interval - Variable in class org.apache.calcite.rel.core.Match
- interval - Variable in class org.apache.calcite.sql.SqlMatchRecognize
- 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 - org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_DAY_HOUR - org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_DAY_MINUTE - org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_DAY_SECOND - org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_DAY_TIME - org.apache.calcite.sql.type.SqlTypeFamily
- INTERVAL_DAY_TIME_TO_STRING - org.apache.calcite.util.BuiltInMethod
- INTERVAL_HOUR - org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_HOUR_MINUTE - org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_HOUR_SECOND - org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_INTERVAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
- INTERVAL_MINUTE - org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_MINUTE_SECOND - org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_MONTH - org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_NUMERIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
- INTERVAL_SAME_SAME - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Parameter type-checking strategy type must a nullable time interval, nullable time interval
- INTERVAL_SECOND - org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_YEAR - org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_YEAR_MONTH - org.apache.calcite.sql.type.SqlTypeFamily
- INTERVAL_YEAR_MONTH - org.apache.calcite.sql.type.SqlTypeName
- INTERVAL_YEAR_MONTH_TO_STRING - 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
- intervalQualifier - Variable in class org.apache.calcite.sql.SqlIntervalLiteral.IntervalValue
- intervalQualifier - Variable in class org.apache.calcite.sql.type.IntervalSqlType
- intervals - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonSegmentMetadata
- intervals - Variable in class org.apache.calcite.adapter.druid.DruidQuery
- intervals - Variable in class org.apache.calcite.adapter.druid.DruidQuery.ScanQuery
- intervals - Variable in class org.apache.calcite.adapter.druid.DruidTable
- 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
- intervalStr - Variable in class org.apache.calcite.sql.SqlIntervalLiteral.IntervalValue
- intervalString(BigDecimal) - Method in class org.apache.calcite.rex.RexLiteral
- 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.
- IntervalValue(SqlIntervalQualifier, int, String) - Constructor for class org.apache.calcite.sql.SqlIntervalLiteral.IntervalValue
-
Creates an interval value.
- 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 - 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
- IntProp(Resources.PropertyAccessor, Method) - Constructor for class org.apache.calcite.runtime.Resources.IntProp
- inTrait - Variable in class org.apache.calcite.rel.convert.ConverterRule
- inTraits - Variable in class org.apache.calcite.rel.convert.ConverterImpl
- ints - Variable in class org.apache.calcite.util.ImmutableIntList
- 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
- intValue(Resources.IntProp) - Method in enum org.apache.calcite.runtime.Resources.EmptyPropertyAccessor
- intValue(Resources.IntProp) - Method in class org.apache.calcite.runtime.Resources.PropertiesAccessor
- intValue(Resources.IntProp) - Method in interface org.apache.calcite.runtime.Resources.PropertyAccessor
- intValue(Resources.IntProp, int) - Method in enum org.apache.calcite.runtime.Resources.EmptyPropertyAccessor
- intValue(Resources.IntProp, int) - Method in class org.apache.calcite.runtime.Resources.PropertiesAccessor
- intValue(Resources.IntProp, int) - Method in interface org.apache.calcite.runtime.Resources.PropertyAccessor
- 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
- invalidDatetimeFormat(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidEscapeCharacter(String) - Static method in class org.apache.calcite.runtime.Like
- invalidEscapeSequence(String, int) - Static method in class org.apache.calcite.runtime.Like
- invalidOrderByPos() - Method in interface org.apache.calcite.runtime.CalciteResource
- invalidRegularExpression(String, int) - Static method in class org.apache.calcite.runtime.Like
- InvalidRelException - Exception in org.apache.calcite.rel
-
Exception that indicates that a relational expression would be invalid with given parameters.
- InvalidRelException(String) - Constructor for exception org.apache.calcite.rel.InvalidRelException
-
Creates an InvalidRelException.
- InvalidRelException(String, Throwable) - Constructor for exception org.apache.calcite.rel.InvalidRelException
-
Creates an InvalidRelException with a cause.
- invalidSampleSize() - 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
- invalidValueException(SqlParserPos, String) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- 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.InverseMapping
- 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.PartialFunctionImpl
- 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(Map<K, V>) - Static method in class org.apache.calcite.linq4j.function.Functions
- INVERSE_FUNCTION - 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 - org.apache.calcite.util.mapping.MappingType
- INVERSE_PARTIAL_FUNCTION - org.apache.calcite.util.mapping.MappingType
- INVERSE_PARTIAL_INJECTION - org.apache.calcite.util.mapping.MappingType
- INVERSE_SURJECTION - org.apache.calcite.util.mapping.MappingType
-
An inverse surjection has a source for every target, and no source has more than one target.
- InverseMapping(Mapping) - Constructor for class org.apache.calcite.util.mapping.Mappings.InverseMapping
- inverseOrdinal - Variable in enum org.apache.calcite.util.mapping.MappingType
- invert(int[]) - Static method in class org.apache.calcite.adapter.clone.ColumnLoader
- invert(Iterable<IntPair>) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Inverts an
Iterable
overIntPair
s. - invert(Iterator<IntPair>) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Inverts an
Iterator
overIntPair
s. - invert(List<Pair<RexNode, String>>, MutableRel, RexShuttle) - Method in class org.apache.calcite.plan.SubstitutionVisitor.FilterToProjectUnifyRule
- invert(MutableRel, MutableRel, MutableProject) - Method in class org.apache.calcite.plan.SubstitutionVisitor.FilterToProjectUnifyRule
- 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.rel.metadata.CachingRelMetadataProvider.CachingInvocationHandler
- invoke(Object, Method, Object[]) - Method in class org.apache.calcite.rel.metadata.ChainedRelMetadataProvider.ChainedInvocationHandler
- 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 - 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. - invokeVisitorInternal(Object, Object, Class, String) - Static method in class org.apache.calcite.util.ReflectUtil
-
Shared implementation of the two forms of invokeVisitor.
- inWindow - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- io - Variable in class org.apache.calcite.plan.volcano.VolcanoCost
- iOriginColumn - Variable in class org.apache.calcite.rel.metadata.RelColumnOrigin
- iOutputColumn - Variable in class org.apache.calcite.rel.metadata.RelColumnMapping
-
0-based ordinal of mapped output column.
- iRestructureInput - Variable in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- irreducible - Variable in class org.apache.calcite.rel.rules.ReduceDecimalsRule.DecimalShuttle
- IRREDUCIBLE_CONSTANT - org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator.Constancy
- is(Type) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Returns whether a given type is primitive.
- IS_A_SET - 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 - org.apache.calcite.sql.SqlKind
-
The is-distinct-from operator.
- IS_DISTINCT_FROM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
IS DISTINCT FROM
operator. - IS_EMPTY - 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_AGGREGATE - Static variable in class org.apache.calcite.rel.rules.SemiJoinRule
- IS_EMPTY_J - Static variable in class org.apache.calcite.rel.core.Values
- IS_FALSE - org.apache.calcite.sql.SqlKind
-
The "IS FALSE" operator.
- IS_FALSE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_JSON_ARRAY - org.apache.calcite.util.BuiltInMethod
- IS_JSON_ARRAY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_JSON_OBJECT - org.apache.calcite.util.BuiltInMethod
- IS_JSON_OBJECT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_JSON_SCALAR - org.apache.calcite.util.BuiltInMethod
- IS_JSON_SCALAR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_JSON_VALUE - org.apache.calcite.util.BuiltInMethod
- IS_JSON_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_LEFT_OR_INNER - Static variable in class org.apache.calcite.rel.rules.SemiJoinRule
- IS_NAME - Static variable in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
- IS_NOT_A_SET - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_NOT_DISTINCT_FROM - org.apache.calcite.sql.SqlKind
-
The 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 - org.apache.calcite.sql.SqlKind
-
The "IS NOT FALSE" operator.
- IS_NOT_FALSE - 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 - org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
Return true if result is not null, false if result is null.
- IS_NOT_NULL - org.apache.calcite.sql.SqlKind
-
The "IS NOT NULL" operator.
- IS_NOT_NULL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_NOT_TRUE - org.apache.calcite.sql.SqlKind
-
The "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 - org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
Return false if result is not null, true if result is null.
- IS_NULL - org.apache.calcite.sql.SqlKind
-
The "IS NULL" operator.
- IS_NULL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_PHASE_TRANSITION - org.apache.calcite.util.BuiltInMethod
- IS_SIMPLE - Static variable in class org.apache.calcite.rel.core.Aggregate
-
Deprecated.
- IS_TRUE - org.apache.calcite.sql.SqlKind
-
The "IS TRUE" operator.
- IS_TRUE - org.apache.calcite.util.BuiltInMethod
- IS_TRUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- IS_UNKNOWN - org.apache.calcite.sql.SqlKind
-
The "IS UNKNOWN" operator.
- IS_UNKNOWN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- isA(Type, Primitive) - Static method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- 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.
- isAbstractMethodPrimitive() - Method in class org.apache.calcite.linq4j.tree.FunctionExpression
- isAggregate(SqlNode) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Deprecated.
- isAggregate(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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
- isAggregation(SqlKind) - Static method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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
- 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
- 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.
- 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.
- 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.
- isAlwaysTrue(RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- isAlwaysUseParentheses() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isAlwaysUseParentheses() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- 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.
- isAny(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- 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
- 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
- isArray(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- isArray(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- 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
- isAssociative(SqlOperator) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether an operator is associative.
- 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
- isBackwards(SqlStatisticProvider) - Method in class org.apache.calcite.materialize.Step
- 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 - Variable in class org.apache.calcite.plan.RelOptSamplingParameters
- isBernoulli - Variable in class org.apache.calcite.sql.SqlSampleSpec.SqlTableSampleSpec
- 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.
- isBigint(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- 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.
- isBoolean() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.LiteralExpression
- isBoolean(RexNode) - Method in class org.apache.calcite.rex.RexTransformer
- isBoundedVariableWidth(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- 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.CachingCalciteSchema
- isCacheEnabled() - Method in class org.apache.calcite.jdbc.CalciteSchema
- isCacheEnabled() - Method in class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- isCacheEnabled() - Method in class org.apache.calcite.jdbc.SimpleCalciteSchema
- isCacheEnabled() - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- isCacheEnabled() - Method in interface org.apache.calcite.schema.SchemaPlus
- 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
- 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 interface org.apache.calcite.sql.validate.SqlNameMatcher
-
Returns whether name matching is case-sensitive.
- isCaseSensitive() - Method in class org.apache.calcite.sql.validate.SqlNameMatchers.BaseMatcher
- isCaseSensitive() - Method in interface org.apache.calcite.sql.validate.SqlValidatorCatalogReader
- 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
- isCastExpression(PredicateAnalyzer.Expression) - Static method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CastExpression
- isCastFromLiteral() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CastExpression
- 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.
- isClauseStartsLine() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isClauseStartsLine() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- isClauseStartsLine() - Method in interface org.apache.calcite.sql.SqlWriter
-
Returns whether this writer should start each clause (e.g.
- isCollationTrivial() - Method in class org.apache.calcite.rel.RelRoot
- isColumn(PredicateAnalyzer.Expression, RexNode, String, boolean) - Static method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor
- isComparable(RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether two types are comparable.
- isComplex() - Method in enum org.apache.calcite.adapter.druid.DruidType
-
Returns true if and only if this enum should be used inside of a
ComplexMetric
- isComplexMetric(String) - Method in class org.apache.calcite.adapter.druid.DruidTable
-
Returns true if and only if the given
alias
is a reference to a registeredComplexMetric
- 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.ClassDeclarationFinder
-
Verifies if the expression is effectively constant.
- isConstant(Expression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
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.
- isConstantNull(Expression) - Method in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- isConstructor(RexNode) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- isConstructorDeterministic(NewExpression) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Checks if new instance creation can be reused.
- isContextVariableName(String) - Method in interface org.apache.calcite.sql.parser.SqlAbstractParserImpl.Metadata
-
Returns whether token is the name of a context variable such as "CURRENT_USER".
- isContextVariableName(String) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
- isConvertedSubq(RexNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Determines whether a RexNode corresponds to a sub-query that's been converted to a constant.
- isConvertTableAccess() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns the
convertTableAccess
option. - isConvertTableAccess() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- isCostly(DeclarationStatement) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- isCount - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationRexShuttle
- isCountDistinct(SqlCall) - Method in class org.apache.calcite.adapter.druid.DruidTable
- isCountStar() - Method in class org.apache.calcite.sql.SqlCall
-
Test to see if it is the function COUNT(*)
- isCreateValuesRel() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns the
createValuesRel
option. - isCreateValuesRel() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- isCurrentRow() - Method in class org.apache.calcite.rex.RexWindowBound
-
Returns if the bound is CURRENT ROW.
- isCurrentRow() - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundCurrentRow
- isCurrentRow(SqlNode) - Static method in class org.apache.calcite.sql.SqlWindow
-
Returns whether an expression represents the "CURRENT ROW" bound.
- isCyclic() - Method in class org.apache.calcite.materialize.MutableNode
-
Returns whether this node is cylic, in an undirected sense; that is, whether the same descendant can be reached by more than one route.
- isCyclicRecurse(Set<MutableNode>) - Method in class org.apache.calcite.materialize.MutableNode
- isDatetime(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- isDecimal(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- isDecorrelationEnabled() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns the
decorrelationEnabled
option. - isDecorrelationEnabled() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- isDecreasing() - Method in enum org.apache.calcite.sql.validate.SqlMonotonicity
-
Whether values of this monotonicity are decreasing.
- isDefaultLiteral(SqlLiteral) - Method in class org.apache.calcite.sql.fun.SqlJsonValueFunction
- 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.
- isDelete() - Method in class org.apache.calcite.rel.core.TableModify
- isDependent(DirectedGraph<Integer, DefaultEdge>, List<Integer>, int, int) - Method in class org.apache.calcite.rel.rules.ProjectToWindowRule.WindowedAggRelSplitter
- isDerived - Variable in class org.apache.calcite.rel.metadata.RelColumnOrigin
- isDerived() - Method in class org.apache.calcite.rel.metadata.RelColumnOrigin
-
Consider the query
select a+b as c, d as e from t
. - isDescendantOfAny(PartiallyOrderedSet.Node<E>, Set<PartiallyOrderedSet.Node<E>>) - Method in class org.apache.calcite.util.PartiallyOrderedSet
-
Returns whether node's value is a descendant of any of the values in nodeSet.
- 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.SqlSequenceValueOperator
- isDeterministic() - Method in class org.apache.calcite.sql.SqlOperator
- 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.AbstractRelNode
- isDistinct() - Method in class org.apache.calcite.rel.core.AggregateCall
-
Returns whether this AggregateCall is distinct, as in
COUNT(DISTINCT empno)
. - isDistinct() - Method in interface org.apache.calcite.rel.RelNode
-
Deprecated.
- 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. - isDistinctFromInternal(RexBuilder, RexNode, RexNode, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
- 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.SqlRandFunction
- isDynamicFunction() - Method in class org.apache.calcite.sql.fun.SqlRandIntegerFunction
- isDynamicFunction() - Method in class org.apache.calcite.sql.SqlOperator
- 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
- isDynamicStruct() - Method in class org.apache.calcite.rel.type.RelDataTypeImpl
- isEmpty() - Method in class org.apache.calcite.linq4j.LookupImpl
- isEmpty() - Method in class org.apache.calcite.runtime.AbstractImmutableList
- 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(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. - isEmpty(RelNode) - Static method in class org.apache.calcite.rel.rules.PruneEmptyRules
- 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.
- isEqualityOnKey(RexNode, List<String>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeFilterRule
-
Check if the node is a supported predicate (primary field condition).
- isEqualityOnKey(RexNode, List<String>, Set<String>, List<String>) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraFilterRule
-
Check if the node is a supported predicate (primary key equality).
- isEqui() - Method in class org.apache.calcite.rel.core.JoinInfo.EquiJoinInfo
- isEqui() - Method in class org.apache.calcite.rel.core.JoinInfo
-
Returns whether this is an equi-join.
- isEqui() - Method in class org.apache.calcite.rel.core.JoinInfo.NonEquiJoinInfo
- isEqui(RelNode, RelNode, RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- isEquivalent(RexBuilder, RexNode, RexNode) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
- isEquivalentOp(SqlKind, SqlKind) - Method in class org.apache.calcite.plan.RexImplicationChecker
- 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
- isEqWithEpsilon(RelOptCost) - Method in class org.apache.calcite.plan.volcano.VolcanoCost
- 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.
- isEvolveLattice() - Method in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- isExact - Variable in class org.apache.calcite.sql.SqlNumericLiteral
- isExact() - Method in class org.apache.calcite.sql.SqlNumericLiteral
- isExactNumeric(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- isExpand() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns the
expand
option. - isExpand() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- isExpanded() - Method in class org.apache.calcite.sql.SqlBasicCall
- 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. - isExplain() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- isExtractCall(RexNode) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A false condition value.
- isFile(Source) - Static method in class org.apache.calcite.util.Sources
- isFixedNumeric() - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Returns whether this Primitive is a fixed-point numeric type.
- isFlat(List<? extends RexNode>, SqlOperator) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether a call to
op
withexprs
as arguments would be considered "flat". - 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
- isFloatingPoint() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.LiteralExpression
- isFloorCeilCall(RexNode) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- isFollowing() - Method in class org.apache.calcite.rex.RexWindowBound
-
Returns if the bound is FOLLOWING.
- isFollowing() - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundBounded
- isFollowing() - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundUnbounded
- isFractionalSecondFieldInRange(BigDecimal) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- 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 - Variable in class org.apache.calcite.rel.rules.MultiJoin
- isFullOuterJoin() - Method in class org.apache.calcite.rel.rules.MultiJoin
- 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.
- 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
- isGroupExpr(SqlNode) - Method in class org.apache.calcite.sql.validate.AggChecker
- 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
- 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.InverseMapping
- 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(int[]) - Static method in class org.apache.calcite.adapter.clone.ColumnLoader
- isIdentity(List<? extends RexNode>, RelDataType) - Static method in class org.apache.calcite.rel.rules.ProjectRemoveRule
-
Deprecated.
- 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.
- isInfinite() - Method in interface org.apache.calcite.plan.RelOptCost
- isInfinite() - Method in class org.apache.calcite.plan.RelOptCostImpl
- isInfinite() - Method in class org.apache.calcite.plan.volcano.VolcanoCost
- 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
- isIntegral() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.LiteralExpression
- isInterval(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- isIntType(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- isItem(RexCall) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules
-
Returns 'string' if it is a call to item['string'], null otherwise.
- isItem(RexCall) - Static method in class org.apache.calcite.adapter.geode.rel.GeodeRules
-
Returns 'string' if it is a call to item['string'], null otherwise.
- isItem(RexCall) - Static method in class org.apache.calcite.adapter.mongodb.MongoRules
-
Returns 'string' if it is a call to item['string'], null otherwise.
- 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
- isJoinTree(RelNode) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Returns whether a RelNode corresponds to a Join that wasn't one of the original MultiJoin input factors.
- 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.SqlFunctions
- isJsonObject(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- isJsonScalar(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- isJsonValue(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- 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 class org.apache.calcite.rel.AbstractRelNode
- isKey(ImmutableBitSet) - Method in interface org.apache.calcite.rel.RelNode
-
Deprecated.
- 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.
- isKeyword(String) - Method in interface org.apache.calcite.sql.parser.SqlAbstractParserImpl.Metadata
-
Returns whether token is a keyword.
- isKeyword(String) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
- 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
- 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.
- isKnownNullable(RexNode) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Walks parent translator chain and verifies if the expression is nullable.
- isLateral(SqlNode) - Static method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- isLcsRidColumnId(int) - Static method in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer.LucidDbSpecialOperators
- 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
- isLe(RelOptCost) - Method in class org.apache.calcite.plan.volcano.VolcanoCost
- isLead - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.LeadLagImplementor
- isLeadFieldInRange(RelDataTypeSystem, BigDecimal, TimeUnit) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- isLeftFactorInRemovableSelfJoin(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- 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
- 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
- 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
- isLogicalNavigation(SqlKind) - Static method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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.
- isLowerBound(RexNode) - Static method in class org.apache.calcite.rex.RexSimplify
- 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
- isLt(RelOptCost) - Method in class org.apache.calcite.plan.volcano.VolcanoCost
- 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.
- 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 - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternValidator
- isMerge() - Method in class org.apache.calcite.rel.core.TableModify
- isMetaField() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.NamedFieldExpression
- 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
- isMissingBucket(JsonNode) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.AggregationsDeserializer
-
Determines if current key is a missing field key.
- isMissingValue(JsonNode) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping.Datatype
- 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.jdbc.CalciteSchema.SchemaPlusImpl
- isMutable() - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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) - Method in class org.apache.calcite.sql.SqlOperator
- isNameTrivial() - Method in class org.apache.calcite.rel.RelRoot
- 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
- isNegated() - Method in class org.apache.calcite.sql.fun.SqlLikeOperator
-
Returns whether this is the 'NOT LIKE' operator.
- isNestedAggregateWindow(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- isNonNegative(Double, boolean) - Static method in class org.apache.calcite.rel.metadata.RelMetadataQuery
- isNonReservedKeyword(String) - Method in interface org.apache.calcite.sql.parser.SqlAbstractParserImpl.Metadata
-
Returns true if token is a keyword but not a reserved word.
- isNonReservedKeyword(String) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
- isNormalized(Litmus, RexBuilder) - Method in class org.apache.calcite.rex.RexProgram
-
Returns whether this program is in canonical form.
- 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 a 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 an expression is definitely not true.
- 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 not 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(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.tools.RelBuilder
-
Creates a 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.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.
- isNullable(RexNode) - Method in class org.apache.calcite.rex.RexTransformer
- isNullGenerating(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- 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
- isNumeric() - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Returns whether this Primitive is a numeric type.
- isNumeric(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
- ISO_TIME_FORMAT - Static variable in class org.apache.calcite.adapter.druid.TimeExtractionFunction
- 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()).
- isOp(int) - Method in class org.apache.calcite.sql.parser.SqlParserUtil.OldTokenSequenceImpl
- isOp(int) - Method in class org.apache.calcite.sql.parser.SqlParserUtil.TokenSequenceImpl
- isOp(int) - Method in interface org.apache.calcite.sql.SqlSpecialOperator.TokenSequence
- 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.
- isOppositeOp(SqlKind, SqlKind) - Method in class org.apache.calcite.plan.RexImplicationChecker
- isOptional() - Method in interface org.apache.calcite.schema.FunctionParameter
-
Returns whether this parameter is optional.
- isOptional(int) - Method in class org.apache.calcite.sql.type.AssignableOperandTypeChecker
- 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 class org.apache.calcite.sql.type.LiteralOperandTypeChecker
- isOptional(int) - Method in class org.apache.calcite.sql.type.MultisetOperandTypeChecker
- isOptional(int) - Method in class org.apache.calcite.sql.type.OperandTypes.PeriodOperandTypeChecker
- isOptional(int) - Method in class org.apache.calcite.sql.type.SameOperandTypeChecker
- isOptional(int) - Method in class org.apache.calcite.sql.type.SetopOperandTypeChecker
- 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
- 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. - isParentsCount - Variable in class org.apache.calcite.rex.RexTransformer
- isPartial() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- isPartial() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- isPartialFunction() - Method in enum org.apache.calcite.util.mapping.MappingType
-
A mapping is a partial function if every source has at most one target.
- isPassthrough - Variable in class org.apache.calcite.sql.type.TableFunctionReturnTypeInference
- isPatternVarRef - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- isPercentage(Double, boolean) - Static method in class org.apache.calcite.rel.metadata.RelMetadataQuery
- 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
- 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 - Variable in class org.apache.calcite.plan.RelOptListener.RelEquivalenceEvent
- isPhysical() - Method in class org.apache.calcite.plan.RelOptListener.RelEquivalenceEvent
- isPhysicalNavigation(SqlKind) - Static method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- isPreceding() - Method in class org.apache.calcite.rex.RexWindowBound
-
Returns if the bound is PRECEDING.
- isPreceding() - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundBounded
- isPreceding() - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundUnbounded
- isPredicate(RelNode, int) - Method in class org.apache.calcite.rel.core.Aggregate
- IsPredicate(RexNode, SqlKind) - Constructor for class org.apache.calcite.rex.RexSimplify.IsPredicate
- 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. - isQueryable() - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableFunctionScan
- isQuoteAllIdentifiers() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isQuoteAllIdentifiers() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- 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.
- isReducible(SqlKind) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Returns whether the aggregate call is a reducible function
- 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
- isRemovableOuterJoinFactor(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- 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.
- isRepeatable - Variable in class org.apache.calcite.plan.RelOptSamplingParameters
- isRepeatable - Variable in class org.apache.calcite.sql.SqlSampleSpec.SqlTableSampleSpec
- 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.
- isReservedFunctionName(String) - Method in interface org.apache.calcite.sql.parser.SqlAbstractParserImpl.Metadata
-
Returns whether token is a reserved function name such as "CURRENT_USER".
- isReservedFunctionName(String) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
- isReservedWord(String) - Method in interface org.apache.calcite.sql.parser.SqlAbstractParserImpl.Metadata
-
Returns whether token is a reserved word.
- isReservedWord(String) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
- isRightFactorInRemovableSelfJoin(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
- isRolledUp(String) - Method in class org.apache.calcite.adapter.druid.DruidTable
- 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. - isRolledUpColumn(SqlIdentifier, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- isRolledUpColumnAllowedInAgg(SqlIdentifier, SqlValidatorScope, SqlCall, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- isRoot() - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns whether this is a root schema.
- isRowConstructor(SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- isRows - Variable in class org.apache.calcite.rel.core.Window.Group
- isRows - Variable in class org.apache.calcite.rel.logical.LogicalWindow.WindowKey
- isRows - Variable in class org.apache.calcite.rex.RexWindow
- isRows - Variable in class org.apache.calcite.sql.SqlWindow
-
Whether it is a physical (rows) or logical (values) range.
- isRows() - Method in class org.apache.calcite.rex.RexWindow
- isRows() - Method in class org.apache.calcite.sql.SqlWindow
- isRowWithDefault(SqlNode, int) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- isRuleExcluded(RelOptRule) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Determines whether a given rule is excluded by ruleDescExclusionFilter.
- isRunningOrFinal(SqlKind) - Static method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- isSafeExpression(RexNode) - Static method in class org.apache.calcite.rex.RexSimplify
-
Analyzes a given
RexNode
and decides whenever it is safe to unwind. - isSafeForReuse(DeclarationStatement) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- isSameFamily(RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether two types are scalar types of the same family, or struct types whose fields are pairwise of the same family.
- isSatisfiable(RexNode, DataContext) - Method in class org.apache.calcite.plan.RexImplicationChecker
- isScalarObject(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- 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
- isSecondaryFieldInRange(BigDecimal, TimeUnit) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- isSelectListExtraIndentFlag() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- isSelectListItem(SqlNode, SqlParserPos, String) - Static method in class org.apache.calcite.sql.advise.SqlAdvisor
- isSelectListItemsOnSeparateLines() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isSelectListItemsOnSeparateLines() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- isSelectListItemsOnSeparateLines() - Method in interface org.apache.calcite.sql.SqlWriter
-
Returns whether the items in the SELECT clause should each be on a separate line.
- isSelfJoinFilterUnique(RelMetadataQuery, LoptMultiJoin, int, int, List<RexNode>) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Determines if the equality join filters between two factors that map to the same table consist of unique, identical keys.
- isSemiJoin - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- 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() - Method in class org.apache.calcite.runtime.Resources.Prop
- isSet(Resources.Prop) - Method in enum org.apache.calcite.runtime.Resources.EmptyPropertyAccessor
- isSet(Resources.Prop) - Method in class org.apache.calcite.runtime.Resources.PropertiesAccessor
- isSet(Resources.Prop) - Method in interface org.apache.calcite.runtime.Resources.PropertyAccessor
- 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.
- 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.
- isSinglePartition() - Method in class org.apache.calcite.adapter.cassandra.CassandraFilter.Translator
-
Check if the query spans only one 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(SqlCall) - Static method in class org.apache.calcite.util.Util
-
Does nothing with its argument.
- isSingleVarRequired(SqlKind) - Static method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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
- isSortCompatible(SelectScope, SqlNode, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- isSpecial() - Method in enum org.apache.calcite.sql.type.SqlTypeName
- isSpecific() - Method in enum org.apache.calcite.sql.SqlFunctionCategory
- isSql92ReservedWord(String) - Method in interface org.apache.calcite.sql.parser.SqlAbstractParserImpl.Metadata
-
Returns whether token is a reserved word as specified by the SQL:92 standard.
- isSql92ReservedWord(String) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
- 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
- isStream(SqlNode) - Static method in class org.apache.calcite.sql2rel.SqlToRelConverter
- isStrictEnd() - Method in class org.apache.calcite.rel.core.Match
- isStrictStart() - Method in class org.apache.calcite.rel.core.Match
- isString() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.LiteralExpression
- isStrong(ImmutableBitSet, RexNode) - Method in class org.apache.calcite.rel.rules.PushProjector.InputSpecialOpFinder
- 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
- isSubQueryNonCorrelated(RelNode, SqlToRelConverter.Blackboard) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Determines whether a sub-query is non-correlated.
- isSuitableFilter(LoptMultiJoin, RexNode, int) - Method in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
-
Determines if a join filter can be used with a semijoin against a specified fact table.
- isSupportedPostAggOperation(SqlKind) - Method in class org.apache.calcite.adapter.druid.DruidTable
- isSupportedUnaryOperators(SqlKind) - Method in class org.apache.calcite.plan.RexImplicationChecker
- 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.
- isSwapped() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor.SwapResult
- 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
-
Determines whether a table is accessed at all.
- isTableAccessedForRead(List<String>) - Method in class org.apache.calcite.plan.TableAccessMap
-
Determines whether a table is accessed for read.
- isTableAccessedForWrite(List<String>) - Method in class org.apache.calcite.plan.TableAccessMap
-
Determines whether a table is accessed for write.
- isTableFunction() - Method in enum org.apache.calcite.sql.SqlFunctionCategory
- 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
- isTop() - Method in class org.apache.calcite.rel.RelDistributions.RelDistributionImpl
- isTransformable(RexNode) - Method in class org.apache.calcite.rex.RexTransformer
- isTrimUnusedFields() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Returns the
trimUnusedFields
option. - isTrimUnusedFields() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- 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() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- isTrue() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- isTrue() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A true condition value.
- isUdf(SqlOperator) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- isUnbounded() - Method in class org.apache.calcite.rex.RexWindowBound
-
Returns if the bound is unbounded.
- isUnbounded() - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundUnbounded
- isUnboundedFollowing(SqlNode) - Static method in class org.apache.calcite.sql.SqlWindow
-
Returns whether an expression represents the "UNBOUNDED FOLLOWING" bound.
- 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.
- isUpdate() - Method in class org.apache.calcite.rel.core.TableModify
- isUpperBound(RexNode) - Static method in class org.apache.calcite.rex.RexSimplify
- 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
- isValid() - Method in class org.apache.calcite.plan.SubstitutionVisitor.AbstractUnifyRule
- isValid() - Method in class org.apache.calcite.profile.ProfilerImpl.SurpriseQueue
- isValid() - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- isValid(boolean) - Method in class org.apache.calcite.rel.AbstractRelNode
- isValid(boolean) - Method in interface org.apache.calcite.rel.RelNode
-
Deprecated.
- isValid(boolean) - Method in class org.apache.calcite.util.ChunkList
-
For debugging and testing.
- isValid(boolean) - Method in class org.apache.calcite.util.PartiallyOrderedSet
-
Checks internal consistency of this lattice.
- isValid(boolean) - Method in class org.apache.calcite.util.Permutation
-
Checks whether this permutation is valid.
- isValid(int, TimeUnitRange) - Static method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- 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.materialize.Lattice
- isValid(Litmus) - Method in class org.apache.calcite.materialize.LatticeRootNode
-
Validates that nodes form a tree; each node except the first references a predecessor.
- isValid(Litmus) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Checks internal consistency.
- isValid(Litmus, RelNode.Context) - Method in class org.apache.calcite.adapter.druid.DruidQuery
- 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.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.
- isValidArgCount(SqlCallBinding) - Method in interface org.apache.calcite.sql.SqlJdbcFunctionCall.MakeCall
- isValidArgCount(SqlCallBinding) - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall.PermutingMakeCall
- 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. - isValidCount(int) - Method in class org.apache.calcite.sql.type.SqlOperandCountRanges.RangeImpl
- isValidDecimal(BigDecimal) - Static method in class org.apache.calcite.util.NumberUtil
- isValidJavaIdentifier(String) - Static method in class org.apache.calcite.util.Util
-
Returns true when input string is a valid Java identifier.
- isValidLeafCast(RexNode) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
- isValidParentKind(SqlNode) - Method in class org.apache.calcite.adapter.druid.DruidTable
- isValidPlan(Project, RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
- isValidPlan(Project, RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewAggregateRule
- isValidPlan(Project, RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewJoinRule
- isValidRelNodePlan(RelNode, RelMetadataQuery) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
Currently we only support TableScan - Project - Filter - Inner Join
- isValidSignature(String) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Returns whether a signature represents an sequence of relational operators that can be translated into a valid Druid query.
- 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.
- isValidTimeZone(String) - Static method in class org.apache.calcite.util.DateTimeStringUtils
- isValuesWithDefault(SqlNode, int) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Returns whether a query uses
DEFAULT
to populate a given column. - 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.InternalOperand
- isWeaker(SubstitutionVisitor, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor.Operand
- isWeaker(SubstitutionVisitor, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor.TargetOperand
- isWeaker(MutableRel, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor
-
Returns if one rel is weaker than another.
- isWhereListItemsOnSeparateLines() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isWhereListItemsOnSeparateLines() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- isWidening(RelDataType, RelDataType) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Returns whether one type is just a widening of another.
- isWindowDeclarationStartsLine() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- isWindowListItemsOnSeparateLines() - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- 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(SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.TableScope
- isWrapperFor(Class<?>) - Method in class org.apache.calcite.sql.validate.AbstractNamespace
- 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.
- IsXxxImplementor(Boolean, boolean) - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.IsXxxImplementor
- 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(Ast.Node, RelDataType) - Method in class org.apache.calcite.piglet.Handler
- ITEM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The item operator
[ ... ]
, used to access a given element of an array or map. - itemCount - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
-
Number of items which have been printed in this list so far.
- itemIf(String, Object, boolean) - Method in class org.apache.calcite.rel.externalize.RelJsonWriter
- itemIf(String, Object, boolean) - Method in class org.apache.calcite.rel.externalize.RelWriterImpl
- 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.
- ItemImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.ItemImplementor
- 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.Linq4j.IterableEnumerable
- iterable - Variable in class org.apache.calcite.linq4j.Linq4j.IterableEnumerator
- iterable() - Method in class org.apache.calcite.util.NameSet
-
Returns the contents as an iterable.
- iterable(Enumeration<E>) - Static method in class org.apache.calcite.adapter.spark.HttpServer
- IterableEnumerable(Iterable<T>) - Constructor for class org.apache.calcite.linq4j.Linq4j.IterableEnumerable
- iterableEnumerator(Iterable<? extends T>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Adapter that converts an iterable into an enumerator.
- IterableEnumerator(Iterable<? extends T>) - Constructor for class org.apache.calcite.linq4j.Linq4j.IterableEnumerator
- iterationIdx - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference.ExprsItr
- iterator - Variable in class org.apache.calcite.adapter.cassandra.CassandraEnumerator
- iterator - Variable in class org.apache.calcite.adapter.file.FileEnumerator
- iterator - Variable in class org.apache.calcite.adapter.geode.rel.GeodeEnumerator
- iterator - Variable in class org.apache.calcite.interpreter.Interpreter.ListSource
- iterator - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerStatementImpl
- iterator - Variable in class org.apache.calcite.jdbc.CalciteMetaImpl.LimitIterator
- iterator - Variable in class org.apache.calcite.linq4j.Linq4j.IterableEnumerator
- iterator - Variable in class org.apache.calcite.util.Filterator
- iterator - Variable in class org.apache.calcite.util.graph.DepthFirstIterator
- iterator - Variable in class org.apache.calcite.util.Pair.AdjacentIterator
- iterator - Variable in class org.apache.calcite.util.Pair.FirstAndIterator
- iterator - Variable in class org.apache.calcite.util.Pair.LeftIterator
- iterator - Variable in class org.apache.calcite.util.Pair.RightIterator
- iterator - Variable in class org.apache.calcite.util.Util.FilteringIterator
- iterator() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Aggregations
-
Iterates over the
ElasticsearchJson.Aggregation
s. - iterator() - Method in class org.apache.calcite.adapter.enumerable.OrderedAggregateLambdaFactory.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.EnumerableDefaults.LookupResultEnumerable
- iterator() - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- iterator() - Method in class org.apache.calcite.linq4j.Linq4j.IterableEnumerable
- iterator() - Method in class org.apache.calcite.linq4j.QueryableDefaults.ReplayableQueryable
- iterator() - Method in class org.apache.calcite.runtime.AbstractImmutableList
- 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.sql.validate.AggFinder.AggIterable
- iterator() - Method in class org.apache.calcite.tools.RuleSets.ListRuleSet
- iterator() - Method in class org.apache.calcite.util.ImmutableBitSet
- iterator() - Method in class org.apache.calcite.util.ImmutableIntList.EmptyImmutableIntList
- iterator() - Method in class org.apache.calcite.util.ImmutableIntList
- 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.InverseMapping
- 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.PartialFunctionImpl
- 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.Util.TransformingList
- ITERATOR_HAS_NEXT - org.apache.calcite.util.BuiltInMethod
- ITERATOR_NEXT - 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.
J
- JaninoCompiler - Class in org.apache.calcite.util.javac
- JaninoCompiler() - Constructor for class org.apache.calcite.util.javac.JaninoCompiler
- JaninoCompiler.AccountingClassLoader - Class in org.apache.calcite.util.javac
-
Refinement of JavaSourceClassLoader which keeps track of the total bytecode length of the classes it has compiled.
- 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(RelMetadataProvider) - Constructor for class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
-
Private constructor; use
JaninoRelMetadataProvider.of(org.apache.calcite.rel.metadata.RelMetadataProvider)
. - JaninoRelMetadataProvider.Key - Class in org.apache.calcite.rel.metadata
-
Key for the cache.
- JaninoRelMetadataProvider.NoHandler - Exception in org.apache.calcite.rel.metadata
-
Exception that indicates there there should be a handler for this class but there is not.
- JaninoRexCompiler - Class in org.apache.calcite.interpreter
- JaninoRexCompiler(RexBuilder) - Constructor for class org.apache.calcite.interpreter.JaninoRexCompiler
- JAR - org.apache.calcite.sql.ddl.SqlDdlNodes.FileType
- JAVA - org.apache.calcite.config.Lex
-
Lexical policy similar to Java.
- JAVA_ID_PATTERN - Static variable in class org.apache.calcite.util.Util
-
Regular expression for a valid java identifier which contains no underscores and can therefore be returned intact by
Util.toJavaId(java.lang.String, int)
. - JAVA_PLAN - org.apache.calcite.runtime.Hook
-
Called with the generated Java plan, just before it is compiled by Janino.
- JAVA_REGEX_SPECIALS - Static variable in class org.apache.calcite.runtime.Like
- JAVA_TO_SQL_METHOD_MAP - Static variable in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- JAVA_TYPE_FACTORY - Static variable in class org.apache.calcite.adapter.geode.util.GeodeUtils
- Java9Workaround - Class in org.apache.calcite.adapter
-
JavaDoc from Java 9 seems to fail when package contents is empty.
- Java9Workaround() - Constructor for class org.apache.calcite.adapter.Java9Workaround
- javaClass(JavaTypeFactory, RelDataType) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
- 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
- javaFieldClass(JavaTypeFactory, RelDataType, int) - Method in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
-
Returns the java class that is used to physically store the given field.
- javaPrimitive(RelDataType) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- 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
- javaRowClass - Variable in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- javaRowClass(JavaTypeFactory, RelDataType) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
- javaRowClass(JavaTypeFactory, RelDataType) - Method in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
- JavaRowFormat - Enum in org.apache.calcite.adapter.enumerable
-
How a row is represented as a Java value.
- JavaRowFormat() - Constructor for enum org.apache.calcite.adapter.enumerable.JavaRowFormat
- 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
- JavaToSqlTypeConversionRules.ColumnList - Interface in org.apache.calcite.sql.type
-
Make this public when needed.
- 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.RecordFieldImpl - Class in org.apache.calcite.jdbc
-
Implementation of a field.
- 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 - org.apache.calcite.model.JsonSchema.Type
- JDBC_ARRAY_TO_LIST - org.apache.calcite.util.BuiltInMethod
- JDBC_FN - org.apache.calcite.sql.SqlKind
-
Call to a function using JDBC function syntax.
- JDBC_SCHEMA_DATA_SOURCE - org.apache.calcite.util.BuiltInMethod
- JDBC_TYPE_TO_FAMILY - Static variable in enum org.apache.calcite.sql.type.SqlTypeFamily
- JDBC_TYPE_TO_NAME - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- JdbcAggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcAggregate
- JdbcAggregateRule(JdbcConvention) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcAggregateRule
-
Deprecated.
- JdbcAggregateRule(JdbcConvention, RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcAggregateRule
-
Creates a JdbcAggregateRule.
- JdbcCalc(RelOptCluster, RelTraitSet, RelNode, RexProgram) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcCalc
- JdbcCalc(RelOptCluster, RelTraitSet, RelNode, RexProgram, int) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcCalc
-
Deprecated.
- JdbcCalcRule(JdbcConvention, RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcCalcRule
-
Creates a JdbcCalcRule.
- 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
- 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
- JdbcConverterRule(Class<? extends RelNode>, RelTrait, JdbcConvention, String) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcConverterRule
-
Deprecated.
- JdbcConverterRule(Class<R>, Predicate<? super R>, RelTrait, JdbcConvention, RelBuilderFactory, String) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcConverterRule
-
Deprecated.
- JdbcConverterRule(Class<R>, Predicate<? super R>, RelTrait, JdbcConvention, RelBuilderFactory, String) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcConverterRule
- 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(JdbcConvention) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcFilterRule
-
Deprecated.
- JdbcFilterRule(JdbcConvention, RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcFilterRule
-
Creates a JdbcFilterRule.
- jdbcGet(ResultSet, int) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Gets a value from a given column in a JDBC result set.
- jdbcGetMethod(Primitive) - Method in class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverter
-
E,g,
jdbcGetMethod(int)
returns "getInt". - 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(JdbcConvention, RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcIntersectRule
-
Creates a JdbcIntersectRule.
- 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(JdbcConvention) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcJoinRule
-
Deprecated.
- JdbcJoinRule(JdbcConvention, RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcJoinRule
-
Creates a JdbcJoinRule.
- JdbcMinus(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcMinus
- JdbcMinusRule(JdbcConvention, RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcMinusRule
-
Creates a JdbcMinusRule.
- jdbcName - Variable in enum org.apache.calcite.schema.Schema.TableType
-
The name used in JDBC.
- jdbcName - Variable in class org.apache.calcite.sql.SqlJdbcFunctionCall
- jdbcOrdinal - Variable in enum org.apache.calcite.sql.type.SqlTypeName
- 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(JdbcConvention) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcProjectRule
-
Deprecated.
- JdbcProjectRule(JdbcConvention, RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcProjectRule
-
Creates a JdbcProjectRule.
- JdbcQueryProvider - Class in org.apache.calcite.adapter.jdbc
-
Implementation of
QueryProvider
that talks to JDBC databases. - JdbcQueryProvider() - Constructor for class org.apache.calcite.adapter.jdbc.JdbcQueryProvider
- 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() - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules
- JdbcRules.CheckingUserDefinedFunctionVisitor - Class in org.apache.calcite.adapter.jdbc
-
Visitor for checking whether part of projection is a user defined function or not
- 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
-
Calc operator implemented in JDBC convention.
- JdbcRules.JdbcCalcRule - Class in org.apache.calcite.adapter.jdbc
-
Rule to convert a
Calc
to anJdbcRules.JdbcCalc
. - JdbcRules.JdbcConverterRule - Class in org.apache.calcite.adapter.jdbc
-
Abstract base class for rule that converts to JDBC.
- 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(DataSource, SqlDialect, JdbcConvention, String, String, ImmutableMap<String, JdbcTable>) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcSchema
- JdbcSchema.Factory - Class in org.apache.calcite.adapter.jdbc
-
Schema factory that creates a
JdbcSchema
. - 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(JdbcConvention) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcSortRule
-
Deprecated.
- JdbcSortRule(JdbcConvention, RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcSortRule
-
Creates a JdbcSortRule.
- 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.
- JdbcTable(JdbcSchema, String, String, String, Schema.TableType) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcTable
- JdbcTable.JdbcTableQueryable<T> - Class in org.apache.calcite.adapter.jdbc
-
Enumerable that returns the contents of a
JdbcTable
by connecting to the JDBC data source. - JdbcTableModificationRule(JdbcConvention, RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcTableModificationRule
-
Creates a JdbcTableModificationRule.
- 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
- JdbcTableQueryable(QueryProvider, SchemaPlus, String) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcTable.JdbcTableQueryable
- JdbcTableScan - Class in org.apache.calcite.adapter.jdbc
-
Relational expression representing a scan of a table in a JDBC data source.
- JdbcTableScan(RelOptCluster, 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(JdbcConvention, RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverterRule
-
Creates a JdbcToEnumerableConverterRule.
- JdbcToInternalLookupTable() - Constructor for class org.apache.calcite.sql.SqlJdbcFunctionCall.JdbcToInternalLookupTable
- 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
-
Creates a JdbcToSparkConverterRule.
- JdbcUnion(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcUnion
- JdbcUnionRule(JdbcConvention) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcUnionRule
-
Deprecated.
- JdbcUnionRule(JdbcConvention, RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcUnionRule
-
Creates a JdbcUnionRule.
- 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.
- JdbcUtils - Class in org.apache.calcite.adapter.jdbc
-
Utilities for the JDBC provider.
- JdbcUtils() - Constructor for class org.apache.calcite.adapter.jdbc.JdbcUtils
- JdbcUtils.DataSourcePool - Class in org.apache.calcite.adapter.jdbc
-
Ensures that if two data sources have the same definition, they will use the same object.
- JdbcUtils.DialectPool - Class in org.apache.calcite.adapter.jdbc
-
Pool of dialects.
- JdbcUtils.ObjectArrayRowBuilder - Class in org.apache.calcite.adapter.jdbc
-
Builder that calls
ResultSet.getObject(int)
for every column, orgetXxx
if the result type is a primitivexxx
, and returns an array of objects for each row. - JdbcValues(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, RelTraitSet) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcValues
- JdbcValuesRule(JdbcConvention, RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcValuesRule
-
Creates a JdbcValuesRule.
- JETHRO - org.apache.calcite.sql.SqlDialect.DatabaseProduct
- jethroCache - Variable in class org.apache.calcite.sql.SqlDialectFactoryImpl
- 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.
- JethroDataSqlDialect.JethroInfoCacheImpl - Class in org.apache.calcite.sql.dialect
-
Implementation of
JethroInfoCache
. - JethroDataSqlDialect.JethroSupportedFunction - Class in org.apache.calcite.sql.dialect
-
Information about a function supported by Jethro.
- jethroInfo - Variable in class org.apache.calcite.sql.SqlDialect.ContextImpl
- jethroInfo() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- jethroInfo() - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- JethroInfo(Multimap<String, JethroDataSqlDialect.JethroSupportedFunction>) - Constructor for class org.apache.calcite.sql.dialect.JethroDataSqlDialect.JethroInfo
- JethroInfoCacheImpl() - Constructor for class org.apache.calcite.sql.dialect.JethroDataSqlDialect.JethroInfoCacheImpl
- JethroSupportedFunction(String, String) - Constructor for class org.apache.calcite.sql.dialect.JethroDataSqlDialect.JethroSupportedFunction
- join - Variable in class org.apache.calcite.sql.validate.JoinNamespace
- join - Variable in class org.apache.calcite.sql.validate.JoinScope
- join(Enumerable<TInner>, Function1<T, TKey>, Function1<TInner, TKey>, Function2<T, TInner, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- join(Enumerable<TInner>, Function1<T, TKey>, Function1<TInner, TKey>, Function2<T, TInner, TResult>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- join(Enumerable<TInner>, Function1<T, TKey>, Function1<TInner, TKey>, Function2<T, TInner, TResult>, EqualityComparer<TKey>, boolean, boolean) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- join(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.
- join(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.
- join(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.
- join(Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, TInner, TResult>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- join(Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, TInner, TResult>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- join(Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, TInner, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- join(Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, TInner, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- join(Enumerable<TInner>, FunctionExpression<Function1<TSource, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<TSource, TInner, TResult>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Correlates the elements of two sequences based on matching keys.
- join(Enumerable<TInner>, FunctionExpression<Function1<TSource, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<TSource, TInner, TResult>>, EqualityComparer<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Correlates the elements of two sequences based on matching keys.
- join(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.
- join(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.
- join(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.
- 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>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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<T>, Enumerable<TInner>, FunctionExpression<Function1<T, TKey>>, FunctionExpression<Function1<TInner, TKey>>, FunctionExpression<Function2<T, TInner, TResult>>, EqualityComparer<TKey>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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
- 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
. - Join - Class in org.apache.calcite.rel.core
-
Relational expression that combines two relational expressions according to some condition.
- Join(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.rel.core.Join
-
Creates a Join.
- Join(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, Set<String>) - Constructor for class org.apache.calcite.rel.core.Join
-
Deprecated.
- JOIN - org.apache.calcite.rel.mutable.MutableRelType
- JOIN - org.apache.calcite.schema.Schema.TableType
-
Join table.
- JOIN - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- JOIN - org.apache.calcite.sql.SqlKind
-
JOIN operator or compound FROM clause.
- JOIN - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Pair-wise join.
- JOIN - org.apache.calcite.util.BuiltInMethod
- JOIN - Static variable in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
-
Instance of the rule that operates only on logical expressions and generates a join.
- JOIN - Static variable in class org.apache.calcite.rel.rules.FilterJoinRule
-
Rule that pushes predicates in a Join into the inputs to the join.
- JOIN - Static variable in class org.apache.calcite.rel.rules.SemiJoinRule
- JOIN - Static variable in class org.apache.calcite.rel.rules.SubQueryRemoveRule
- join_(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
-
Implementation of join that builds the right input and probes with the left.
- JOIN_INSTANCE - Static variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Singleton rule that reduces constants inside a
Join
. - 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_PREDICATE - Static variable in class org.apache.calcite.rex.RexUtil.SubQueryFinder
-
Deprecated.
- 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. - 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
-
Creates an JoinAddRedundantSemiJoinRule.
- JoinAssociateRule - Class in org.apache.calcite.rel.rules
-
Planner rule that changes a join based on the associativity rule.
- JoinAssociateRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.JoinAssociateRule
-
Creates a JoinAssociateRule.
- JoinCommuteRule - Class in org.apache.calcite.rel.rules
-
Planner rule that permutes the inputs to a
Join
. - JoinCommuteRule(boolean) - Constructor for class org.apache.calcite.rel.rules.JoinCommuteRule
- 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
-
Creates a JoinCommuteRule.
- JoinCommuteRule.VariableReplacer - Class in org.apache.calcite.rel.rules
-
Walks over an expression, replacing references to fields of the left and right inputs.
- JoinConditionBasedPredicateInference(Join, boolean, RexNode, RexNode, RexSimplify) - Constructor for class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- JoinConditionBasedPredicateInference(Join, RexNode, RexNode, RexSimplify) - Constructor for class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- JoinConditionPushRule(RelFactories.FilterFactory, RelFactories.ProjectFactory, FilterJoinRule.Predicate) - Constructor for class org.apache.calcite.rel.rules.FilterJoinRule.JoinConditionPushRule
-
Deprecated.
- JoinConditionPushRule(RelBuilderFactory, FilterJoinRule.Predicate) - Constructor for class org.apache.calcite.rel.rules.FilterJoinRule.JoinConditionPushRule
- JoinConditionType - Enum in org.apache.calcite.sql
-
Enumerates the types of condition in a join expression.
- JoinConditionType() - Constructor for enum org.apache.calcite.sql.JoinConditionType
- joinContext(SqlImplementor.Context, SqlImplementor.Context) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- JoinContext(SqlDialect, SqlImplementor.Context, SqlImplementor.Context) - Constructor for class org.apache.calcite.rel.rel2sql.SqlImplementor.JoinContext
-
Creates a JoinContext; use
SqlImplementor.joinContext(Context, Context)
. - JoinExtractFilterRule - Class in org.apache.calcite.rel.rules
- JoinExtractFilterRule(Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.JoinExtractFilterRule
-
Creates a JoinExtractFilterRule.
- joinFactors - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Original inputs into the MultiJoin
- joinFactory - Variable in class org.apache.calcite.tools.RelBuilder
- JoinFactoryImpl() - Constructor for class org.apache.calcite.rel.core.RelFactories.JoinFactoryImpl
- joinFieldRefCountsMap - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Map containing reference counts of the fields referenced in join conditions for each join factor.
- joinFieldRefCountsMap - Variable in class org.apache.calcite.rel.rules.MultiJoin
- joinFilter - Variable in class org.apache.calcite.rel.rules.MultiJoin
- joinFilters - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Join filters associated with the MultiJoin, decomposed into a list.
- JoinInfo - Class in org.apache.calcite.rel.core
-
An analyzed join condition.
- JoinInfo(ImmutableIntList, ImmutableIntList) - Constructor for class org.apache.calcite.rel.core.JoinInfo
-
Creates a JoinInfo.
- JoinInfo.EquiJoinInfo - Class in org.apache.calcite.rel.core
-
JoinInfo that represents an equi-join.
- JoinInfo.NonEquiJoinInfo - Class in org.apache.calcite.rel.core
-
JoinInfo that represents a non equi-join.
- JoinNamespace - Class in org.apache.calcite.sql.validate
-
Namespace representing the row type produced by joining two relations.
- JoinNamespace(SqlValidatorImpl, SqlJoin) - Constructor for class org.apache.calcite.sql.validate.JoinNamespace
- JoinNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
Join
. - JoinNode(Compiler, Join) - Constructor for class org.apache.calcite.interpreter.JoinNode
- 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
-
Creates a JoinProjectTransposeRule with default factory.
- 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
-
Creates a JoinProjectTransposeRule.
- JoinProjectTransposeRule(RelOptRuleOperand, String, RelFactories.ProjectFactory) - Constructor for class org.apache.calcite.rel.rules.JoinProjectTransposeRule
-
Deprecated.
- 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
-
Creates a JoinPushExpressionsRule.
- 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
-
Creates a JoinPushThroughJoinRule.
- 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
-
Creates a JoinPushTransitivePredicatesRule.
- JoinReduceExpressionsRule(Class<? extends Join>, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.JoinReduceExpressionsRule
- JoinReduceExpressionsRule(Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.JoinReduceExpressionsRule
-
Deprecated.
- joinRel - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- JoinRelType - Enum in org.apache.calcite.rel.core
-
Enumeration of join types.
- JoinRelType() - Constructor for enum org.apache.calcite.rel.core.JoinRelType
- joinRemovalFactors - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Indicates for each factor whether its join can be removed because it is the dimension table in a semijoin.
- joinRemovalSemiJoins - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
The semijoins that allow the join of a dimension table to be removed
- 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.
- JoinScope(SqlValidatorScope, SqlValidatorScope, SqlJoin) - Constructor for class org.apache.calcite.sql.validate.JoinScope
-
Creates a
JoinScope
. - joinSelector(JoinRelType, PhysType, List<PhysType>) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
- joinSelector(SemiJoinType, PhysType, List<PhysType>) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
- joinStart - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Starting RexInputRef index corresponding to each join factor
- JoinStyle() - Constructor for enum org.apache.calcite.runtime.GeoFunctions.JoinStyle
- JoinToCorrelateRule - Class in org.apache.calcite.rel.rules
-
Rule that converts a
LogicalJoin
into aLogicalCorrelate
, which can then be implemented using nested loops. - JoinToCorrelateRule(RelFactories.FilterFactory) - Constructor for class org.apache.calcite.rel.rules.JoinToCorrelateRule
-
Deprecated.
- JoinToCorrelateRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.JoinToCorrelateRule
-
Creates a JoinToCorrelateRule.
- 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
-
Creates a JoinToMultiJoinRule.
- JoinToMultiJoinRule.InputReferenceCounter - Class in org.apache.calcite.rel.rules
-
Visitor that keeps a reference count of the inputs used by an expression.
- JoinToSemiJoinRule(Class<Join>, Class<Aggregate>, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.SemiJoinRule.JoinToSemiJoinRule
-
Creates a JoinToSemiJoinRule.
- joinTree - Variable in class org.apache.calcite.rel.rules.LoptJoinTree
- 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 - Variable in class org.apache.calcite.sql.SqlJoin
-
Value must be a
SqlLiteral
, one of the integer codes forJoinType
. - joinType(JoinRelType) - Static method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- JoinType - Enum in org.apache.calcite.sql
-
Enumerates the types of join.
- JoinType() - Constructor for enum org.apache.calcite.sql.JoinType
- joinTypes - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
If a join factor is null generating in a left or right outer join, joinTypes indicates the join type corresponding to the factor.
- joinTypes - Variable in class org.apache.calcite.rel.rules.MultiJoin
- JoinUnionTransposeRule - Class in org.apache.calcite.rel.rules
- JoinUnionTransposeRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.JoinUnionTransposeRule
-
Creates a JoinUnionTransposeRule.
- JoinVertex(int, int, int, ImmutableBitSet, double, ImmutableList<RexNode>) - Constructor for class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.JoinVertex
- JSON - org.apache.calcite.adapter.os.SqlShell.Format
- JSON - org.apache.calcite.sql.SqlExplainFormat
-
Indicates that the plan should be output in JSON format.
- JSON_API_COMMON_SYNTAX - org.apache.calcite.sql.SqlKind
-
The JSON API common syntax.
- JSON_API_COMMON_SYNTAX - org.apache.calcite.util.BuiltInMethod
- JSON_API_COMMON_SYNTAX - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_ARRAY - org.apache.calcite.util.BuiltInMethod
- JSON_ARRAY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_ARRAYAGG - org.apache.calcite.sql.SqlKind
-
The
JSON_ARRAYAGG
aggregate function. - JSON_ARRAYAGG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_ARRAYAGG_ADD - org.apache.calcite.util.BuiltInMethod
- JSON_EXISTS - org.apache.calcite.util.BuiltInMethod
- JSON_EXISTS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_MAPPER - Static variable in class org.apache.calcite.model.ModelHandler
- JSON_OBJECT - org.apache.calcite.util.BuiltInMethod
- JSON_OBJECT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_OBJECTAGG - org.apache.calcite.sql.SqlKind
-
The
JSON_OBJECTAGG
aggregate function. - JSON_OBJECTAGG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_OBJECTAGG_ADD - org.apache.calcite.util.BuiltInMethod
- JSON_PATH_BASE - Static variable in class org.apache.calcite.runtime.SqlFunctions
- JSON_PATH_JSON_PROVIDER - Static variable in class org.apache.calcite.runtime.SqlFunctions
- JSON_PATH_MAPPING_PROVIDER - Static variable in class org.apache.calcite.runtime.SqlFunctions
- JSON_QUERY - org.apache.calcite.util.BuiltInMethod
- JSON_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_STRUCTURED_VALUE_EXPRESSION - org.apache.calcite.util.BuiltInMethod
- JSON_STRUCTURED_VALUE_EXPRESSION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_VALUE_ANY - org.apache.calcite.util.BuiltInMethod
- JSON_VALUE_ANY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JSON_VALUE_EXPRESSION - org.apache.calcite.sql.SqlKind
-
The JSON value expression.
- JSON_VALUE_EXPRESSION - org.apache.calcite.util.BuiltInMethod
- JSON_VALUE_EXPRESSION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- JsonAggregation(String, String, String, String) - Constructor for class org.apache.calcite.adapter.druid.DruidQuery.JsonAggregation
- JsonAggregator() - Constructor for class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonAggregator
- jsonApiCommonSyntax(Object, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- jsonArray(SqlJsonConstructorNullClause, Object...) - Static method in class org.apache.calcite.runtime.SqlFunctions
- jsonArrayAggAdd(List, Object, SqlJsonConstructorNullClause) - Static method in class org.apache.calcite.runtime.SqlFunctions
- JsonArrayAggImplementor(Method) - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.JsonArrayAggImplementor
- JsonBound(String, String, boolean, String, boolean, boolean, ExtractionFunction) - Constructor for class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonBound
- jsonBuilder - Variable in class org.apache.calcite.rel.externalize.RelJson
- jsonBuilder - Variable in class org.apache.calcite.rel.externalize.RelJsonWriter
- JsonBuilder - Class in org.apache.calcite.util
-
Builder for JSON documents (represented as
List
,Map
,String
,Boolean
,Long
). - JsonBuilder() - Constructor for class org.apache.calcite.util.JsonBuilder
- JsonCardinalityAggregation(String, String, List<String>) - Constructor for class org.apache.calcite.adapter.druid.DruidQuery.JsonCardinalityAggregation
- JsonCollation(String, String, String) - Constructor for class org.apache.calcite.adapter.druid.DruidQuery.JsonCollation
- JsonColumn - Class in org.apache.calcite.model
-
JSON object representing a column.
- JsonColumn() - Constructor for class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonColumn
- JsonColumn() - Constructor for class org.apache.calcite.model.JsonColumn
- JsonCompositeFilter(DruidJsonFilter.Type, Iterable<? extends DruidJsonFilter>) - Constructor for class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonCompositeFilter
- JsonCompositeFilter(DruidJsonFilter.Type, DruidJsonFilter...) - Constructor for class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonCompositeFilter
- JsonCustomSchema - Class in org.apache.calcite.model
-
JSON schema element that represents a custom schema.
- JsonCustomSchema() - Constructor for class org.apache.calcite.model.JsonCustomSchema
- JsonCustomTable - Class in org.apache.calcite.model
-
Custom table schema element.
- JsonCustomTable() - Constructor for class org.apache.calcite.model.JsonCustomTable
- JsonDimHavingFilter(DruidJsonFilter) - Constructor for class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonDimHavingFilter
- JsonEnumerator - Class in org.apache.calcite.adapter.csv
-
Enumerator that reads from a JSON file.
- JsonEnumerator(Source) - Constructor for class org.apache.calcite.adapter.csv.JsonEnumerator
- jsonExists(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- jsonExists(Object, SqlJsonExistsErrorBehavior) - Static method in class org.apache.calcite.runtime.SqlFunctions
- JsonExpressionFilter(String) - Constructor for class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonExpressionFilter
- JsonExpressionPostAgg(String, String, String) - Constructor for class org.apache.calcite.adapter.druid.DruidQuery.JsonExpressionPostAgg
- jsonFilter - Variable in class org.apache.calcite.adapter.druid.DruidQuery.ScanQuery
- JsonFilteredAggregation(DruidJsonFilter, DruidQuery.JsonAggregation) - Constructor for class org.apache.calcite.adapter.druid.DruidQuery.JsonFilteredAggregation
- JsonFunction - Class in org.apache.calcite.model
-
Function schema element.
- JsonFunction() - Constructor for class org.apache.calcite.model.JsonFunction
- JsonInFilter(String, List<String>, ExtractionFunction) - Constructor for class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonInFilter
- jsonize(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- JSONIZE - org.apache.calcite.util.BuiltInMethod
- JsonJdbcSchema - Class in org.apache.calcite.model
-
JSON object representing a schema that maps to a JDBC database.
- JsonJdbcSchema() - Constructor for class org.apache.calcite.model.JsonJdbcSchema
- 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() - Constructor for class org.apache.calcite.model.JsonLattice
- JsonLimit(String, Integer, List<DruidQuery.JsonCollation>) - Constructor for class org.apache.calcite.adapter.druid.DruidQuery.JsonLimit
- JsonMapSchema - Class in org.apache.calcite.model
-
JSON object representing a schema whose tables are explicitly specified.
- JsonMapSchema() - 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() - 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() - Constructor for class org.apache.calcite.model.JsonMeasure
- jsonObject(SqlJsonConstructorNullClause, Object...) - Static method in class org.apache.calcite.runtime.SqlFunctions
- jsonObjectAggAdd(Map, String, Object, SqlJsonConstructorNullClause) - Static method in class org.apache.calcite.runtime.SqlFunctions
- JsonObjectAggImplementor(Method) - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.JsonObjectAggImplementor
- JsonParserFn(ObjectMapper, Class<T>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport.JsonParserFn
- JsonPostAggregation(String, String) - Constructor for class org.apache.calcite.adapter.druid.DruidQuery.JsonPostAggregation
- jsonQuery(Object, SqlJsonQueryWrapperBehavior, SqlJsonQueryEmptyOrErrorBehavior, SqlJsonQueryEmptyOrErrorBehavior) - Static method in class org.apache.calcite.runtime.SqlFunctions
- JsonRoot - Class in org.apache.calcite.model
-
Root schema element.
- JsonRoot() - Constructor for class org.apache.calcite.model.JsonRoot
- JsonSchema - Class in org.apache.calcite.model
-
Schema schema element.
- JsonSchema() - Constructor for class org.apache.calcite.model.JsonSchema
- JsonSchema.Type - Enum in org.apache.calcite.model
-
Built-in schema types.
- JsonSegmentMetadata() - Constructor for class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonSegmentMetadata
- JsonSelector(String, String, ExtractionFunction) - Constructor for class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonSelector
- JsonStream - Class in org.apache.calcite.model
-
Information about whether a table allows streaming.
- JsonStream() - Constructor for class org.apache.calcite.model.JsonStream
- jsonStructuredValueExpression(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- JsonTable - Class in org.apache.calcite.adapter.csv
-
Table based on a JSON file.
- JsonTable - Class in org.apache.calcite.model
-
Table schema element.
- JsonTable() - Constructor for class org.apache.calcite.model.JsonTable
- JsonTable(Source) - Constructor for class org.apache.calcite.adapter.csv.JsonTable
-
Creates a JsonTable.
- JsonTile - Class in org.apache.calcite.model
-
Materialized view within a
JsonLattice
. - JsonTile() - Constructor for class org.apache.calcite.model.JsonTile
- JsonType - Class in org.apache.calcite.model
-
Type schema element.
- JsonType() - Constructor for class org.apache.calcite.model.JsonType
- JsonTypeAttribute - Class in org.apache.calcite.model
-
JSON object representing a type attribute.
- JsonTypeAttribute() - Constructor for class org.apache.calcite.model.JsonTypeAttribute
- jsonValueAny(Object, SqlJsonValueEmptyOrErrorBehavior, Object, SqlJsonValueEmptyOrErrorBehavior, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- jsonValueExpression(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- JsonView - Class in org.apache.calcite.model
-
View schema element.
- JsonView() - Constructor for class org.apache.calcite.model.JsonView
- justFrameRowCount - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.CountWinImplementor
K
- Kev(int, Comparable) - Constructor for class org.apache.calcite.adapter.clone.ColumnLoader.Kev
- key - Variable in class org.apache.calcite.adapter.clone.ColumnLoader.Kev
- key - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Bucket
- key - Variable in class org.apache.calcite.adapter.enumerable.impl.AggResultContextImpl
- key - Variable in class org.apache.calcite.linq4j.GroupingImpl
- key - Variable in class org.apache.calcite.materialize.MaterializationActor.Materialization
- key - Variable in class org.apache.calcite.runtime.Resources.Element
- key - Variable in class org.apache.calcite.schema.impl.MaterializedViewTable
- key - Variable in class org.apache.calcite.schema.impl.MaterializedViewTable.MaterializedViewTableMacro
- key - Variable in class org.apache.calcite.sql.ddl.SqlCreateMaterializedView.MaterializedViewTable
-
The key with which this was stored in the materialization service, or null if not (yet) materialized.
- key() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Bucket
- 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() - Method in annotation type org.apache.calcite.adapter.java.Map
-
Key type.
- key(RelNode) - Static method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Computes the key for
VolcanoPlanner.mapDigestToRel
. - Key(String, int) - Constructor for class org.apache.calcite.util.CaseInsensitiveComparator.Key
- Key(String, SqlSyntax) - Constructor for class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable.Key
- Key(MetadataDef, RelMetadataProvider, ImmutableList<Class<? extends RelNode>>) - Constructor for class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider.Key
- Key(StructKind, List<String>, List<RelDataType>) - Constructor for class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.Key
- keyAsString() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Bucket
- keyBySql - Variable in class org.apache.calcite.materialize.MaterializationActor
- keyByTile - Variable in class org.apache.calcite.materialize.MaterializationActor
- keyColumns(ImmutableBitSet, ImmutableList<RexNode>) - Static method in class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Computes the closure of a set of columns according to a given list of constraints.
- 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
- keyFields - Variable in class org.apache.calcite.adapter.cassandra.CassandraTable
- keyIsNullable - Variable in class org.apache.calcite.linq4j.tree.Types.MapType
- keyIsNullable() - Method 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.
- keyMap - Variable in class org.apache.calcite.materialize.MaterializationActor
- keyOrdinalLists - Variable in class org.apache.calcite.profile.ProfilerImpl.Run
- keyOrdinalLists - Variable in class org.apache.calcite.profile.SimpleProfiler.Run
- 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.EnumerableAggregate.AggContextImpl
- keyPhysType - Variable in class org.apache.calcite.adapter.enumerable.impl.AggResultContextImpl
- keyPoset - Variable in class org.apache.calcite.profile.ProfilerImpl.Run
- 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.EnumerableAggregate.AggContextImpl
- keyResults - Variable in class org.apache.calcite.profile.SimpleProfiler.Run
- keys - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.RowKey
- keys - Variable in class org.apache.calcite.materialize.Step
- keys - Variable in class org.apache.calcite.piglet.Ast.GroupStmt
-
Grouping keys.
- keys - Variable in class org.apache.calcite.rel.core.Window.Group
- keys - Variable in class org.apache.calcite.rel.RelDistributions.RelDistributionImpl
- keys() - Method in class org.apache.calcite.rel.core.JoinInfo
- keySelector - Variable in class org.apache.calcite.adapter.enumerable.SourceSorter
- keySet() - Method in class org.apache.calcite.linq4j.LookupImpl
- keySet() - Method in class org.apache.calcite.util.CompositeMap
- keyspace - Variable in class org.apache.calcite.adapter.cassandra.CassandraSchema
- keyToType(Object) - Static method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- keyType - Variable in class org.apache.calcite.linq4j.tree.Types.MapType
- keyType - Variable in class org.apache.calcite.piglet.Ast.MapType
- keyType - Variable in class org.apache.calcite.sql.type.MapSqlType
- 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.EnumerableAggregate.AggContextImpl
- keyword - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- 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 - org.apache.calcite.sql.validate.SqlMonikerType
- keywordList - Variable in class org.apache.calcite.sql.SqlSelect
- keywords - Variable in class org.apache.calcite.sql.SqlInsert
- keywordsLowercase - Variable in class org.apache.calcite.sql.pretty.SqlFormatOptions
- keywordsLowerCase - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- 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.rel.type.RelDataTypeFactory.Builder
- kind - Variable in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.Key
- kind - Variable in class org.apache.calcite.rel.type.RelRecordType
-
Name resolution policy; usually
StructKind.FULLY_QUALIFIED
. - kind - Variable in class org.apache.calcite.rex.RexSimplify.Comparison
- kind - Variable in class org.apache.calcite.rex.RexSimplify.IsPredicate
- kind - Variable in class org.apache.calcite.sql.SqlOperator
-
See
SqlKind
. - kind - Variable in class org.apache.calcite.sql.validate.SqlValidatorScope.Step
- kind - Variable in class org.apache.calcite.sql2rel.StandardConvertletTable.AvgVarianceConvertlet
- kind - Variable in class org.apache.calcite.sql2rel.StandardConvertletTable.RegrCovarianceConvertlet
- 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.
- KINDS - Static variable in class org.apache.calcite.rex.RexFieldCollation
-
Canonical map of all combinations of
SqlKind
values that can ever occur. - klass - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport.JsonParserFn
- KNOWN_NON_NULL_METHODS - Static variable in class org.apache.calcite.linq4j.tree.OptimizeShuttle
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 - 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 - 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A lambda expression, such as
a -> a + a
in Java. - LambdaExpression - Class in org.apache.calcite.linq4j.tree
-
Describes a lambda expression.
- LambdaExpression(ExpressionType, Class) - Constructor for class org.apache.calcite.linq4j.tree.LambdaExpression
- LambdaScalarTranslator(RexBuilder, List<ParameterExpression>, List<RexNode>) - Constructor for class org.apache.calcite.prepare.CalcitePrepareImpl.LambdaScalarTranslator
- larger(Type, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- largest(Type...) - Method in class org.apache.calcite.linq4j.tree.Expressions
- last - Variable in class org.apache.calcite.util.ChunkList
- last - Variable in class org.apache.calcite.util.PrecedenceClimbingParser
- last - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Result
- 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.linq4j.tree.ConditionalStatement
- 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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- last(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- last(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- last(FunctionExpression<Predicate1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Returns the last element of a sequence that satisfies a specified condition.
- LAST - org.apache.calcite.config.NullCollation
-
Nulls last for DESC and ASC.
- LAST - org.apache.calcite.rel.RelFieldCollation.NullDirection
- LAST - org.apache.calcite.sql.SqlKind
- LAST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
LAST
function to be used withinMATCH_RECOGNIZE
. - LAST_ID - Static variable in class org.apache.calcite.chinook.PreferredAlbumsTableFactory
- LAST_ID - Static variable in class org.apache.calcite.chinook.PreferredGenresTableFactory
- LAST_VALUE - 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. - lastAlias - Variable in class org.apache.calcite.tools.PigRelBuilder
- lastDay(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
- 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.util.ImmutableIntList
- lastNanoTime - Variable in class org.apache.calcite.util.trace.CalciteTimingTracer
- 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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- lastOrDefault(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- lastOrDefault(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- lastOrDefault(FunctionExpression<Predicate1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Returns the last element of a sequence that satisfies a condition or a default value if no such element is found.
- lastRel - Variable in class org.apache.calcite.rel.externalize.RelJsonReader
- lastRet - Variable in class org.apache.calcite.util.ChunkList.ChunkListIterator
-
Offset within the current chunk of the last element returned.
- LastValueImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.LastValueImplementor
- LATERAL - 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. - latest - Variable in class org.apache.calcite.adapter.splunk.SplunkQuery
- latest - Variable in class org.apache.calcite.adapter.splunk.SplunkTableScan
- lattice - Variable in class org.apache.calcite.jdbc.CalciteSchema.LatticeEntryImpl
- lattice - Variable in class org.apache.calcite.materialize.CachingLatticeStatisticProvider
- lattice - Variable in class org.apache.calcite.materialize.Lattice.SqlWriter
- lattice - Variable in class org.apache.calcite.materialize.SqlLatticeStatisticProvider
- lattice - Variable in class org.apache.calcite.materialize.TileKey
- lattice - Variable in class org.apache.calcite.materialize.TileSuggester
- lattice - Variable in class org.apache.calcite.materialize.TileSuggester.StatisticsProviderImpl
- 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(CalciteSchema, LatticeRootNode, boolean, boolean, long, LatticeStatisticProvider.Factory, Double, ImmutableList<Lattice.Column>, ImmutableSortedSet<Lattice.Measure>, ImmutableList<Lattice.Tile>) - Constructor for class org.apache.calcite.materialize.Lattice
- Lattice.BaseColumn - Class in org.apache.calcite.materialize
-
Column in a lattice.
- Lattice.Builder - Class in org.apache.calcite.materialize
-
Lattice builder.
- Lattice.Builder.Fixer - Class in org.apache.calcite.materialize
-
Work space for fixing up a tree of mutable nodes.
- 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.Edge - Class in org.apache.calcite.materialize
-
Edge in the temporary graph.
- 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.
- Lattice.Vertex - Class in org.apache.calcite.materialize
-
Vertex in the temporary graph.
- latticeBuilder - Variable in class org.apache.calcite.model.ModelHandler
- latticeByName - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Map of lattices by the qualified name of their star table.
- LatticeChildNode - Class in org.apache.calcite.materialize
-
Non-root node in a
Lattice
. - LatticeChildNode(LatticeSpace, LatticeNode, MutableNode) - Constructor for class org.apache.calcite.materialize.LatticeChildNode
- 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
- latticeMap - Variable in class org.apache.calcite.materialize.LatticeSuggester
-
Lattices, indexed by digest.
- LatticeNode - Class in org.apache.calcite.materialize
-
Source relation of a lattice.
- LatticeNode(LatticeSpace, LatticeNode, MutableNode) - Constructor for class org.apache.calcite.materialize.LatticeNode
-
Creates a LatticeNode.
- LatticeRootNode - Class in org.apache.calcite.materialize
-
Root node in a
Lattice
. - LatticeRootNode(LatticeSpace, MutableNode) - Constructor for class org.apache.calcite.materialize.LatticeRootNode
- lattices - Variable in class org.apache.calcite.model.JsonSchema
- Lattices - Class in org.apache.calcite.materialize
-
Utilities for
Lattice
,LatticeStatisticProvider
. - Lattices() - Constructor for class org.apache.calcite.materialize.Lattices
- LatticeSpace - Class in org.apache.calcite.materialize
-
Space within which lattices exist.
- LatticeSpace(SqlStatisticProvider) - Constructor for class org.apache.calcite.materialize.LatticeSpace
- 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.
- LatticeSuggester.BaseColRef - Class in org.apache.calcite.materialize
-
Reference to a base column.
- LatticeSuggester.ColRef - Class in org.apache.calcite.materialize
-
Column reference.
- LatticeSuggester.DerivedColRef - Class in org.apache.calcite.materialize
-
Reference to a derived column (that is, an expression).
- LatticeSuggester.Frame - Class in org.apache.calcite.materialize
-
Information about the parent of fields from a relational expression.
- LatticeSuggester.Hop - Class in org.apache.calcite.materialize
-
A hop is a join condition.
- LatticeSuggester.MutableMeasure - Class in org.apache.calcite.materialize
-
An aggregate call.
- LatticeSuggester.Query - Class in org.apache.calcite.materialize
-
Holds state for a particular query graph.
- LatticeSuggester.StepRef - Class in org.apache.calcite.materialize
-
Use of a step within a query.
- LatticeSuggester.StepRef.Factory - Class in org.apache.calcite.materialize
-
Creates
LatticeSuggester.StepRef
instances. - LatticeSuggester.TableRef - Class in org.apache.calcite.materialize
-
Use of a table within a query.
- LatticeTable - Class in org.apache.calcite.materialize
-
Table registered in the graph.
- LatticeTable(RelOptTable) - Constructor for class org.apache.calcite.materialize.LatticeTable
- LAX - org.apache.calcite.runtime.SqlFunctions.PathMode
- layout(Random, PrintWriter) - Method in class org.apache.calcite.example.maze.Maze
- LazySource() - Constructor for class org.apache.calcite.adapter.enumerable.OrderedAggregateLambdaFactory.LazySource
- LcsIndexOptimizer(LoptSemiJoinOptimizer.LcsTableScan) - Constructor for class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer.LcsIndexOptimizer
- LcsTable() - Constructor for class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer.LcsTable
- LcsTableScan() - Constructor for class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer.LcsTableScan
- le(boolean, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≤
operator applied to boolean values. - le(String, 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(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
≤
operator applied to ByteString values. - le(RexBuilder, RexNode, RexNode) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- LEAD - 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 - org.apache.calcite.sql.fun.SqlTrimFunction.Flag
- LeadLagImplementor(boolean) - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.LeadLagImplementor
- Leaf(int, LoptJoinTree) - Constructor for class org.apache.calcite.rel.rules.LoptJoinTree.Leaf
- LEAF - org.apache.calcite.plan.RelOptRuleOperandChildPolicy
-
Signifies that operand has no children.
- LEAF_CHILDREN - Static variable in class org.apache.calcite.plan.RelOptRuleOperandChildren
- leafToRanges(RexCall, boolean) - Static method in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
- LeafVertex(int, RelNode, double, int) - Constructor for class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.LeafVertex
- 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 - org.apache.calcite.sql.SqlKind
-
The "LEAST" function (Oracle).
- LEAST - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
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_RESTRICTIVE - 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 (that is, one type to which they can all be cast), or null if conversion is not possible.
- leastRestrictive(List<RelDataType>) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- leastRestrictive(List<RelDataType>) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- leastRestrictiveByCast(List<RelDataType>) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- 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
type0
andtype1
using=
. - leastRestrictiveSqlType(List<RelDataType>) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryImpl
- 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.MutableBiRel
- left - Variable in class org.apache.calcite.rel.rules.LoptJoinTree.Node
- left - Variable in enum org.apache.calcite.sql.fun.SqlTrimFunction.Flag
- left - Variable in class org.apache.calcite.sql.SqlJoin
- left - Variable in class org.apache.calcite.tools.RelBuilder.Shifter
- left - Variable in class org.apache.calcite.util.Pair
- left - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Token
- left() - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- left(Iterable<? extends Map.Entry<L, R>>) - Static method in class org.apache.calcite.util.Pair
-
Returns an iterable over the left slice of an iterable.
- left(List<? extends Map.Entry<K, 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 - org.apache.calcite.example.maze.Maze.Direction
- LEFT - org.apache.calcite.linq4j.CorrelateJoinType
-
Left-outer join
- LEFT - org.apache.calcite.plan.RelOptUtil.Side
- LEFT - org.apache.calcite.rel.core.JoinRelType
- LEFT - org.apache.calcite.sql.JoinType
-
Left outer join.
- LEFT - org.apache.calcite.sql.SemiJoinType
-
Left-outer join
- 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 class org.apache.calcite.util.mapping.IntPair
-
Function that returns the left (source) side of a pair.
- LEFT_PROJECT - Static variable in class org.apache.calcite.rel.rules.JoinProjectTransposeRule
- LEFT_PROJECT_INCLUDE_OUTER - Static variable in class org.apache.calcite.rel.rules.JoinProjectTransposeRule
- LEFT_RIGHT - Static variable in class org.apache.calcite.adapter.enumerable.EnumUtils
- LEFT_SEMI_JOIN - org.apache.calcite.sql.JoinType
-
Left semi join.
- LEFT_UNION - Static variable in class org.apache.calcite.rel.rules.JoinUnionTransposeRule
- leftChildPredicates - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- leftContext - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.JoinContext
- leftDestFields - Variable in class org.apache.calcite.plan.RelOptUtil.RexInputConverter
- leftEnumerator - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- leftFactor - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin.RemovableSelfJoin
-
The left factor in a removable self-join
- leftFactor - Variable in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.JoinVertex
- leftFields - Variable in class org.apache.calcite.rel.rules.JoinCommuteRule.VariableReplacer
- leftFields - Variable in class org.apache.calcite.rel.rules.PushProjector.InputSpecialOpFinder
- leftFieldsBitSet - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- leftInferredPredicates - Variable in class org.apache.calcite.plan.RelOptPredicateList
-
Predicates that were inferred from the right input.
- leftIterator - Variable in class org.apache.calcite.util.Pair.ZipIterator
- LeftIterator(Iterator<? extends Map.Entry<L, R>>) - Constructor for class org.apache.calcite.util.Pair.LeftIterator
- leftKeys - Variable in class org.apache.calcite.rel.core.EquiJoin
- leftKeys - Variable in class org.apache.calcite.rel.core.JoinInfo
- leftKeys - Variable in class org.apache.calcite.rel.mutable.MutableSemiJoin
- leftPrec - Variable in class org.apache.calcite.sql.SqlOperator
-
The precedence with which this operator binds to the expression to the left.
- leftPrec(int, boolean) - Static method in class org.apache.calcite.sql.SqlOperator
- lefts - Variable in class org.apache.calcite.example.maze.Maze
- lefts - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- 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 - 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise left-shift compound assignment, such as (a <<= b).
- leftSource - Variable in class org.apache.calcite.interpreter.JoinNode
- length - Variable in class org.apache.calcite.benchmarks.ParserBenchmark
- 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. - LENIENT - org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that allows just about everything supported by Calcite.
- LESS_THAN - org.apache.calcite.sql.SqlKind
-
The less-than operator, "<".
- LESS_THAN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Logical less-than operator, '
<
'. - LESS_THAN_OR_EQUAL - org.apache.calcite.sql.SqlKind
-
The 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 - 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 - 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A "less than or equal to" comparison, such as (a <= b).
- level - Variable in class org.apache.calcite.linq4j.tree.ExpressionWriter
- level - Variable in class org.apache.calcite.rel.mutable.MutableRel.MutableRelDumper
- level - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter.InputToCommonExprConverter
- level - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter.MaxInputFinder
- lex() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- lex() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- Lex - Enum in org.apache.calcite.config
-
Named, built-in lexical policy.
- Lex(Quoting, Casing, Casing, boolean) - Constructor for enum org.apache.calcite.config.Lex
- LEX - org.apache.calcite.config.CalciteConnectionProperty
-
Lexical policy.
- liberal() - Static method in class org.apache.calcite.sql.validate.SqlNameMatchers
-
Creates a name matcher that can suggest corrections to what the user typed.
- LiberalNameMatcher() - Constructor for class org.apache.calcite.sql.validate.SqlNameMatchers.LiberalNameMatcher
- library - Variable in class org.apache.calcite.sql.ddl.SqlCreateForeignSchema
- like(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LIKE
function. - like(String, String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LIKE
function with escape. - like(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- like(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- like(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- Like - Class in org.apache.calcite.runtime
-
Utilities for converting SQL
LIKE
andSIMILAR
operators to regular expressions. - Like() - Constructor for class org.apache.calcite.runtime.Like
- LIKE - org.apache.calcite.sql.SqlKind
-
The "LIKE" operator.
- LIKE - org.apache.calcite.util.BuiltInMethod
- LIKE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- 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 - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonLimit
- limit - Variable in class org.apache.calcite.adapter.elasticsearch.Scrolling.SequentialIterator
- limit - Variable in class org.apache.calcite.jdbc.CalciteMetaImpl.LimitIterator
- limit - Variable in class org.apache.calcite.plan.hep.HepInstruction.MatchLimit
- limit - Variable in class org.apache.calcite.rex.RexUtil.ForwardRefFinder
- limit(int, int) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a limit 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() - Constructor for enum org.apache.calcite.sql.type.SqlTypeName.Limit
- LIMIT - org.apache.calcite.piglet.Ast.Op
- LimitIterator(Iterator<E>, long) - Constructor for class org.apache.calcite.jdbc.CalciteMetaImpl.LimitIterator
- limitStartCountNotAllowed() - 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
- limitValue - Variable in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- 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).
- lineLength - Variable in class org.apache.calcite.sql.pretty.SqlFormatOptions
- lineLength - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- lineNumber - Variable in class org.apache.calcite.sql.parser.SqlParserPos
- lines(Iterable<String>) - Static method in class org.apache.calcite.util.Util
-
Converts a list of strings to a string separated by newlines.
- LINESTRING - org.apache.calcite.runtime.GeoFunctions.Type
- LINGER - Static variable in class org.apache.calcite.runtime.SocketFactoryImpl
-
amount of time to linger
- link - Variable in class org.apache.calcite.materialize.LatticeChildNode
- Linq4j - Class in org.apache.calcite.linq4j
-
Utility and factory methods for Linq4j.
- Linq4j() - Constructor for class org.apache.calcite.linq4j.Linq4j
- Linq4j.CartesianProductListEnumerator<E> - Class in org.apache.calcite.linq4j
-
Enumerates over the cartesian product of the given lists, returning a list for each row.
- Linq4j.CollectionEnumerable<T> - Class in org.apache.calcite.linq4j
-
Collection enumerable.
- Linq4j.CompositeEnumerable<E> - Class in org.apache.calcite.linq4j
-
Composite enumerable.
- Linq4j.EnumeratorIterator<T> - Class in org.apache.calcite.linq4j
-
Iterator that reads from an underlying
Enumerator
. - Linq4j.IterableEnumerable<T> - Class in org.apache.calcite.linq4j
-
Iterable enumerable.
- Linq4j.IterableEnumerator<T> - Class in org.apache.calcite.linq4j
-
Iterable enumerator.
- Linq4j.ListEnumerable<T> - Class in org.apache.calcite.linq4j
-
List enumerable.
- Linq4j.ListEnumerator<V> - Class in org.apache.calcite.linq4j
-
Enumerator optimized for random-access list.
- Linq4j.SingletonEnumerator<E> - Class in org.apache.calcite.linq4j
-
Enumerator that returns one element.
- Linq4j.SingletonNullEnumerator<E> - Class in org.apache.calcite.linq4j
-
Enumerator that returns one null element.
- list - Variable in class org.apache.calcite.adapter.clone.ColumnLoader
- list - Variable in class org.apache.calcite.adapter.clone.ListTable
- list - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
- list - Variable in class org.apache.calcite.adapter.enumerable.OrderedAggregateLambdaFactory.LazySource
- list - Variable in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- list - Variable in class org.apache.calcite.adapter.mongodb.MongoRel.Implementor
- list - Variable in class org.apache.calcite.interpreter.Interpreter.ListSink
- list - Variable in class org.apache.calcite.interpreter.Interpreter.ListSource
- list - Variable in class org.apache.calcite.linq4j.Linq4j.ListEnumerator
- list - Variable in class org.apache.calcite.plan.volcano.RuleQueue.PhaseMatchList
-
Current list of VolcanoRuleMatches for this phase.
- list - Variable in class org.apache.calcite.runtime.FlatLists.ComparableListImpl
- list - Variable in class org.apache.calcite.runtime.SqlFunctions.ProductComparableListEnumerator
- list - Variable in class org.apache.calcite.sql.parser.SqlParserUtil.OldTokenSequenceImpl
- list - Variable in class org.apache.calcite.sql.parser.SqlParserUtil.TokenSequenceImpl
- list - Variable in class org.apache.calcite.sql.SqlNodeList
- list - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.AggregateFinder
- list - Variable in class org.apache.calcite.util.CastingList
- list - Variable in class org.apache.calcite.util.Closer
- list - Variable in class org.apache.calcite.util.Util.TransformingList
- list() - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an empty fluent list.
- list() - Method in class org.apache.calcite.util.JsonBuilder
-
Creates a JSON object (represented by a
List
). - list(E, E[]) - Static method in class org.apache.calcite.util.CompositeMap
- list(Iterable<SqlTypeName>) - Static method in class org.apache.calcite.sql.type.SqlTypeExplicitPrecedenceList
- list(Iterable<T>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a fluent list with elements from the given collection.
- list(String, String, String, Iterable<?>) - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
- list(ExpressionWriter, List, String, String, String) - Static method in class org.apache.calcite.linq4j.tree.ConstantExpression
- list(SqlTypeName...) - Static method in class org.apache.calcite.sql.type.SqlTypeExplicitPrecedenceList
- list(T...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a fluent list with given elements.
- LIST - org.apache.calcite.adapter.enumerable.JavaRowFormat
-
A list that is comparable and immutable.
- LIST - org.apache.calcite.runtime.SqlFunctions.FlatProductInputType
- LIST_AS_ENUMERABLE - Static variable in class org.apache.calcite.runtime.SqlFunctions
- LIST_GET - org.apache.calcite.util.BuiltInMethod
- LIST_N - org.apache.calcite.util.BuiltInMethod
- LIST2 - org.apache.calcite.util.BuiltInMethod
- LIST3 - org.apache.calcite.util.BuiltInMethod
- LIST4 - org.apache.calcite.util.BuiltInMethod
- LIST5 - org.apache.calcite.util.BuiltInMethod
- LIST6 - org.apache.calcite.util.BuiltInMethod
- 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.
- listener - Variable in class org.apache.calcite.plan.AbstractRelOptPlanner
- listener - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Listener for this planner, or null if none set.
- listeners - Variable in class org.apache.calcite.plan.MulticastRelOptListener
- ListEnumerable(List<T>) - Constructor for class org.apache.calcite.linq4j.Linq4j.ListEnumerable
- listEnumerator(List<? extends V>) - Static method in class org.apache.calcite.linq4j.Linq4j
- ListEnumerator(List<? extends V>) - Constructor for class org.apache.calcite.linq4j.Linq4j.ListEnumerator
- listGetter(List<Map.Entry<String, Class>>) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchEnumerators
-
Function that extracts a given set of fields from elastic search result objects.
- listGetter(List<Map.Entry<String, Class>>) - Static method in class org.apache.calcite.adapter.mongodb.MongoEnumerator
- 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 - 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.AbstractImmutableList
- listIterator() - Method in class org.apache.calcite.runtime.ConsList
- listIterator() - Method in class org.apache.calcite.util.ImmutableIntList.EmptyImmutableIntList
- listIterator() - Method in class org.apache.calcite.util.ImmutableIntList
- listIterator(int) - Method in class org.apache.calcite.runtime.AbstractImmutableList
- listIterator(int) - Method in class org.apache.calcite.runtime.ConsList
- listIterator(int) - Method in class org.apache.calcite.util.ChunkList
- listIterator(int) - Method in class org.apache.calcite.util.ImmutableIntList
- listMatches(List<String>, List<String>) - Method in class org.apache.calcite.sql.validate.SqlNameMatchers.BaseMatcher
- listMatches(List<String>, List<String>) - Method in class org.apache.calcite.sql.validate.SqlNameMatchers.LiberalNameMatcher
- 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.
- ListRuleSet(ImmutableList<RelOptRule>) - Constructor for class org.apache.calcite.tools.RuleSets.ListRuleSet
- lists - Variable in class org.apache.calcite.util.CompositeList
- 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
- ListSink(ArrayDeque<Row>) - Constructor for class org.apache.calcite.interpreter.Interpreter.ListSink
- ListSource(ArrayDeque<Row>) - Constructor for class org.apache.calcite.interpreter.Interpreter.ListSource
- 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
- ListSqlOperatorTable(List<SqlOperator>) - Constructor for class org.apache.calcite.sql.util.ListSqlOperatorTable
- listStack - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- ListTable - Class in org.apache.calcite.adapter.clone
-
Implementation of table that reads rows from a read-only list and returns an enumerator of rows.
- ListTable(Type, RelProtoDataType, Expression, List) - Constructor for class org.apache.calcite.adapter.clone.ListTable
-
Creates a ListTable.
- listToString(List<String>) - Static method in class org.apache.calcite.util.Util
-
Converts ["ab", "c"] to "ab"."c".
- listTypesFromElastic() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchema
-
Queries
_mapping
definition to automatically detect all types for an index - literal - Variable in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.LiteralExpression
- literal - Variable in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor.SwapResult
- literal - Variable in class org.apache.calcite.rex.RexSimplify.Comparison
- literal(Object) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a literal (constant expression).
- 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 - org.apache.calcite.piglet.Ast.Op
- LITERAL - 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_CHAIN - org.apache.calcite.sql.SqlKind
-
Literal chain operator (for composite string literals).
- LITERAL_CHAIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- LiteralExpression(RexLiteral) - Constructor for class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.LiteralExpression
- literalList - Variable in class org.apache.calcite.rel.rules.ValuesReduceRule.MyRexShuttle
- 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
- literalValue(RexLiteral) - Static method in class org.apache.calcite.adapter.cassandra.CassandraFilter.Translator
-
Convert the value of a literal to a string.
- literalValue(RexLiteral) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
- literalValue(RexLiteral) - Static method in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
-
Converts the value of a literal to a string.
- literalValue(RexLiteral) - Static method in class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
- 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.
- LixToRelTranslator - Class in org.apache.calcite.prepare
- LixToRelTranslator(RelOptCluster, Prepare) - Constructor for class org.apache.calcite.prepare.LixToRelTranslator
- ln(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LN(number)
function applied to double values. - ln(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LN(number)
function applied to BigDecimal values. - LN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- load(String, RexNode, RelDataType) - Method in class org.apache.calcite.tools.PigRelBuilder
-
Loads a data set.
- load(RelDataType, List<ColumnMetaData.Rep>, int[]) - Method in class org.apache.calcite.adapter.clone.ColumnLoader
- LOAD - org.apache.calcite.piglet.Ast.Op
- load3(MetadataDef<M>, Multimap<Method, MetadataHandler<M>>, ImmutableList<Class<? extends RelNode>>) - Static method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- loader(RelMetadataProvider) - Static method in class org.apache.calcite.rel.metadata.MetadataFactoryImpl
- LoadStmt(SqlParserPos, Ast.Identifier, Ast.Literal) - Constructor for class org.apache.calcite.piglet.Ast.LoadStmt
- local - Variable in class org.apache.calcite.adapter.druid.TimeExtractionFunction
- LOCAL - org.apache.calcite.sql.SqlDialect.CalendarPolicy
- LOCAL_REF - org.apache.calcite.sql.SqlKind
-
Reference to a sub-expression computed within the current relational operator.
- LOCAL_TEMPORARY - org.apache.calcite.schema.Schema.TableType
-
A table that is only visible to one connection.
- LOCAL_TIME - org.apache.calcite.util.BuiltInMethod
- LOCAL_TIMESTAMP - org.apache.calcite.DataContext.Variable
-
The time at which the current statement started executing.
- LOCAL_TIMESTAMP - org.apache.calcite.util.BuiltInMethod
- LOCAL_TZ - Static variable in class org.apache.calcite.runtime.SqlFunctions
- localDateTime - Variable in class org.apache.calcite.util.TimestampWithTimeZoneString
- locale - Variable in class org.apache.calcite.runtime.Resources.Inst
- locale - Variable in class org.apache.calcite.sql.parser.SqlParserUtil.ParsedCollation
- locale - Variable in class org.apache.calcite.sql.SqlCollation
- localExprList - Variable in class org.apache.calcite.rex.RexProgramBuilder.RegisterMidputShuttle
- localExprList - Variable in class org.apache.calcite.rex.RexProgramBuilder.RegisterOutputShuttle
- localIpAddress - Static variable in class org.apache.calcite.adapter.spark.HttpServer
- localIpAddress() - Static method in class org.apache.calcite.adapter.spark.HttpServer
-
Get the local host's IP address in dotted-quad format (e.g.
- localize(Locale) - Method in class org.apache.calcite.runtime.Resources.ExInstWithCause
- localize(Locale) - Method in class org.apache.calcite.runtime.Resources.Inst
- localRefList - Variable in class org.apache.calcite.rex.RexProgramBuilder
- localTime - Variable in class org.apache.calcite.util.TimeWithTimeZoneString
- 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. - locate(int) - Method in class org.apache.calcite.util.ChunkList
- 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.
- 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
- locatorHost - Variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchema
- locatorPort - Variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchema
- locked - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Whether the planner can accept new rules.
- log10(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LOG10(numeric)
operator applied to double values. - log10(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LOG10(number)
function applied to BigDecimal values. - LOG10 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- log2(int) - Static method in class org.apache.calcite.adapter.clone.ColumnLoader
- log2(long) - Static method in class org.apache.calcite.adapter.clone.ColumnLoader
- logger - Variable in class org.apache.calcite.util.trace.CalciteLogger
- logger - Variable in class org.apache.calcite.util.trace.CalciteTimingTracer
- LOGGER - Static variable in class org.apache.calcite.adapter.cassandra.CassandraSchema
- 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.elasticsearch.ElasticsearchTable
- LOGGER - Static variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- LOGGER - Static variable in class org.apache.calcite.adapter.enumerable.EnumerableRules
- LOGGER - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeEnumerator
- LOGGER - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeTable
- 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 class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- LOGGER - Static variable in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- 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.plan.RexImplicationChecker
- LOGGER - Static variable in class org.apache.calcite.plan.SubstitutionVisitor
- LOGGER - Static variable in class org.apache.calcite.plan.VisitorDataContext
- LOGGER - Static variable in class org.apache.calcite.plan.volcano.RelSet
- LOGGER - Static variable in class org.apache.calcite.plan.volcano.RelSubset
- LOGGER - Static variable in class org.apache.calcite.plan.volcano.RuleQueue
- LOGGER - Static variable in class org.apache.calcite.prepare.Prepare
- LOGGER - Static variable in class org.apache.calcite.rel.AbstractRelNode
- LOGGER - Static variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
- LOGGER - Static variable in class org.apache.calcite.rel.rules.ValuesReduceRule
- LOGGER - Static variable in exception org.apache.calcite.runtime.CalciteException
- LOGGER - Static variable in class org.apache.calcite.runtime.ResultSetEnumerable
- LOGGER - Static variable in class org.apache.calcite.sql.advise.SqlAdvisor
- LOGGER - Static variable in class org.apache.calcite.sql.parser.SqlParserUtil
- 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.sql.SqlDialectFactoryImpl
- LOGGER - Static variable in exception org.apache.calcite.sql.validate.SqlValidatorException
- LOGGER - Static variable in class org.apache.calcite.util.Benchmark
-
Certain tests are enabled only if logging is enabled at debug level or higher.
- logic - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.SubQuery
- Logic() - Constructor for enum org.apache.calcite.plan.RelOptUtil.Logic
- LOGICAL - org.apache.calcite.sql.SqlExplain.Depth
- 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. - LogicalAggregate - Class in org.apache.calcite.rel.logical
-
LogicalAggregate
is a relational operator which eliminates duplicates and computes totals. - LogicalAggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.rel.logical.LogicalAggregate
-
Creates a LogicalAggregate.
- 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.
- LogicalCalc - Class in org.apache.calcite.rel.logical
-
A relational expression which computes project expressions and also filters.
- LogicalCalc(RelOptCluster, RelTraitSet, RelNode, RexProgram) - Constructor for class org.apache.calcite.rel.logical.LogicalCalc
-
Creates a LogicalCalc.
- LogicalCalc(RelOptCluster, RelTraitSet, RelNode, RexProgram, List<RelCollation>) - Constructor for class org.apache.calcite.rel.logical.LogicalCalc
-
Deprecated.
- 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, RelNode, RelNode, CorrelationId, ImmutableBitSet, SemiJoinType) - Constructor for class org.apache.calcite.rel.logical.LogicalCorrelate
-
Creates a LogicalCorrelate.
- LogicalCorrelate(RelOptCluster, RelNode, RelNode, CorrelationId, ImmutableBitSet, SemiJoinType) - 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(RelOptCluster, RelTraitSet, RelNode, RelDistribution) - Constructor for class org.apache.calcite.rel.logical.LogicalExchange
- 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, 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<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, 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, 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, List<RexNode>, 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<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, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.rel.logical.LogicalProject
-
Creates a LogicalProject.
- 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<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.
- LogicalSort - Class in org.apache.calcite.rel.logical
-
Sub-class of
Sort
not targeted at any particular engine or calling convention. - LogicalSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.calcite.rel.logical.LogicalSort
- 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(RelOptCluster, RelTraitSet, RelNode, RelDistribution, RelCollation) - Constructor for class org.apache.calcite.rel.logical.LogicalSortExchange
- 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<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.
- 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, RelOptTable) - Constructor for class org.apache.calcite.rel.logical.LogicalTableScan
-
Creates a LogicalTableScan.
- LogicalTableScan(RelInput) - Constructor for class org.apache.calcite.rel.logical.LogicalTableScan
-
Creates a LogicalTableScan by parsing serialized output.
- 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<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, 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, RelNode, List<RexLiteral>, RelDataType, List<Window.Group>) - Constructor for class org.apache.calcite.rel.logical.LogicalWindow
-
Creates a LogicalWindow.
- LogicalWindow.WindowKey - Class in org.apache.calcite.rel.logical
-
Group specification.
- logicCollection - Variable in class org.apache.calcite.rex.LogicVisitor
- LogicVisitor - Class in org.apache.calcite.rex
-
Visitor pattern for traversing a tree of
RexNode
objects. - LogicVisitor(RexNode, Collection<RelOptUtil.Logic>) - Constructor for class org.apache.calcite.rex.LogicVisitor
-
Creates a LogicVisitor.
- login(EnvironmentFairy.User) - Static method in class org.apache.calcite.chinook.EnvironmentFairy
- logWarning(String) - Static method in class org.apache.calcite.adapter.spark.HttpServer
- LONG - org.apache.calcite.adapter.csv.CsvFieldType
- LONG - org.apache.calcite.adapter.druid.DruidType
- LONG - org.apache.calcite.adapter.file.FileFieldType
- LONG - org.apache.calcite.linq4j.tree.Primitive
- LONG_B - Static variable in class org.apache.calcite.adapter.clone.ColumnLoader
- LONG_MAX - Static variable in class org.apache.calcite.linq4j.Extensions
- LONG_MIN - Static variable in class org.apache.calcite.linq4j.Extensions
- LONG_S - Static variable in class org.apache.calcite.adapter.clone.ColumnLoader
- LONG_SUM - Static variable in class org.apache.calcite.linq4j.Extensions
- LONG_VALUE - 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() - Method in class org.apache.calcite.linq4j.Linq4j.CollectionEnumerable
- 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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- longCount(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- longCount(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- longCount(FunctionExpression<Predicate1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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. - LONGNVARCHAR - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- 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
- longValue() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.LiteralExpression
- longValue(boolean) - Method in class org.apache.calcite.sql.SqlLiteral
-
Returns the long value of this literal.
- lookAhead - Variable in class org.apache.calcite.util.Filterator
- lookup(int, SqlToRelConverter.LookupContext) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Creates an expression with which to reference the expression whose offset in its from-list is
offset
. - lookup(Class) - Method in class org.apache.calcite.sql.type.JavaToSqlTypeConversionRules
-
Returns a corresponding
SqlTypeName
for a given Java class. - lookup(Method) - Static method in enum org.apache.calcite.adapter.spark.SparkMethod
- lookup(String) - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall.JdbcToInternalLookupTable
-
Tries to lookup a given function name JDBC to an internal representation.
- lookup(List<RelDataTypeField>, String) - Static method in class org.apache.calcite.rex.RexPermuteInputsShuttle
- lookup(RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.DecimalShuttle
-
Lookup registered node
- lookup(RexNode) - Method in class org.apache.calcite.rex.RexUtil.ExpressionNormalizer
- 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.
- lookupAggregates(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- lookupCall - Variable in class org.apache.calcite.sql.SqlJdbcFunctionCall
- lookupChild(String) - Method in class org.apache.calcite.sql.validate.AbstractNamespace
- lookupChild(String) - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- lookupChild(String) - Method in class org.apache.calcite.sql.validate.FieldNamespace
- 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.
- LookupContext(SqlToRelConverter.Blackboard, List<RelNode>, int) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.LookupContext
-
Creates a LookupContext with multiple input relational expressions.
- lookupCorrel(String) - Method in class org.apache.calcite.plan.RelOptQuery
-
Returns the relational expression which populates a correlating variable.
- lookupExp(SqlQualified) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Returns an expression with which to reference a from-list item.
- 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
- lookupFieldNamespace(RelDataType, String) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- lookupFromHints(SqlNode, SqlValidatorScope, SqlParserPos, Collection<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- lookupGroupExpr(SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
-
If an expression is structurally identical to one of the group-by expressions, returns a reference to the expression, otherwise returns null.
- lookupGroupExpr(SqlValidatorUtil.GroupAnalyzer, SqlNode) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
- 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.
- LookupImpl<K,V> - Class in org.apache.calcite.linq4j
-
Implementation of
Lookup
that uses an underlying map. - LookupImpl(Map<K, List<V>>) - Constructor for class org.apache.calcite.linq4j.LookupImpl
-
Creates a MultiMapImpl.
- lookupInput(String) - Method in class org.apache.calcite.rel.externalize.RelJsonReader
- lookupJoinHints(SqlJoin, SqlValidatorScope, SqlParserPos, Collection<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- lookupMakeCallObj - Variable in class org.apache.calcite.sql.SqlJdbcFunctionCall
- 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.
- lookupMethod(Class, String, Class...) - Static method in enum org.apache.calcite.runtime.Resources.BuiltinMethod
-
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>) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- lookupOperatorOverloads(SqlIdentifier, SqlFunctionCategory, SqlSyntax, List<SqlOperator>) - 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>) - Method in class org.apache.calcite.sql.util.ChainedSqlOperatorTable
- lookupOperatorOverloads(SqlIdentifier, SqlFunctionCategory, SqlSyntax, List<SqlOperator>) - Method in class org.apache.calcite.sql.util.ListSqlOperatorTable
- lookupOperatorOverloads(SqlIdentifier, SqlFunctionCategory, SqlSyntax, List<SqlOperator>) - Method in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
- lookupOrAdd(List<T>, T) - Static method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Finds the ordinal of an element in a list, or adds it.
- lookupOrCreateGroupExpr(RexNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- 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. - LookupResultEnumerable(Map<TKey, TAccumulate>, Function2<TKey, TAccumulate, TResult>) - Constructor for class org.apache.calcite.linq4j.EnumerableDefaults.LookupResultEnumerable
- lookupRoutine(SqlOperatorTable, SqlIdentifier, List<RelDataType>, List<String>, SqlFunctionCategory, SqlSyntax, SqlKind) - Static method in class org.apache.calcite.sql.SqlUtil
-
Looks up a (possibly overloaded) routine based on name and argument types.
- lookupSelectHints(SqlSelect, SqlParserPos, Collection<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Looks up completion hints for a syntactically correct select SQL that has been parsed into an expression tree.
- lookupSelectHints(SqlValidatorNamespace, SqlParserPos, Collection<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- lookupSubjectRoutines(SqlOperatorTable, SqlIdentifier, List<RelDataType>, List<String>, SqlSyntax, SqlKind, SqlFunctionCategory) - Static method in class org.apache.calcite.sql.SqlUtil
-
Looks up all subject routines matching the given name and argument types.
- lookupSubjectRoutinesByName(SqlOperatorTable, SqlIdentifier, SqlSyntax, SqlFunctionCategory) - Static method in class org.apache.calcite.sql.SqlUtil
- lookupVisitMethod(Class<?>, Class<?>, String) - Static method in class org.apache.calcite.util.ReflectUtil
-
Looks up a visit method.
- lookupVisitMethod(Class<?>, Class<?>, String, Class<?>[], Map<Class<?>, Method>) - Static method in class org.apache.calcite.util.ReflectUtil
- 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.EmptyScope
- 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 - 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
- LoptMultiJoin.Edge - Class in org.apache.calcite.rel.rules
-
Information about a join-condition.
- LoptMultiJoin.RemovableSelfJoin - Class in org.apache.calcite.rel.rules
-
Utility class used to keep track of the factors in a removable self-join.
- 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(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Creates a LoptOptimizeJoinRule.
- 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
- LoptSemiJoinOptimizer.FactorCostComparator - Class in org.apache.calcite.rel.rules
-
Compares factors.
- LoptSemiJoinOptimizer.FemLocalIndex - Class in org.apache.calcite.rel.rules
-
Dummy class to allow code to compile.
- LoptSemiJoinOptimizer.LcsIndexOptimizer - Class in org.apache.calcite.rel.rules
-
Dummy class to allow code to compile.
- LoptSemiJoinOptimizer.LcsTable - Class in org.apache.calcite.rel.rules
-
Dummy class to allow code to compile.
- LoptSemiJoinOptimizer.LcsTableScan - Class in org.apache.calcite.rel.rules
-
Dummy class to allow code to compile.
- LoptSemiJoinOptimizer.LucidDbSpecialOperators - Class in org.apache.calcite.rel.rules
-
Dummy class to allow code to compile.
- LOW - org.apache.calcite.config.NullCollation
-
Nulls last for DESC, nulls first for ASC.
- lower - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonBound
- lower(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL LOWER(string) function.
- LOWER - org.apache.calcite.util.BuiltInMethod
- LOWER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- 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 - Variable in class org.apache.calcite.rel.logical.LogicalWindow.WindowKey
- lowerBound - Variable in class org.apache.calcite.rex.RexWindow
- lowerBound - Variable in class org.apache.calcite.sql.SqlWindow
-
The lower bound of the window.
- lowerBound - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.HistogramShuttle
- 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.
- lowercase() - Method in enum org.apache.calcite.adapter.druid.DruidJsonFilter.Type
- 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.SemiJoinType
-
Lower-case name.
- lowerName - Variable in enum org.apache.calcite.sql.SqlKind
-
Lower-case name.
- lowerStrict - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonBound
- LPAREN - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
-
left parenthesis
- lprec - Variable in enum org.apache.calcite.linq4j.tree.ExpressionType
- lt - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- lt(boolean, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
<
operator applied to boolean values. - lt(Object) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- lt(String, 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(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- lt(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- lt(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- lt(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
<
operator applied to ByteString values. - LT - org.apache.calcite.piglet.Ast.Op
- ltAny(Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
<
operator applied to Object values. - lte - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- lte(Object) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- lte(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- lte(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- lte(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- LTE - org.apache.calcite.piglet.Ast.Op
- ltrim(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
LTRIM
function. - LTRIM - org.apache.calcite.sql.SqlKind
-
The "LTRIM" function (Oracle).
- LTRIM - org.apache.calcite.util.BuiltInMethod
- LTRIM - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
The "LTRIM(string)" function.
- LUCIDDB - org.apache.calcite.sql.SqlDialect.DatabaseProduct
- LucidDbSpecialOperators() - Constructor for class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer.LucidDbSpecialOperators
- 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
- m - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.JsonArrayAggImplementor
- m - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.JsonObjectAggImplementor
- 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.benchmarks.ParserBenchmark
- main(String[]) - Static method in class org.apache.calcite.benchmarks.PreconditionTest
- main(String[]) - Static method in class org.apache.calcite.Demo
- mainProgram - Variable in class org.apache.calcite.plan.hep.HepPlanner
- major - Variable in class org.apache.calcite.jdbc.CalciteFactory
- makeAbstractCast(RelDataType, RexNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a call to the CAST operator.
- 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.
- makeApproxLiteral(BigDecimal, RelDataType) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates an approximate numeric literal (double or float).
- makeApproxScaleFactor(int) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Makes an approximate literal to be used for scaling
- 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(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.
- makeCall(SqlOperatorTable, SqlIdentifier) - Static method in class org.apache.calcite.sql.SqlUtil
-
If an identifier is a legitimate call to a function which has no arguments and requires no parentheses (for example "CURRENT_USER"), returns a call to that function, otherwise returns null.
- 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
-
Creates a call to the CAST operator, expanding if possible, and optionally also preserving nullability.
- makeCastBooleanToExact(RelDataType, RexNode) - Method in class org.apache.calcite.rex.RexBuilder
- makeCastExactToBoolean(RelDataType, RexNode) - Method in class org.apache.calcite.rex.RexBuilder
- makeCastIntervalToExact(RelDataType, RexNode) - Method in class org.apache.calcite.rex.RexBuilder
- 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
. - makeConstructorCall(SqlRexContext, SqlFunction, List<RexNode>) - Static method in class org.apache.calcite.sql2rel.StandardConvertletTable
- makeContext(CalciteConnectionConfig, JavaTypeFactory, DataContext, CalciteSchema, List<String>, List<String>) - Static method in class org.apache.calcite.schema.Schemas
- makeContext(CalciteConnection, CalciteSchema, List<String>, List<String>, ImmutableMap<CalciteConnectionProperty, String>) - Static method in class org.apache.calcite.schema.Schemas
-
Creates a context for the purposes of preparing a statement.
- 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.
- makeCost(double, double, double) - Method in class org.apache.calcite.plan.RelOptCostImpl.Factory
- makeCost(double, double, double) - Method in class org.apache.calcite.plan.volcano.VolcanoCost.Factory
- 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(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) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a numeric literal.
- makeExactLiteral(BigDecimal, RelDataType) - 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.
- makeFieldAccessInternal(RexNode, RelDataTypeField) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates an expression accessing a given field from a record.
- makeFlag(Enum) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a literal representing a flag.
- makeFormat(StringBuilder[], List<String>) - Static method in class org.apache.calcite.util.Template
-
Called when a complete parameter has been seen.
- 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.
- makeHugeCost() - Method in class org.apache.calcite.plan.RelOptCostImpl.Factory
- makeHugeCost() - Method in class org.apache.calcite.plan.volcano.VolcanoCost.Factory
- makeImmutable() - Method in class org.apache.calcite.util.XmlOutput.StringEscaper
-
Call this before attempting to escape strings; after this, defineEscape may not be called again.
- 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.
- makeInfiniteCost() - Method in interface org.apache.calcite.plan.RelOptCostFactory
-
Creates a cost object representing infinite cost.
- makeInfiniteCost() - Method in class org.apache.calcite.plan.RelOptCostImpl.Factory
- makeInfiniteCost() - Method in class org.apache.calcite.plan.volcano.VolcanoCost.Factory
- makeInfo(Connection) - Method in class org.apache.calcite.sql.dialect.JethroDataSqlDialect.JethroInfoCacheImpl
- 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. - makeLine(GeoFunctions.Geom...) - Static method in class org.apache.calcite.runtime.GeoFunctions
- 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, 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.
- makeMemberAccess(Expression, PseudoField) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberExpression that represents accessing a field.
- makeMinus(RexNode, RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
- makeMultiply(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 a value to NOT NULL; no-op if the type already has NOT NULL.
- makeNullable() - Method in class org.apache.calcite.sql.validate.AbstractNamespace
- 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
- 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.
- 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
-
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(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.
- 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
- makeSemiJoinSelectivityRexNode(RelMetadataQuery, SemiJoin) - 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.
- makeStruct(RelDataTypeFactory, RelDataType) - Static method in class org.apache.calcite.prepare.CalcitePrepareImpl
- 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.
- makeTimestampWithLocalTimeZoneLiteral(TimestampString, int) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a Timestamp with local 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.
- makeTinyCost() - Method in class org.apache.calcite.plan.RelOptCostImpl.Factory
- makeTinyCost() - Method in class org.apache.calcite.plan.volcano.VolcanoCost.Factory
- 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.
- makeZeroCost() - Method in interface org.apache.calcite.plan.RelOptCostFactory
-
Creates a cost object representing zero cost.
- makeZeroCost() - Method in class org.apache.calcite.plan.RelOptCostImpl.Factory
- makeZeroCost() - Method in class org.apache.calcite.plan.volcano.VolcanoCost.Factory
- makeZeroLiteral(RelDataType) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a literal of the default value for the given type.
- MANDATORY - 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.clone.ColumnLoader.ValueSet
- map - Variable in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- map - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable
- map - Variable in class org.apache.calcite.adapter.jdbc.JdbcUtils.DialectPool
- map - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl.DataContextImpl
- map - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.LookupResultEnumerable
- map - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.WrapMap
- map - Variable in class org.apache.calcite.linq4j.LookupImpl
- map - Variable in class org.apache.calcite.linq4j.tree.BlockBuilder.SubstituteVariableVisitor
- map - Variable in class org.apache.calcite.linq4j.tree.BlockBuilder.UseCounter
- map - Variable in class org.apache.calcite.piglet.Handler
- map - Variable in class org.apache.calcite.plan.RelTraitSet.Cache
- map - Variable in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
- map - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Set of active metadata queries, and cache of previous results.
- map - Variable in class org.apache.calcite.rel.rules.ReduceDecimalsRule.ExpanderMap
- map - Variable in class org.apache.calcite.rex.RexSqlReflectiveConvertletTable
- map - Variable in class org.apache.calcite.rex.RexUtil.ExpressionNormalizer
- map - Variable in class org.apache.calcite.schema.Schemas.DummyDataContext
- map - Static variable in class org.apache.calcite.sql.advise.SqlSimpleParser.Tokenizer
- map - Variable in class org.apache.calcite.sql.dialect.JethroDataSqlDialect.JethroInfoCacheImpl
- map - Variable in class org.apache.calcite.sql.SqlJdbcFunctionCall.JdbcToInternalLookupTable
- map - Variable in class org.apache.calcite.sql.type.SqlTypeAssignmentRules.Builder
- map - Variable in class org.apache.calcite.sql.type.SqlTypeAssignmentRules
- map - Variable in class org.apache.calcite.sql2rel.ReflectiveConvertletTable
- map - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.DecorrelateRexShuttle
- 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 - Variable in class org.apache.calcite.util.NameMap
- map - Variable in class org.apache.calcite.util.NameMultimap
- map - Variable in class org.apache.calcite.util.PartiallyOrderedSet
- 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(K, V, Object...) - Static method in class org.apache.calcite.linq4j.function.Functions
- map(ExpressionWriter, Map, String, String, String) - Static method in class org.apache.calcite.linq4j.tree.ConstantExpression
- Map - Annotation Type in org.apache.calcite.adapter.java
-
Annotation that indicates that a field is a map type.
- MAP - org.apache.calcite.model.JsonSchema.Type
- MAP - org.apache.calcite.runtime.SqlFunctions.FlatProductInputType
- MAP - org.apache.calcite.sql.type.SqlTypeFamily
- MAP - org.apache.calcite.sql.type.SqlTypeName
- MAP - Static variable in enum org.apache.calcite.adapter.cassandra.CassandraMethod
- MAP - Static variable in enum org.apache.calcite.adapter.csv.CsvFieldType
- MAP - Static variable in enum org.apache.calcite.adapter.elasticsearch.ElasticsearchMethod
- MAP - Static variable in enum org.apache.calcite.adapter.file.FileFieldType
- MAP - Static variable in enum org.apache.calcite.adapter.mongodb.MongoMethod
- MAP - Static variable in enum org.apache.calcite.adapter.spark.SparkMethod
- MAP - Static variable in class org.apache.calcite.plan.Strong
- MAP - Static variable in enum org.apache.calcite.util.BuiltInMethod
- MAP_CLEAR - org.apache.calcite.util.BuiltInMethod
- MAP_GET - org.apache.calcite.util.BuiltInMethod
- MAP_ITEM - org.apache.calcite.util.BuiltInMethod
- MAP_KEY_COLUMN_NAME - Static variable in class org.apache.calcite.sql.SqlUnnestOperator
- MAP_PUT - org.apache.calcite.util.BuiltInMethod
- MAP_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The MAP Query Constructor.
- MAP_QUERY_CONSTRUCTOR - org.apache.calcite.sql.SqlKind
-
Map Query Constructor, e.g.
- MAP_THREAD_TO_LOCALE - Static variable in class org.apache.calcite.runtime.Resources
- MAP_TYPE - org.apache.calcite.piglet.Ast.Op
- MAP_VALUE_COLUMN_NAME - Static variable in class org.apache.calcite.sql.SqlUnnestOperator
- MAP_VALUE_CONSTRUCTOR - 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.
- map0 - Variable in class org.apache.calcite.adapter.jdbc.JdbcUtils.DialectPool
- mapArcToConverterRule - Variable in class org.apache.calcite.plan.ConventionTraitDef.ConversionData
-
For a given source/target convention, there may be several possible conversion rules.
- mapConvertedNonCorrSubqs - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Mapping of non-correlated sub-queries that have been converted to their equivalent constants.
- mapCorrel(String, RelNode) - Method in class org.apache.calcite.plan.RelOptQuery
-
Maps a correlating variable to a
RelNode
. - mapCorrelateToRex - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- mapCorrelToDeferred - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Fields used in name resolution for correlated sub-queries.
- mapCorrelToRel - Variable in class org.apache.calcite.plan.RelOptCluster
- mapCorrelToRel - Variable in class org.apache.calcite.plan.RelOptQuery
-
Maps name of correlating variable (e.g.
- mapCorToCorRel - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMap
- mapCorToCorRel - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
- mapDescToRule - Variable in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Maps rule description to rule, just to ensure that rules' descriptions are unique.
- mapDigestToRel - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Canonical map from
digest
to the uniquerelational expression
with that digest. - mapDigestToVertex - Variable in class org.apache.calcite.plan.hep.HepPlanner
- mapFieldAccessToCorRef - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMap
- mapFieldAccessToCorVar - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
- MapGeom(MapGeometry) - Constructor for class org.apache.calcite.runtime.GeoFunctions.MapGeom
- mapGetter() - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchEnumerators
- mapGetter() - Static method in class org.apache.calcite.adapter.mongodb.MongoEnumerator
- 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. - 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.
- mapper - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.PredicateAnalyzerTranslator
- mapper - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchema
- mapper - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
- mapper - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport.JsonParserFn
- mapper - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- mapper() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- mapper(Lattice, Lattice.Builder) - Method in class org.apache.calcite.materialize.LatticeSuggester
- mapping - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping
- mapping - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- mapping - Variable in class org.apache.calcite.plan.RelOptMaterialization.ProjectFilterTable
- mapping - Variable in class org.apache.calcite.rex.RexPermuteInputsShuttle
- mapping - Variable in class org.apache.calcite.util.mapping.Mappings.FunctionMappingIter
- mapping() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping
-
Returns ES schema for each field.
- mapping() - Method in class org.apache.calcite.plan.RelOptMaterialization.ProjectFilterTable
- Mapping - Interface in org.apache.calcite.util.mapping
-
A Mapping is a relationship between a source domain to target domain of integers.
- MappingItr() - Constructor for class org.apache.calcite.util.mapping.Mappings.PartialMapping.MappingItr
- mappings(RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- Mappings - Class in org.apache.calcite.util.mapping
-
Utility functions related to mappings.
- Mappings() - Constructor for class org.apache.calcite.util.mapping.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.FunctionMappingIter - Class in org.apache.calcite.util.mapping
-
Iterator that yields the (source, target) values in a
Mappings.FunctionMapping
. - Mappings.IdentityMapping - Class in org.apache.calcite.util.mapping
-
The identity mapping, of a given size, or infinite.
- Mappings.InverseMapping - Class in org.apache.calcite.util.mapping
-
Decorator which converts any
Mapping
into the inverse of itself. - Mappings.NoElementException - Exception 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.PartialFunctionImpl - Class in org.apache.calcite.util.mapping
-
Implementation of
Mapping
where a source can have at most one target, and a target can have any number of sources. - 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.PartialMapping.MappingItr - Class in org.apache.calcite.util.mapping
-
Mapping iterator.
- Mappings.SourceMapping - Interface in org.apache.calcite.util.mapping
-
Mapping suitable for sourcing columns.
- Mappings.SurjectionWithInverse - Class in org.apache.calcite.util.mapping
-
A surjection with inverse has precisely one source for each target.
- Mappings.TargetMapping - Interface in org.apache.calcite.util.mapping
-
Mapping suitable for mapping columns to a target.
- Mappings.TooManyElementsException - Exception in org.apache.calcite.util.mapping
-
Thrown when a mapping is expected to return one element but returns several.
- mappingType - Variable in class org.apache.calcite.util.mapping.Mappings.PartialFunctionImpl
- mappingType - Variable in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- 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 retrictedMappingType.BIJECTION
(every element in the source and target domain must be paired with precisely one element in the other domain). - MappingType() - Constructor for enum org.apache.calcite.util.mapping.MappingType
- MapProjectionFieldVisitor - Class in org.apache.calcite.adapter.elasticsearch
-
Visitor that extracts the actual field name from an item expression.
- MapProjectionFieldVisitor() - Constructor for class org.apache.calcite.adapter.elasticsearch.MapProjectionFieldVisitor
- mapRefRelToCorRef - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMap
- mapRefRelToCorRef - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
- mapRel2Subset - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
- MapRelProtoDataType(ImmutableMap<String, SqlTypeName>) - Constructor for class org.apache.calcite.adapter.druid.DruidTable.MapRelProtoDataType
- MapRelProtoDataType(ImmutableMap<String, SqlTypeName>, String) - Constructor for class org.apache.calcite.adapter.druid.DruidTable.MapRelProtoDataType
- mapRequiresEvenArgCount() - Method in interface org.apache.calcite.runtime.CalciteResource
- mapRequiresTwoOrMoreArgs() - Method in interface org.apache.calcite.runtime.CalciteResource
- mapRootRelToFieldProjection - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Project the groupby expressions out of the root of this sub-select.
- mapRuleDescription(RelOptRule) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Registers a rule's description.
- maps - Variable in class org.apache.calcite.util.CompositeMap
- MapSqlStatisticProvider - Enum in org.apache.calcite.materialize
-
Implementation of
SqlStatisticProvider
that looks up values in a table. - MapSqlStatisticProvider() - Constructor for enum org.apache.calcite.materialize.MapSqlStatisticProvider
- 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
- markAsEquivalent(int, int) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- Marshaller() - Constructor for class org.apache.calcite.rex.RexProgram.Marshaller
- 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 - Variable in class org.apache.calcite.adapter.cassandra.CassandraFilter
- match - Variable in class org.apache.calcite.adapter.geode.rel.GeodeFilter
- match(SubstitutionVisitor, MutableRel, MutableRel) - Method in class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor.FilterToFilterUnifyRule1
- match(SubstitutionVisitor, MutableRel, MutableRel) - Method in class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor.FilterToProjectUnifyRule1
- match(SubstitutionVisitor, MutableRel, MutableRel) - Method in class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor.ProjectToProjectUnifyRule1
- match(SubstitutionVisitor, MutableRel, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRule
- match(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoRuleCall
-
Applies this rule, with a given relational expression in the first slot.
- 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
-
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, List<RexNode>, RelCollation, RexNode) - Constructor for class org.apache.calcite.rel.core.Match
-
Creates a Match.
- MATCH_COMPARATOR - Static variable in class org.apache.calcite.plan.volcano.RuleQueue
-
Sorts rule-matches into decreasing order of importance.
- MATCH_NULL_FETCH - Static variable in class org.apache.calcite.rel.rules.SortUnionTransposeRule
-
Rule instance for Union implementation that preserves the ordering of its inputs.
- MATCH_NUMBER - org.apache.calcite.sql.SqlKind
- MATCH_NUMBER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
MATCH_NUMBER
function to be used withinMATCH_RECOGNIZE
. - MATCH_RECOGNIZE - org.apache.calcite.sql.SqlFunctionCategory
- MATCH_RECOGNIZE - 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.AggregateFinder - Class in org.apache.calcite.rel.core
-
Find aggregate functions in operands.
- Match.PatternVarFinder - Class in org.apache.calcite.rel.core
-
Visits the operands of an aggregate call to retrieve relevant pattern variables.
- Match.RexMRAggCall - Class in org.apache.calcite.rel.core
-
Aggregate calls in match recognize.
- matchAll() - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A query that matches on all documents.
- MatchAllQueryBuilder() - Constructor for class org.apache.calcite.adapter.elasticsearch.QueryBuilders.MatchAllQueryBuilder
- matched(List<String>, List<String>) - Method in class org.apache.calcite.sql.validate.SqlNameMatchers.BaseMatcher
- matched(List<String>, List<String>) - Method in class org.apache.calcite.sql.validate.SqlNameMatchers.LiberalNameMatcher
- matchedNames - Variable in class org.apache.calcite.sql.validate.SqlNameMatchers.LiberalNameMatcher
- matcher(Meta.Pat) - Static method in class org.apache.calcite.jdbc.CalciteMetaImpl
- 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(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 class org.apache.calcite.sql.validate.SqlNameMatchers.BaseMatcher
- 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.geode.rel.GeodeRules.GeodeFilterRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeProjectRule
- 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.AggregateReduceFunctionsRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinToCorrelateRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SortJoinTransposeRule
- matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SortUnionTransposeRule
- 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.AnyOperand
- matches(SubstitutionVisitor, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor.InternalOperand
- matches(SubstitutionVisitor, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor.Operand
- matches(SubstitutionVisitor, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor.QueryOperand
- matches(SubstitutionVisitor, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor.TargetOperand
- 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(RelDataTypeFactory, Function, List<RelDataType>) - Static method in class org.apache.calcite.schema.Schemas
- matchesUnquoted(String, String) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
- matchFactory - Variable in class org.apache.calcite.tools.RelBuilder
- MatchFactoryImpl() - Constructor for class org.apache.calcite.rel.core.RelFactories.MatchFactoryImpl
- MatchFailed() - Constructor for exception org.apache.calcite.plan.SubstitutionVisitor.MatchFailed
- matchingConstructor(Object) - Static method in class org.apache.calcite.linq4j.tree.ConstantExpression
- matchLimit - Variable in class org.apache.calcite.plan.hep.HepProgram
- MatchLimit() - Constructor for class org.apache.calcite.plan.hep.HepInstruction.MatchLimit
- matchListMap - Variable in class org.apache.calcite.plan.volcano.RuleQueue
-
Map of
VolcanoPlannerPhase
to a list of rule-matches. - matchMap - Variable in class org.apache.calcite.plan.volcano.RuleQueue.PhaseMatchList
-
Multi-map of RelSubset to VolcanoRuleMatches.
- MatchModality() - Constructor for enum org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MatchModality
- matchNullability - Variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule
- matchNullability - Variable in class org.apache.calcite.rex.RexUtil.ExprSimplifier
-
Deprecated.
- matchNullability(RelDataType, RexNode) - Method in class org.apache.calcite.rex.RexBuilder
-
Ensures that a type's nullability matches a value's nullability.
- matchNullFetch - Variable in class org.apache.calcite.rel.rules.SortUnionTransposeRule
-
Whether to match a Sort whose
Sort.fetch
is null. - matchOperands(RelOptRuleOperand, RelNode, List<RelNode>, Map<RelNode, List<RelNode>>) - Method in class org.apache.calcite.plan.hep.HepPlanner
- matchOrder - Variable in class org.apache.calcite.plan.hep.HepProgram
- MatchOrder() - Constructor for class org.apache.calcite.plan.hep.HepInstruction.MatchOrder
- matchPattern - Variable in class org.apache.calcite.adapter.file.FileRowConverter.CellReader
- matchQuality(Lattice, Lattice) - Method in class org.apache.calcite.materialize.LatticeSuggester
- matchRecognize - Variable in class org.apache.calcite.sql.validate.MatchRecognizeNamespace
- matchRecognize - Variable in class org.apache.calcite.sql.validate.MatchRecognizeScope
- 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.
- matchRecurse(int) - Method in class org.apache.calcite.plan.volcano.VolcanoRuleCall
-
Recursively matches operands above a given solve order.
- matchRecurse(MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor
- 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) - Static method in class org.apache.calcite.sql.SqlUtil
-
Determines whether there is a routine matching the given name and number of arguments.
- matchSeq - Variable in class org.apache.calcite.adapter.file.FileRowConverter.CellReader
- matchText - Variable in class org.apache.calcite.adapter.file.FileRowConverter.CellReader
- Materialization(CalciteSchema.TableEntry, String, List<String>) - Constructor for class org.apache.calcite.prepare.Prepare.Materialization
- Materialization(MaterializationKey, CalciteSchema, CalciteSchema.TableEntry, String, RelDataType, List<String>) - Constructor for class org.apache.calcite.materialize.MaterializationActor.Materialization
-
Creates a materialization.
- MATERIALIZATION_CONNECTION - Static variable in class org.apache.calcite.schema.impl.MaterializedViewTable
-
Internal connection, used to execute queries to materialize views.
- MaterializationActor - Class in org.apache.calcite.materialize
-
Actor that manages the state of materializations in the system.
- MaterializationActor() - Constructor for class org.apache.calcite.materialize.MaterializationActor
- MaterializationActor.Materialization - Class in org.apache.calcite.materialize
-
A query materialized in a table, so that reading from the table gives the same results as executing the query.
- MaterializationActor.QueryKey - Class in org.apache.calcite.materialize
-
A materialization can be re-used if it is the same SQL, on the same schema, with the same path for resolving functions.
- 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 - Variable in class org.apache.calcite.plan.hep.HepPlanner
- materializations - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
- MATERIALIZATIONS_ENABLED - org.apache.calcite.config.CalciteConnectionProperty
-
Whether Calcite should use materializations.
- materializationsEnabled() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- 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() - Constructor for class org.apache.calcite.materialize.MaterializationService
- 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 - org.apache.calcite.schema.Schema.TableType
-
A materialized query table.
- MATERIALIZED_VIEW - org.apache.calcite.schema.Schema.TableType
-
Materialized view.
- materializedTable - Variable in class org.apache.calcite.materialize.MaterializationActor.Materialization
- materializedTable - Variable in class org.apache.calcite.prepare.Prepare.Materialization
-
The table that holds the materialized data.
- MaterializedViewAggregateRule(RelOptRuleOperand, RelBuilderFactory, String, boolean, HepProgram) - Constructor for class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewAggregateRule
-
Creates a MaterializedViewAggregateRule.
- MaterializedViewFilterScanRule - Class in org.apache.calcite.rel.rules
- MaterializedViewFilterScanRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.MaterializedViewFilterScanRule
-
Creates a MaterializedViewFilterScanRule.
- MaterializedViewJoinRule(RelOptRuleOperand, RelBuilderFactory, String, boolean, HepProgram, boolean) - Constructor for class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewJoinRule
-
Creates a MaterializedViewJoinRule.
- MaterializedViewOnlyAggregateRule(RelBuilderFactory, boolean, HepProgram) - Constructor for class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewOnlyAggregateRule
- MaterializedViewOnlyFilterRule(RelBuilderFactory, boolean, HepProgram, boolean) - Constructor for class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewOnlyFilterRule
- MaterializedViewOnlyJoinRule(RelBuilderFactory, boolean, HepProgram, boolean) - Constructor for class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewOnlyJoinRule
- MaterializedViewProjectAggregateRule(RelBuilderFactory, boolean, HepProgram) - Constructor for class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewProjectAggregateRule
- MaterializedViewProjectFilterRule(RelBuilderFactory, boolean, HepProgram, boolean) - Constructor for class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewProjectFilterRule
- MaterializedViewProjectJoinRule(RelBuilderFactory, boolean, HepProgram, boolean) - Constructor for class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewProjectJoinRule
- MaterializedViewSubstitutionVisitor - Class in org.apache.calcite.plan
-
Extension to
SubstitutionVisitor
. - MaterializedViewSubstitutionVisitor(RelNode, RelNode) - Constructor for class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor
- MaterializedViewSubstitutionVisitor(RelNode, RelNode, RelBuilderFactory) - Constructor for class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor
- MaterializedViewSubstitutionVisitor.FilterToFilterUnifyRule1 - Class in org.apache.calcite.plan
-
Implementation of
SubstitutionVisitor.UnifyRule
that matches aMutableFilter
to aMutableFilter
where the condition of the target relation is weaker. - MaterializedViewSubstitutionVisitor.FilterToProjectUnifyRule1 - Class in org.apache.calcite.plan
-
Implementation of
SubstitutionVisitor.UnifyRule
that matches aMutableFilter
to aMutableProject
on top of aMutableFilter
where the condition of the target relation is weaker. - MaterializedViewSubstitutionVisitor.ProjectToProjectUnifyRule1 - Class in org.apache.calcite.plan
-
Implementation of
SubstitutionVisitor.UnifyRule
that matches aMutableProject
to aMutableProject
where the condition of the target relation is weaker. - 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(String, RelProtoDataType) - Constructor for class org.apache.calcite.sql.ddl.SqlCreateMaterializedView.MaterializedViewTable
- MaterializedViewTable.MaterializedViewTableMacro - Class in org.apache.calcite.schema.impl
-
Table function that returns the table that materializes a view.
- MaterializedViewTableMacro(CalciteSchema, String, List<String>, List<String>, String, boolean) - Constructor for class org.apache.calcite.schema.impl.MaterializedViewTable.MaterializedViewTableMacro
- MATH_MAX - org.apache.calcite.util.BuiltInMethod
- MATH_MIN - org.apache.calcite.util.BuiltInMethod
- max - Variable in class org.apache.calcite.adapter.clone.ColumnLoader.ValueSet
- max - Variable in enum org.apache.calcite.linq4j.tree.Primitive
-
The maximum value of this primitive class.
- max - Variable in class org.apache.calcite.sql.type.SqlOperandCountRanges.RangeImpl
- 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(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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- max(FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- max(FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- max(FunctionExpression<Function1<TSource, TResult>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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 - org.apache.calcite.sql.SqlKind
-
The
MAX
aggregate function. - MAX - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
MAX
aggregate function. - 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 - org.apache.calcite.util.BuiltInMethod
- maxClause() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
- MaxDouble() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MaxDouble
- MaxFloat() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MaxFloat
- maxFunction() - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- maximumCardinality - Variable in class org.apache.calcite.linq4j.tree.Types.ArrayType
- maximumCardinality() - Method 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.
- MaxInputFinder(int[]) - Constructor for class org.apache.calcite.rel.rules.CalcRelSplitter.MaxInputFinder
- maxInputFor(RexNode) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.MaxInputFinder
-
Returns the highest level of any of the inputs of an expression.
- MaxInt() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MaxInt
- MaxLong() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MaxLong
- maxMax(List<SqlOperandCountRange>) - Method in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- maxNegative - Variable in enum org.apache.calcite.linq4j.tree.Primitive
-
The largest value that is less than zero.
- maxNodeCount - Variable in class org.apache.calcite.rex.RexUtil.CnfHelper
- 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.jdbc.CalcitePrepare.CalciteSignature
- maxRowCountHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- maxSize(CacheBuilder<K, V>, int) - Static method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- maxUsingLevelOrdinals - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter.HighestUsageFinder
- maxValue(RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns the maximum value of an integral type, as a long value
- maybeAddValueGenerator(RelNode, RelDecorrelator.Frame) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Adds a value generator to satisfy the correlating variables used by a relational expression, if those variables are not already provided by its input.
- maybeBox(Expression) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.BinaryImplementor
- maybeCast(SqlNode, RelDataType, RelDataType) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- maybeNegate(boolean, Expression) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- maybeQuote(String) - Static method in class org.apache.calcite.adapter.mongodb.MongoRules
- mayBeSatisfiable(RexNode) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
-
Returns whether a boolean expression ever returns true.
- maybeWhitespace(String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- 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 - Class in org.apache.calcite.example.maze
-
Maze generator.
- Maze(int, int) - Constructor for class org.apache.calcite.example.maze.Maze
- Maze.CellContent - Interface in org.apache.calcite.example.maze
-
Callback to get what to print in a particular cell.
- Maze.Direction - Enum in org.apache.calcite.example.maze
-
Direction.
- MazeTable - Class in org.apache.calcite.example.maze
-
User-defined table function that generates a Maze and prints it in text form.
- MazeTable(int, int, int, boolean) - Constructor for class org.apache.calcite.example.maze.MazeTable
- MDX_PRECEDENCE - Static variable in class org.apache.calcite.sql.SqlOperator
-
Maximum precedence.
- Measure(SqlAggFunction, boolean, String, Iterable<Lattice.Column>) - Constructor for class org.apache.calcite.materialize.Lattice.Measure
- measureBuilder - Variable in class org.apache.calcite.materialize.Lattice.TileBuilder
- measureList - Variable in class org.apache.calcite.sql.SqlMatchRecognize
- measures - Variable in class org.apache.calcite.materialize.Lattice.Tile
- measures - Variable in class org.apache.calcite.materialize.LatticeSuggester.Frame
- 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
- 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 - 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 - 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.adapter.enumerable.EnumerableRelImplementor.TypeRegistrar
- 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, Field) - Constructor for class org.apache.calcite.linq4j.tree.MemberExpression
- MemberExpression(Expression, PseudoField) - 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 - 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 - org.apache.calcite.util.BuiltInMethod
- memoryHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- 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(long, long) - Method in class org.apache.calcite.interpreter.AggregateNode.LongSum
- merge(RelTraitSet) - Method in class org.apache.calcite.plan.RelTraitSet
- merge(RelSet, RelSet) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- 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 - org.apache.calcite.rel.core.TableModify.Operation
- MERGE - org.apache.calcite.sql.SqlKind
-
MERGE statement
- MERGE - org.apache.calcite.tools.PigRelBuilder.GroupOption
- MERGE_JOIN - org.apache.calcite.util.BuiltInMethod
- 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
-
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
-
Helper method to determine a
Join
's collation assuming that it uses a merge-join algorithm. - MergeJoinEnumerator(Enumerator<TSource>, Enumerator<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, Function2<TSource, TInner, TResult>) - Constructor for class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- mergeMethod - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- MergeNamespace(SqlValidatorImpl, SqlMerge, SqlNode, SqlValidatorScope) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.MergeNamespace
- 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.
- mergeWith(VolcanoPlanner, RelSet) - Method in class org.apache.calcite.plan.volcano.RelSet
-
Merges
otherSet
into this RelSet. - MESSAGE_MATCH - org.apache.calcite.runtime.Resources.Validation
-
Checks that the base message matches the message in the bundle.
- MESSAGE_SPECIFIED - org.apache.calcite.runtime.Resources.Validation
-
Checks that the base message annotation is on every resource.
- meta() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- META_COLUMNS - Static variable in interface org.apache.calcite.adapter.elasticsearch.ElasticsearchConstants
- metadata - Variable in class org.apache.calcite.rel.metadata.CachingRelMetadataProvider.CachingInvocationHandler
- metadata(Class<M>, RelMetadataQuery) - Method in class org.apache.calcite.rel.AbstractRelNode
- metadata(Class<M>, RelMetadataQuery) - Method in interface org.apache.calcite.rel.RelNode
-
Returns a metadata interface.
- metadata(String, String, List<Interval>, Map<String, SqlTypeName>, Set<String>, Map<String, List<ComplexMetric>>) - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
-
Reads segment metadata, and populates a list of columns and metrics.
- metaData(JavaTypeFactory, int, String, RelDataType, RelDataType, List<String>) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- Metadata - Interface in org.apache.calcite.rel.metadata
-
Metadata about a relational expression.
- METADATA_REL - org.apache.calcite.util.BuiltInMethod
- metadataClass - Variable in class org.apache.calcite.rel.metadata.MetadataDef
- metadataClass0 - Variable in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
- metadataClass0 - Variable in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider.Space2
- MetadataDef<M extends Metadata> - Class in org.apache.calcite.rel.metadata
-
Definition of metadata.
- MetadataDef(Class<M>, Class<? extends MetadataHandler<M>>, Method...) - Constructor for class org.apache.calcite.rel.metadata.MetadataDef
- metadataFactory - Variable in class org.apache.calcite.plan.RelOptCluster
- MetadataFactory - Interface in org.apache.calcite.rel.metadata
-
Source of metadata about relational expressions.
- MetadataFactoryImpl - Class in org.apache.calcite.rel.metadata
-
Implementation of
MetadataFactory
that gets providers from aRelMetadataProvider
and stores them in a cache. - MetadataFactoryImpl(RelMetadataProvider) - Constructor for class org.apache.calcite.rel.metadata.MetadataFactoryImpl
- 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
-
The string property "saffron.metadata.handler.cache.maximum.size" is the maximum size of the cache of metadata handlers.
- MetadataImpl(SqlAbstractParserImpl) - Constructor for class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
-
Creates a MetadataImpl.
- metadataList - Variable in class org.apache.calcite.rel.metadata.ChainedRelMetadataProvider.ChainedInvocationHandler
- metadataProvider - Variable in class org.apache.calcite.plan.RelOptCluster
- metadataProvider - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- metadataQuery(String, List<Interval>) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
-
Generates a JSON string to query metadata about a data source.
- MetadataSchema - Class in org.apache.calcite.jdbc
-
Schema that contains metadata tables such as "TABLES" and "COLUMNS".
- MetadataSchema() - Constructor for class org.apache.calcite.jdbc.MetadataSchema
-
Creates the data dictionary, also called the information schema.
- MetadataTable(Class<E>) - Constructor for class org.apache.calcite.jdbc.CalciteMetaImpl.MetadataTable
- method - Variable in enum org.apache.calcite.adapter.cassandra.CassandraMethod
- method - Variable in enum org.apache.calcite.adapter.elasticsearch.ElasticsearchMethod
- method - Variable in class org.apache.calcite.adapter.enumerable.ReflectiveCallNotNullImplementor
- method - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.MethodImplementor
- 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 enum org.apache.calcite.runtime.Resources.BuiltinMethod
- method - Variable in class org.apache.calcite.runtime.Resources.Element
- method - Variable in class org.apache.calcite.schema.impl.ReflectiveFunctionBase
-
Method that implements the function.
- method - Variable in enum org.apache.calcite.util.BuiltInMethod
- METHOD - Static variable in class org.apache.calcite.adapter.splunk.SplunkTableScan
- METHOD_POSTFIX_FOR_ANY_TYPE - Static variable in class org.apache.calcite.adapter.enumerable.RexImpTable.BinaryImplementor
- MethodCallExpression - Class in org.apache.calcite.linq4j.tree
-
Represents a call to either a static or an instance method.
- MethodCallExpression(Method, Expression, List<Expression>) - Constructor for class org.apache.calcite.linq4j.tree.MethodCallExpression
- MethodCallExpression(Type, Method, Expression, List<Expression>) - Constructor for class org.apache.calcite.linq4j.tree.MethodCallExpression
- 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
- MethodImplementor(Method) - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.MethodImplementor
- methodName - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.MethodNameImplementor
- methodName - Variable in class org.apache.calcite.model.JsonFunction
-
Name of the method that implements this function.
- MethodNameImplementor(String) - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.MethodNameImplementor
- methods - Variable in class org.apache.calcite.rel.metadata.MetadataDef
- MethodTableMacro(ReflectiveSchema, Method) - Constructor for class org.apache.calcite.adapter.java.ReflectiveSchema.MethodTableMacro
- metricFieldNames - Variable in class org.apache.calcite.adapter.druid.DruidTable
- metricName - Variable in class org.apache.calcite.adapter.druid.ComplexMetric
-
The underlying metric column this complex metric represents
- mg - Variable in class org.apache.calcite.runtime.GeoFunctions.MapGeom
- MICROSECOND_PRECISION - Static variable in class org.apache.calcite.sql.fun.SqlTimestampAddFunction
- mightMatch(SubstitutionVisitor.UnifyRule, Class, Class) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
- MILLISECOND_PRECISION - Static variable in class org.apache.calcite.sql.fun.SqlTimestampAddFunction
- min - Variable in class org.apache.calcite.adapter.clone.ColumnLoader.ValueSet
- min - Variable in enum org.apache.calcite.linq4j.tree.Primitive
-
The minimum value of this primitive class.
- min - Variable in class org.apache.calcite.sql.type.SqlOperandCountRanges.RangeImpl
- 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(Double, Double) - Static method in class org.apache.calcite.util.NumberUtil
-
Like
Math.min(int, int)
but null safe. - min(String, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
MIN
aggregate function, optionally with an alias. - 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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- min(FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- min(FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- min(FunctionExpression<Function1<TSource, TResult>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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 - org.apache.calcite.sql.SqlKind
-
The
MIN
aggregate function. - MIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
MIN
aggregate function. - 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 - org.apache.calcite.util.BuiltInMethod
- MinDouble() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MinDouble
- MinFloat() - Constructor for class org.apache.calcite.interpreter.AggregateNode.MinFloat
- minFunction() - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- minimal - Variable in class org.apache.calcite.profile.Profiler.Distribution
- 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
- MinMaxImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.MinMaxImplementor
- minMaxKind - Variable in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
- minMin(List<SqlOperandCountRange>) - Method in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- minor - Variable in class org.apache.calcite.jdbc.CalciteFactory
- minPos(List<E>, Comparator<E>) - Static method in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule
-
Returns the index within a list at which compares least according to a comparator.
- minPositive - Variable in enum org.apache.calcite.linq4j.tree.Primitive
-
The smallest value that is greater than zero.
- minRowCountHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- 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(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 BigDecimal values. - minus(Collection<E>, Collection<E>) - Static method in class org.apache.calcite.materialize.LatticeSuggester
- 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(RelOptCost) - Method in class org.apache.calcite.plan.volcano.VolcanoCost
- minus(RexBuilder, RexNode, RexNode) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- 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<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 - org.apache.calcite.piglet.Ast.Op
- MINUS - org.apache.calcite.rel.mutable.MutableRelType
- MINUS - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- MINUS - org.apache.calcite.sql.SqlKind
-
The arithmetic minus operator, "-".
- 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_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that removes empty children of a
LogicalMinus
. - MINUS_INSTANCE - Static variable in class org.apache.calcite.rel.rules.UnionMergeRule
- MINUS_OPERATOR - Static variable in class org.apache.calcite.sql.type.OperandTypes
- MINUS_PREFIX - org.apache.calcite.sql.SqlKind
-
The unary minus operator, as in "-1".
- 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
- MINUTE - org.apache.calcite.adapter.druid.Granularity.Type
- MINUTE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
MINUTE
operator. - MINUTE_SECOND_MILLIS_PATTERN - Static variable in class org.apache.calcite.adapter.os.PsTableFunction
- MISSING_VALUES - Static variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping.Datatype
- missingValue - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping.Datatype
- missingValue() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping.Datatype
- missingValueFor(String) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping
-
Used as special aggregation key for missing values (documents that are missing a field).
- missingValueForType(String) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping.Datatype
-
Mapping between ES type and json value that represents
missing value
during aggregations. - MITRE - org.apache.calcite.runtime.GeoFunctions.JoinStyle
- MockSplunkConnection() - Constructor for class org.apache.calcite.adapter.splunk.SplunkDriver.MockSplunkConnection
- 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(Expression, long) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- mod(RexBuilder, RelDataType, RexNode, BigDecimal) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- Mod - org.apache.calcite.linq4j.tree.ExpressionType
-
A percent remainder operation, such as (a % b), for numeric operands.
- MOD - org.apache.calcite.sql.SqlKind
-
The arithmetic remainder operator, "MOD" (and "%" in some dialects).
- MOD - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Arithmetic remainder function
MOD
. - modality - Variable in class org.apache.calcite.sql.fun.SqlCollectionTableOperator
- mode - Variable in class org.apache.calcite.runtime.SqlFunctions.PathContext
- Mode() - Constructor for enum org.apache.calcite.plan.TableAccessMap.Mode
- model() - Static method in class org.apache.calcite.adapter.os.SqlShell
- model() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- model() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- MODEL - org.apache.calcite.config.CalciteConnectionProperty
-
URI of the model.
- MODEL - Static variable in class org.apache.calcite.adapter.os.SqlShell
- MODEL_URI - 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. - modelUri - Variable in class org.apache.calcite.model.ModelHandler
- 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 - Variable in class org.apache.calcite.schema.impl.ViewTableMacro
- MODIFIABLE_TABLE_GET_MODIFIABLE_COLLECTION - 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 - 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.
- ModifiableViewTable.ModifiableViewTableInitializerExpressionFactory - Class in org.apache.calcite.schema.impl
-
Initializes columns based on the view constraint.
- ModifiableViewTableInitializerExpressionFactory() - Constructor for class org.apache.calcite.schema.impl.ModifiableViewTable.ModifiableViewTableInitializerExpressionFactory
- 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.jdbc.JavaTypeFactoryImpl.RecordFieldImpl
- modifiers - Variable in class org.apache.calcite.linq4j.tree.DeclarationStatement
- modifiesLvalue - Variable in enum org.apache.calcite.linq4j.tree.ExpressionType
- 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 - 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
An arithmetic remainder compound assignment operation, such as (a %= b) in C#.
- MONGO_OPERATORS - Static variable in class org.apache.calcite.adapter.mongodb.MongoRules.RexToMongoTranslator
- MONGO_QUERYABLE_AGGREGATE - org.apache.calcite.adapter.mongodb.MongoMethod
- MONGO_QUERYABLE_FIND - 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
- MongoAggregateRule() - Constructor for class org.apache.calcite.adapter.mongodb.MongoRules.MongoAggregateRule
- MongoConverterRule(Class<? extends RelNode>, RelTrait, Convention, String) - Constructor for class org.apache.calcite.adapter.mongodb.MongoRules.MongoConverterRule
- mongoDb - Variable in class org.apache.calcite.adapter.mongodb.MongoSchema
- MongoEnumerator - Class in org.apache.calcite.adapter.mongodb
-
Enumerator that reads from a MongoDB collection.
- MongoEnumerator(Iterator<Document>, Function1<Document, Object>) - Constructor for class org.apache.calcite.adapter.mongodb.MongoEnumerator
-
Creates a MongoEnumerator.
- mongoFieldNames(RelDataType) - Static method in class org.apache.calcite.adapter.mongodb.MongoRules
- 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
- MongoFilter.Translator - Class in org.apache.calcite.adapter.mongodb
-
Translates
RexNode
expressions into MongoDB expression strings. - MongoFilterRule() - Constructor for class org.apache.calcite.adapter.mongodb.MongoRules.MongoFilterRule
- MongoMethod - Enum in org.apache.calcite.adapter.mongodb
-
Builtin methods in the MongoDB adapter.
- MongoMethod(Class, String, Class...) - Constructor for enum org.apache.calcite.adapter.mongodb.MongoMethod
- 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.
- MongoProjectRule() - Constructor for class org.apache.calcite.adapter.mongodb.MongoRules.MongoProjectRule
- MongoQueryable(QueryProvider, SchemaPlus, MongoTable, String) - Constructor for class org.apache.calcite.adapter.mongodb.MongoTable.MongoQueryable
- 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. - MongoRules() - Constructor for class org.apache.calcite.adapter.mongodb.MongoRules
- MongoRules.MongoAggregateRule - Class in org.apache.calcite.adapter.mongodb
-
Rule to convert an
LogicalAggregate
to anMongoAggregate
. - MongoRules.MongoConverterRule - Class in org.apache.calcite.adapter.mongodb
-
Base class for planner rules that convert a relational expression to MongoDB calling convention.
- MongoRules.MongoFilterRule - Class in org.apache.calcite.adapter.mongodb
-
Rule to convert a
LogicalFilter
to aMongoFilter
. - MongoRules.MongoProjectRule - Class in org.apache.calcite.adapter.mongodb
-
Rule to convert a
LogicalProject
to aMongoProject
. - MongoRules.MongoSortRule - Class in org.apache.calcite.adapter.mongodb
- MongoRules.RexToMongoTranslator - Class in org.apache.calcite.adapter.mongodb
-
Translator from
RexNode
to strings in MongoDB's expression language. - MongoSchema - Class in org.apache.calcite.adapter.mongodb
-
Schema mapped onto a directory of MONGO files.
- MongoSchema(MongoDatabase) - Constructor for class org.apache.calcite.adapter.mongodb.MongoSchema
-
Allows tests to inject their instance of the database.
- MongoSchema(String, String, List<MongoCredential>, MongoClientOptions) - Constructor for class org.apache.calcite.adapter.mongodb.MongoSchema
-
Creates a MongoDB schema.
- 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
- MongoSortRule() - Constructor for class org.apache.calcite.adapter.mongodb.MongoRules.MongoSortRule
- mongoTable - Variable in class org.apache.calcite.adapter.mongodb.MongoRel.Implementor
- mongoTable - Variable in class org.apache.calcite.adapter.mongodb.MongoTableScan
- MongoTable - Class in org.apache.calcite.adapter.mongodb
-
Table based on a MongoDB collection.
- MongoTable(String) - Constructor for class org.apache.calcite.adapter.mongodb.MongoTable
-
Creates a MongoTable.
- 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(RelBuilderFactory) - Constructor for class org.apache.calcite.adapter.mongodb.MongoToEnumerableConverterRule
-
Creates a MongoToEnumerableConverterRule.
- moniker(CalciteSchema, String, SqlMonikerType) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- MONOTONIC - org.apache.calcite.sql.validate.SqlMonotonicity
-
Catch-all value for expressions that have some monotonic properties.
- monotonicExprs - Variable in class org.apache.calcite.sql.validate.IdentifierNamespace
-
List of monotonic expressions.
- monotonicity() - Method in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Converts the direction to a
SqlMonotonicity
. - MONTH - org.apache.calcite.adapter.druid.Granularity.Type
- MONTH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
MONTH
operator. - moreThanOneMappedColumn(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- moreThanOneValueInList(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- moveNext() - Method in class org.apache.calcite.adapter.cassandra.CassandraEnumerator
- moveNext() - Method in class org.apache.calcite.adapter.clone.ArrayTable.Content.ArrayEnumerator
- moveNext() - Method in class org.apache.calcite.adapter.clone.ArrayTable.Content.ObjectEnumerator
- moveNext() - Method in class org.apache.calcite.adapter.csv.CsvEnumerator
- moveNext() - Method in class org.apache.calcite.adapter.csv.JsonEnumerator
- moveNext() - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl.BlockingQueueEnumerator
- moveNext() - Method in class org.apache.calcite.adapter.file.FileEnumerator
- moveNext() - Method in class org.apache.calcite.adapter.geode.rel.GeodeEnumerator
- moveNext() - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleEnumerator
- moveNext() - Method in class org.apache.calcite.adapter.mongodb.MongoEnumerator
- 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 class org.apache.calcite.linq4j.EnumerableDefaults.CastingEnumerator
- moveNext() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- moveNext() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.SkipWhileEnumerator
- moveNext() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileEnumerator
- moveNext() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileLongEnumerator
- 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.Linq4j.IterableEnumerator
- moveNext() - Method in class org.apache.calcite.linq4j.Linq4j.ListEnumerator
- moveNext() - Method in class org.apache.calcite.linq4j.Linq4j.SingletonEnumerator
- moveNext() - Method in class org.apache.calcite.linq4j.Linq4j.SingletonNullEnumerator
- moveNext() - Method in class org.apache.calcite.linq4j.TransformedEnumerator
- moveNext() - Method in class org.apache.calcite.runtime.ResultSetEnumerable.ResultSetEnumerator
- moveNext() - Method in class org.apache.calcite.util.Util.FilteringIterator
- mq - Variable in class org.apache.calcite.plan.RelOptCluster
- mq - Variable in class org.apache.calcite.rel.metadata.RelMdUtil.CardOfProjExpr
- mq - Variable in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
- msg - Variable in enum org.apache.calcite.sql.SqlStateCodes
-
Deprecated.
- MSSQL - org.apache.calcite.sql.SqlDialect.DatabaseProduct
- MSSQL_SUBSTRING - Static variable in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- 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_BOTH_PROJECT - Static variable in class org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule
- MULTI_FUNCTION - org.apache.calcite.util.mapping.MappingType
- MULTI_LEFT_PROJECT - Static variable in class org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule
- MULTI_RIGHT_PROJECT - Static variable in class org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule
- MultiBucketsAggregation(String, List<ElasticsearchJson.Bucket>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.MultiBucketsAggregation
- 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 - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
The MultiJoin being optimized
- 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<RexNode>, List<JoinRelType>, List<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(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule
-
Creates an MultiJoinOptimizeBushyRule.
- MultiJoinOptimizeBushyRule.JoinVertex - Class in org.apache.calcite.rel.rules
-
Participant in a join which is itself a join.
- MultiJoinOptimizeBushyRule.LeafVertex - Class in org.apache.calcite.rel.rules
-
Relation participating in a join.
- MultiJoinOptimizeBushyRule.Vertex - Class in org.apache.calcite.rel.rules
-
Participant in a join (relation or join).
- 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
-
Creates a MultiJoinProjectTransposeRule.
- MULTILINESTRING - org.apache.calcite.runtime.GeoFunctions.Type
- multimap - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
- multimap - Variable in class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
- 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
- MULTIPLE_SOURCE - Static variable in enum org.apache.calcite.util.mapping.MappingType
-
Allow more than one source for a given target.
- MULTIPLE_TARGET - Static variable in enum org.apache.calcite.util.mapping.MappingType
-
Allow more than one target for a given source.
- 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
- 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 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(RexBuilder, RexNode, RexNode) - Static method in class org.apache.calcite.sql2rel.StandardConvertletTable
- multiply(Mapping, Mapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Multiplies one mapping by another.
- Multiply - 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 - 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 - 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
- multiplyBy(double) - Method in class org.apache.calcite.plan.volcano.VolcanoCost
- 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 - 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
- MULTIPOINT - org.apache.calcite.runtime.GeoFunctions.Type
- MULTIPOLYGON - org.apache.calcite.runtime.GeoFunctions.Type
- MULTISET - org.apache.calcite.sql.type.SqlTypeFamily
- MULTISET - 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_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Returns the element type of a multiset
- MULTISET_EXCEPT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
MULTISET EXCEPT [ALL]
operator. - MULTISET_EXCEPT_ALL - org.apache.calcite.util.BuiltInMethod
- MULTISET_EXCEPT_DISTINCT - 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 - org.apache.calcite.util.BuiltInMethod
- MULTISET_INTERSECT_DISTINCT - 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_OPERATORS - Static variable in class org.apache.calcite.rex.RexMultisetUtil
-
A set defining all implementable multiset calls
- 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 - org.apache.calcite.sql.SqlKind
-
The 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 - org.apache.calcite.util.BuiltInMethod
- MULTISET_UNION_DISTINCT - 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 - org.apache.calcite.sql.SqlKind
-
The MULTISET value constructor.
- multisetCount - Variable in class org.apache.calcite.rex.RexMultisetUtil.RexCallMultisetOperatorCounter
- 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.
- 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 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
- 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.
- MultiValue(String, Map<String, Object>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.MultiValue
- must(QueryBuilders.QueryBuilder) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.BoolQueryBuilder
- mustClauses - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.BoolQueryBuilder
- mustNot(QueryBuilders.QueryBuilder) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.BoolQueryBuilder
- mustNotClauses - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.BoolQueryBuilder
- mustNotNullInElse() - Method in interface org.apache.calcite.runtime.CalciteResource
- MutableAggregate - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Aggregate
. - MutableAggregate(MutableRel, RelDataType, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.rel.mutable.MutableAggregate
- MutableArrayTable(String, RelProtoDataType, RelProtoDataType, InitializerExpressionFactory) - Constructor for class org.apache.calcite.sql.ddl.SqlCreateTable.MutableArrayTable
-
Creates a MutableArrayTable.
- MutableBiRel - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
BiRel
. - MutableBiRel(MutableRelType, RelOptCluster, RelDataType, MutableRel, MutableRel) - Constructor for class org.apache.calcite.rel.mutable.MutableBiRel
- MutableCalc - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Calc
. - MutableCalc(MutableRel, RexProgram) - Constructor for class org.apache.calcite.rel.mutable.MutableCalc
- MutableCollect - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Collect
. - MutableCollect(RelDataType, MutableRel, String) - Constructor for class org.apache.calcite.rel.mutable.MutableCollect
- MutableCorrelate - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Correlate
. - MutableCorrelate(RelDataType, MutableRel, MutableRel, CorrelationId, ImmutableBitSet, SemiJoinType) - Constructor for class org.apache.calcite.rel.mutable.MutableCorrelate
- MutableExchange - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Exchange
. - MutableExchange(MutableRel, RelDistribution) - Constructor for class org.apache.calcite.rel.mutable.MutableExchange
- MutableFilter - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Filter
. - MutableFilter(MutableRel, RexNode) - Constructor for class org.apache.calcite.rel.mutable.MutableFilter
- MutableIntersect - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Intersect
. - MutableIntersect(RelOptCluster, RelDataType, List<MutableRel>, boolean) - Constructor for class org.apache.calcite.rel.mutable.MutableIntersect
- MutableJoin - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Join
. - MutableJoin(RelDataType, MutableRel, MutableRel, RexNode, JoinRelType, Set<CorrelationId>) - Constructor for class org.apache.calcite.rel.mutable.MutableJoin
- MutableLeafRel - Class in org.apache.calcite.rel.mutable
-
Abstract base class for implementations of
MutableRel
that have no inputs. - MutableLeafRel(MutableRelType, RelNode) - Constructor for class org.apache.calcite.rel.mutable.MutableLeafRel
- MutableMeasure(SqlAggFunction, boolean, List<LatticeSuggester.ColRef>, String) - Constructor for class org.apache.calcite.materialize.LatticeSuggester.MutableMeasure
- MutableMinus - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Minus
. - MutableMinus(RelOptCluster, RelDataType, List<MutableRel>, boolean) - Constructor for class org.apache.calcite.rel.mutable.MutableMinus
- MutableMultiRel - Class in org.apache.calcite.rel.mutable
-
Base Class for relations with three or more inputs
- MutableMultiRel(RelOptCluster, RelDataType, MutableRelType, List<MutableRel>) - Constructor for class org.apache.calcite.rel.mutable.MutableMultiRel
- MutableNode - Class in org.apache.calcite.materialize
-
Mutable version of
LatticeNode
, used while a graph is being built. - MutableNode(LatticeTable) - Constructor for class org.apache.calcite.materialize.MutableNode
-
Creates a root node.
- MutableNode(LatticeTable, MutableNode, Step) - Constructor for class org.apache.calcite.materialize.MutableNode
-
Creates a non-root node.
- MutableProject - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Project
. - MutableProject(RelDataType, MutableRel, List<RexNode>) - Constructor for class org.apache.calcite.rel.mutable.MutableProject
- 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
- MutableRel.MutableRelDumper - Class in org.apache.calcite.rel.mutable
-
Implementation of MutableVisitor that dumps the details of a MutableRel tree.
- MutableRelDumper() - Constructor for class org.apache.calcite.rel.mutable.MutableRel.MutableRelDumper
- MutableRels - Class in org.apache.calcite.rel.mutable
-
Utilities for dealing with
MutableRel
s. - MutableRels() - Constructor for class org.apache.calcite.rel.mutable.MutableRels
- MutableRelType - Enum in org.apache.calcite.rel.mutable
-
Type of
MutableRel
. - MutableRelType() - Constructor for enum org.apache.calcite.rel.mutable.MutableRelType
- MutableRelVisitor - Class in org.apache.calcite.rel.mutable
-
Visitor over
MutableRel
. - MutableRelVisitor() - Constructor for class org.apache.calcite.rel.mutable.MutableRelVisitor
- mutableRootSchema - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl.ContextImpl
- MutableSample - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Sample
. - MutableSample(MutableRel, RelOptSamplingParameters) - Constructor for class org.apache.calcite.rel.mutable.MutableSample
- MutableScan - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
TableScan
. - MutableScan(TableScan) - Constructor for class org.apache.calcite.rel.mutable.MutableScan
- MutableSemiJoin - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
SemiJoin
. - MutableSemiJoin(RelDataType, MutableRel, MutableRel, RexNode, ImmutableIntList, ImmutableIntList) - Constructor for class org.apache.calcite.rel.mutable.MutableSemiJoin
- 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
- MutableSingleRel - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
SingleRel
. - MutableSingleRel(MutableRelType, RelDataType, MutableRel) - Constructor for class org.apache.calcite.rel.mutable.MutableSingleRel
- MutableSort - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Sort
. - MutableSort(MutableRel, RelCollation, RexNode, RexNode) - Constructor for class org.apache.calcite.rel.mutable.MutableSort
- MutableTableFunctionScan - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
TableFunctionScan
. - MutableTableFunctionScan(RelOptCluster, RelDataType, List<MutableRel>, RexNode, Type, Set<RelColumnMapping>) - Constructor for class org.apache.calcite.rel.mutable.MutableTableFunctionScan
- MutableTableModify - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
TableModify
. - MutableTableModify(RelDataType, MutableRel, RelOptTable, Prepare.CatalogReader, TableModify.Operation, List<String>, List<RexNode>, boolean) - Constructor for class org.apache.calcite.rel.mutable.MutableTableModify
- MutableUncollect - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Uncollect
. - MutableUncollect(RelDataType, MutableRel, boolean) - Constructor for class org.apache.calcite.rel.mutable.MutableUncollect
- MutableUnion - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Union
. - MutableUnion(RelOptCluster, RelDataType, List<MutableRel>, boolean) - Constructor for class org.apache.calcite.rel.mutable.MutableUnion
- MutableValues - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Values
. - MutableValues(Values) - Constructor for class org.apache.calcite.rel.mutable.MutableValues
- MutableWindow - Class in org.apache.calcite.rel.mutable
-
Mutable equivalent of
Window
. - MutableWindow(RelDataType, MutableRel, List<Window.Group>, List<RexLiteral>) - Constructor for class org.apache.calcite.rel.mutable.MutableWindow
- mutate(List<T>) - Method in class org.apache.calcite.rex.RexShuttle
-
Applies this shuttle to each expression in a list.
- mutate(CalciteConnectionConfig, ImmutableMap<CalciteConnectionProperty, String>) - Static method in class org.apache.calcite.schema.Schemas
- MyPropertyResourceBundle(InputStream) - Constructor for class org.apache.calcite.runtime.Resources.MyPropertyResourceBundle
- MyRexShuttle() - Constructor for class org.apache.calcite.rel.rules.ValuesReduceRule.MyRexShuttle
- MyRexVisitor(CorrelationReferenceFinder) - Constructor for class org.apache.calcite.sql2rel.CorrelationReferenceFinder.MyRexVisitor
- MySchemaPlus(SchemaPlus, String, Schema) - Constructor for class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- MYSQL - org.apache.calcite.adapter.os.SqlShell.Format
- MYSQL - org.apache.calcite.config.Lex
-
Lexical policy similar to MySQL.
- MYSQL - org.apache.calcite.sql.SqlDialect.DatabaseProduct
- MYSQL_5 - org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that instructs Calcite to use SQL semantics consistent with MySQL version 5.x.
- MYSQL_ANSI - org.apache.calcite.config.Lex
-
Lexical policy similar to MySQL with ANSI_QUOTES option enabled.
- 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.
N
- n - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.SkipWhileEnumerator
- n - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileEnumerator
- n - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileLongEnumerator
- N - Static variable in class org.apache.calcite.rex.RexInterpreter
- name - Variable in class org.apache.calcite.adapter.cassandra.CassandraSchema
- name - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonAggregator
- name - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonAggregation
- name - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonPostAggregation
- name - Variable in class org.apache.calcite.adapter.druid.VirtualColumn.Builder
- name - Variable in class org.apache.calcite.adapter.druid.VirtualColumn
- name - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Bucket
- name - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.MultiBucketsAggregation
- name - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.MultiValue
- name - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping.Datatype
- name - Variable in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.NamedFieldExpression
- name - Variable in class org.apache.calcite.adapter.file.FileRowConverter.FieldDef
- name - Variable in class org.apache.calcite.benchmarks.StatementTest.Department
- name - Variable in class org.apache.calcite.benchmarks.StatementTest.Employee
- 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.jdbc.JavaTypeFactoryImpl.RecordFieldImpl
- name - Variable in class org.apache.calcite.jdbc.JavaTypeFactoryImpl.SyntheticRecordType
- 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.materialize.LatticeSuggester.MutableMeasure
- 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.piglet.Ast.LoadStmt
- name - Variable in class org.apache.calcite.piglet.Ast.ScalarType
- name - Variable in class org.apache.calcite.plan.Convention.Impl
- name - Variable in class org.apache.calcite.plan.RelOptAbstractTable
- name - Variable in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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.rel.core.CorrelationId
- name - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter.RelType
- name - Variable in class org.apache.calcite.rel.type.RelDataTypeFieldImpl
- 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.SqlCheckConstraint
- 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.SqlCreateFunction
- 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.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.SqlKeyConstraint
- name - Variable in class org.apache.calcite.sql.SqlOperator
-
The name of the operator/function.
- name - Variable in class org.apache.calcite.sql.SqlSampleSpec.SqlSubstitutionSampleSpec
- name - Variable in class org.apache.calcite.sql.SqlSetOption
-
Name of the option as an
SqlIdentifier
with one or more parts. - name - Variable in class org.apache.calcite.sql.SqlWithItem
- name - Variable in class org.apache.calcite.sql.validate.ScopeChild
- name - Variable in class org.apache.calcite.sql.validate.SqlValidatorScope.Step
- name() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping.Datatype
-
Name of the type:
text
,integer
,float
etc. - name() - Method in annotation type org.apache.calcite.linq4j.function.Parameter
-
The name of the parameter.
- name() - Method in annotation type org.apache.calcite.runtime.Resources.Property
- name() - Method in interface org.apache.calcite.sql.SqlLiteral.SqlSymbol
-
Deprecated.
- NAME_TO_PROPS - Static variable in enum org.apache.calcite.config.CalciteConnectionProperty
- NamedFieldExpression() - Constructor for class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.NamedFieldExpression
- NamedFieldExpression(RexInputRef) - Constructor for class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.NamedFieldExpression
- NamedFieldExpression(RexLiteral) - Constructor for class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.NamedFieldExpression
- namedMatcher(Meta.Pat) - Static method in class org.apache.calcite.jdbc.CalciteMetaImpl
- nameExists(String) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Returns whether a field exists with the given name.
- nameMap - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- 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.
- NameMap(NavigableMap<String, V>) - Constructor for class org.apache.calcite.util.NameMap
-
Creates a NameSet based on an existing set.
- 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. - 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.
- NameMultimap(NameMap<List<V>>) - Constructor for class org.apache.calcite.util.NameMultimap
-
Creates a NameMultimap based on an existing map.
- names - Variable in class org.apache.calcite.jdbc.CachingCalciteSchema.SubSchemaCache
-
The names of sub-schemas returned from the
Schema
SPI. - names - Variable in class org.apache.calcite.plan.volcano.RuleQueue.PhaseMatchList
-
A set of rule-match names contained in
RuleQueue.PhaseMatchList.list
. - names - Variable in class org.apache.calcite.prepare.RelOptTableImpl
- names - Variable in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
- names - Variable in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.Key
- 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.sql.SqlInfixOperator
- names - Variable in class org.apache.calcite.sql.validate.CatalogScope
-
Fully-qualified name of the catalog.
- names - Variable in class org.apache.calcite.sql.validate.SchemaNamespace
-
The path of this schema.
- names - Variable in class org.apache.calcite.sql.validate.SqlMonikerImpl
- names - Variable in class org.apache.calcite.tools.RelBuilder.Registrar
- names - Variable in class org.apache.calcite.util.NameSet
- names() - Method in interface org.apache.calcite.schema.Path
-
Returns the names of this path, not including the name of the root.
- names() - Method in class org.apache.calcite.schema.Schemas.PathImpl
- names(Set<CorrelationId>) - Static method in class org.apache.calcite.rel.core.CorrelationId
-
Converts a set of names to a set of correlation ids.
- NAMES - Static variable in class org.apache.calcite.rex.RexInputRef
- NAMES - Static variable in class org.apache.calcite.rex.RexLocalRef
- 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.
- NameSet(NameMap<Object>) - Constructor for class org.apache.calcite.util.NameSet
-
Creates a NameSet based on an existing set.
- namespace - Variable in class org.apache.calcite.sql.validate.DelegatingNamespace
- namespace - Variable in class org.apache.calcite.sql.validate.ScopeChild
- 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
- nameToNodeMap - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- nameToTypeMap - Variable in class org.apache.calcite.sql.validate.ParameterScope
-
Map from the simple names of the parameters to types of the parameters (
RelDataType
). - 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 expression eg (arg1 Op arg2 Op arg3)
- NaryOperatorConverter(SqlOperator, String) - Constructor for class org.apache.calcite.adapter.druid.NaryOperatorConverter
- NATIVE_UTF16_CHARSET_NAME - Static variable in class org.apache.calcite.util.ConversionUtil
- natural - Variable in class org.apache.calcite.sql.SqlJoin
-
Operand says whether this is a natural join.
- naturalDisallowsOnOrUsing() - Method in interface org.apache.calcite.runtime.CalciteResource
- naturalOrUsingColumnNotCompatible(String, String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- NavigationExpander() - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.NavigationExpander
- NavigationExpander(SqlOperator, SqlNode) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.NavigationExpander
- navigationInDefine(SqlNode, String) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Checks that all pattern variables within a function are the same, and canonizes expressions such as
PREV(B.price)
toLAST(B.price, 0)
. - navigationInMeasure(SqlNode, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- NavigationModifier() - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.NavigationModifier
- NavigationReplacer(String) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.NavigationReplacer
- nBytes - Variable in class org.apache.calcite.util.javac.JaninoCompiler.AccountingClassLoader
- NCHAR - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- nChildFields - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Number of fields in the RelNode that the projection is being pushed past
- NCLOB - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- nDynamicParams - Variable in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
- 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(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
<gt;
operator applied to BigDecimal values. - NE - 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.FirstLastValueImplementor
- needCacheWhenFrameIntact() - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.LeadLagImplementor
- needCacheWhenFrameIntact() - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.NthValueImplementor
- needCacheWhenFrameIntact() - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.NtileImplementor
- needCacheWhenFrameIntact() - Method in class org.apache.calcite.adapter.enumerable.StrictWinAggImplementor
- needCacheWhenFrameIntact() - Method in interface org.apache.calcite.adapter.enumerable.WinAggImplementor
- neededAlias - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
- neededType - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
- needIndent - Variable in class org.apache.calcite.util.StackWriter
- needQueryOp(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- needsAdjustment(LoptMultiJoin, int[], LoptJoinTree, LoptJoinTree, boolean) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Sets an array indicating how much each factor in a join tree needs to be adjusted to reflect the tree's join ordering
- needSameTypeParameter() - Method in interface org.apache.calcite.runtime.CalciteResource
- needsIndent - Variable in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
- 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
- needsQuote(String) - Static method in class org.apache.calcite.adapter.mongodb.MongoRules
- needsSpace() - Method in class org.apache.calcite.sql.SqlBinaryOperator
-
Returns whether this operator should be surrounded by space when unparsed.
- needsSpace() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether this operator should be surrounded by space when unparsed.
- 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. - needTrackEmptySet - Variable in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- needWhitespace - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- needWhitespaceAfter(String) - Static method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- needWhitespaceBefore(String) - Static method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- negate - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.IsXxxImplementor
- negate() - Method in enum org.apache.calcite.plan.RelOptUtil.Logic
- negate() - Method in enum org.apache.calcite.sql.SqlKind
-
Returns the kind that you get if you apply NOT to this kind.
- 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(SqlQuantifyOperator) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- negate(SqlParserPos) - Method in class org.apache.calcite.piglet.Ast.NumericLiteral
- Negate - 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
An arithmetic negation operation, such as (-a), that has overflow checking.
- negated - Variable in class org.apache.calcite.sql.fun.SqlBetweenOperator
-
If true the call represents 'NOT BETWEEN'.
- negated - Variable in class org.apache.calcite.sql.fun.SqlLikeOperator
- negateNullSafe() - Method in enum org.apache.calcite.sql.SqlKind
-
Returns the kind that you get if you negate this kind.
- NEOVIEW - 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 class org.apache.calcite.rel.externalize.RelWriterImpl
- 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.
- nestBlock(BlockBuilder, Map<RexNode, Boolean>) - Method in interface org.apache.calcite.adapter.enumerable.NestedBlockBuilder
-
Uses given block as the new code context and the map of nullability.
- nestBlock(BlockBuilder, Map<RexNode, Boolean>) - Method in class org.apache.calcite.adapter.enumerable.NestedBlockBuilderImpl
-
Uses given block as the new code context and the map of nullability.
- 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 and the nullability of particular
RexNode
expressions. - NestedBlockBuilderImpl - Class in org.apache.calcite.adapter.enumerable
-
Allows to build nested code blocks with tracking of current context and the nullability of particular
RexNode
expressions. - NestedBlockBuilderImpl(BlockBuilder) - Constructor for class org.apache.calcite.adapter.enumerable.NestedBlockBuilderImpl
-
Constructs nested block builders starting of a given code block.
- nestedStmtList - Variable in class org.apache.calcite.piglet.Ast.ForeachNestedStmt
- NETEZZA - 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 - 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 - org.apache.calcite.sql.SqlKind
-
NewSpecification
- newAggregateRel(RelBuilder, Aggregate, List<AggregateCall>) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Do a shallow clone of oldAggRel and update 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 - 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 - 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 class org.apache.calcite.schema.impl.ModifiableViewTable.ModifiableViewTableInitializerExpressionFactory
- 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
- 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
-
Add a calc with the expressions to compute the original agg calls from the decomposed ones.
- newChildCreator(Class<? extends ClassDeclarationFinder>) - Static method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Creates factory that creates instances of optimizing visitors.
- newColumnDefaultValue(RelOptTable, int, InitializerContext) - Method in class org.apache.calcite.schema.impl.ModifiableViewTable.ModifiableViewTableInitializerExpressionFactory
- 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
- 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.
- newInput - Variable in class org.apache.calcite.rel.rules.AggregateJoinTransposeRule.Side
- 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
- 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
. - newline() - Method in class org.apache.calcite.piglet.Ast.UnParser
- newline(StringBuilder, int) - Method in class org.apache.calcite.util.JsonBuilder
- 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.linq4j.tree.ExpressionWriter
- 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.
- 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.
- newName(String, boolean) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Creates a name for a new variable, unique within this block, controlling whether the variable can be inlined later.
- newPreparedStatement(AvaticaConnection, Meta.StatementHandle, Meta.Signature, int, int, int) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory
- newRefs - Variable in class org.apache.calcite.rex.RexProgramBuilder.UpdateRefShuttle
- 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
- newTopViewProject - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.ViewPartialRewriting
- 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, SqlConformance) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Factory method for
SqlValidator
. - newView - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.ViewPartialRewriting
- newViewNode - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.ViewPartialRewriting
- next - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.BlockingQueueEnumerator
- next - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Token
- next() - Method in class org.apache.calcite.adapter.elasticsearch.Scrolling.AutoClosingIterator
- next() - Method in class org.apache.calcite.adapter.file.FileReader.FileReaderIterator
- next() - Method in class org.apache.calcite.jdbc.CalciteMetaImpl.LimitIterator
- next() - Method in class org.apache.calcite.linq4j.Linq4j.EnumeratorIterator
- next() - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference.ExprsItr
- 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.ChunkList.ChunkListIterator
- 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() - Method in class org.apache.calcite.util.ImmutableIntList.AbstractIndexedListIterator
- next() - Method in class org.apache.calcite.util.mapping.Mappings.FunctionMappingIter
- next() - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping.MappingItr
- next() - Method in class org.apache.calcite.util.Pair.AdjacentIterator
- next() - Method in class org.apache.calcite.util.Pair.FirstAndIterator
- next() - Method in class org.apache.calcite.util.Pair.LeftIterator
- next() - Method in class org.apache.calcite.util.Pair.RightIterator
- next() - Method in class org.apache.calcite.util.Pair.ZipIterator
- next() - Method in class org.apache.calcite.util.Util.FilteringIterator
- next(Object[]) - Static method in class org.apache.calcite.util.ChunkList
- next(String) - Method in class org.apache.calcite.adapter.file.FileReader.FileReaderIterator
- next(Calendar, TimeUnitRange, int, Range<Calendar>, boolean) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- NEXT - org.apache.calcite.sql.SqlKind
- NEXT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
NEXT
function to be used withinMATCH_RECOGNIZE
. - NEXT_ID - Static variable in class org.apache.calcite.rel.AbstractRelNode
-
Generator for
AbstractRelNode.id
values. - NEXT_VALUE - 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
- nextBatch(int) - Method in class org.apache.calcite.profile.ProfilerImpl.Run
-
Populates
spaces
with the next batch. - 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. - nextCorrel - Variable in class org.apache.calcite.plan.RelOptCluster
- nextCorrel - Variable in class org.apache.calcite.plan.RelOptQuery
- nextGeneratedId - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- nextId - Static variable in class org.apache.calcite.plan.RelOptRuleCall
-
Generator for
RelOptRuleCall.id
values. - nextIndex() - Method in class org.apache.calcite.util.ChunkList.ChunkListIterator
- nextIndex() - Method in class org.apache.calcite.util.ImmutableIntList.AbstractIndexedListIterator
- nextLeft(PrecedenceClimbingParser.Token) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
-
Returns the left precedence of the following operator token.
- nextLine(String, int) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- nextMapping - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference.ExprsItr
- nextPowerOf2(int) - Static method in class org.apache.calcite.adapter.clone.ColumnLoader
- nextPowerOf2(long) - Static method in class org.apache.calcite.adapter.clone.ColumnLoader
- 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. - nextSetId - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
- nextToken() - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Tokenizer
- nextWhitespace - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- nFields - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Number of fields in the RelNode that the projection is being pushed past, if the RelNode is not a join.
- nFieldsInJoinFactor - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Number of fields in each join factor
- nFieldsLeft - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- nFieldsRight - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- nFieldsRight - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Number of fields in the right hand side of a join, in the case where the projection is being pushed past a join.
- NICKNAME - 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.
- nJoinFactors - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Number of factors into the MultiJoin
- NL - Static variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- NL - Static variable in class org.apache.calcite.sql.SqlOperator
- nLeftDestFields - Variable in class org.apache.calcite.plan.RelOptUtil.RexInputConverter
- nLogN(double) - Static method in class org.apache.calcite.util.Util
-
Computes
nlogn(n)
using the natural logarithm (orn
ifn <
, so the result is never negative.Math.E
- 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(String, ByteString, String, SqlCollation) - Constructor for class org.apache.calcite.util.NlsString
-
Internal constructor; other constructors must call it.
- NlsString(ByteString, String, SqlCollation) - Constructor for class org.apache.calcite.util.NlsString
-
Creates a string in a specified character set.
- NO_ACCESS - org.apache.calcite.plan.TableAccessMap.Mode
-
Table is not accessed at all.
- NO_ATTRIBUTES - org.apache.calcite.sql.SqlExplainLevel
-
Suppress all attributes.
- NO_EXPRS - Static variable in class org.apache.calcite.adapter.enumerable.EnumUtils
- NO_INDICATOR - Static variable in class org.apache.calcite.rel.core.Aggregate
-
Deprecated.
- NO_NO - Static variable in interface org.apache.calcite.sql.type.SqlTypeName.PrecScale
- NO_PARAMS - Static variable in class org.apache.calcite.adapter.enumerable.EnumUtils
- NO_SRID - Static variable in class org.apache.calcite.runtime.GeoFunctions
- noDag - Variable in class org.apache.calcite.plan.hep.HepPlanner
- node - Variable in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
- node - Variable in class org.apache.calcite.interpreter.Interpreter.NodeInfo
- node - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
- node - Variable in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundUnbounded
- node - Variable in class org.apache.calcite.sql.SqlSpecialOperator.ReduceResult
- node - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.DeleteNamespace
- node - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.InsertNamespace
- node - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.MergeNamespace
- node - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.UpdateNamespace
- node - Variable in class org.apache.calcite.sql.validate.TableScope
- node - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.SubQuery
- node - Variable in exception org.apache.calcite.util.Util.FoundOne
- node(int) - Method in class org.apache.calcite.sql.parser.SqlParserUtil.OldTokenSequenceImpl
- node(int) - Method in class org.apache.calcite.sql.parser.SqlParserUtil.TokenSequenceImpl
- node(int) - Method in interface org.apache.calcite.sql.SqlSpecialOperator.TokenSequence
- 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(E) - Constructor for class org.apache.calcite.util.PartiallyOrderedSet.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 - org.apache.calcite.util.BuiltInMethod
- NoDefaultValueException(String) - Constructor for exception org.apache.calcite.runtime.Resources.NoDefaultValueException
- NodeInfo(RelNode, Enumerable<Row>) - Constructor for class org.apache.calcite.interpreter.Interpreter.NodeInfo
- nodeInputs - Variable in class org.apache.calcite.plan.RelOptRuleCall
- NodeLineage(Map<RexNode, Integer>, Map<RexNode, Integer>) - Constructor for class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.NodeLineage
- nodeLists - Variable in class org.apache.calcite.tools.RelBuilder.GroupKeyImpl
- nodeMap - Variable in class org.apache.calcite.materialize.LatticeSpace
-
Root nodes, indexed by digest.
- nodes - Variable in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
- nodes - Variable in class org.apache.calcite.interpreter.Interpreter
- nodes - Variable in class org.apache.calcite.tools.RelBuilder.GroupKeyImpl
- 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. - nodeToEquivalenceClass - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.EquivalenceClasses
- nodeToTypeMap - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Map of derived RelDataType for each node.
- nodeType - Variable in class org.apache.calcite.linq4j.tree.AbstractNode
- nodeTypesHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- NoElementException(String) - Constructor for exception org.apache.calcite.util.mapping.Mappings.NoElementException
-
Creates a NoElementException.
- NoHandler(Class<? extends RelNode>) - Constructor for exception org.apache.calcite.rel.metadata.JaninoRelMetadataProvider.NoHandler
- noIndicator(Aggregate) - Static method in class org.apache.calcite.rel.core.Aggregate
- 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_ASCII - Static variable in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
- NON_CONSTANT - org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator.Constancy
- NON_COST_ATTRIBUTES - org.apache.calcite.sql.SqlExplainLevel
-
Display all attributes, including id, except cost.
- NON_CUMULATIVE_COST - org.apache.calcite.util.BuiltInMethod
- nonCumulativeCostHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- 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
-
Creates an empty list of child operands.
- NONE - org.apache.calcite.adapter.enumerable.NullPolicy
- NONE - org.apache.calcite.rel.type.RelDataTypeComparability
- NONE - org.apache.calcite.rel.type.StructKind
-
This is not a structured type.
- NONE - org.apache.calcite.sql.JoinConditionType
-
Join clause has no condition, for example "FROM EMP, DEPT"
- NONE - org.apache.calcite.sql.SqlCollation.Coercibility
-
Weakest coercibility.
- NONE - org.apache.calcite.sql.SqlDialect.CalendarPolicy
- NONE - org.apache.calcite.sql.type.SqlOperandTypeChecker.Consistency
-
Do not try to make arguments consistent.
- 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
- NonEquiJoinInfo(ImmutableIntList, ImmutableIntList, RexNode) - Constructor for class org.apache.calcite.rel.core.JoinInfo.NonEquiJoinInfo
- NoneToBindableConverterRule - Class in org.apache.calcite.interpreter
-
Rule to convert a relational expression from
Convention.NONE
toBindableConvention
. - NoneToBindableConverterRule(RelBuilderFactory) - Constructor for class org.apache.calcite.interpreter.NoneToBindableConverterRule
-
Creates a NoneToBindableConverterRule.
- NonLeafReplayableQueryable(Queryable<T>) - Constructor for class org.apache.calcite.linq4j.QueryableDefaults.NonLeafReplayableQueryable
- NonLiteralException() - Constructor for exception org.apache.calcite.sql.validate.SqlUserDefinedTableMacro.NonLiteralException
- nonMonotonicCasts - Variable in class org.apache.calcite.sql.fun.SqlCastFunction
-
Map of all casts that do not preserve monotonicity.
- nonReservedKeyWordSet - Variable in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
- NoOpSubQueryConverter() - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.NoOpSubQueryConverter
- nOperands - Variable in class org.apache.calcite.sql.type.SameOperandTypeChecker
- normalize(RexBuilder, boolean) - Method in class org.apache.calcite.rex.RexProgram
-
Deprecated.
- normalize(RexBuilder, RexProgram) - Static method in class org.apache.calcite.rex.RexProgramBuilder
-
Deprecated.
- normalize(RexBuilder, RexSimplify) - Method in class org.apache.calcite.rex.RexProgram
-
Creates a simplified/normalized copy of this program.
- normalize(SqlSyntax) - Static method in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable.Key
- normalize(SqlTypeName, Expression) - Method in class org.apache.calcite.adapter.enumerable.RexImpTable.DatetimeArithmeticImplementor
-
Normalizes a TIME value into 00:00:00..23:59:39.
- normalizeDeclaration(DeclarationStatement) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Prepares declaration for inlining: adds cast
- normalizeException(Throwable) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Removes or transforms misleading information from a parse exception or error, and converts to
SqlParseException
. - normalizePlan(String) - Static method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Normalizes references to subsets within the string representation of a plan.
- normalizeSecondFraction(String) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- not() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- not() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
-
Negate
this
QueryExpression (not the next one). - not() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- not(Boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
NULL → NULL, FALSE → TRUE, TRUE → FALSE.
- not(Comparable) - Method in class org.apache.calcite.rex.RexInterpreter
- 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(RexBuilder, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies NOT to an expression.
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise complement or logical negation operation.
- NOT - org.apache.calcite.adapter.druid.DruidJsonFilter.Type
- NOT - org.apache.calcite.adapter.enumerable.NullPolicy
-
If any argument is true, result is false; else if any argument is null, result is null; else true.
- NOT - org.apache.calcite.piglet.Ast.Op
- NOT - org.apache.calcite.sql.SqlKind
-
The logical "NOT" operator.
- NOT - 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_BETWEEN_NAMES - Static variable in class org.apache.calcite.sql.fun.SqlBetweenOperator
- NOT_BINARY_COMPLEMENT - Static variable in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- NOT_EQUALS - org.apache.calcite.sql.SqlKind
-
The not-equals operator, "!=" or "<>".
- NOT_EQUALS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Logical not-equals operator, '
<>
'. - NOT_IN - org.apache.calcite.sql.SqlKind
-
The "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 - org.apache.calcite.sql.validate.SqlMonotonicity
- NOT_NULL - org.apache.calcite.plan.Strong.Policy
-
This kind of expression is never null.
- NOT_NULLABLE - org.apache.calcite.schema.ColumnStrategy
-
Column does not have a default value, and does not allow nulls.
- NOT_POSSIBLE - org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
It is not possible for any of the arguments to be null.
- NOT_SIMILAR_TO - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- NOT_SPECIFIED - org.apache.calcite.piglet.Ast.Direction
- NOT_SUBMULTISET_OF - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- notArithmetic(String, Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- notASequence(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- notComparable(String, Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- 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. - 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
An inequality comparison, such as (a != b) in C# or (a <> b) in Visual Basic.
- notEquals(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- notEquals(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- notEquals(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- notEquals(RexNode, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
<>
. - notExists() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- notExists() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- notExists() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- 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.
- NotImplementor(NotNullImplementor) - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.NotImplementor
- notLike(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- notLike(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- notLike(PredicateAnalyzer.LiteralExpression) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- NotLikeConverter(RexBuilder) - Constructor for class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.NotLikeConverter
- NotNullImplementor - Interface in org.apache.calcite.adapter.enumerable
-
Simplified version of
CallImplementor
that does not know about null semantics. - notSelectDistinctExpr(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- noValueSuppliedForViewColumn(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- nProject - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Number of fields being projected.
- nRightProject - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Number of fields being projected from the right hand side of a join, in the case where the projection is being pushed past a join.
- nSysFields - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- nSysFields - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Number of system fields.
- nSystemProject - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Number of system fields being projected.
- nth(int) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns the
n
th set bit. - NTH_VALUE - 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
- nthSelectItem(int, SqlParserPos) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.OrderExpressionExpander
-
Returns the
ordinal
th item in the select list. - NthValueImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.NthValueImplementor
- NTILE - org.apache.calcite.sql.SqlKind
-
The
NTILE
aggregate function. - NTILE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
NTILE
aggregate function. - NtileImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.NtileImplementor
- nTotalFields - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Total number of fields in the MultiJoin
- nTransformations - Variable in class org.apache.calcite.plan.hep.HepPlanner
- nTransformationsLastGC - Variable in class org.apache.calcite.plan.hep.HepPlanner
- NULL - org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
The most common policy among the SQL built-in operators.
- NULL - org.apache.calcite.sql.SqlDialect.CalendarPolicy
- NULL - org.apache.calcite.sql.SqlJsonQueryEmptyOrErrorBehavior
- NULL - org.apache.calcite.sql.SqlJsonValueEmptyOrErrorBehavior
- NULL - org.apache.calcite.sql.type.SqlTypeFamily
- NULL - org.apache.calcite.sql.type.SqlTypeName
- NULL - Static variable in exception org.apache.calcite.util.Util.FoundOne
-
Singleton instance.
- NULL_BITS - Static variable in class org.apache.calcite.profile.ProfilerImpl.HllCollector
- NULL_EQUAL_TO_EMPTY - 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 - org.apache.calcite.sql.SqlNullSemantics
-
Wildcard semantics: logically, this is not present in any SQL construct.
- NULL_MATCHES_NOTHING - org.apache.calcite.sql.SqlNullSemantics
-
Predicate semantics: e.g.
- NULL_MATCHES_NULL - org.apache.calcite.sql.SqlNullSemantics
-
GROUP BY key semantics: e.g.
- NULL_ON_NULL - org.apache.calcite.sql.SqlJsonConstructorNullClause
- NULL_VALUE_NOT_ALLOWED - org.apache.calcite.sql.SqlStateCodes
-
Deprecated.
- nullable - Variable in class org.apache.calcite.jdbc.JavaTypeFactoryImpl.RecordFieldImpl
- nullable - Variable in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.JavaType
- nullable - Variable in class org.apache.calcite.sql.SqlDataTypeSpec
-
Whether data type is allows nulls.
- nullable - Variable in class org.apache.calcite.sql.validate.ScopeChild
- nullable - Variable in class org.apache.calcite.sql.validate.SqlValidatorScope.Resolve
- nullable() - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl.RecordFieldImpl
- 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(RexCall, int) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- NULLABLE - 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_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. - nullableArgs(List<Integer>, List<RelDataType>) - Static method in class org.apache.calcite.rex.RexBuilder
- 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. - 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. - nullables - Variable in class org.apache.calcite.adapter.enumerable.NestedBlockBuilderImpl
- nullaryFunctionMap - Variable in class org.apache.calcite.jdbc.CalciteSchema
- NullAs() - Constructor for enum org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
- nullClause - Variable in class org.apache.calcite.sql.fun.SqlJsonArrayAggAggFunction
- nullClause - Variable in class org.apache.calcite.sql.fun.SqlJsonObjectAggAggFunction
- nullCollation - Variable in class org.apache.calcite.sql.SqlDialect.ContextImpl
- nullCollation - Variable in class org.apache.calcite.sql.SqlDialect
- nullCollation - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- nullCollation() - Method in interface org.apache.calcite.sql.SqlDialect.Context
- nullCollation() - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- 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.
- NullCollation() - Constructor for enum org.apache.calcite.config.NullCollation
- nullComparison - Variable in enum org.apache.calcite.rel.RelFieldCollation.NullDirection
- nullCount - Variable in class org.apache.calcite.profile.Profiler.Distribution
- nullCount - Variable in class org.apache.calcite.profile.ProfilerImpl.CompositeCollector
- nullCount - Variable in class org.apache.calcite.profile.ProfilerImpl.HllCollector
- nullCount - Variable in class org.apache.calcite.profile.ProfilerImpl.SingletonCollector
- nullCount - Variable in class org.apache.calcite.profile.ProfilerImpl.Space
-
Assigned by
ProfilerImpl.Collector.finish()
. - nullCount - Variable in class org.apache.calcite.profile.SimpleProfiler.Space
- nullDirection - Variable in class org.apache.calcite.rel.RelFieldCollation
-
Direction of sorting of nulls.
- NullDirection(int) - Constructor for enum org.apache.calcite.rel.RelFieldCollation.NullDirection
- nullEqualToEmpty() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- nullEqualToEmpty() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- NULLIF - org.apache.calcite.sql.SqlKind
-
The "NULLIF" operator.
- NULLIF - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- nullIfEmpty - Variable in class org.apache.calcite.interpreter.AggregateNode.UdaAccumulatorFactory
- nullifyType(RelDataType, boolean) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- 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.EmptyScope
- 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
- nullIndicator - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationRexShuttle
- 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
- NullPolicy - Enum in org.apache.calcite.adapter.enumerable
-
Describes when a function/operator will return null.
- NullPolicy() - Constructor for enum org.apache.calcite.adapter.enumerable.NullPolicy
- NULLS_COMPARATOR - org.apache.calcite.util.BuiltInMethod
- NULLS_FIRST - org.apache.calcite.sql.SqlKind
-
NULLS FIRST clause in ORDER BY.
- NULLS_FIRST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- NULLS_FIRST_COMPARATOR - Static variable in class org.apache.calcite.linq4j.function.Functions
- NULLS_FIRST_REVERSE_COMPARATOR - Static variable in class org.apache.calcite.linq4j.function.Functions
- NULLS_LAST - org.apache.calcite.sql.SqlKind
-
NULLS LAST clause in ORDER BY.
- NULLS_LAST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- NULLS_LAST_COMPARATOR - Static variable in class org.apache.calcite.linq4j.function.Functions
- NULLS_LAST_REVERSE_COMPARATOR - Static variable in class org.apache.calcite.linq4j.function.Functions
- nullsComparator(boolean, boolean) - 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.
- NullSentinel() - Constructor for enum org.apache.calcite.rel.metadata.NullSentinel
- nullsFirst(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Converts a sort expression to nulls first.
- NullsFirstComparator() - Constructor for class org.apache.calcite.linq4j.function.Functions.NullsFirstComparator
- NullsFirstReverseComparator() - Constructor for class org.apache.calcite.linq4j.function.Functions.NullsFirstReverseComparator
- nullsLast(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Converts a sort expression to nulls last.
- NullsLastComparator() - Constructor for class org.apache.calcite.linq4j.function.Functions.NullsLastComparator
- NullsLastReverseComparator() - Constructor for class org.apache.calcite.linq4j.function.Functions.NullsLastReverseComparator
- number(Comparable) - Method in class org.apache.calcite.rex.RexInterpreter
- number(Number) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Creates a number value of this primitive's box type.
- numberFormat - Variable in class org.apache.calcite.adapter.file.FileRowConverter
-
Format for parsing numbers.
- 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.
- NumberUtil() - Constructor for class org.apache.calcite.util.NumberUtil
- 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(SqlTypeName) - Static method in class org.apache.calcite.sql.type.SqlTypeExplicitPrecedenceList
- NUMERIC - org.apache.calcite.sql.SqlFunctionCategory
- NUMERIC - org.apache.calcite.sql.type.SqlTypeFamily
- NUMERIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
- NUMERIC_FUNCTIONS - Static variable in class org.apache.calcite.sql.SqlJdbcFunctionCall
-
List of all numeric function names defined by JDBC.
- 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_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 class org.apache.calcite.sql.type.SqlTypeExplicitPrecedenceList
- NUMERIC_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- NUMERIC_VALUE_OUT_OF_RANGE - org.apache.calcite.sql.SqlStateCodes
-
Deprecated.
- NumericComparison(T, BiFunction<T, T, T>) - Constructor for class org.apache.calcite.interpreter.AggregateNode.NumericComparison
- NumericLiteral(SqlParserPos, BigDecimal, int, int, boolean) - Constructor for class org.apache.calcite.piglet.Ast.NumericLiteral
- numRows - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonSegmentMetadata
- numTagsWritten() - Method in class org.apache.calcite.util.XmlOutput
-
Get the total number of tags written
- NVARCHAR - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- NVL - org.apache.calcite.sql.SqlKind
-
The "NVL" function (Oracle).
- NVL - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
The "NVL(value, value)" function.
O
- o - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.Bean
- o - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Token
- OBJECT - org.apache.calcite.linq4j.tree.Primitive.Flavor
-
Neither a primitive nor a boxing type.
- OBJECT_ARRAY - org.apache.calcite.adapter.clone.ArrayTable.RepresentationType
-
Object array.
- OBJECT_DICTIONARY - org.apache.calcite.adapter.clone.ArrayTable.RepresentationType
-
Dictionary of objects.
- OBJECT_TO_STRING - org.apache.calcite.runtime.Resources.BuiltinMethod
- OBJECT_TO_STRING - org.apache.calcite.util.BuiltInMethod
- ObjectArray(int) - Constructor for class org.apache.calcite.adapter.clone.ArrayTable.ObjectArray
- ObjectArrayRowBuilder(ResultSet, ColumnMetaData.Rep[], int[]) - Constructor for class org.apache.calcite.adapter.jdbc.JdbcUtils.ObjectArrayRowBuilder
- ObjectDictionary(int, ArrayTable.Representation) - Constructor for class org.apache.calcite.adapter.clone.ArrayTable.ObjectDictionary
- ObjectEnumerator(int, ArrayTable.Column) - Constructor for class org.apache.calcite.adapter.clone.ArrayTable.Content.ObjectEnumerator
- 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 - 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.
- obliterateRelNode(RelNode) - Method in class org.apache.calcite.plan.volcano.RelSet
-
Removes all references to a specific
RelNode
in both the subsets and their parent relationships. - 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.
- obsoleteLatticeMap - Variable in class org.apache.calcite.materialize.LatticeSuggester
-
Lattices that have been made obsolete.
- occupied(Object[]) - Static method in class org.apache.calcite.util.ChunkList
- of() - Static method in class org.apache.calcite.runtime.FlatLists
-
Creates a flat list with 0 elements.
- of() - Static method in class org.apache.calcite.sql.parser.Span
-
Creates an empty Span.
- 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(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) - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter.Indent
- 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.BitSets
-
Creates a bitset with given bits set.
- of(int...) - Static method in class org.apache.calcite.util.ImmutableBitSet
- of(int...) - Static method in class org.apache.calcite.util.ImmutableIntList
-
Creates an ImmutableIntList from an array of
int
. - 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(SortedSetMultimap<RelNode, RelDecorrelator.CorRef>, SortedMap<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.ImmutableNullableList
-
Creates an immutable list 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, E) - Static method in class org.apache.calcite.util.ImmutableNullableList
-
Creates an immutable list 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, 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, 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(Class<M>, Class<? extends MetadataHandler<M>>, Method...) - Static method in class org.apache.calcite.rel.metadata.MetadataDef
-
Creates a
MetadataDef
. - of(Comparable) - Static method in enum org.apache.calcite.rex.RexInterpreter.Truthy
- 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(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<Integer>) - Static method in class org.apache.calcite.util.ImmutableBitSet
- 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.plan.Contexts
-
Returns a context that wraps an object.
- 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(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 enum org.apache.calcite.adapter.csv.CsvFieldType
- of(String) - Static method in enum org.apache.calcite.adapter.file.FileFieldType
- of(String) - Static method in class org.apache.calcite.jdbc.CalcitePrepare.Query
- of(String) - Static method in enum org.apache.calcite.runtime.GeoFunctions.CapStyle
- of(String) - Static method in enum org.apache.calcite.runtime.GeoFunctions.JoinStyle
- 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, int, RelDataType) - Static method in class org.apache.calcite.rex.RexPatternFieldRef
- of(String, Object) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.GroupValue
-
Constructs a
ElasticsearchJson.GroupValue
instance with a single value. - 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(Collection<? extends SqlNode>) - Static method in class org.apache.calcite.sql.parser.Span
-
Creates a Span of a list of nodes.
- of(Iterator<E>, long) - Static method in class org.apache.calcite.jdbc.CalciteMetaImpl.LimitIterator
- 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<RelReferentialConstraint>) - Static method in class org.apache.calcite.schema.Statistics
-
Returns a statistic with a given set of referential constraints.
- 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<K, V>) - Static method in class org.apache.calcite.util.Pair
-
Creates a
Pair
from aMap.Entry
. - of(Map<K, V>, Map<K, V>...) - Static method in class org.apache.calcite.util.CompositeMap
-
Creates a CompositeMap.
- of(DataSource, String) - Static method in class org.apache.calcite.runtime.ResultSetEnumerable
-
Creates an 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 an ResultSetEnumerable that retrieves columns as specific Java types.
- of(JavaRowFormat) - Method in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
- of(NotNullImplementor) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable.NotImplementor
- of(JavaTypeFactory, Type) - Static method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- 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(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(RelTraitDef, List<T>) - Static method in class org.apache.calcite.plan.RelCompositeTrait
-
Creates a RelCompositeTrait.
- of(JoinRelType) - Static method in enum org.apache.calcite.sql.SemiJoinType
- 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(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) - Static method in class org.apache.calcite.plan.RelOptMaterialization.ProjectFilterTable
- of(RelNode, Project, RelNode) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.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<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, List<Pair<RexInputRef, RexNode>>) - Static method in class org.apache.calcite.plan.VisitorDataContext
- 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, SemiJoinType) - 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, MutableRel, RexNode, ImmutableIntList, ImmutableIntList) - Static method in class org.apache.calcite.rel.mutable.MutableSemiJoin
-
Creates a MutableSemiJoin.
- 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(RexNode) - Static method in class org.apache.calcite.rex.RexSimplify.Comparison
-
Creates a comparison, or returns null.
- of(RexNode) - Static method in class org.apache.calcite.rex.RexSimplify.IsPredicate
-
Creates an IS predicate, or returns null.
- of(RexNode) - Static method in interface org.apache.calcite.rex.RexSimplify.Predicate
-
Wraps an expression in a Predicate or returns null.
- 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(SqlParserPos) - Static method in class org.apache.calcite.sql.parser.Span
-
Creates a Span with one position.
- 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(SqlNode, RelDataType, ColumnStrategy) - Static method in class org.apache.calcite.sql.ddl.SqlCreateTable.ColumnDef
- 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(SqlOperatorTable...) - Static method in class org.apache.calcite.sql.util.ChainedSqlOperatorTable
-
Creates a
ChainedSqlOperatorTable
. - 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(ImmutableBitSet, int) - Static method in enum org.apache.calcite.plan.RelOptUtil.Side
- 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(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.util.TryThreadLocal
-
Creates a TryThreadLocal.
- 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 - Static variable in class org.apache.calcite.profile.ProfilerImpl.CompositeCollector
- of_(List<T>) - Static method in class org.apache.calcite.runtime.FlatLists
- 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.
- of2(RexNode, RelNode) - Static method in class org.apache.calcite.plan.RelOptMaterialization.ProjectFilterTable
- of3(RexNode, Mappings.TargetMapping, RelNode) - Static method in class org.apache.calcite.plan.RelOptMaterialization.ProjectFilterTable
- 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.
- OFF - Static variable in class org.apache.calcite.adapter.os.GitCommitsTableFunction
-
An example of the offset at the end of author and committer fields.
- offer(double) - Method in class org.apache.calcite.profile.ProfilerImpl.SurpriseQueue
- offset - Variable in class org.apache.calcite.adapter.cassandra.CassandraLimit
- offset - Variable in class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
- offset - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.Page
- offset - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
-
Starting index (default
0
). - 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.rex.RexRangeRef
- offset - Variable in class org.apache.calcite.rex.RexUtil.RexShiftShuttle
- offset - Variable in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundBounded
- offset - Variable in class org.apache.calcite.sql.SqlOrderBy
- offset - Variable in class org.apache.calcite.sql.SqlSelect
- offset - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.NavigationExpander
- offset - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
- offset(long) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
- 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 - org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- OFFSET - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
OFFSET clause.
- 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.
- 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.linq4j.DefaultQueryable
- ofType(Class<TResult>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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 interface org.apache.calcite.linq4j.ExtendedQueryable
-
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
- ofType(Queryable<T>, Class<TResult>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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.
- OldTokenSequenceImpl(List<Object>) - Constructor for class org.apache.calcite.sql.parser.SqlParserUtil.OldTokenSequenceImpl
- oldToNewOutputs - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.Frame
- oldToNewRelMap - Variable in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- ON - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- ON - 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.
- onCopyHook - Variable in class org.apache.calcite.plan.hep.HepPlanner
- ONE_MINUS_EPSILON - Static variable in class org.apache.calcite.plan.volcano.RuleQueue
-
Largest value which is less than one.
- 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 - org.apache.calcite.sql.SqlMatchRecognize.RowsPerMatchOption
- 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 - 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.VolcanoPlanner.DeferringRuleCall
-
Rather than invoking the rule (as the base method does), creates a
VolcanoRuleMatch
which can be invoked later. - 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.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.EnumerableFilterToCalcRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.enumerable.EnumerableLimitRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.adapter.enumerable.EnumerableProjectToCalcRule
- 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.splunk.SplunkPushDownRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.interpreter.Bindables.BindableTableScanRule
- 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.SubstitutionVisitor.FilterOnProjectRule
- 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.AbstractMaterializedViewRule.MaterializedViewOnlyAggregateRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewOnlyFilterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewOnlyJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewProjectAggregateRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewProjectFilterRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewProjectJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
- 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.AggregateJoinTransposeRule
- 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.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.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.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.FilterSetOpTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterTableFunctionTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.FilterToCalcRule
- 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.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.MaterializedViewFilterScanRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule
- 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.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.ProjectRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectSetOpTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.ProjectSortTransposeRule
- 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.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
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SemiJoinRule.ProjectToSemiJoinRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SortJoinTransposeRule
- 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.SortRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SortUnionTransposeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SubQueryRemoveRule.SubQueryFilterRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SubQueryRemoveRule.SubQueryJoinRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.SubQueryRemoveRule.SubQueryProjectRemoveRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.TableScanRule
- 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.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(RexNode[]) - Method in interface org.apache.calcite.rex.RexAction
- onMatch2(RelOptRuleCall, LogicalCorrelate, RelNode, LogicalProject, LogicalAggregate) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.AdjustProjectForCountAggregateRule
- onMatchLeft(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinPushThroughJoinRule
-
Similar to
JoinPushThroughJoinRule.onMatch(org.apache.calcite.plan.RelOptRuleCall)
, but swaps the upper sibling with the left of the two lower siblings, rather than the right. - onMatchRight(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.JoinPushThroughJoinRule
- 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.
- OOBINLINE - Static variable in class org.apache.calcite.runtime.SocketFactoryImpl
-
is out of band in-line enabled
- op - Variable in enum org.apache.calcite.linq4j.tree.ExpressionType
- 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.rex.RexSqlStandardConvertletTable.EquivConvertlet
- op - Variable in class org.apache.calcite.sql.parser.SqlParserUtil.ToTreeListItem
- op - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.NavigationExpander
- op - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Call
- op(int) - Method in class org.apache.calcite.sql.parser.SqlParserUtil.OldTokenSequenceImpl
- op(int) - Method in class org.apache.calcite.sql.parser.SqlParserUtil.TokenSequenceImpl
- op(int) - Method in interface org.apache.calcite.sql.SqlSpecialOperator.TokenSequence
- op(Ast.Op) - Static method in class org.apache.calcite.piglet.Handler
- op(SqlKind) - Static method in class org.apache.calcite.rex.RexUtil
- op(SqlKind, SqlOperator) - Static method in class org.apache.calcite.plan.RelOptUtil
- Op() - Constructor for enum org.apache.calcite.piglet.Ast.Op
- Op(PrecedenceClimbingParser.Type, Object, int, int) - Constructor for class org.apache.calcite.util.PrecedenceClimbingParser.Op
- op2 - Variable in enum org.apache.calcite.linq4j.tree.ExpressionType
- open - Variable in class org.apache.calcite.prepare.PlannerImpl
- open - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- 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
- openCsv(Source) - Static method in class org.apache.calcite.adapter.csv.CsvEnumerator
- openPropertiesFile(Class) - Static method in class org.apache.calcite.runtime.Resources.ShadowResourceBundle
-
Opens the properties file corresponding to a given class.
- openQuote - Variable in class org.apache.calcite.sql.advise.SqlSimpleParser.Tokenizer
- openStream() - Method in interface org.apache.calcite.util.Source
- openStream() - Method in class org.apache.calcite.util.Sources.FileSource
- 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 - Variable in class org.apache.calcite.plan.RelOptRule
-
Root of operand tree.
- operand(int) - Method in class org.apache.calcite.sql.SqlBasicCall
- operand(int) - Method in class org.apache.calcite.sql.SqlCall
- 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>, RelOptRuleOperandChildren) - Static method in class org.apache.calcite.plan.RelOptRule
-
Creates an operand that matches a relational expression that has no children.
- operand(Class<R>, RelOptRuleOperand, RelOptRuleOperand...) - Static method in class org.apache.calcite.plan.RelOptRule
-
Creates an operand that matches a relational expression with a given list of children.
- 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
-
Creates an operand that matches a relational expression that has no children.
- Operand(Class<? extends MutableRel>) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.Operand
- 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
- OPERAND_TYPES - Static variable in class org.apache.calcite.sql.fun.SqlLeadLagAggFunction
- operand0 - Variable in class org.apache.calcite.plan.RelOptRuleCall
- operandCount() - Method in class org.apache.calcite.sql.SqlBasicCall
- operandCount() - Method in class org.apache.calcite.sql.SqlCall
- operandJ(Class<R>, RelTrait, Predicate<? super R>, RelOptRuleOperandChildren) - Static method in class org.apache.calcite.plan.RelOptRule
-
Creates an operand that matches a relational expression that has a particular trait and predicate.
- operandJ(Class<R>, RelTrait, Predicate<? super R>, RelOptRuleOperand, RelOptRuleOperand...) - Static method in class org.apache.calcite.plan.RelOptRule
-
Creates an operand that matches a relational expression that has no children.
- operandMap(JsonSchema, Map<String, Object>) - Method in class org.apache.calcite.model.ModelHandler
-
Adds extra entries to an operand to a custom schema.
- operandNotComparable(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- operandRanges - Variable in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- operands - Variable in class org.apache.calcite.piglet.Ast.Call
- operands - Variable in class org.apache.calcite.plan.RelOptRule
-
Flattened list of operands.
- operands - Variable in class org.apache.calcite.plan.RelOptRuleOperandChildren
- operands - Variable in class org.apache.calcite.rel.core.Aggregate.AggCallBinding
- operands - Variable in class org.apache.calcite.rex.RexCall
- operands - Variable in class org.apache.calcite.rex.RexCallBinding
- operands - Variable in class org.apache.calcite.sql.SqlBasicCall
- operands - Variable in class org.apache.calcite.tools.RelBuilder.AggCallImpl
- 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
- operandTypeChecker - Variable in class org.apache.calcite.sql.SqlOperator
-
used to validate operand types
- operandTypeInference - Variable in class org.apache.calcite.sql.SqlOperator
-
used to infer types of unknown operands
- operandTypes - Variable in class org.apache.calcite.sql.dialect.JethroDataSqlDialect.JethroSupportedFunction
- OperandTypes - Class in org.apache.calcite.sql.type
-
Strategies for checking operand types.
- OperandTypes() - Constructor for class org.apache.calcite.sql.type.OperandTypes
- OperandTypes.PeriodOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Operand type checker that accepts period types: PERIOD (DATETIME, DATETIME) PERIOD (DATETIME, INTERVAL) [ROW] (DATETIME, DATETIME) [ROW] (DATETIME, INTERVAL)
- operation - Variable in class org.apache.calcite.rel.core.TableModify
- operation - Variable in class org.apache.calcite.rel.mutable.MutableTableModify
- Operation() - Constructor for enum org.apache.calcite.rel.core.TableModify.Operation
- operator - Variable in class org.apache.calcite.adapter.druid.BinaryOperatorConversion
- operator - Variable in class org.apache.calcite.adapter.druid.DirectOperatorConversion
- operator - Variable in class org.apache.calcite.adapter.druid.NaryOperatorConverter
- operator - Variable in class org.apache.calcite.adapter.druid.UnaryPrefixOperatorConversion
- operator - Variable in class org.apache.calcite.adapter.druid.UnarySuffixOperatorConversion
- operator - Variable in class org.apache.calcite.sql.SqlBasicCall
- operator - Variable in class org.apache.calcite.sql.SqlDdl
- operator - Variable in class org.apache.calcite.sql.SqlJdbcFunctionCall.SimpleMakeCall
- Operator() - Constructor for class org.apache.calcite.sql.SqlOrderBy.Operator
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlAttributeDefinition
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlCheckConstraint
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlColumnDeclaration
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlCreateForeignSchema
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlCreateFunction
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlCreateMaterializedView
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlCreateSchema
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlCreateTable
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlCreateType
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlCreateView
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlDropFunction
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlDropMaterializedView
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlDropSchema
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlDropTable
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlDropType
- OPERATOR - Static variable in class org.apache.calcite.sql.ddl.SqlDropView
- 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.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
- OperatorExprCondition(Iterable<? extends SqlOperator>) - Constructor for class org.apache.calcite.rel.rules.PushProjector.OperatorExprCondition
-
Creates an OperatorExprCondition.
- operatorList - Variable in class org.apache.calcite.sql.util.ListSqlOperatorTable
- operators - Variable in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
- operatorSet - Variable in class org.apache.calcite.rel.rules.PushProjector.OperatorExprCondition
- operatorTable - Variable in class org.apache.calcite.prepare.PlannerImpl
- operatorTable - Variable in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- operatorTable - Variable in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- operatorTable(String) - Static method in class org.apache.calcite.prepare.CalciteCatalogReader
-
Creates an operator table that contains functions in the given class.
- operatorTable(String, Collection<SqlOperatorTable>) - Static method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- operatorTable(SqlOperatorTable) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- opKinds - Variable in class org.apache.calcite.rel.rules.DateRangeRules.ExtractFinder
- opTab - Variable in class org.apache.calcite.rex.RexBuilder
- opTab - Variable in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Operator table containing the standard SQL operators and functions.
- opTab - Variable in class org.apache.calcite.sql.validate.AggVisitor
- opTab - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- opTab - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- optimize(Expression) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- optimize(Shuttle, boolean) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Optimizes the list of statements.
- optimize(RelNode) - Method in class org.apache.calcite.interpreter.Interpreter
- 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
- OPTIMIZE - org.apache.calcite.plan.volcano.VolcanoPlannerPhase
- OPTIMIZE_SHUTTLE - Static variable in class org.apache.calcite.linq4j.tree.BlockBuilder
- optimize2(Expression, Expression) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- optimizeDeclarations(List<MemberDeclaration>) - Method in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
Adds new declarations (e.g.
- optimizeFilteredAggregations(RelOptRuleCall, DruidQuery, Project, Aggregate) - Method in class org.apache.calcite.adapter.druid.DruidRules.DruidAggregateProjectRule
-
Attempts to optimize any aggregations with filters in the DruidQuery.
- OptimizeShuttle - Class in org.apache.calcite.linq4j.tree
-
Shuttle that optimizes expressions.
- OptimizeShuttle() - Constructor for class org.apache.calcite.linq4j.tree.OptimizeShuttle
- optimizing - Variable in class org.apache.calcite.linq4j.tree.BlockBuilder
- optional - Variable in class org.apache.calcite.sql.type.FamilyOperandTypeChecker
- optional() - Method in annotation type org.apache.calcite.linq4j.function.Parameter
-
Returns whether the parameter is optional.
- OPTIONAL - org.apache.calcite.util.Optionality
-
A property is optional if an instance may or may not possess it; neither state is an error.
- OPTIONAL_SOURCE - Static variable in enum org.apache.calcite.util.mapping.MappingType
-
Allow less than one source for a given target.
- OPTIONAL_TARGET - Static variable in enum org.apache.calcite.util.mapping.MappingType
-
Allow less than one target for a given source.
- Optionality - Enum in org.apache.calcite.util
-
Four states that describe whether a particular behavior or property is allowed and/or not allowed.
- Optionality() - Constructor for enum org.apache.calcite.util.Optionality
- optionList - Variable in class org.apache.calcite.sql.ddl.SqlCreateForeignSchema
- options(SqlNodeList) - Static method in class org.apache.calcite.sql.ddl.SqlCreateForeignSchema
- OpType - Enum in org.apache.calcite.linq4j
-
Operator type.
- OpType() - Constructor for enum org.apache.calcite.linq4j.OpType
- oqlAggregateFunctions - Variable in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- or(Iterable<? extends RexNode>) - Method in class org.apache.calcite.rex.RexUtil.CnfHelper
- or(Iterable<? extends RexNode>) - Method in class org.apache.calcite.rex.RexUtil.DnfHelper
- or(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an OR.
- or(PredicateAnalyzer.QueryExpression...) - Static method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- 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(RexBuilder, RexNode, RexNode) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- or(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an 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...) - 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 - 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 - org.apache.calcite.adapter.druid.DruidJsonFilter.Type
- OR - org.apache.calcite.adapter.enumerable.NullPolicy
-
If any of the arguments are true, result is true; else if any arguments are null, result is null; else false.
- OR - org.apache.calcite.piglet.Ast.Op
- OR - org.apache.calcite.sql.SqlKind
-
The logical "OR" operator.
- OR - org.apache.calcite.sql.type.CompositeOperandTypeChecker.Composition
- OR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Logical
OR
operator. - ORACLE - org.apache.calcite.config.Lex
-
Lexical policy similar to Oracle.
- ORACLE - org.apache.calcite.sql.SqlDialect.DatabaseProduct
- ORACLE_10 - 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 - 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
-
Operator table that contains only Oracle-specific functions and operators.
- OracleSqlOperatorTable() - Constructor for class org.apache.calcite.sql.fun.OracleSqlOperatorTable
- 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 - 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.
- Ord.OrdArrayList<E> - Class in org.apache.calcite.linq4j
-
List of
Ord
backed by an array of elements. - Ord.OrdList<E> - Class in org.apache.calcite.linq4j
-
List of
Ord
backed by a list of elements. - Ord.OrdRandomAccessList<E> - Class in org.apache.calcite.linq4j
-
List of
Ord
backed by a random-access list of elements. - OrdArrayList(E[]) - Constructor for class org.apache.calcite.linq4j.Ord.OrdArrayList
- order - Variable in class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
- order - Variable in class org.apache.calcite.plan.hep.HepInstruction.MatchOrder
- order - Variable in class org.apache.calcite.sql.SqlJdbcFunctionCall.PermutingMakeCall
- ORDER - org.apache.calcite.piglet.Ast.Op
- ORDER - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- ORDER_BY - org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- ORDER_BY - org.apache.calcite.sql.SqlKind
-
ORDER BY clause.
- ORDER_BY - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
ORDER BY clause of a SELECT statement.
- ORDER_BY - org.apache.calcite.util.BuiltInMethod
- ORDER_BY_LIST - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
ORDER BY list.
- orderBy - Variable in class org.apache.calcite.sql.SqlSelect
- 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(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>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- orderBy(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- orderBy(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- orderBy(FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- orderBy(FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- orderBy(FunctionExpression<Function1<TSource, TKey>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Sorts the elements of a sequence in ascending order according to a key.
- orderBy(FunctionExpression<Function1<TSource, TKey>>, Comparator<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Sorts the elements of a sequence in ascending order by using a specified comparer.
- 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>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- orderByDescending(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- orderByDescending(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- orderByDescending(FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- orderByDescending(FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- orderByDescending(FunctionExpression<Function1<TSource, TKey>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Sorts the elements of a sequence in descending order according to a key.
- orderByDescending(FunctionExpression<Function1<TSource, TKey>>, Comparator<TKey>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Sorts the elements of a sequence in descending order by using a specified comparer.
- orderByFields - Variable in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- 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
- OrderByScope - Class in org.apache.calcite.sql.validate
-
Represents the name-resolution context for expressions in an ORDER BY clause.
- OrderByScope(SqlValidatorScope, SqlNodeList, SqlSelect) - Constructor for class org.apache.calcite.sql.validate.OrderByScope
- orderbyShouldNotContainOver() - Method in interface org.apache.calcite.runtime.CalciteResource
- ORDERED_AGGREGATE_LAMBDA_FACTORY - org.apache.calcite.util.BuiltInMethod
- OrderedAggregateLambdaFactory<TSource,TKey,TSortKey,TOrigAccumulate,TResult> - Class in org.apache.calcite.adapter.enumerable
-
Generate aggregate lambdas that sorts the input source before calling each aggregate adder.
- OrderedAggregateLambdaFactory(Function0<TOrigAccumulate>, List<SourceSorter<TOrigAccumulate, TSource, TSortKey>>) - Constructor for class org.apache.calcite.adapter.enumerable.OrderedAggregateLambdaFactory
- OrderedAggregateLambdaFactory.LazySource<TSource> - Class in org.apache.calcite.adapter.enumerable
-
Cache the input sources.
- 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
. - OrderExpressionExpander(SqlSelect, SqlNode) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.OrderExpressionExpander
- ordering - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonExpressionPostAgg
- ordering - Variable in class org.apache.calcite.profile.SimpleProfiler.Run
- ordering - Variable in class org.apache.calcite.util.PartiallyOrderedSet
- ORDERING - Static variable in class org.apache.calcite.materialize.MutableNode
-
Comparator for sorting children within a parent.
- ORDERING - Static variable in class org.apache.calcite.rel.RelDistributions.RelDistributionImpl
- 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.logical.LogicalWindow.WindowKey
- orderKeys - Variable in class org.apache.calcite.rex.RexWindow
- orderKeys - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.HistogramShuttle
- orderKeys - Variable in class org.apache.calcite.tools.RelBuilder.AggCallImpl
- orderList - Variable in class org.apache.calcite.sql.SqlMatchRecognize
- orderList - Variable in class org.apache.calcite.sql.SqlOrderBy
- orderList - Variable in class org.apache.calcite.sql.SqlWindow
-
The list of ordering columns.
- orderList - Variable in class org.apache.calcite.sql.validate.OrderByScope
- orderList - Variable in class org.apache.calcite.sql.validate.SelectScope
-
List of column names which sort this scope.
- orderList - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.AggregateFinder
- orderScopes - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Maps a
SqlSelect
node to the scope used by its ORDER BY clause. - 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.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- ordinal - Variable in class org.apache.calcite.adapter.clone.ArrayTable.Constant
- ordinal - Variable in class org.apache.calcite.adapter.clone.ArrayTable.ObjectArray
- ordinal - Variable in class org.apache.calcite.adapter.clone.ArrayTable.ObjectDictionary
- ordinal - Variable in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveArray
- ordinal - Variable in class org.apache.calcite.materialize.Lattice.Column
-
Ordinal of the column within the lattice.
- ordinal - Variable in class org.apache.calcite.plan.SubstitutionVisitor.QueryOperand
- ordinal - Variable in class org.apache.calcite.plan.SubstitutionVisitor.TargetOperand
- 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.sql.type.CursorReturnTypeInference
- ordinal - Variable in class org.apache.calcite.sql.type.OrdinalReturnTypeInference
- ordinal - Variable in class org.apache.calcite.sql.validate.ScopeChild
- ordinal() - Method in interface org.apache.calcite.sql.SqlLiteral.SqlSymbol
-
Deprecated.
- ordinalInParent - Variable in class org.apache.calcite.plan.RelOptRuleOperand
- ordinalInParent - Variable in class org.apache.calcite.rel.mutable.MutableRel
- ordinalInParent - Variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverter.Frame
- ordinalInQuery - Variable in class org.apache.calcite.materialize.LatticeSuggester.StepRef
- ordinalInQuery - Variable in class org.apache.calcite.materialize.LatticeSuggester.TableRef
- ordinalInRule - Variable in class org.apache.calcite.plan.RelOptRuleOperand
- ordinality - Variable in class org.apache.calcite.runtime.SqlFunctions.ProductComparableListEnumerator
- ORDINALITY_COLUMN_NAME - Static variable in class org.apache.calcite.sql.SqlUnnestOperator
- ordinalMap - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor
- 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.
- OrdList(List<? extends E>) - Constructor for class org.apache.calcite.linq4j.Ord.OrdList
- OrdRandomAccessList(List<? extends E>) - Constructor for class org.apache.calcite.linq4j.Ord.OrdRandomAccessList
- 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 - 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 - package org.apache.calcite.adapter
-
Calcite adapters.
- 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
-
Calcite query provider that reads from web tables (HTML).
- 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 provider based on Apache Geode (Gemfire) In Memory Data Grid
- org.apache.calcite.adapter.geode.util - package org.apache.calcite.adapter.geode.util
-
Query provider based on Apache Geode (Gemfire) In Memory Data Grid
- 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.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.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.benchmarks - package org.apache.calcite.benchmarks
-
JMH benchmarks for Calcite
- 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.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.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.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.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.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.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
-
Provides a SQL parser.
- org.apache.calcite.sql.pretty - package org.apache.calcite.sql.pretty
-
Provides a pretty-printer for SQL statements.
- 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.sql2rel - package org.apache.calcite.sql2rel
-
Translates a SQL parse tree to relational expression.
- org.apache.calcite.tools - package org.apache.calcite.tools
-
Provides utility classes.
- org.apache.calcite.util - package org.apache.calcite.util
-
Provides utility classes.
- 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.
- origFilter - Variable in class org.apache.calcite.rel.rules.PushProjector
- origin(List<String>, int) - Static method in class org.apache.calcite.prepare.CalcitePrepareImpl
- original - Variable in class org.apache.calcite.linq4j.QueryableDefaults.NonLeafReplayableQueryable
- originalBitSet - Variable in class org.apache.calcite.util.ImmutableBitSet.Rebuilder
- originalExpression - Variable in class org.apache.calcite.plan.RelOptCluster
- originalExprs - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- originalRelName - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.DeferredLookup
- originalRoot - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
- originalRootString - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Dump of the root relational expression, as it was before any rules were applied.
- originalSql - Variable in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
- originalStatement - Variable in exception org.apache.calcite.runtime.CalciteContextException
- originTable - Variable in class org.apache.calcite.rel.metadata.RelColumnOrigin
- origProj - Variable in class org.apache.calcite.rel.rules.PushProjector
- origProjExprs - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Original projection expressions
- orLong(int, int, long[], int, long) - Static method in class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- orLong(int, long[], int, long) - Static method in class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- OTC_CUSTOM - Static variable in class org.apache.calcite.sql.fun.SqlAbstractTimeFunction
- OTC_CUSTOM - Static variable in class org.apache.calcite.sql.fun.SqlBetweenOperator
-
Custom operand-type checking strategy.
- OTC_CUSTOM - Static variable in class org.apache.calcite.sql.fun.SqlOverlayFunction
- OTC_CUSTOM - Static variable in class org.apache.calcite.sql.fun.SqlPositionFunction
- 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 - org.apache.calcite.linq4j.tree.Primitive
- OTHER - org.apache.calcite.rel.core.Aggregate.Group
- OTHER - org.apache.calcite.schema.Schema.TableType
-
Table type not known to Calcite.
- OTHER - org.apache.calcite.sql.SqlKind
-
Expression not covered by any other
SqlKind
value. - OTHER - org.apache.calcite.sql.type.SqlTypeName
- OTHER_DDL - org.apache.calcite.sql.SqlKind
-
DDL statement not handled above.
- OTHER_FUNCTION - org.apache.calcite.sql.SqlKind
-
Function that is not a special function.
- out - Variable in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraConverterRule
- out - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.ElasticsearchConverterRule
- out - Variable in class org.apache.calcite.adapter.geode.rel.GeodeRules.GeodeConverterRule
- out - Variable in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcConverterRule
- out - Variable in class org.apache.calcite.adapter.mongodb.MongoRules.MongoConverterRule
- out - Variable in class org.apache.calcite.adapter.os.SqlShell
- out - Variable in class org.apache.calcite.util.XmlOutput
- out() - Method in class org.apache.calcite.piglet.Ast.UnParser
- out(StringBuilder) - Method in class org.apache.calcite.util.PartiallyOrderedSet
- OUTDENT - Static variable in class org.apache.calcite.util.StackWriter
-
directive for decreasing the indentation level
- outEdges - Variable in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
- outEdges - Variable in class org.apache.calcite.util.graph.DefaultDirectedGraph.VertexInfo
- outerJoin - Variable in class org.apache.calcite.plan.RelOptUtil.Exists
- outerJoinConditions - Variable in class org.apache.calcite.rel.rules.MultiJoin
- outerJoinFactors - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
If a join factor is null generating in a left or right outer join, the bitmap contains the non-null generating factors that the null generating factor is dependent upon
- outerKeySelector - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- output(PrintWriter, ResultSet) - Method in enum org.apache.calcite.adapter.os.SqlShell.Format
- outputName - Variable in class org.apache.calcite.adapter.druid.DefaultDimensionSpec
- outputName - Variable in class org.apache.calcite.adapter.druid.ExtractionDimensionSpec
- outputRowLength - Variable in class org.apache.calcite.interpreter.AggregateNode
- outputRowType - Variable in class org.apache.calcite.rex.RexProgram
- outputType - Variable in class org.apache.calcite.adapter.druid.DefaultDimensionSpec
- outputType - Variable in class org.apache.calcite.adapter.druid.ExtractionDimensionSpec
- outputType - Variable in class org.apache.calcite.adapter.druid.VirtualColumn
- outTrait - Variable in class org.apache.calcite.rel.convert.ConverterRule
- over - Variable in class org.apache.calcite.sql.validate.AggVisitor
-
Whether to find windowed aggregates.
- OVER - 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
. - overCall - Variable in class org.apache.calcite.sql.validate.OverScope
- overFinder - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- OverFinder() - Constructor for class org.apache.calcite.util.Util.OverFinder
- OVERFLOW - org.apache.calcite.sql.type.SqlTypeName.Limit
- OverflowError() - Constructor for exception org.apache.calcite.rex.RexUtil.CnfHelper.OverflowError
- OverFound() - Constructor for exception org.apache.calcite.rex.RexOver.OverFound
- overlap(RexNode, Set<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
- overlaps(SqlParserPos) - Method in class org.apache.calcite.sql.parser.SqlParserPos
- OVERLAPS - org.apache.calcite.sql.SqlKind
-
The "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 - org.apache.calcite.util.BuiltInMethod
- OVERLAY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- OVERLAY3 - 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.
- OverScope(SqlValidatorScope, SqlCall) - Constructor for class org.apache.calcite.sql.validate.OverScope
-
Creates a scope corresponding to a SELECT clause.
- ownerType - Variable in class org.apache.calcite.linq4j.tree.Types.ParameterizedTypeImpl
P
- p - Variable in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveArray
- p2(Object[], int[], boolean, SqlFunctions.FlatProductInputType[]) - Static method in class org.apache.calcite.runtime.SqlFunctions
- 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
- pad(int, long) - Static method in class org.apache.calcite.util.DateTimeStringUtils
- pad(StringBuilder, String, int) - Static method in class org.apache.calcite.rex.RexLiteral
- padRight(String, int) - Static method in class org.apache.calcite.rex.RexBuilder
-
Returns a string padded with spaces to make it at least a given length.
- padRight(ByteString, int) - Static method in class org.apache.calcite.rex.RexBuilder
-
Returns a byte-string padded with zero bytes to make it at least a given length,
- padRight(NlsString, int) - Static method in class org.apache.calcite.rex.RexBuilder
-
Returns an
NlsString
with spaces to make it at least a given length. - Page() - Constructor for class org.apache.calcite.adapter.druid.DruidConnectionImpl.Page
- pagingIdentifier - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.Page
- 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.AdjacentIterator<E> - Class in org.apache.calcite.util
-
Iterator that returns consecutive pairs of elements from an underlying iterator.
- Pair.FirstAndIterator<E> - Class in org.apache.calcite.util
-
Iterator that returns the first element of a collection paired with every other element.
- Pair.LeftIterator<L,R> - Class in org.apache.calcite.util
-
Iterator that returns the left field of each pair.
- Pair.RightIterator<L,R> - Class in org.apache.calcite.util
-
Iterator that returns the right field of each pair.
- Pair.ZipIterator<L,R> - Class in org.apache.calcite.util
-
Iterator that pairs elements from two iterators.
- pairs - Variable in class org.apache.calcite.materialize.Lattice.Edge
- pairs - Variable in class org.apache.calcite.schema.Schemas.PathImpl
- pairs() - Method in class org.apache.calcite.rel.core.JoinInfo
-
Returns a list of (left, right) key ordinals.
- pairs() - Method in class org.apache.calcite.sql.ddl.SqlCreateFunction
- 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), ...
- pairs(SqlNodeList) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Converts a list of extended columns (of the form [name0, type0, name1, type1, ...]) into a list of (name, type) pairs.
- 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 - 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.
- parallelismHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- param - Variable in class org.apache.calcite.benchmarks.PreconditionTest
- 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(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(ParameterExpression) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.EmptyScalarTranslator
- parameter(ParameterExpression) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.LambdaScalarTranslator
- Parameter - 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
- ParameterizedTypeImpl(Type, List<Type>, Type) - Constructor for class org.apache.calcite.linq4j.tree.Types.ParameterizedTypeImpl
- parameterList - Variable in class org.apache.calcite.linq4j.tree.FunctionExpression
- parameterList - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl.LambdaScalarTranslator
- ParameterListBuilder() - Constructor for class org.apache.calcite.schema.impl.ReflectiveFunctionBase.ParameterListBuilder
- parameterNames - Variable in class org.apache.calcite.util.Template
- ParameterNamespace - Class in org.apache.calcite.sql.validate
-
Namespace representing the type of a dynamic parameter.
- ParameterNamespace(SqlValidatorImpl, RelDataType) - Constructor for class org.apache.calcite.sql.validate.ParameterNamespace
- 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.EnumerableAggregate.AggContextImpl
- parameterRowType - Variable in class org.apache.calcite.prepare.Prepare
- parameterRowType - Variable in class org.apache.calcite.prepare.Prepare.PreparedExplain
- 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.Evaluator
- parameters - Variable in class org.apache.calcite.linq4j.tree.MethodDeclaration
- parameters - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- parameters - Variable in class org.apache.calcite.schema.impl.ReflectiveFunctionBase
-
Types of parameter for the function call.
- PARAMETERS - Static variable in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction
- PARAMETERS - Static variable in class org.apache.calcite.sql.advise.SqlAdvisorGetHintsFunction2
- 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.EnumerableAggregate.AggContextImpl
- paramList(StringBuilder, Method) - Static method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
-
Returns e.g.
- paramNames - Variable in class org.apache.calcite.sql.type.AssignableOperandTypeChecker
- paramNames - Variable in class org.apache.calcite.sql.type.TableFunctionReturnTypeInference
- params - Variable in class org.apache.calcite.rel.core.Sample
- params - Variable in class org.apache.calcite.rel.mutable.MutableSample
- paramTypes - Variable in class org.apache.calcite.sql.SqlFunction
- paramTypes - Variable in class org.apache.calcite.sql.type.AssignableOperandTypeChecker
- paramTypes - Variable in class org.apache.calcite.sql.type.ExplicitOperandTypeInference
- paranoid - Variable in class org.apache.calcite.rex.RexSimplify
- parent - Variable in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- parent - Variable in class org.apache.calcite.jdbc.CalciteSchema
- parent - Variable in class org.apache.calcite.linq4j.tree.BlockBuilder
- 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.materialize.MutableNode
- parent - Variable in class org.apache.calcite.plan.RelOptRuleOperand
- parent - Variable in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- parent - Variable in class org.apache.calcite.rel.mutable.MutableRel
- parent - Variable in class org.apache.calcite.rel.rules.LoptJoinTree.BinaryTree
- parent - Variable in class org.apache.calcite.sql.validate.DelegatingScope
-
Parent scope.
- parent - Variable in class org.apache.calcite.sql.validate.SqlValidatorScope.Step
- parent - Variable in class org.apache.calcite.util.mapping.Mappings.InverseMapping
- parent - Variable in class org.apache.calcite.util.mapping.Mappings.OverridingSourceMapping
- parent - Variable in class org.apache.calcite.util.mapping.Mappings.OverridingTargetMapping
- parent() - Method in interface org.apache.calcite.schema.Path
-
Returns the parent path, or null if the path is empty.
- parent() - Method in class org.apache.calcite.schema.Schemas.PathImpl
- parentCallTypeStack - Variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- parentFunction - Variable in class org.apache.calcite.util.PartiallyOrderedSet
- parentList - Variable in class org.apache.calcite.util.PartiallyOrderedSet.Node
- parents - Variable in class org.apache.calcite.plan.RelOptRuleCall
- parents - Variable in class org.apache.calcite.plan.volcano.RelSet
-
Relational expressions that have a subset in this set as a child.
- parents - Variable in class org.apache.calcite.util.EquivalenceSet
- parentSchema - Variable in class org.apache.calcite.adapter.cassandra.CassandraSchema
- parentScope - Variable in class org.apache.calcite.sql.validate.IdentifierNamespace
- 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) - Method in class org.apache.calcite.sql.dialect.JethroDataSqlDialect.JethroSupportedFunction
- parse(String) - Method in interface org.apache.calcite.tools.Planner
-
Parses and validates a SQL statement.
- parse(QueryType, InputStream, Sink, List<String>, List<ColumnMetaData.Rep>, DruidConnectionImpl.Page) - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
-
Parses the output of a query, sending the results to a
Sink
. - 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_(CalcitePrepare.Context, String, boolean, boolean, boolean) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Shared implementation for
CalcitePrepareImpl.parse(org.apache.calcite.jdbc.CalcitePrepare.Context, java.lang.String)
,CalcitePrepareImpl.convert(org.apache.calcite.jdbc.CalcitePrepare.Context, java.lang.String)
andCalcitePrepareImpl.analyzeView(org.apache.calcite.jdbc.CalcitePrepare.Context, java.lang.String, boolean)
. - PARSE_TREE - org.apache.calcite.runtime.Hook
-
Called with the SQL string and parse tree, in an array.
- parse2(Properties, Map<String, ? extends ConnectionProperty>) - Static method in enum org.apache.calcite.config.CalciteConnectionProperty
-
Fixed version of
ConnectionConfigImpl.parse(java.util.Properties, java.util.Map<java.lang.String, ? extends org.apache.calcite.avatica.ConnectionProperty>)
until we upgrade Avatica. - parseAggregations(JsonParser, ObjectNode) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.AggregationsDeserializer
- parseArgs(String[], Map<String, String>) - Static method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- 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
- parseBucket(JsonParser, String, ObjectNode) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.AggregationsDeserializer
- parseBuckets(JsonParser, String, ArrayNode) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.AggregationsDeserializer
- parseCached() - Method in class org.apache.calcite.benchmarks.ParserBenchmark
- parseCollation(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Extracts the values from a collation name.
- parseCorrelTable(RelNode, SqlImplementor.Result) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- parseDate(String) - Method in class org.apache.calcite.adapter.file.FileRowConverter.FieldDef
- parseDate(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Deprecated.this method is not localized for Farrago standards
- parseDateLiteral(String, SqlParserPos) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- ParsedCollation(Charset, Locale, String) - Constructor for class org.apache.calcite.sql.parser.SqlParserUtil.ParsedCollation
- parseDecimal(String) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- parseExpression() - Method in class org.apache.calcite.sql.parser.SqlParser
-
Parses a SQL expression.
- parseField(List<String>, List<ColumnMetaData.Rep>, int, Row.RowBuilder, JsonParser) - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- parseField(Matcher, int) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- parseFieldForName(List<String>, List<ColumnMetaData.Rep>, int, Row.RowBuilder, JsonParser, String) - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- parseFields(List<String>, List<ColumnMetaData.Rep>, int, Row.RowBuilder, JsonParser) - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- parseFields(List<String>, List<ColumnMetaData.Rep>, Row.RowBuilder, JsonParser) - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- 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
- parseIntString(String) - Static method in class org.apache.calcite.adapter.mongodb.MongoTable
-
Helper method to strip non-numerics from a string.
- parseLocale(String) - Static method in class org.apache.calcite.util.Util
-
Parses a locale string.
- parseNonCached() - Method in class org.apache.calcite.benchmarks.ParserBenchmark
- 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(CalcitePrepare.Query<T>, CalcitePrepare.Context, long) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- parseQuotedIdentifier() - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Tokenizer
- parser - Variable in class org.apache.calcite.adapter.csv.CsvStreamReader
- parser - Variable in class org.apache.calcite.benchmarks.ParserBenchmark
- parser - Variable in class org.apache.calcite.sql.parser.SqlParser
- parser - Variable in class org.apache.calcite.sql.parser.SqlParserUtil.TokenSequenceImpl
- parser(int, Predicate<PrecedenceClimbingParser.Token>) - Method in class org.apache.calcite.sql.parser.SqlParserUtil.OldTokenSequenceImpl
- parser(int, Predicate<PrecedenceClimbingParser.Token>) - Method in class org.apache.calcite.sql.parser.SqlParserUtil.TokenSequenceImpl
- 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 - org.apache.calcite.config.CalciteConnectionProperty
-
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. - ParserBenchmark - Class in org.apache.calcite.benchmarks
-
Benchmarks JavaCC-generated SQL parser
- ParserBenchmark() - Constructor for class org.apache.calcite.benchmarks.ParserBenchmark
- parserConfig - Variable in class org.apache.calcite.prepare.PlannerImpl
- parserConfig - Variable in class org.apache.calcite.sql.advise.SqlAdvisor
- parserConfig - Variable in class org.apache.calcite.sql.advise.SqlSimpleParser
- parserConfig - Variable in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- parserConfig - Variable in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- 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
- parseResults(InputStream, SearchResultListener) - Static method in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- parserException - Variable in exception org.apache.calcite.sql.parser.SqlParseException
-
The original exception thrown by the generated parser.
- parserFactory - Variable in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- parserFactory - Variable in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- parserFactory() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- parserFactory() - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- parserFactory(Class<T>, T) - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- parserFactory(Class<T>, T) - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- parseSqlExpressionEof() - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Parses a SQL expression ending with EOF and constructs a parse tree.
- parseSqlStmtEof() - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Parses a SQL statement ending with EOF and constructs a parse tree.
- parseStmt() - Method in class org.apache.calcite.sql.parser.SqlParser
-
Parses an SQL statement.
- 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
- 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
- parseTimestampLiteral(String, SqlParserPos) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
- parseTypeString(RelDataTypeFactory, String) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
-
Given "INTEGER", returns BasicSqlType(INTEGER).
- parseValue(JsonParser, String, ObjectNode) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.AggregationsDeserializer
- part - Variable in class org.apache.calcite.adapter.tpch.TpchSchema
- partCount - Variable in class org.apache.calcite.adapter.tpch.TpchSchema
- partial - Variable in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- PARTIAL_FUNCTION - org.apache.calcite.util.mapping.MappingType
- PARTIAL_INJECTION - org.apache.calcite.util.mapping.MappingType
- PARTIAL_SURJECTION - 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.
- PartialFunctionImpl(int, int, MappingType) - Constructor for class org.apache.calcite.util.mapping.Mappings.PartialFunctionImpl
- 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(PartiallyOrderedSet.Ordering<E>, Map<E, PartiallyOrderedSet.Node<E>>, Function<E, Iterable<E>>, Function<E, Iterable<E>>) - Constructor for class org.apache.calcite.util.PartiallyOrderedSet
-
Internal constructor.
- PartiallyOrderedSet.Node<E> - Class in org.apache.calcite.util
-
Holds a value, its parent nodes, and child nodes.
- PartiallyOrderedSet.Ordering<E> - Interface in org.apache.calcite.util
-
Ordering relation.
- PartiallyOrderedSet.TopBottomNode<E> - Class in org.apache.calcite.util
-
Subclass of Node for top/bottom nodes.
- PartialMapping(int[], int[], MappingType) - Constructor for class org.apache.calcite.util.mapping.Mappings.PartialMapping
- 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
- partitionbyShouldNotContainOver() - Method in interface org.apache.calcite.runtime.CalciteResource
- partitionKeys - Variable in class org.apache.calcite.adapter.cassandra.CassandraFilter
- partitionKeys - Variable in class org.apache.calcite.adapter.cassandra.CassandraFilter.Translator
- partitionKeys - Variable in class org.apache.calcite.rel.core.Match
- partitionKeys - Variable in class org.apache.calcite.rex.RexWindow
- partitionKeys - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.HistogramShuttle
- partitionList - Variable in class org.apache.calcite.sql.SqlMatchRecognize
- partitionList - Variable in class org.apache.calcite.sql.SqlWindow
-
The list of partitioning columns.
- partitionNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- partitionRowCount - Variable in class org.apache.calcite.adapter.enumerable.impl.WinAggResetContextImpl
- pass(int, List<ProfilerImpl.Space>, Iterable<List<Comparable>>) - Method in class org.apache.calcite.profile.ProfilerImpl.Run
- PassThroughExpander(RexBuilder) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule.PassThroughExpander
- password - Variable in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- path - Variable in class org.apache.calcite.jdbc.CalciteSchema
- path - Variable in class org.apache.calcite.materialize.MaterializationActor.QueryKey
- 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 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() - Method in class org.apache.calcite.util.Sources.FileSource
- path(ImmutableList<Pair<String, Schema>>) - Static method in class org.apache.calcite.schema.Schemas
- path(String) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns the path of an object in this schema.
- 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 - Class in org.apache.calcite.materialize
-
A sequence of
Step
s from a root node (fact table) to another node (dimension table), possibly via intermediate dimension tables. - 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
- Path(List<Step>, int) - Constructor for class org.apache.calcite.materialize.Path
- PathContext(SqlFunctions.PathMode, Object, Exception) - Constructor for class org.apache.calcite.runtime.SqlFunctions.PathContext
- PathImpl(ImmutableList<Pair<String, Schema>>) - Constructor for class org.apache.calcite.schema.Schemas.PathImpl
- pathMap - Variable in class org.apache.calcite.materialize.LatticeSpace
- pathMap - Variable in class org.apache.calcite.plan.ConventionTraitDef.ConversionData
- PathMode() - Constructor for enum org.apache.calcite.runtime.SqlFunctions.PathMode
- pathOffsetToColumn(Path, int) - Method in class org.apache.calcite.materialize.Lattice.Builder
- pathReturned - Variable in class org.apache.calcite.runtime.SqlFunctions.PathContext
- paths - Variable in class org.apache.calcite.materialize.LatticeRootNode
- pattern - Variable in class org.apache.calcite.rel.core.Match
- pattern - Variable in class org.apache.calcite.sql.SqlMatchRecognize
- PATTERN - Static variable in class org.apache.calcite.util.DateString
- PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
This table shows how and where the Gang of Four patterns are applied.
- PATTERN - Static variable in class org.apache.calcite.util.TimestampString
- PATTERN - Static variable in class org.apache.calcite.util.TimeString
- PATTERN_ALTER - org.apache.calcite.sql.SqlKind
-
the 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_CONCAT - org.apache.calcite.sql.SqlKind
-
the 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 - org.apache.calcite.sql.SqlKind
-
The special patterns to exclude enclosing pattern from output in a MATCH_RECOGNIZE clause.
- PATTERN_INPUT_REF - org.apache.calcite.sql.SqlKind
-
Reference to an input field, with pattern var as modifier
- PATTERN_PERMUTE - 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 - 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
. - 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)
. - 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
- patternDefList - Variable in class org.apache.calcite.sql.SqlMatchRecognize
- 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
- 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
- PatternValidator(boolean) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternValidator
- PatternValidator(boolean, int, int, int) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternValidator
- patternVarAlreadyDefined(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- PatternVarFinder() - Constructor for class org.apache.calcite.rel.core.Match.PatternVarFinder
- patternVars - Variable in class org.apache.calcite.rel.core.Match.PatternVarFinder
- patternVars - Variable in class org.apache.calcite.sql.validate.MatchRecognizeScope
- PatternVarVisitor(MatchRecognizeScope) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternVarVisitor
- 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
- pdxAutoSerializerPackageExp - Variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchema
- 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(ParameterExpression) - Method in class org.apache.calcite.linq4j.tree.Evaluator
- peek_() - Method in class org.apache.calcite.tools.RelBuilder
- peek_(int) - Method in class org.apache.calcite.tools.RelBuilder
- peek_(int, int) - Method in class org.apache.calcite.tools.RelBuilder
- PEEK_FIELDS - 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 - 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 - org.apache.calcite.rel.type.StructKind
-
As
StructKind.PEEK_FIELDS
, but fields are not expanded in "SELECT *". - PER_THREAD - Static variable in class org.apache.calcite.sql.parser.SqlParserUtil.Format
- PERCENT_RANK - 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 - org.apache.calcite.util.BuiltInMethod
- percentageOriginalRowsHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- 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.AbstractMaterializedViewRule
-
Rewriting logic is based on "Optimizing Queries Using Materialized Views: A Practical, Scalable Solution" by Goldstein and Larson.
- perform(CalciteServerStatement, Frameworks.PrepareAction<R>) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Executes a prepare action.
- performUnconditionalRewrites(SqlNode, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Performs expression rewrites which are always used unconditionally.
- period - Variable in class org.apache.calcite.adapter.druid.Granularities.PeriodGranularity
- PERIOD - Static variable in class org.apache.calcite.sql.type.OperandTypes
- PERIOD_EQUALS - org.apache.calcite.sql.SqlKind
-
The "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
- PeriodGranularity(Granularity.Type, String, String) - Constructor for class org.apache.calcite.adapter.druid.Granularities.PeriodGranularity
- PeriodOperandTypeChecker() - Constructor for class org.apache.calcite.sql.type.OperandTypes.PeriodOperandTypeChecker
- permAssert(boolean, String) - Static method in class org.apache.calcite.util.Util
-
Deprecated.Use
Preconditions.checkArgument(boolean)
- permutation - Variable in class org.apache.calcite.rex.RexPermutationShuttle
- 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.
- Permutation(int[], int[]) - Constructor for class org.apache.calcite.util.Permutation
-
Creates a permutation.
- permutationIgnoreCast(List<RexNode>, RelDataType) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Returns a permutation describing where output fields come from.
- permute(int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.Column
- 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 class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- permute(Object, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ByteStringDictionary
- permute(Object, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.Constant
- permute(Object, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectArray
- permute(Object, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectDictionary
- permute(Object, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveArray
- permute(Object, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveDictionary
- permute(Object, int[]) - Method in interface org.apache.calcite.adapter.clone.ArrayTable.Representation
-
Creates a data set that is the same as a given data set but re-ordered.
- permute(Object, int[]) - Method in class org.apache.calcite.adapter.clone.ArrayTable.StringDictionary
- permute(Object, int[]) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Permutes an array.
- permute(List<SqlNode>, List<Map.Entry<String, RelDataType>>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.Permute
-
Moves fields according to the permutation.
- 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(SqlNode, int) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.Permute
- 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.
- permutedOperands(SqlCall) - 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.
- permuteList(List<E>, int[]) - Static method in class org.apache.calcite.adapter.clone.ArrayTable
- PermutingMakeCall(SqlOperator, int[]) - Constructor for class org.apache.calcite.sql.SqlJdbcFunctionCall.PermutingMakeCall
-
Creates a MakeCall strategy object with reordering of operands.
- 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
- phase - Variable in class org.apache.calcite.plan.volcano.RuleQueue.PhaseMatchList
-
The VolcanoPlannerPhase that this PhaseMatchList is used in.
- phaseCompleted(VolcanoPlannerPhase) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Removes the
rule-match list
for the given planner phase. - PhaseMatchList(VolcanoPlannerPhase) - Constructor for class org.apache.calcite.plan.volcano.RuleQueue.PhaseMatchList
- phaseRuleMapping - Variable in class org.apache.calcite.plan.volcano.RuleQueue
-
Maps a
VolcanoPlannerPhase
to a set of rule names. - PHOENIX - 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 - org.apache.calcite.sql.SqlExplain.Depth
- 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
. - PhysTypeImpl(JavaTypeFactory, RelDataType, Type, JavaRowFormat) - Constructor for class org.apache.calcite.adapter.enumerable.PhysTypeImpl
-
Creates a PhysTypeImpl.
- PI - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- pickEmployee() - Method in class org.apache.calcite.benchmarks.StatementTest.HrConnection
- PigAggFunction - Enum in org.apache.calcite.adapter.pig
-
Supported Pig aggregate functions and their Calcite counterparts.
- PigAggFunction(SqlKind) - Constructor for enum org.apache.calcite.adapter.pig.PigAggFunction
- PigAggFunction(SqlKind, boolean) - Constructor for enum org.apache.calcite.adapter.pig.PigAggFunction
- 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
-
Creates a PigAggregate.
- PigAggregateFactory() - Constructor for class org.apache.calcite.adapter.pig.PigRelFactories.PigAggregateFactory
- PigAggregateRule() - Constructor for class org.apache.calcite.adapter.pig.PigRules.PigAggregateRule
- PigDataType - Enum in org.apache.calcite.adapter.pig
-
Supported Pig data types and their Calcite counterparts.
- PigDataType(byte, SqlTypeName) - Constructor for enum org.apache.calcite.adapter.pig.PigDataType
- 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
- PigFilterRule() - Constructor for class org.apache.calcite.adapter.pig.PigRules.PigFilterRule
- 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
- PigJoinRule() - Constructor for class org.apache.calcite.adapter.pig.PigRules.PigJoinRule
- 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.
- PigProjectRule() - Constructor for class org.apache.calcite.adapter.pig.PigRules.PigProjectRule
- 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.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.Partitioner - Interface in org.apache.calcite.tools
-
Partitioner for group and join
- PigRelFactories - Class in org.apache.calcite.adapter.pig
-
Implementations of factories in
RelFactories
for the Pig adapter. - PigRelFactories() - Constructor for class org.apache.calcite.adapter.pig.PigRelFactories
- 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
. - PigRules - Class in org.apache.calcite.adapter.pig
-
Various
RelOptRule
s using the Pig convention. - PigRules() - Constructor for class org.apache.calcite.adapter.pig.PigRules
- PigRules.PigAggregateRule - Class in org.apache.calcite.adapter.pig
-
Rule to convert a
LogicalAggregate
to aPigAggregate
. - PigRules.PigFilterRule - Class in org.apache.calcite.adapter.pig
-
Rule to convert a
LogicalFilter
to aPigFilter
. - PigRules.PigJoinRule - Class in org.apache.calcite.adapter.pig
-
Rule to convert a
LogicalJoin
to aPigJoin
. - PigRules.PigProjectRule - Class in org.apache.calcite.adapter.pig
-
Rule to convert a
LogicalProject
to aPigProject
. - PigRules.PigTableScanRule - Class in org.apache.calcite.adapter.pig
-
Rule to convert a
LogicalTableScan
to aPigTableScan
. - 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
. - PigSchemaFactory() - Constructor for class org.apache.calcite.adapter.pig.PigSchemaFactory
- PigTable - Class in org.apache.calcite.adapter.pig
-
Represents a Pig relation that is created by Pig Latin
LOAD
statement. - 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
- PigTableScanRule() - Constructor for class org.apache.calcite.adapter.pig.PigRules.PigTableScanRule
- 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
. - PigToEnumerableConverterRule() - Constructor for class org.apache.calcite.adapter.pig.PigToEnumerableConverterRule
- pigType - Variable in enum org.apache.calcite.adapter.pig.PigDataType
- planAsGroupBy(List<DimensionSpec>, DruidJsonFilter, List<VirtualColumn>, List<DruidQuery.JsonAggregation>, List<DruidQuery.JsonExpressionPostAgg>, DruidQuery.JsonLimit, DruidJsonFilter) - Method in class org.apache.calcite.adapter.druid.DruidQuery
- planAsTimeSeries(List<DimensionSpec>, DruidJsonFilter, List<VirtualColumn>, List<DruidQuery.JsonAggregation>, List<DruidQuery.JsonExpressionPostAgg>, DruidQuery.JsonLimit, DruidJsonFilter) - Method in class org.apache.calcite.adapter.druid.DruidQuery
- planAsTopN(List<DimensionSpec>, DruidJsonFilter, List<VirtualColumn>, List<DruidQuery.JsonAggregation>, List<DruidQuery.JsonExpressionPostAgg>, DruidQuery.JsonLimit, DruidJsonFilter) - Method in class org.apache.calcite.adapter.druid.DruidQuery
- planner - Variable in class org.apache.calcite.plan.RelOptCluster
- planner - Variable in class org.apache.calcite.plan.RelOptQuery
- planner - Variable in class org.apache.calcite.plan.RelOptRuleCall
- planner - Variable in class org.apache.calcite.plan.RelTraitPropagationVisitor
- planner - Variable in class org.apache.calcite.plan.volcano.RelSubset.CheapestPlanReplacer
- planner - Variable in class org.apache.calcite.plan.volcano.RuleQueue
- planner - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- planner - Variable in class org.apache.calcite.prepare.PlannerImpl
- planner - Variable in class org.apache.calcite.rel.metadata.CachingRelMetadataProvider
- 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 - 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.State - Enum in org.apache.calcite.prepare
-
Stage of a statement in the query-preparation lifecycle.
- PlannerImpl.ViewExpanderImpl - Class in org.apache.calcite.prepare
-
Deprecated.Now
PlannerImpl
implementsRelOptTable.ViewExpander
directly. - plus() - Method in class org.apache.calcite.jdbc.CalciteSchema
- 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(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(RelOptCost) - Method in class org.apache.calcite.plan.volcano.VolcanoCost
- 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(RexBuilder, RexNode, RexNode) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- 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(SqlParserPos, SqlNode, SqlNode) - Method in class org.apache.calcite.sql2rel.StandardConvertletTable
- PLUS - org.apache.calcite.piglet.Ast.Op
- PLUS - org.apache.calcite.sql.SqlKind
-
The 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 - org.apache.calcite.sql.SqlKind
-
The unary plus operator, as in "+1".
- plusAll(Collection<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.
- point(double, double) - Static method in class org.apache.calcite.runtime.GeoFunctions
- POINT - org.apache.calcite.runtime.GeoFunctions.Type
- policy - Variable in class org.apache.calcite.plan.RelOptRuleOperandChildren
- policy(SqlKind) - Static method in class org.apache.calcite.plan.Strong
-
Returns how to deduce whether a particular kind of expression is null, given whether its arguments are null.
- Policy() - Constructor for enum org.apache.calcite.plan.Strong.Policy
- POLYGON - org.apache.calcite.runtime.GeoFunctions.Type
- POLYHEDRALSURFACE - org.apache.calcite.runtime.GeoFunctions.Type
- pop(int) - Method in class org.apache.calcite.linq4j.tree.Evaluator
- 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
- popMatch(VolcanoPlannerPhase) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Removes the rule match with the highest importance, and returns it.
- popQuote(Character) - Method in class org.apache.calcite.util.StackWriter
- 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(List<RelNode>, List<int[][]>, RelNode) - Static method in class org.apache.calcite.materialize.Lattice
- populate(Map<V, int[]>, List<V>) - Method in class org.apache.calcite.util.graph.TopologicalOrderIterator
- populate(Prepare.Materialization) - Method in class org.apache.calcite.prepare.CalciteMaterializer
-
Populates a materialization record, converting a table path (essentially a list of strings, like ["hr", "sales"]) into a table object that can be used in the planning process.
- populate(SqlIdentifier, SqlNode, CalcitePrepare.Context) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Populates the table called
name
by executingquery
. - populateAliases(SqlNode, List<String>, String) - Static method in class org.apache.calcite.materialize.Lattice
- populateBounds() - Method in class org.apache.calcite.sql.SqlWindow
-
Fill in missing bounds.
- populateEquivalence(Map<Integer, BitSet>, int, int) - Static method in class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
- populateEquivalences(Map<Integer, BitSet>, RexNode) - Static method in class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
- populateLattice(JsonLattice, Lattice.Builder) - Method in class org.apache.calcite.model.ModelHandler
- populateMaterializations(CalcitePrepare.Context, RelOptPlanner, Prepare.Materialization) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- populateSchema(JsonSchema, SchemaPlus) - Method in class org.apache.calcite.model.ModelHandler
- POPULATION_SIZE - org.apache.calcite.util.BuiltInMethod
- populationSizeHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- port - Variable in class org.apache.calcite.adapter.spark.HttpServer
- pos - Variable in class org.apache.calcite.piglet.Ast.Node
- pos - Variable in class org.apache.calcite.sql.advise.SqlSimpleParser.Tokenizer
- pos - Variable in exception org.apache.calcite.sql.parser.SqlParseException
- pos - Variable in class org.apache.calcite.sql.parser.SqlParserUtil.StringAndPos
- pos - Variable in class org.apache.calcite.sql.parser.SqlParserUtil.ToTreeListItem
- 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 class org.apache.calcite.sql.parser.SqlParserUtil.OldTokenSequenceImpl
- pos(int) - Method in class org.apache.calcite.sql.parser.SqlParserUtil.TokenSequenceImpl
- pos(int) - Method in interface org.apache.calcite.sql.SqlSpecialOperator.TokenSequence
- pos(RexNode) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- pos(PrecedenceClimbingParser.Token) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil.TokenSequenceImpl
- POS - Static variable in class org.apache.calcite.rel.rel2sql.SqlImplementor
- posColumn - Variable in exception org.apache.calcite.runtime.CalciteContextException
- position - Variable in class org.apache.calcite.util.ImmutableIntList.AbstractIndexedListIterator
- 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(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 - 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.
- posLine - Variable in exception org.apache.calcite.runtime.CalciteContextException
- posList - Variable in class org.apache.calcite.sql.parser.Span
- possibleSemiJoins - Variable in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
-
Associates potential semijoins with each fact table factor.
- 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>) - Static method in class org.apache.calcite.runtime.HttpUtils
- post(String, CharSequence, Map<String, String>, int, int) - Static method in class org.apache.calcite.runtime.HttpUtils
- POST_AGGREGATION_PROJECT - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- postCheck(SqlNode) - Method in class org.apache.calcite.sql.SqlUtil.Genealogist
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A unary postfix decrement, such as (a--).
- postEquivalenceEvent(VolcanoPlanner, RelNode) - Method in class org.apache.calcite.plan.volcano.RelSet
- postfix - Variable in enum org.apache.calcite.linq4j.tree.ExpressionType
- postfix(Object, int) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- postfix(Object, int) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- postfix(RexCall) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor
- POSTFIX - org.apache.calcite.sql.SqlSyntax
-
Postfix unary operator syntax, as in "x ++".
- POSTFIX - org.apache.calcite.util.PrecedenceClimbingParser.Type
- POSTGRESQL - org.apache.calcite.sql.SqlDialect.DatabaseProduct
- POSTGRESQL_TYPE_SYSTEM - Static variable in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
-
PostgreSQL type system.
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A unary postfix increment, such as (a++).
- postJoinFilter - Variable in class org.apache.calcite.rel.rules.MultiJoin
- postPredicate - Variable in class org.apache.calcite.sql.SqlUtil.Genealogist
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A mathematical operation that raises a number to a power, such as (a ^ b) in Visual Basic.
- POWER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Uses SqlOperatorTable.useDouble for its return type since we don't know what the result type will be by just looking at the operand types.
- 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 - 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
- POWERS10 - Static variable in class org.apache.calcite.sql.SqlIntervalQualifier
- 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
- PRAGMATIC_2003 - 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 - 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)
- PRE_PROCESS - org.apache.calcite.plan.volcano.VolcanoPlannerPhase
- PRE_PROCESS_MDR - org.apache.calcite.plan.volcano.VolcanoPlannerPhase
- prec - Variable in class org.apache.calcite.piglet.Ast.NumericLiteral
- prec - Variable in class org.apache.calcite.sql.SqlNumericLiteral
- 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(List<PrecedenceClimbingParser.Token>) - Constructor for class org.apache.calcite.util.PrecedenceClimbingParser
- 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.TokenList - Class in org.apache.calcite.util
-
List view onto the tokens in a parser.
- PrecedenceClimbingParser.Type - Enum in org.apache.calcite.util
-
Token type.
- PRECEDES - org.apache.calcite.sql.SqlKind
-
The "PRECEDES" operator for periods.
- PRECEDES - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- PRECEDING - org.apache.calcite.sql.SqlKind
-
The "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.
- preCheck(SqlNode) - Method in class org.apache.calcite.sql.SqlUtil.Genealogist
- precision - Variable in class org.apache.calcite.sql.SqlAbstractDateTimeLiteral
- precision - Variable in class org.apache.calcite.sql.SqlDataTypeSpec
- precision - Variable in class org.apache.calcite.sql.type.BasicSqlType
- precision() - Method in class org.apache.calcite.util.TimestampString
- precision() - Method in class org.apache.calcite.util.TimeString
- PRECISION_NOT_SPECIFIED - Static variable in interface org.apache.calcite.rel.type.RelDataType
- PreconditionTest - Class in org.apache.calcite.benchmarks
-
Checks if silent precondition has noticeable overhead
- PreconditionTest() - Constructor for class org.apache.calcite.benchmarks.PreconditionTest
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A unary prefix decrement, such as (--a).
- predicate - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.SkipWhileEnumerator
- predicate - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileEnumerator
- predicate - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileLongEnumerator
- predicate - Variable in class org.apache.calcite.plan.RelOptRuleOperand
- predicate - Variable in class org.apache.calcite.profile.ProfilerImpl.Builder
- predicate - Variable in class org.apache.calcite.profile.ProfilerImpl
-
Whether a successor is considered interesting enough to analyze.
- predicate - Variable in class org.apache.calcite.rel.rules.FilterJoinRule
-
Predicate that returns whether a filter is valid in the ON clause of a join for this particular kind of join.
- predicate - Variable in class org.apache.calcite.sql.SqlUtil.Genealogist
- predicate - Variable in class org.apache.calcite.util.Util.FilteringIterator
- predicate(EnumerableRelImplementor, BlockBuilder, PhysType, PhysType, RexNode) - Method in class org.apache.calcite.adapter.enumerable.EnumerableThetaJoin
- PREDICATE - Static variable in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraFilterRule
- PREDICATE - Static variable in class org.apache.calcite.rel.rules.FilterTableScanRule
-
Deprecated.
- PREDICATE - Static variable in class org.apache.calcite.rel.rules.ProjectTableScanRule
-
Deprecated.
- 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. - PredicateAnalyzer - Class in org.apache.calcite.adapter.elasticsearch
-
Query predicate analyzer.
- PredicateAnalyzer() - Constructor for class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer
- PredicateAnalyzer.CastExpression - Class in org.apache.calcite.adapter.elasticsearch
-
SQL cast:
cast(col as INTEGER)
- PredicateAnalyzer.CompoundQueryExpression - Class in org.apache.calcite.adapter.elasticsearch
-
Builds conjunctions / disjunctions based on existing expressions
- PredicateAnalyzer.Expression - Interface in org.apache.calcite.adapter.elasticsearch
-
Empty interface; exists only to define type hierarchy
- PredicateAnalyzer.ExpressionNotAnalyzableException - Exception in org.apache.calcite.adapter.elasticsearch
-
Thrown when
RelNode
expression can't be processed (or converted into ES query) - PredicateAnalyzer.LiteralExpression - Class in org.apache.calcite.adapter.elasticsearch
-
Literal like
'foo' or 42 or true
etc. - PredicateAnalyzer.NamedFieldExpression - Class in org.apache.calcite.adapter.elasticsearch
-
Used for bind variables
- PredicateAnalyzer.NotLikeConverter - Class in org.apache.calcite.adapter.elasticsearch
-
Converts expressions of the form NOT(LIKE(...)) into NOT_LIKE(...)
- PredicateAnalyzer.PredicateAnalyzerException - Exception in org.apache.calcite.adapter.elasticsearch
-
Internal exception
- PredicateAnalyzer.QueryExpression - Class in org.apache.calcite.adapter.elasticsearch
-
Main expression operators (like
equals
,gt
,exists
etc.) - PredicateAnalyzer.SimpleQueryExpression - Class in org.apache.calcite.adapter.elasticsearch
-
Usually basic expression of type
a = 'val'
orb > 42
. - PredicateAnalyzer.TerminalExpression - Interface in org.apache.calcite.adapter.elasticsearch
-
Empty interface; exists only to define type hierarchy
- PredicateAnalyzer.Visitor - Class in org.apache.calcite.adapter.elasticsearch
-
Traverses
RexNode
tree and builds ES query. - PredicateAnalyzer.Visitor.SwapResult - Class in org.apache.calcite.adapter.elasticsearch
-
Holder class for a pair of expressions.
- PredicateAnalyzerException(String) - Constructor for exception org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.PredicateAnalyzerException
- PredicateAnalyzerException(Throwable) - Constructor for exception org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.PredicateAnalyzerException
- PredicateAnalyzerTranslator(ObjectMapper) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.PredicateAnalyzerTranslator
- 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.
- predicateElimination - Variable in class org.apache.calcite.rex.RexSimplify
- 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 - Variable in class org.apache.calcite.rex.RexSimplify
- PREDICATES - org.apache.calcite.util.BuiltInMethod
- predicatesHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- prefer - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- prefer(JavaRowFormat) - Method in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
- Prefer() - Constructor for 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 - Variable in enum org.apache.calcite.linq4j.tree.GotoExpressionKind
- prefix - Variable in class org.apache.calcite.rex.RexSlot.SelfPopulatingList
- 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(RexCall) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor
- PREFIX - org.apache.calcite.sql.SqlSyntax
-
Prefix unary operator syntax, as in "- x".
- PREFIX - org.apache.calcite.util.PrecedenceClimbingParser.Type
- PREFIX_PATTERN - Static variable in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A unary prefix increment, such as (++a).
- 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(RelNode) - Method in interface org.apache.calcite.tools.RelRunner
-
Runs a relational expression.
- 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_(Supplier<RelNode>, RelDataType) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- prepare_(CalcitePrepare.Context, CalcitePrepare.Query<T>, Type, long) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- 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.
- prepare2_(CalcitePrepare.Context, CalcitePrepare.Query<T>, Type, long, CalciteCatalogReader, RelOptPlanner) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- PrepareAction() - Constructor for class org.apache.calcite.tools.Frameworks.PrepareAction
- PrepareAction(FrameworkConfig) - Constructor for class org.apache.calcite.tools.Frameworks.PrepareAction
- 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
- prepareBindExecute(StatementTest.HrConnection) - Method in class org.apache.calcite.benchmarks.StatementTest
- PreparedExplain(RelDataType, RelDataType, RelRoot, SqlExplainFormat, SqlExplainLevel) - Constructor for class org.apache.calcite.prepare.Prepare.PreparedExplain
- PreparedResultImpl(RelDataType, RelDataType, List<List<String>>, List<RelCollation>, RelNode, TableModify.Operation, boolean) - Constructor for class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- preparedStatementEnricher - Variable in class org.apache.calcite.runtime.ResultSetEnumerable
- prepareFactory - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl
- 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(String, int, int, int) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- prepareStatement_(CalcitePrepare.Query<?>, int, int, int) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- preparingStmt - Variable in class org.apache.calcite.prepare.LixToRelTranslator
- preserve(RexNode) - Method in class org.apache.calcite.rel.rules.PushProjector.InputSpecialOpFinder
- PRESERVE - Static variable in class org.apache.calcite.rel.RelCollationImpl
-
Deprecated.
- PRESERVE - Static variable in class org.apache.calcite.rel.RelCollations
-
Deprecated.
- preserveExprCondition - Variable in class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule
-
preserveExprCondition to define the condition for a expression not to be pushed
- preserveExprCondition - Variable in class org.apache.calcite.rel.rules.ProjectFilterTransposeRule
-
Expressions that should be preserved in the projection
- preserveExprCondition - Variable in class org.apache.calcite.rel.rules.ProjectJoinTransposeRule
-
Condition for expressions that should be preserved in the projection.
- preserveExprCondition - Variable in class org.apache.calcite.rel.rules.ProjectSetOpTransposeRule
-
Expressions that should be preserved in the projection
- preserveExprCondition - Variable in class org.apache.calcite.rel.rules.PushProjector.InputSpecialOpFinder
- preserveExprCondition - Variable in class org.apache.calcite.rel.rules.PushProjector
- preserveLeft - Variable in class org.apache.calcite.rel.rules.PushProjector.InputSpecialOpFinder
- preserveLeft - Variable in class org.apache.calcite.rel.rules.PushProjector.RefAndExprConverter
- preserveRight - Variable in class org.apache.calcite.rel.rules.PushProjector.InputSpecialOpFinder
- preserveRight - Variable in class org.apache.calcite.rel.rules.PushProjector.RefAndExprConverter
- prev(Object[]) - Static method in class org.apache.calcite.util.ChunkList
- PREV - org.apache.calcite.sql.SqlKind
- 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.
- previous - Variable in class org.apache.calcite.util.Pair.AdjacentIterator
- previous - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Token
- previous() - Method in class org.apache.calcite.util.ChunkList.ChunkListIterator
- previous() - Method in class org.apache.calcite.util.ImmutableIntList.AbstractIndexedListIterator
- 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.
- previousId - Variable in class org.apache.calcite.rel.externalize.RelJsonWriter
- previousIndex() - Method in class org.apache.calcite.util.ChunkList.ChunkListIterator
- previousIndex() - Method in class org.apache.calcite.util.ImmutableIntList.AbstractIndexedListIterator
- 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(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(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
- prevNextCount - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternValidator
- prevPreferredCasing - Variable in class org.apache.calcite.sql.advise.SqlAdvisor
- prevRight(PrecedenceClimbingParser.Token) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
-
Returns the right precedence of the preceding operator token.
- prevWord - Variable in class org.apache.calcite.sql.advise.SqlAdvisor
- 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 - org.apache.calcite.sql.SqlKind
-
PRIMARY KEY
constraint. - primitive - Variable in class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- primitive - Variable in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveArray
- primitive - Variable in enum org.apache.calcite.adapter.file.FileFieldType
- primitive - Variable in class org.apache.calcite.linq4j.tree.BinaryExpression
- Primitive - Enum in org.apache.calcite.linq4j.tree
-
Enumeration of Java's primitive types.
- Primitive(Class, Class, int, Object, Object, Object, Object, Object, int) - Constructor for enum org.apache.calcite.linq4j.tree.Primitive
- PRIMITIVE - org.apache.calcite.linq4j.tree.Primitive.Flavor
-
A primitive type, e.g.
- PRIMITIVE_ARRAY - org.apache.calcite.adapter.clone.ArrayTable.RepresentationType
-
Array of primitives.
- PRIMITIVE_DICTIONARY - org.apache.calcite.adapter.clone.ArrayTable.RepresentationType
-
Dictionary of primitives.
- PRIMITIVE_MAP - Static variable in enum org.apache.calcite.linq4j.tree.Primitive
- Primitive.Flavor - Enum in org.apache.calcite.linq4j.tree
-
What kind of type?
- 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.
- PrimitiveArray(int, Primitive, Primitive) - Constructor for class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveArray
- primitiveClass - Variable in enum org.apache.calcite.linq4j.tree.Primitive
- PrimitiveDictionary() - Constructor for class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveDictionary
- primitiveName - Variable in enum org.apache.calcite.linq4j.tree.Primitive
- primitiveRowBuilderFactory(Primitive[]) - Static method in class org.apache.calcite.runtime.ResultSetEnumerable
- primitiveToBoxingMap - Static variable in class org.apache.calcite.util.ReflectUtil
- primitiveToByteBufferReadMethod - Static variable in class org.apache.calcite.util.ReflectUtil
- primitiveToByteBufferWriteMethod - Static variable in class org.apache.calcite.util.ReflectUtil
- print - Variable in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.CountingSearchResultListener
- 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, boolean) - Method in class org.apache.calcite.example.maze.Maze
-
Prints the maze.
- print(PrintWriter, Object) - Static method in class org.apache.calcite.util.Util
-
Prints an object using reflection.
- print(PrintWriter, Object, int) - Static method in class org.apache.calcite.util.Util
- 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.
- printAsJava(Comparable, PrintWriter, SqlTypeName, boolean) - Static method in class org.apache.calcite.rex.RexLiteral
-
Prints a value as a Java string.
- printAtt(PrintWriter, String, String) - Static method in class org.apache.calcite.util.XmlOutput
-
Print an XML attribute name and value for string val
- printDuration(String, long) - Static method in class org.apache.calcite.util.Benchmark
- printDurations() - Method in class org.apache.calcite.util.Benchmark.Statistician
- printJavaString(PrintWriter, String, boolean) - Static method in class org.apache.calcite.util.Util
-
Prints a string, enclosing in double quotes (") and escaping if necessary.
- println(PrintWriter, Object) - Static method in class org.apache.calcite.util.Util
- printOp(StringBuilder, boolean, boolean) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Call
- 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.
- 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. - priorityQueue - Variable in class org.apache.calcite.profile.ProfilerImpl.SurpriseQueue
- PROCEDURE_CALL - org.apache.calcite.sql.SqlKind
-
ProcedureCall
- 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.
- ProcedureNamespace(SqlValidatorImpl, SqlValidatorScope, SqlCall, SqlNode) - Constructor for class org.apache.calcite.sql.validate.ProcedureNamespace
- process(String, List<String>) - Static method in class org.apache.calcite.util.Template
-
Parses the pattern, populates the parameter names, and returns the pattern with parameter names converted to parameter ordinals.
- Processes - Class in org.apache.calcite.adapter.os
-
Utilities regarding operating system processes.
- Processes() - Constructor for class org.apache.calcite.adapter.os.Processes
- Processes.ProcessFactory - Class in org.apache.calcite.adapter.os
-
Creates processes.
- Processes.ProcessLinesEnumerator - Class in org.apache.calcite.adapter.os
-
Enumerator that executes a process and returns each line as an element.
- Processes.SeparatedLinesEnumerable - Class in org.apache.calcite.adapter.os
-
Enumerator that executes a process and returns each line as an element.
- ProcessFactory(String...) - Constructor for class org.apache.calcite.adapter.os.Processes.ProcessFactory
- processLines(char, String...) - Static method in class org.apache.calcite.adapter.os.Processes
-
Executes a command and returns its result as an enumerable of lines.
- processLines(char, Supplier<Process>) - Static method in class org.apache.calcite.adapter.os.Processes
-
Executes a command and returns its result as an enumerable of lines.
- processLines(String...) - Static method in class org.apache.calcite.adapter.os.Processes
-
Executes a command and returns its result as an enumerable of lines.
- ProcessLinesEnumerator(Supplier<Process>) - Constructor for class org.apache.calcite.adapter.os.Processes.ProcessLinesEnumerator
- processRange(RexBuilder, List<RexNode>, Map<RexNode, Pair<Range<C>, List<RexNode>>>, RexNode, RexNode, C, SqlKind) - Static method in class org.apache.calcite.rex.RexSimplify
- 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
- processSupplier - Variable in class org.apache.calcite.adapter.os.Processes.ProcessLinesEnumerator
- processSupplier - Variable in class org.apache.calcite.adapter.os.Processes.SeparatedLinesEnumerable
- processSupplier(String...) - Static method in class org.apache.calcite.adapter.os.Processes
- 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_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
. - ProductComparableListEnumerator(List<Enumerator<List<E>>>, int, boolean) - Constructor for class org.apache.calcite.runtime.SqlFunctions.ProductComparableListEnumerator
- profile - Variable in class org.apache.calcite.materialize.ProfilerLatticeStatisticProvider
- profile(Iterable<List<Comparable>>) - Method in class org.apache.calcite.profile.ProfilerImpl.Run
- profile(Iterable<List<Comparable>>) - Method in class org.apache.calcite.profile.SimpleProfiler.Run
- 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
- Profile(List<Profiler.Column>, Profiler.RowCount, Iterable<Profiler.FunctionalDependency>, Iterable<Profiler.Distribution>, Iterable<Profiler.Unique>) - Constructor for class org.apache.calcite.profile.Profiler.Profile
- 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(int, int, Predicate<Pair<ProfilerImpl.Space, Profiler.Column>>) - Constructor for class org.apache.calcite.profile.ProfilerImpl
-
Creates a
ProfilerImpl
. - ProfilerImpl.Builder - Class in org.apache.calcite.profile
-
Builds a
ProfilerImpl
. - ProfilerImpl.Collector - Class in org.apache.calcite.profile
-
Collects values of a column or columns.
- ProfilerImpl.CompositeCollector - Class in org.apache.calcite.profile
-
Collector that collects two or more column values in a tree set.
- ProfilerImpl.HllCollector - Class in org.apache.calcite.profile
-
Collector that collects two or more column values into a HyperLogLog sketch.
- ProfilerImpl.HllCompositeCollector - Class in org.apache.calcite.profile
-
Collector that collects two or more column values into a HyperLogLog sketch.
- ProfilerImpl.HllSingletonCollector - Class in org.apache.calcite.profile
-
Collector that collects one column value into a HyperLogLog sketch.
- ProfilerImpl.Run - Class in org.apache.calcite.profile
-
A run of the profiler.
- ProfilerImpl.SingletonCollector - Class in org.apache.calcite.profile
-
Collector that collects values of a single column.
- ProfilerImpl.Space - Class in org.apache.calcite.profile
-
Work space for a particular combination of columns.
- ProfilerImpl.SurpriseQueue - Class in org.apache.calcite.profile
-
A priority queue of the last N surprise values.
- ProfilerLatticeStatisticProvider - Class in org.apache.calcite.materialize
-
Implementation of
LatticeStatisticProvider
that uses aProfiler
. - ProfilerLatticeStatisticProvider(Lattice) - Constructor for class org.apache.calcite.materialize.ProfilerLatticeStatisticProvider
-
Creates a ProfilerLatticeStatisticProvider.
- program - Variable in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- program - Variable in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcCalc
- program - Variable in class org.apache.calcite.adapter.spark.SparkRules.SparkCalc
- 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 - Variable in class org.apache.calcite.rel.rules.MaterializedViewFilterScanRule
- 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 - org.apache.calcite.piglet.Ast.Op
- PROGRAM - org.apache.calcite.runtime.Hook
-
Called to create a Program to optimize the statement.
- PROGRAM - Static variable in class org.apache.calcite.materialize.LatticeSuggester
- programs - Variable in class org.apache.calcite.prepare.PlannerImpl
- programs - Variable in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- programs - Variable in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- programs - Variable in class org.apache.calcite.tools.Programs.SequenceProgram
- 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. - Programs() - Constructor for class org.apache.calcite.tools.Programs
- Programs.DecorrelateProgram - Class in org.apache.calcite.tools
-
Program that de-correlates a query.
- Programs.RuleSetProgram - Class in org.apache.calcite.tools
-
Program backed by a
RuleSet
. - Programs.SequenceProgram - Class in org.apache.calcite.tools
-
Program that runs sub-programs, sending the output of the previous as input to the next.
- Programs.TrimFieldsProgram - Class in org.apache.calcite.tools
-
Program that trims fields.
- 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(int[]) - Method in class org.apache.calcite.adapter.file.FileTable
-
Returns an enumerable over a given projection of the fields.
- 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<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<String>, boolean) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Project
of the given list of expressions, using the given names. - 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(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 collation. - 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, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.rel.core.Project
-
Creates a Project.
- 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 - org.apache.calcite.rel.mutable.MutableRelType
- PROJECT - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- PROJECT - Static variable in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- PROJECT - Static variable in class org.apache.calcite.rel.rules.ProjectToWindowRule
- PROJECT - Static variable in class org.apache.calcite.rel.rules.SemiJoinRule
- PROJECT - Static variable in class org.apache.calcite.rel.rules.SubQueryRemoveRule
- PROJECT_EXTRACT_RULE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- PROJECT_FACTORY - Static variable in interface org.apache.calcite.adapter.enumerable.EnumerableRel
- PROJECT_FILTER_INSTANCE - Static variable in class org.apache.calcite.rel.rules.ValuesReduceRule
-
Singleton instance of this rule that applies to the pattern Project(Filter(Values)).
- PROJECT_FILTER_TRANSPOSE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- PROJECT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts a
LogicalProject
to empty if its child is empty. - PROJECT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Singleton rule that reduces constants inside a
LogicalProject
. - PROJECT_INSTANCE - Static variable in class org.apache.calcite.rel.rules.ValuesReduceRule
-
Instance of this rule that applies to the pattern Project(Values).
- PROJECT_ON_FILTER - Static variable in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- 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_SORT_TRANSPOSE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- 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.
- ProjectCalcMergeRule - Class in org.apache.calcite.rel.rules
-
Planner rule which merges a
LogicalProject
and aLogicalCalc
. - ProjectCalcMergeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectCalcMergeRule
-
Creates a ProjectCalcMergeRule.
- ProjectCorrelateTransposeRule - Class in org.apache.calcite.rel.rules
-
Push Project under Correlate to apply on Correlate's left and right child
- ProjectCorrelateTransposeRule(PushProjector.ExprCondition, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule
- 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. - projectCount - Variable in class org.apache.calcite.interpreter.ProjectNode
- projectedLiteral(RelNode, int) - Static method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Returns a literal output field, or null if it is not literal.
- projectFactory - Variable in class org.apache.calcite.tools.RelBuilder
- ProjectFactoryImpl() - Constructor for class org.apache.calcite.rel.core.RelFactories.ProjectFactoryImpl
- ProjectFilterTable(RexNode, Mappings.TargetMapping, TableScan) - Constructor for class org.apache.calcite.plan.RelOptMaterialization.ProjectFilterTable
- 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
-
Creates a ProjectFilterTransposeRule.
- ProjectFilterTransposeRule(RelOptRuleOperand, PushProjector.ExprCondition, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectFilterTransposeRule
- projectJoinInputs(RelNode[], List<RexNode>, List<RexNode>, int, List<Integer>, List<Integer>, List<Integer>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- projectJoinOutputWithNullability(LogicalJoin, LogicalProject, int) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Pulls project above the join from its RHS input.
- ProjectJoinTransposeRule - Class in org.apache.calcite.rel.rules
- ProjectJoinTransposeRule(PushProjector.ExprCondition, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectJoinTransposeRule
-
Creates a ProjectJoinTransposeRule with an explicit condition.
- projectMap - Variable in class org.apache.calcite.schema.impl.ModifiableViewTable.ModifiableViewTableInitializerExpressionFactory
- projectMapping(RelNode, Mapping, List<String>, RelFactories.ProjectFactory) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- projectMergeRule - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewAggregateRule
-
Instance of rule to merge project operators.
- ProjectMergeRule - Class in org.apache.calcite.rel.rules
- 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
-
Creates a ProjectMergeRule, specifying whether to always merge projects.
- projectMultiJoin(MultiJoin, LogicalProject) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Creates a new
MultiJoin
to reflect projection references from aLogicalProject
that is on top of theMultiJoin
. - ProjectMultiJoinMergeRule - Class in org.apache.calcite.rel.rules
- ProjectMultiJoinMergeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectMultiJoinMergeRule
-
Creates a ProjectMultiJoinMergeRule.
- projectNamed(Iterable<? extends RexNode>, Iterable<String>, boolean) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Project
of the given expressions and field names, and optionally optimizing. - projectNameList - Variable in class org.apache.calcite.rex.RexProgramBuilder
- ProjectNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
Project
. - ProjectNode(Compiler, Project) - Constructor for class org.apache.calcite.interpreter.ProjectNode
- projectPlus(Iterable<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. - projectPredicate(RexBuilder, RelNode, RexNode, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates
-
Converts a predicate on a particular set of columns into a predicate on a subset of those columns, weakening if necessary.
- projectPulledAboveLeftCorrelator - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationRexShuttle
- ProjectReduceExpressionsRule(Class<? extends Project>, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.ProjectReduceExpressionsRule
- ProjectReduceExpressionsRule(Class<? extends Project>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.ProjectReduceExpressionsRule
-
Deprecated.
- projectRefList - Variable in class org.apache.calcite.rex.RexProgramBuilder
- 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(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectRemoveRule
-
Creates a ProjectRemoveRule.
- projectRowType - Variable in class org.apache.calcite.adapter.cassandra.CassandraTableScan
- projectRowType - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTableScan
- projectRowType - Variable in class org.apache.calcite.adapter.geode.rel.GeodeTableScan
- projectRowType - Variable in class org.apache.calcite.adapter.mongodb.MongoTableScan
- projects - Variable in class org.apache.calcite.interpreter.Bindables.BindableTableScan
- projects - Variable in class org.apache.calcite.rel.mutable.MutableProject
- projects - Variable in class org.apache.calcite.rex.RexProgram
-
With
RexProgram.condition
, the second stage of expression evaluation. - ProjectSetOpTransposeRule - Class in org.apache.calcite.rel.rules
-
Planner rule that pushes a
LogicalProject
past aSetOp
. - ProjectSetOpTransposeRule(PushProjector.ExprCondition, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectSetOpTransposeRule
-
Creates a ProjectSetOpTransposeRule with an explicit condition whether to preserve expressions.
- 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.
- ProjectSortTransposeRule - Class in org.apache.calcite.rel.rules
- ProjectSortTransposeRule(Class<Project>, Class<Sort>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectSortTransposeRule
-
Creates a ProjectSortTransposeRule.
- ProjectSortTransposeRule(RelOptRuleOperand) - Constructor for class org.apache.calcite.rel.rules.ProjectSortTransposeRule
-
Deprecated.
- ProjectSortTransposeRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.ProjectSortTransposeRule
-
Creates a ProjectSortTransposeRule with an operand.
- 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
-
Creates a ProjectTableScanRule.
- ProjectToCalcRule - Class in org.apache.calcite.rel.rules
-
Rule to convert a
LogicalProject
to aLogicalCalc
- ProjectToCalcRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectToCalcRule
-
Creates a ProjectToCalcRule.
- ProjectToFilterUnifyRule() - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.ProjectToFilterUnifyRule
- ProjectToLogicalProjectAndWindowRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectToWindowRule.ProjectToLogicalProjectAndWindowRule
-
Creates a ProjectToWindowRule.
- ProjectToProjectUnifyRule() - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.ProjectToProjectUnifyRule
- ProjectToProjectUnifyRule1() - Constructor for class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor.ProjectToProjectUnifyRule1
- ProjectToSemiJoinRule(Class<Project>, Class<Join>, Class<Aggregate>, RelBuilderFactory, String) - 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(RelOptRuleOperand, RelBuilderFactory, String) - 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.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.WindowedAggRelSplitter - Class in org.apache.calcite.rel.rules
-
Splitter that distinguishes between windowed aggregation expressions (calls to
RexOver
) and ordinary expressions. - 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(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ProjectWindowTransposeRule
-
Creates ProjectWindowTransposeRule.
- projFields - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Bitmap corresponding to the fields projected from each join factor, after row scan processing has completed.
- projFields - Variable in class org.apache.calcite.rel.rules.MultiJoin
- projRefs - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Bitmap containing the references in the original projection
- 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).
- Prop(Resources.PropertyAccessor, Method) - Constructor for class org.apache.calcite.runtime.Resources.Prop
- propagateBoostRemoval(VolcanoPlanner) - Method in class org.apache.calcite.plan.volcano.RelSubset
- propagateCostImprovements(VolcanoPlanner, RelMetadataQuery, RelNode, Set<RelSubset>) - Method in class org.apache.calcite.plan.volcano.RelSubset
-
Checks whether a relexp has made its subset cheaper, and if it so, recursively checks whether that subset's parents have gotten cheaper.
- propagateCostImprovements0(VolcanoPlanner, RelMetadataQuery, RelNode, Set<RelSubset>) - Method in class org.apache.calcite.plan.volcano.RelSubset
- properties - Variable in class org.apache.calcite.runtime.Resources.PropertiesAccessor
- properties - Variable in enum org.apache.calcite.sql.SqlFunctionCategory
- PropertiesAccessor(Properties) - Constructor for class org.apache.calcite.runtime.Resources.PropertiesAccessor
- 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)
. - Property() - Constructor for enum org.apache.calcite.sql.SqlFunctionCategory.Property
- 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
- protocol() - Method in class org.apache.calcite.util.Sources.FileSource
- protoDataType - Variable in class org.apache.calcite.jdbc.CalciteSchema.TypeEntryImpl
- protoRowType - Variable in class org.apache.calcite.adapter.cassandra.CassandraTable
- protoRowType - Variable in class org.apache.calcite.adapter.clone.ArrayTable
- protoRowType - Variable in class org.apache.calcite.adapter.clone.ListTable
- protoRowType - Variable in class org.apache.calcite.adapter.csv.CsvTable
- protoRowType - Variable in class org.apache.calcite.adapter.druid.DruidTable
- protoRowType - Variable in class org.apache.calcite.adapter.file.FileTable
- protoRowType - Variable in class org.apache.calcite.adapter.jdbc.JdbcTable
- protoRowType - Variable in class org.apache.calcite.schema.impl.ViewTable
- protoRowType - Variable in class org.apache.calcite.sql.ddl.SqlCreateTable.MutableArrayTable
- protoStoredRowType - Variable in class org.apache.calcite.sql.ddl.SqlCreateTable.MutableArrayTable
- 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.
- provenance(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Returns a multi-line string describing the provenance of a tree of relational expressions.
- Provenance() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlanner.Provenance
- provenanceMap - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
- provenanceRecurse(PrintWriter, RelNode, int, Set<RelNode>) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- 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.linq4j.EnumerableQueryable
- provider - Variable in class org.apache.calcite.materialize.DelegatingLatticeStatisticProvider
- provider - Variable in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider.Key
- provider - Variable in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- providerMap - Variable in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider.Space
- providers - Variable in class org.apache.calcite.rel.metadata.ChainedRelMetadataProvider
- provideSchema() - Method in class org.apache.calcite.chinook.CalciteConnectionProvider
- PROXY_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Provide a surrogate or placeholder for another object to control access to it.
- 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.RemoveEmptySingleRule - Class in org.apache.calcite.rel.rules
-
Planner rule that converts a single-rel (e.g.
- ps - Variable in class org.apache.calcite.benchmarks.StatementTest.HrPreparedStatement
- PseudoField - Interface in org.apache.calcite.linq4j.tree
-
Contains the parts of the
Field
class needed for code generation, but might be implemented differently. - PsTableFunction - Class in org.apache.calcite.adapter.os
-
Table function that executes the OS "ps" command to list processes.
- PsTableFunction() - Constructor for class org.apache.calcite.adapter.os.PsTableFunction
- pull(RexNode) - Method in class org.apache.calcite.rex.RexUtil.CnfHelper
- 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.
- pullList(List<RexNode>) - Method in class org.apache.calcite.rex.RexUtil.CnfHelper
- purgeFromExcept(String) - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Query
- purgeGroupByHaving() - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Query
- purgeOrderBy() - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Query
- purgeSelect() - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Query
- purgeSelectExprsKeepAliases() - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Query
- purgeSelectListExcept(String) - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Query
- purgeWhere() - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Query
- 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(ParameterExpression, Object) - Method in class org.apache.calcite.linq4j.tree.Evaluator
- 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.
- pushDownEqualJoinConditions(RexNode, int, int, List<RexNode>, List<RexNode>) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Pushes down parts of a join condition.
- pushDownFactor(RelMetadataQuery, RelBuilder, LoptMultiJoin, LoptSemiJoinOptimizer, LoptJoinTree, int, BitSet, List<RexNode>, boolean) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Creates a join tree where the new factor is pushed down one of the operands of the current join tree
- 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.
- pushDownJoinConditions(Join, RelBuilderFactory) - Static method in class org.apache.calcite.plan.RelOptUtil
- pushDownNotForIn(SqlValidatorScope, SqlNode) - Static method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Push down all the NOT logical operators into any IN/NOT IN operators.
- 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.AbstractMaterializedViewRule.MaterializedViewAggregateRule
- pushFilterToOriginalViewPlan(RelBuilder, RelNode, RelNode, RexNode) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewJoinRule
- pushFilterToOriginalViewPlan(RelBuilder, RelNode, RelNode, RexNode) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
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
- 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. - 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.
- PushProjector.InputSpecialOpFinder - Class in org.apache.calcite.rel.rules
-
Visitor which builds a bitmap of the inputs used by an expressions, as well as locating expressions corresponding to special operators.
- PushProjector.OperatorExprCondition - Class in org.apache.calcite.rel.rules
-
An expression condition that evaluates to true if the expression is a call to one of a set of operators.
- PushProjector.RefAndExprConverter - Class in org.apache.calcite.rel.rules
-
Walks an expression tree, replacing input refs with new values to reflect projection and converting special expressions to field references.
- pushQuote(Character) - Method in class org.apache.calcite.util.StackWriter
- pushShuttle(Project) - Static method in class org.apache.calcite.plan.RelOptUtil
- pushVariable() - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- 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.rel.externalize.RelJsonWriter
- 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, Enumerable<V>) - Method in class org.apache.calcite.linq4j.LookupImpl
- put(K, V) - Method in class org.apache.calcite.linq4j.EnumerableDefaults.WrapMap
- put(K, V) - Method in class org.apache.calcite.util.CompositeMap
- putAll(Map<? extends K, ? extends Enumerable<V>>) - Method in class org.apache.calcite.linq4j.LookupImpl
- 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.plan.RelOptUtil.TypeDumper
- pw - Variable in class org.apache.calcite.rel.externalize.RelWriterImpl
- pw - Variable in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule
- pw - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
Q
- qualified - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.AliasContext
- 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
- QUARTER - org.apache.calcite.adapter.druid.Granularity.Type
- QUARTER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
QUARTER
operator. - query - Variable in class org.apache.calcite.adapter.druid.DruidQuery.DruidQueryNode
- query - Variable in class org.apache.calcite.plan.SubstitutionVisitor
- 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.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(Session) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable
- query(Session, 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(ObjectNode) - Method in class org.apache.calcite.adapter.elasticsearch.Scrolling
- 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(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
- 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(String, Queryable<T>, RelNode) - Constructor for class org.apache.calcite.jdbc.CalcitePrepare.Query
- Query(List<SqlSimpleParser.Token>) - Constructor for class org.apache.calcite.sql.advise.SqlSimpleParser.Query
- Query(LatticeSpace) - Constructor for class org.apache.calcite.materialize.LatticeSuggester.Query
- QUERY - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
-
A token created by reducing an entire sub-query.
- QUERY - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category consisting of query node types.
- QUERY_PARTIAL - org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MatchModality
- QUERY_PLAN - 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() - Method in class org.apache.calcite.linq4j.EnumerableQueryable
-
Returns the target queryable.
- 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 - org.apache.calcite.util.BuiltInMethod
- QUERYABLE_SELECT - org.apache.calcite.util.BuiltInMethod
- QUERYABLE_TABLE_AS_QUERYABLE - 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
- QueryableRelBuilder<T> - Class in org.apache.calcite.prepare
-
Implementation of
QueryableFactory
that builds a tree ofRelNode
planner nodes. - QueryableRelBuilder(LixToRelTranslator) - Constructor for class org.apache.calcite.prepare.QueryableRelBuilder
- QueryableTable - Interface in org.apache.calcite.schema
- QueryBuilder() - Constructor for class org.apache.calcite.adapter.elasticsearch.QueryBuilders.QueryBuilder
- QueryBuilders - Class in org.apache.calcite.adapter.elasticsearch
-
Utility class to generate elastic search queries.
- QueryBuilders() - Constructor for class org.apache.calcite.adapter.elasticsearch.QueryBuilders
- QueryBuilders.BoolQueryBuilder - Class in org.apache.calcite.adapter.elasticsearch
-
Query for boolean logic
- QueryBuilders.ConstantScoreQueryBuilder - Class in org.apache.calcite.adapter.elasticsearch
-
A query that wraps a filter and simply returns a constant score equal to the query boost for every document in the filter.
- QueryBuilders.ExistsQueryBuilder - Class in org.apache.calcite.adapter.elasticsearch
-
Constructs a query that only match on documents that the field has a value in them.
- QueryBuilders.MatchAllQueryBuilder - Class in org.apache.calcite.adapter.elasticsearch
-
A query that matches on all documents.
- QueryBuilders.QueryBuilder - Class in org.apache.calcite.adapter.elasticsearch
-
Base class to build ES queries
- QueryBuilders.RangeQueryBuilder - Class in org.apache.calcite.adapter.elasticsearch
-
A Query that matches documents within an range of terms.
- QueryBuilders.RegexpQueryBuilder - Class in org.apache.calcite.adapter.elasticsearch
-
A Query that does fuzzy matching for a specific value.
- QueryBuilders.TermQueryBuilder - Class in org.apache.calcite.adapter.elasticsearch
-
A Query that matches documents containing a term.
- QueryBuilders.TermsQueryBuilder - Class in org.apache.calcite.adapter.elasticsearch
-
A filter for a field based on several terms matching on any of them.
- queryCount - Variable in class org.apache.calcite.plan.SubstitutionVisitor.SlotCounter
- QueryExpression() - Constructor for class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- QueryKey(String, CalciteSchema, List<String>) - Constructor for class org.apache.calcite.materialize.MaterializationActor.QueryKey
- queryLeaves - Variable in class org.apache.calcite.plan.SubstitutionVisitor
-
Nodes in
SubstitutionVisitor.query
that have no children. - queryName - Variable in enum org.apache.calcite.adapter.druid.QueryType
- queryOperand - Variable in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRule
- QueryOperand(int) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.QueryOperand
- queryProvider - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl.DataContextImpl
- 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
- queryRel - Variable in class org.apache.calcite.prepare.Prepare.Materialization
-
Relational expression for the query to populate the table.
- querySpec - Variable in class org.apache.calcite.adapter.druid.DruidQuery.DruidQueryNode
- querySpec - Variable in class org.apache.calcite.adapter.druid.DruidQuery
- QuerySpec(QueryType, String, List<String>) - Constructor for class org.apache.calcite.adapter.druid.DruidQuery.QuerySpec
- queryString - Variable in class org.apache.calcite.adapter.druid.DruidQuery.QuerySpec
- queryString(String) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CompoundQueryExpression
- queryString(String) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.QueryExpression
- queryString(String) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- queryType - Variable in class org.apache.calcite.adapter.druid.DruidQuery.QuerySpec
- QueryType - Enum in org.apache.calcite.adapter.druid
-
Type of Druid query.
- QueryType(String) - Constructor for enum org.apache.calcite.adapter.druid.QueryType
- queue - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.BlockingQueueEnumerator
- queues - Variable in class org.apache.calcite.interpreter.Interpreter.DuplicatingSink
- quote(String) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules
- quote(String) - Static method in class org.apache.calcite.adapter.mongodb.MongoRules
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
An expression that has a constant value of type Expression.
- quoteAllIdentifiers - Variable in class org.apache.calcite.sql.pretty.SqlFormatOptions
- quoteAllIdentifiers - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- quoteCharLiteral(RexLiteral) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
- QUOTED_CASING - org.apache.calcite.config.CalciteConnectionProperty
-
How identifiers are stored if they are quoted.
- quotedCasing - Variable in enum org.apache.calcite.config.Lex
- quotedCasing - Variable in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- quotedCasing - Variable in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- quotedCasing() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- quotedCasing() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- quotedCasing() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- quotedCasing() - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- quoteEnd() - Method in class org.apache.calcite.sql.advise.SqlAdvisor
- 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.
- quoteStack - Variable in class org.apache.calcite.util.StackWriter
- quoteStart() - Method in class org.apache.calcite.sql.advise.SqlAdvisor
- quoteStringLiteral(String) - Method in class org.apache.calcite.sql.SqlDialect
-
Converts a string into a string literal.
- 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_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
These rules are used for division. - quotientForPercentage(Double, Double) - Static method in class org.apache.calcite.rel.metadata.RelMdPercentageOriginalRows
- 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 - Variable in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- quoting - Variable in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- quoting() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- quoting() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- quoting() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- quoting() - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- QUOTING - org.apache.calcite.config.CalciteConnectionProperty
-
How identifiers are quoted.
R
- r - Variable in class org.apache.calcite.plan.RelOptUtil.Exists
- r - Variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverter.Frame
- r - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.Frame
- r - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.CorrelationUse
-
The relational expression that uses the variable.
- 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 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- rand() - Method in class org.apache.calcite.runtime.RandomFunction
-
Implements the
RAND()
SQL function. - RAND - 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 - 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 - org.apache.calcite.util.BuiltInMethod
- RAND_SEED - 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 - Variable in class org.apache.calcite.runtime.RandomFunction
- RANDOM_DISTRIBUTED - 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.
- RandomAccessTransformingList(List<F>, Function<F, T>) - Constructor for class org.apache.calcite.util.Util.RandomAccessTransformingList
- 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 - Variable in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- range - Variable in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- 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(int, int, boolean) - Method in interface org.apache.calcite.util.IntegerIntervalSet.Handler
- 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(SqlKind, C) - Static method in class org.apache.calcite.rex.RexSimplify
- RANGE_DISTRIBUTED - 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.
- RangeImpl(int, int) - Constructor for class org.apache.calcite.sql.type.SqlOperandCountRanges.RangeImpl
- rangeQuery(String) - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A Query that matches documents within an range of terms.
- RangeQueryBuilder(String) - Constructor for class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- RANK - 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. - RankImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.RankImplementor
- rankWithFrame() - Method in interface org.apache.calcite.runtime.CalciteResource
- raw() - Method in class org.apache.calcite.runtime.Resources.Inst
- RAW - 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.
- rawHttp() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- rawHttp(Class<T>) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- RawQueryable<T> - Interface in org.apache.calcite.linq4j
-
Core methods that define a
Queryable
. - rawType - Variable in class org.apache.calcite.linq4j.tree.Types.ParameterizedTypeImpl
- rawValue() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.LiteralExpression
- RDD_FLAT_MAP - 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(String) - Method in class org.apache.calcite.rel.externalize.RelJsonReader
- read(Element) - Method in class org.apache.calcite.adapter.file.FileRowConverter.CellReader
- READ_ACCESS - org.apache.calcite.plan.TableAccessMap.Mode
-
Table is accessed for read only.
- READ_ONLY - Static variable in class org.apache.calcite.sql.SqlAccessType
- readAllAsString(Reader) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- reader - Variable in class org.apache.calcite.adapter.csv.CsvEnumerator
- reader - Variable in class org.apache.calcite.adapter.file.FileTable
- reader() - Method in interface org.apache.calcite.util.Source
- reader() - Method in class org.apache.calcite.util.Sources.FileSource
- 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. - readNext() - Method in class org.apache.calcite.adapter.csv.CsvStreamReader
-
Reads the next line from the buffer and converts to a string array.
- readObject(ObjectInputStream) - Method in class org.apache.calcite.util.SerializableCharset
-
Per
Serializable
. - readRel(Map<String, Object>) - Method in class org.apache.calcite.rel.externalize.RelJsonReader
- readRels(List<Map<String, Object>>) - Method in class org.apache.calcite.rel.externalize.RelJsonReader
- readResolve() - Method in class org.apache.calcite.rel.type.RelRecordType.SerializableRelRecordType
-
Per
Serializable
API. - READWRITE_ACCESS - org.apache.calcite.plan.TableAccessMap.Mode
-
Table is accessed for both read and write.
- ready - Variable in class org.apache.calcite.util.Filterator
- ready() - Method in class org.apache.calcite.prepare.PlannerImpl
- REAL - org.apache.calcite.sql.type.SqlTypeName
- real8 - Variable in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Type for doubles.
- 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. - realType(TpchColumn<E>) - Method in class org.apache.calcite.adapter.tpch.TpchSchema.TpchQueryableTable
- rebuild() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Creates a Builder whose initial contents are the same as this ImmutableBitSet.
- Rebuilder(ImmutableBitSet) - Constructor for class org.apache.calcite.util.ImmutableBitSet.Rebuilder
- receive() - Method in class org.apache.calcite.interpreter.Interpreter.EnumeratorSource
- receive() - Method in class org.apache.calcite.interpreter.Interpreter.ListSource
- receive() - Method in interface org.apache.calcite.interpreter.Source
-
Reads a row.
- recompute(RelSubset) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Equivalent to
recompute(subset, false)
. - recompute(RelSubset, boolean) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Recomputes the importance of the given RelSubset.
- recomputeDigest() - Method in class org.apache.calcite.plan.volcano.VolcanoRuleMatch
-
Recomputes the digest of this VolcanoRuleMatch.
- recomputeDigest() - Method in class org.apache.calcite.rel.AbstractRelNode
- recomputeDigest() - Method in interface org.apache.calcite.rel.RelNode
-
Computes the digest, assigns it, and returns it.
- 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.
- RecordFieldImpl(JavaTypeFactoryImpl.SyntheticRecordType, String, Type, boolean, int) - Constructor for class org.apache.calcite.jdbc.JavaTypeFactoryImpl.RecordFieldImpl
- recursiveCreatePdxType(PdxInstance, List<RelDataTypeField>, String) - Method in class org.apache.calcite.adapter.geode.util.JavaTypeFactoryExtImpl
- redoReplacement(List<SubstitutionVisitor.Replacement>) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
- REDSHIFT - 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.
- reduceAgg(Aggregate, AggregateCall, List<AggregateCall>, Map<AggregateCall, RexNode>, List<RexNode>) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
- reduceAggs(RelOptRuleCall, Aggregate) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Reduces all calls to AVG, STDDEV_POP, STDDEV_SAMP, VAR_POP, VAR_SAMP in the aggregates list to.
- reduceAndCheck(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Reduces this node to a simpler expression.
- reduceAvg(Aggregate, AggregateCall, List<AggregateCall>, Map<AggregateCall, RexNode>, List<RexNode>) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
- reduceCasts(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- reduceCovariance(Aggregate, AggregateCall, boolean, List<AggregateCall>, Map<AggregateCall, RexNode>, List<RexNode>) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
- ReduceDecimalsRule - Class in org.apache.calcite.rel.rules
-
ReduceDecimalsRule is a rule which reduces decimal operations (such as casts or arithmetic) into operations involving more primitive types (such as longs and doubles).
- ReduceDecimalsRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule
-
Creates a ReduceDecimalsRule.
- ReduceDecimalsRule.BinaryArithmeticExpander - Class in org.apache.calcite.rel.rules
-
Expands a decimal arithmetic expression
- ReduceDecimalsRule.CaseExpander - Class in org.apache.calcite.rel.rules
-
Expander that rewrites case expressions, in place.
- ReduceDecimalsRule.CastArgAsDoubleExpander - Class in org.apache.calcite.rel.rules
-
An expander which casts decimal arguments as doubles
- ReduceDecimalsRule.CastArgAsTypeExpander - Class in org.apache.calcite.rel.rules
-
An expander which casts decimal arguments as another type
- ReduceDecimalsRule.CastExpander - Class in org.apache.calcite.rel.rules
-
Expands a decimal cast expression
- ReduceDecimalsRule.CeilExpander - Class in org.apache.calcite.rel.rules
-
Expander that rewrites ceiling(decimal) expressions:
- ReduceDecimalsRule.DecimalShuttle - Class in org.apache.calcite.rel.rules
-
A shuttle which converts decimal expressions to expressions based on longs.
- ReduceDecimalsRule.ExpanderMap - Class in org.apache.calcite.rel.rules
-
Maps a RexCall to a RexExpander
- ReduceDecimalsRule.FloorExpander - Class in org.apache.calcite.rel.rules
-
Expander that rewrites floor(decimal) expressions:
- ReduceDecimalsRule.PassThroughExpander - Class in org.apache.calcite.rel.rules
-
An expander that substitutes decimals with their integer representations.
- ReduceDecimalsRule.ReinterpretExpander - Class in org.apache.calcite.rel.rules
-
This expander simplifies reinterpret calls.
- ReduceDecimalsRule.RexExpander - Class in org.apache.calcite.rel.rules
-
Rewrites a decimal expression for a specific set of SqlOperator's.
- reducedValues - Variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule.RexReplacer
- 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) - Static method in class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Reduces a list of expressions.
- reduceExpressionsInternal(RelNode, RexSimplify, RexUnknownAs, List<RexNode>, RelOptPredicateList) - Static method in class org.apache.calcite.rel.rules.ReduceExpressionsRule
- ReduceExpressionsRule - Class in org.apache.calcite.rel.rules
-
Collection of planner rules that apply various simplifying transformations on RexNode trees.
- ReduceExpressionsRule(Class<? extends RelNode>, boolean, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Creates a ReduceExpressionsRule.
- ReduceExpressionsRule(Class<? extends RelNode>, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Deprecated.
- ReduceExpressionsRule.CalcReduceExpressionsRule - Class in org.apache.calcite.rel.rules
-
Rule that reduces constants inside a
Calc
. - ReduceExpressionsRule.CaseShuttle - Class in org.apache.calcite.rel.rules
-
Shuttle that pushes predicates into a CASE.
- ReduceExpressionsRule.FilterReduceExpressionsRule - Class in org.apache.calcite.rel.rules
-
Rule that reduces constants inside a
Filter
. - ReduceExpressionsRule.JoinReduceExpressionsRule - Class in org.apache.calcite.rel.rules
-
Rule that reduces constants inside a
Join
. - ReduceExpressionsRule.ProjectReduceExpressionsRule - Class in org.apache.calcite.rel.rules
-
Rule that reduces constants inside a
Project
. - 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.ReducibleExprLocator.Constancy - Enum in org.apache.calcite.rel.rules
-
Whether an expression is constant, and if so, whether it can be reduced to a simpler constant.
- ReduceExpressionsRule.RexReplacer - Class in org.apache.calcite.rel.rules
-
Replaces expressions with their reductions.
- 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.
- reduceNotNullableFilter(RelOptRuleCall, Filter, RexNode, boolean) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.FilterReduceExpressionsRule
- reduceRegrSzz(Aggregate, AggregateCall, List<AggregateCall>, Map<AggregateCall, RexNode>, List<RexNode>, int, int, int) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
- ReduceResult(int, int, SqlNode) - Constructor for class org.apache.calcite.sql.SqlSpecialOperator.ReduceResult
- reduceStddev(Aggregate, AggregateCall, boolean, boolean, List<AggregateCall>, Map<AggregateCall, RexNode>, List<RexNode>) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
- reduceSum(Aggregate, AggregateCall, List<AggregateCall>, Map<AggregateCall, RexNode>) - Method in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
- REDUCIBLE_CONSTANT - org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator.Constancy
- ReducibleExprLocator(RelDataTypeFactory, ImmutableMap<RexNode, RexNode>, List<RexNode>, List<Boolean>, List<RexNode>) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- reducibleExps - Variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule.RexReplacer
- ref - Variable in class org.apache.calcite.rex.RexSimplify.Comparison
- ref - Variable in class org.apache.calcite.rex.RexSimplify.IsPredicate
- REF_CURSOR - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- RefAndExprConverter(RexBuilder, List<RelDataTypeField>, List<RelDataTypeField>, int[], List<RexNode>, int, List<RexNode>, int) - Constructor for class org.apache.calcite.rel.rules.PushProjector.RefAndExprConverter
- refCounts - Variable in class org.apache.calcite.rel.rules.JoinToMultiJoinRule.InputReferenceCounter
- refCounts - Variable in class org.apache.calcite.rex.RexProgram
-
Reference counts for each expression, computed on demand.
- ReferenceCounter() - Constructor for class org.apache.calcite.rex.RexProgram.ReferenceCounter
- 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.
- references(RexNode, RelDecorrelator.CorRef) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- ReflectedPseudoField - Class in org.apache.calcite.linq4j.tree
-
Represents a PseudoField that is implemented via java reflection Field
- ReflectedPseudoField(Field) - Constructor for class org.apache.calcite.linq4j.tree.ReflectedPseudoField
- REFLECTIVE_SCHEMA_GET_TARGET - 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
-
ReflectiveFunctionBase
constructor - 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>) - Constructor for class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
-
Creates a ReflectiveRelMetadataProvider.
- ReflectiveRelMetadataProvider.Space - Class in org.apache.calcite.rel.metadata
-
Workspace for computing which methods can act as handlers for given metadata methods.
- ReflectiveRelMetadataProvider.Space2 - Class in org.apache.calcite.rel.metadata
-
Extended work space.
- 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.
- ReflectiveSchema.FieldSelector - Class in org.apache.calcite.adapter.java
-
Function that returns an array of a given object's field values.
- ReflectiveSchema.FieldTable<T> - Class in org.apache.calcite.adapter.java
-
Table based on a Java field.
- ReflectiveSchema.MethodTableMacro - Class in org.apache.calcite.adapter.java
-
Table macro based on a Java method.
- ReflectiveSchema.ReflectiveTable - Class in org.apache.calcite.adapter.java
-
Table that is implemented by reading from a Java object.
- reflectiveSource(Method, MetadataHandler) - Static method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
-
Returns an implementation of
RelMetadataProvider
that scans for methods with a preceding argument. - reflectiveSource(MetadataHandler, ImmutableList<Method>) - Static method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
- reflectiveSource(MetadataHandler, Method...) - Static method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
-
Returns a reflective metadata provider that implements several methods.
- 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
- ReflectiveSqlOperatorTable.Key - Class in org.apache.calcite.sql.util
-
Key for looking up operators.
- ReflectiveTable(Type, Enumerable) - Constructor for class org.apache.calcite.adapter.java.ReflectiveSchema.ReflectiveTable
- 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.
- refName - Variable in class org.apache.calcite.sql.SqlWindow
-
The name of the window being referenced, or null.
- refresh() - Method in class org.apache.calcite.adapter.file.FileReader
- refWindowWithFrame() - Method in interface org.apache.calcite.runtime.CalciteResource
- reg(SqlValidatorScope, SqlNode) - Static method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Registers with the validator a
SqlNode
that has been created during the Sql-to-Rel process. - REG_CHAR_CLASSES - Static variable in class org.apache.calcite.runtime.Like
- regexpQuery(String, String) - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A Query that matches documents containing terms with a specified regular expression.
- RegexpQueryBuilder(String, String) - Constructor for class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RegexpQueryBuilder
- region(int) - Method in class org.apache.calcite.example.maze.Maze
- REGION_MAP - Static variable in class org.apache.calcite.adapter.geode.util.GeodeUtils
-
Cache for the client proxy regions created in the current ClientCache.
- regionName - Variable in class org.apache.calcite.adapter.geode.rel.GeodeTable
- regionName - Variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleScannableTable
- regionNames - Variable in class org.apache.calcite.adapter.geode.rel.GeodeSchema
- regionNames - Variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchema
- regions - Variable in class org.apache.calcite.example.maze.Maze
- 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
-
Registers some classes.
- register(Type) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor.TypeRegistrar
- register(String) - Method in class org.apache.calcite.piglet.Handler
-
Assigns the current relational expression to a given name.
- register(JavaTypeFactoryImpl.SyntheticRecordType) - Method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl
- 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.geode.rel.GeodeTableScan
- 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 class org.apache.calcite.plan.RelCompositeTrait
- 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 class org.apache.calcite.rel.RelDistributions.RelDistributionImpl
- register(RelOptPlanner) - Method in interface org.apache.calcite.rel.RelNode
-
Registers any special rules specific to this kind of relational expression.
- register(RelOptTable) - Method in class org.apache.calcite.materialize.LatticeSpace
- register(MutableRel, MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor
- 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(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, Map<Integer, Integer>, SortedMap<RelDecorrelator.CorDef, Integer>) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Registers a relational expression and the relational expression it became after decorrelation.
- register(RexNode) - Method in class org.apache.calcite.rex.RexUtil.ExpressionNormalizer
- register(RexNode, RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.DecimalShuttle
-
Registers node so it will not be computed again
- register(SqlOperator) - Method in class org.apache.calcite.sql.util.ReflectiveSqlOperatorTable
-
Registers a function or operator in the table.
- registerAbstractRelationalRules() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- registerAbstractRels(RelOptPlanner) - Static method in class org.apache.calcite.plan.RelOptUtil
- registerCaseOp(SqlOperator) - Method in class org.apache.calcite.rex.RexSqlStandardConvertletTable
-
Creates and registers a convertlet for the CASE operator, which takes different forms for SQL vs Rex.
- 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
- registerCount - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Incremented every time a relational expression is registered or two sets are merged.
- registeredSchemas - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
List of all schemas which have been registered.
- 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.
- registerExpanders(RexBuilder) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.ExpanderMap
- registerExpression(RexNode) - Method in class org.apache.calcite.tools.RelBuilder.Registrar
- registerExpressions(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder.Registrar
- registerFrom(SqlValidatorScope, SqlValidatorScope, boolean, SqlNode, SqlNode, String, SqlNodeList, boolean, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Registers scopes and namespaces implied a relational expression in the FROM clause.
- registerId(SqlIdentifier, SqlValidatorScope) - Method in class org.apache.calcite.sql.advise.SqlAdvisorValidator
- registerImpl(RelNode, RelSet) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Registers a new expression
exp
and queues up rule matches. - 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.
- RegisterInputShuttle(boolean) - Constructor for class org.apache.calcite.rex.RexProgramBuilder.RegisterInputShuttle
- registerInternal(RexNode, boolean) - 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.
- registerMatchRecognize(SqlValidatorScope, SqlValidatorScope, SqlMatchRecognize, SqlNode, String, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- registerMaterializations() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- registerMetadataProviders(List<RelMetadataProvider>) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- registerMetadataProviders(List<RelMetadataProvider>) - Method in class org.apache.calcite.plan.hep.HepPlanner
- registerMetadataProviders(List<RelMetadataProvider>) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Gives this planner a chance to register one or more
RelMetadataProvider
s in the chain which will be used to answer metadata queries. - registerMetadataProviders(List<RelMetadataProvider>) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- registerMetadataRels() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Informs
JaninoRelMetadataProvider
about the different kinds ofRelNode
that we will be dealing with. - RegisterMidputShuttle(boolean, List<RexNode>) - Constructor for class org.apache.calcite.rex.RexProgramBuilder.RegisterMidputShuttle
- 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.
- registerNodeTypeMethod(Method) - Method in class org.apache.calcite.sql2rel.ReflectiveConvertletTable
-
Registers method if it: a.
- 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
- registerOperandSubQueries(SqlValidatorScope, SqlCall, int) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Registers any sub-queries inside a given call operand, and converts the operand to a scalar sub-query if the operator requires it.
- registerOpTypeMethod(Method) - Method in class org.apache.calcite.sql2rel.ReflectiveConvertletTable
-
Registers method if it: a.
- 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.
- RegisterOutputShuttle(List<RexNode>) - Constructor for class org.apache.calcite.rex.RexProgramBuilder.RegisterOutputShuttle
- registerProjectsAndCondition(RexProgram) - Method in class org.apache.calcite.rex.RexProgramBuilder
- registerQuery(SqlValidatorScope, SqlValidatorScope, SqlNode, SqlNode, String, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Registers a query in a parent scope.
- registerQuery(SqlValidatorScope, SqlValidatorScope, SqlNode, SqlNode, String, boolean, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Registers a query in a parent scope.
- registerRules(CalcitePrepare.SparkHandler.RuleSetBuilder) - Method in class org.apache.calcite.adapter.spark.SparkHandlerImpl
- registerRules(CalcitePrepare.SparkHandler.RuleSetBuilder) - Method in class org.apache.calcite.jdbc.CalcitePrepare.Dummy.TrivialSparkHandler
- 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 of 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
- registerSetop(SqlValidatorScope, SqlValidatorScope, SqlNode, SqlNode, String, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- RegisterShuttle() - Constructor for class org.apache.calcite.rex.RexProgramBuilder.RegisterShuttle
- registerSubQueries(SqlValidatorScope, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- registerSubQuery(SqlNode, RelOptUtil.Logic) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- registerSubset(RelSet, RelSubset) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- registerTable(String, PigTable) - Method in class org.apache.calcite.adapter.pig.PigSchema
- registerTypeAppendOp(SqlOperator) - Method in class org.apache.calcite.rex.RexSqlStandardConvertletTable
-
Creates and registers a convertlet for an operator in which the SQL representation needs the result type appended as an extra argument (e.g.
- registerWith(SqlValidatorScope, SqlValidatorScope, SqlWith, SqlNode, String, boolean, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- Registrar() - Constructor for class org.apache.calcite.tools.RelBuilder.Registrar
- registry(List<E>) - Static method in class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Creates a
SqlSplittableAggFunction.Registry
that is a view of a list. - REGR_COUNT - 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 - org.apache.calcite.sql.fun.SqlCovarAggFunction.Subtype
-
Deprecated.
- REGR_SXX - 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 - org.apache.calcite.sql.fun.SqlCovarAggFunction.Subtype
-
Deprecated.
- REGR_SYY - 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. - RegrCovarianceConvertlet(SqlKind) - Constructor for class org.apache.calcite.sql2rel.StandardConvertletTable.RegrCovarianceConvertlet
- ReInit(Reader) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Reinitializes parser with new input.
- REINTERPRET - 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. - ReinterpretExpander(RexBuilder) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule.ReinterpretExpander
- ReinterpretImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.ReinterpretImplementor
- rel - Variable in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- rel - Variable in class org.apache.calcite.interpreter.AbstractSingleNode
- rel - Variable in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
- rel - Variable in class org.apache.calcite.interpreter.Interpreter.NodeInfo
- rel - Variable in class org.apache.calcite.interpreter.JoinNode
- rel - Variable in class org.apache.calcite.interpreter.UnionNode
- rel - Variable in class org.apache.calcite.jdbc.CalcitePrepare.Query
- rel - Variable in class org.apache.calcite.plan.RelOptListener.RelEvent
- rel - Variable in class org.apache.calcite.plan.volcano.RelSet
- rel - Variable in class org.apache.calcite.prepare.CalciteMaterializer.Callback
- rel - Variable in class org.apache.calcite.prepare.QueryableRelBuilder
- rel - Variable in class org.apache.calcite.rel.metadata.RelMdUtil.CardOfProjExpr
- rel - Variable in class org.apache.calcite.rel.mutable.MutableLeafRel
- rel - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- rel - Variable in class org.apache.calcite.rel.RelRoot
- rel - Variable in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.LeafVertex
- rel - Variable in class org.apache.calcite.rex.RexSubQuery
- rel - Variable in class org.apache.calcite.tools.RelBuilder.Frame
- 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 - org.apache.calcite.runtime.Hook
-
Returns a boolean value, whether RelBuilder should simplify expressions.
- REL_TYPES - Static variable in class org.apache.calcite.rel.rules.ProjectToWindowRule.WindowedAggRelSplitter
- relation - Variable in class org.apache.calcite.piglet.Ast.DescribeStmt
- relation - Variable in class org.apache.calcite.piglet.Ast.DumpStmt
- RELATION - 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.
- relative(Source) - Method in class org.apache.calcite.util.Sources.FileSource
- 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.rel.rules.PushProjector
- relBuilder - Variable in class org.apache.calcite.sql2rel.RelDecorrelator
- relBuilder - Variable in class org.apache.calcite.sql2rel.RelFieldTrimmer
- relBuilder - Variable in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- relBuilder - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- 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.AggCallImpl - Class in org.apache.calcite.tools
-
Implementation of
RelBuilder.AggCall
. - RelBuilder.AggCallImpl2 - Class in org.apache.calcite.tools
-
Implementation of
RelBuilder.AggCall
that wraps anAggregateCall
. - RelBuilder.Field - Class in org.apache.calcite.tools
-
A field that belongs to a stack
RelBuilder.Frame
. - RelBuilder.Frame - Class in org.apache.calcite.tools
-
Builder stack frame.
- RelBuilder.GroupKey - Interface in org.apache.calcite.tools
-
Information necessary to create the GROUP BY clause of an Aggregate.
- RelBuilder.GroupKeyImpl - Class in org.apache.calcite.tools
-
Implementation of
RelBuilder.GroupKey
. - RelBuilder.Registrar - Class in org.apache.calcite.tools
-
Collects the extra expressions needed for
RelBuilder.aggregate(org.apache.calcite.tools.RelBuilder.GroupKey, org.apache.calcite.tools.RelBuilder.AggCall...)
. - RelBuilder.Shifter - Class in org.apache.calcite.tools
-
Shuttle that shifts a predicate's inputs to the left, replacing early ones with references to a
RexCorrelVariable
. - relBuilderFactory - Variable in class org.apache.calcite.plan.RelOptRule
-
Factory for a builder for relational expressions.
- relBuilderFactory - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- relBuilderFactory - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- 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.
- RelChosenEvent(Object, RelNode) - Constructor for class org.apache.calcite.plan.RelOptListener.RelChosenEvent
- relClass - Variable in class org.apache.calcite.plan.Convention.Impl
- relClass - Variable in exception org.apache.calcite.rel.metadata.JaninoRelMetadataProvider.NoHandler
- relClasses - Variable in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider.Key
- 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
. - RelCollations() - Constructor for class org.apache.calcite.rel.RelCollations
- RelCollationTraitDef - Class in org.apache.calcite.rel
-
Definition of the ordering trait.
- RelCollationTraitDef() - Constructor for class org.apache.calcite.rel.RelCollationTraitDef
- 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
- RelCompositeTrait<T extends RelMultipleTrait> - Class in org.apache.calcite.plan
-
A trait that consists of a list of traits, all of the same type.
- RelCompositeTrait(RelTraitDef, T[]) - Constructor for class org.apache.calcite.plan.RelCompositeTrait
-
Creates a RelCompositeTrait.
- RelConversionException - Exception in org.apache.calcite.tools
-
An Exception thrown when attempting conversion to a set of
RelNode
s. - RelConversionException(String) - Constructor for exception org.apache.calcite.tools.RelConversionException
-
Creates a RelConversionException with the specified detail message.
- RelConversionException(String, Throwable) - Constructor for exception org.apache.calcite.tools.RelConversionException
-
Creates a RelConversionException with the specified detail message and cause.
- RelConversionException(Throwable) - Constructor for exception 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 - Variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleScannableTable
- 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.
- RelDataTypeComparability(String) - Constructor for enum org.apache.calcite.rel.type.RelDataTypeComparability
- 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.
- RelDataTypeFactoryImpl.Key - Class in org.apache.calcite.rel.type
-
Key to the data type cache.
- 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.
- RelDataTypeHolder - Class in org.apache.calcite.rel.type
-
Holding the expandable list of fields for dynamic table.
- RelDataTypeHolder(RelDataTypeFactory) - Constructor for class org.apache.calcite.rel.type.RelDataTypeHolder
- 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.
- RelDataTypeImpl.Slot - Class in org.apache.calcite.rel.type
- 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.CorDef - Class in org.apache.calcite.sql2rel
-
A correlation and a field.
- RelDecorrelator.CorelMap - Class in org.apache.calcite.sql2rel
-
A map of the locations of
LogicalCorrelate
in a tree ofRelNode
s. - RelDecorrelator.CorelMapBuilder - Class in org.apache.calcite.sql2rel
-
Builds a
RelDecorrelator.CorelMap
. - RelDecorrelator.CorRef - Class in org.apache.calcite.sql2rel
-
A unique reference to a correlation field.
- RelDecorrelator.DecorrelateRexShuttle - Class in org.apache.calcite.sql2rel
-
Shuttle that decorrelates.
- RelDecorrelator.Frame - Class in org.apache.calcite.sql2rel
-
Frame describing the relational expression after decorrelation and where to find the output fields and correlation variables among its output fields.
- RelDecorrelator.RemoveCorrelationForScalarAggregateRule - Class in org.apache.calcite.sql2rel
-
Planner rule that removes correlations for scalar aggregates.
- RelDecorrelator.RemoveCorrelationForScalarProjectRule - Class in org.apache.calcite.sql2rel
-
Planner rule that removes correlations for scalar projects.
- RelDecorrelator.RemoveCorrelationRexShuttle - Class in org.apache.calcite.sql2rel
-
Shuttle that removes correlations.
- RelDecorrelator.RemoveSingleAggregateRule - Class in org.apache.calcite.sql2rel
-
Rule to remove single_value rel.
- 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.
- 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.
- RelDistributionImpl(RelDistribution.Type, ImmutableIntList) - Constructor for class org.apache.calcite.rel.RelDistributions.RelDistributionImpl
- RelDistributions - Class in org.apache.calcite.rel
-
Utilities concerning
RelDistribution
. - RelDistributions() - Constructor for class org.apache.calcite.rel.RelDistributions
- RelDistributions.RelDistributionImpl - Class in org.apache.calcite.rel
-
Implementation of
RelDistribution
. - RelDistributionTraitDef - Class in org.apache.calcite.rel
-
Definition of the distribution trait.
- RelDistributionTraitDef() - Constructor for class org.apache.calcite.rel.RelDistributionTraitDef
- 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.
- 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() - Constructor for class org.apache.calcite.rel.core.RelFactories
- RelFactories.AggregateFactory - Interface in org.apache.calcite.rel.core
-
Can create a
LogicalAggregate
of the appropriate type for this rule's calling convention. - RelFactories.AggregateFactoryImpl - Class in org.apache.calcite.rel.core
-
Implementation of
RelFactories.AggregateFactory
that returns a vanillaLogicalAggregate
. - RelFactories.CorrelateFactory - Interface in org.apache.calcite.rel.core
-
Can create a correlate of the appropriate type for a rule's calling convention.
- RelFactories.CorrelateFactoryImpl - Class in org.apache.calcite.rel.core
-
Implementation of
RelFactories.CorrelateFactory
that returns a vanillaLogicalCorrelate
. - RelFactories.ExchangeFactory - Interface in org.apache.calcite.rel.core
-
Can create a
Exchange
of the appropriate type for a rule's calling convention. - RelFactories.ExchangeFactoryImpl - Class in org.apache.calcite.rel.core
-
Implementation of
RelFactories.ExchangeFactory
that returns aExchange
. - RelFactories.FilterFactory - Interface in org.apache.calcite.rel.core
-
Can create a
LogicalFilter
of the appropriate type for this rule's calling convention. - RelFactories.FilterFactoryImpl - Class in org.apache.calcite.rel.core
-
Implementation of
RelFactories.FilterFactory
that returns a vanillaLogicalFilter
. - RelFactories.JoinFactory - Interface in org.apache.calcite.rel.core
-
Can create a join of the appropriate type for a rule's calling convention.
- RelFactories.JoinFactoryImpl - Class in org.apache.calcite.rel.core
-
Implementation of
RelFactories.JoinFactory
that returns a vanillaLogicalJoin
. - RelFactories.MatchFactory - Interface in org.apache.calcite.rel.core
-
Can create a
Match
of the appropriate type for a rule's calling convention. - RelFactories.MatchFactoryImpl - Class in org.apache.calcite.rel.core
-
Implementation of
RelFactories.MatchFactory
that returns aLogicalMatch
. - RelFactories.ProjectFactory - Interface in org.apache.calcite.rel.core
-
Can create a
LogicalProject
of the appropriate type for this rule's calling convention. - RelFactories.ProjectFactoryImpl - Class in org.apache.calcite.rel.core
-
Implementation of
RelFactories.ProjectFactory
that returns a vanillaLogicalProject
. - RelFactories.SemiJoinFactory - Interface in org.apache.calcite.rel.core
-
Can create a semi-join of the appropriate type for a rule's calling convention.
- RelFactories.SemiJoinFactoryImpl - Class in org.apache.calcite.rel.core
-
Implementation of
RelFactories.SemiJoinFactory
that returns a vanillaSemiJoin
. - 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.SetOpFactoryImpl - Class in org.apache.calcite.rel.core
-
Implementation of
RelFactories.SetOpFactory
that returns a vanillaSetOp
for the particular kind of set operation (UNION, EXCEPT, INTERSECT). - RelFactories.SortExchangeFactory - Interface in org.apache.calcite.rel.core
-
Can create a
SortExchange
of the appropriate type for a rule's calling convention. - RelFactories.SortExchangeFactoryImpl - Class in org.apache.calcite.rel.core
-
Implementation of
RelFactories.SortExchangeFactory
that returns aSortExchange
. - RelFactories.SortFactory - Interface in org.apache.calcite.rel.core
-
Can create a
Sort
of the appropriate type for this rule's calling convention. - RelFactories.SortFactoryImpl - Class in org.apache.calcite.rel.core
-
Implementation of
RelFactories.SortFactory
that returns a vanillaSort
. - RelFactories.TableScanFactory - Interface in org.apache.calcite.rel.core
-
Can create a
TableScan
of the appropriate type for a rule's calling convention. - RelFactories.TableScanFactoryImpl - Class in org.apache.calcite.rel.core
-
Implementation of
RelFactories.TableScanFactory
that returns aLogicalTableScan
. - RelFactories.ValuesFactory - Interface in org.apache.calcite.rel.core
-
Can create a
Values
of the appropriate type for a rule's calling convention. - RelFactories.ValuesFactoryImpl - Class in org.apache.calcite.rel.core
-
Implementation of
RelFactories.ValuesFactory
that returns aLogicalValues
. - 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.SemiJoinFactory, 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.
- 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
- relIdMap - Variable in class org.apache.calcite.rel.externalize.RelJsonWriter
- 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. - RelImportanceComparator() - Constructor for class org.apache.calcite.plan.volcano.RuleQueue.RelImportanceComparator
- relImportanceOrdering - Variable in class org.apache.calcite.plan.volcano.RuleQueue
-
Compares relexps according to their cached 'importance'.
- relImportances - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
The importance of relational expressions.
- 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.
- relInputs - Variable in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
- relJson - Variable in class org.apache.calcite.rel.externalize.RelJsonReader
- 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
- 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
- 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
- relList - Variable in class org.apache.calcite.rel.externalize.RelJsonWriter
- relMap - Variable in class org.apache.calcite.rel.externalize.RelJsonReader
- 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. - RelMdCollation() - Constructor for class org.apache.calcite.rel.metadata.RelMdCollation
- 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. - RelMdColumnOrigins() - Constructor for class org.apache.calcite.rel.metadata.RelMdColumnOrigins
- 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. - RelMdColumnUniqueness() - Constructor for class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- 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. - RelMdDistribution() - Constructor for class org.apache.calcite.rel.metadata.RelMdDistribution
- 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. - RelMdExplainVisibility() - Constructor for class org.apache.calcite.rel.metadata.RelMdExplainVisibility
- 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
- RelMdExpressionLineage.RexReplacer - Class in org.apache.calcite.rel.metadata
-
Replaces expressions with their equivalences.
- 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
- 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. - RelMdPercentageOriginalRows() - Constructor for class org.apache.calcite.rel.metadata.RelMdPercentageOriginalRows
- 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. - RelMdPopulationSize() - Constructor for class org.apache.calcite.rel.metadata.RelMdPopulationSize
- 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
- RelMdPredicates.JoinConditionBasedPredicateInference - Class in org.apache.calcite.rel.metadata
-
Utility to infer predicates from one side of the join that apply on the other side.
- RelMdPredicates.JoinConditionBasedPredicateInference.EquivalenceFinder - Class in org.apache.calcite.rel.metadata
-
Find expressions of the form 'col_x = col_y'.
- RelMdPredicates.JoinConditionBasedPredicateInference.ExprsItr - Class in org.apache.calcite.rel.metadata
-
Given an expression returns all the possible substitutions.
- 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. - RelMdUniqueKeys() - Constructor for class org.apache.calcite.rel.metadata.RelMdUniqueKeys
- RelMdUtil - Class in org.apache.calcite.rel.metadata
-
RelMdUtil provides utility methods used by the metadata provider methods.
- RelMdUtil() - Constructor for class org.apache.calcite.rel.metadata.RelMdUtil
- RelMdUtil.CardOfProjExpr - Class in org.apache.calcite.rel.metadata
-
Visitor that walks over a scalar expression and computes the cardinality of its result.
- 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(boolean) - Constructor for class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Creates and initializes the instance that will serve as a prototype for all other instances.
- RelMetadataQuery(JaninoRelMetadataProvider, RelMetadataQuery) - Constructor for class org.apache.calcite.rel.metadata.RelMetadataQuery
- 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.
- RelNodeComparator() - Constructor for class org.apache.calcite.rel.RelNodes.RelNodeComparator
- RelNodes - Class in org.apache.calcite.rel
-
Utilities concerning relational expressions.
- RelNodes() - Constructor for class org.apache.calcite.rel.RelNodes
- RelNodes.RelNodeComparator - Class in org.apache.calcite.rel
-
Arbitrary stable comparator for
RelNode
s. - RelNodesExprsHandler(RexShuttle) - Constructor for class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.RelNodesExprsHandler
- RelNullShuttle() - Constructor for class org.apache.calcite.prepare.CalciteMaterializer.RelNullShuttle
- relOffsetList - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.LookupContext
- 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.
- RelOptCluster(RelOptPlanner, RelDataTypeFactory, RexBuilder, AtomicInteger, Map<String, RelNode>) - Constructor for class org.apache.calcite.plan.RelOptCluster
-
Creates a cluster.
- RelOptCluster(RelOptQuery, RelOptPlanner, RelDataTypeFactory, RexBuilder) - Constructor for class org.apache.calcite.plan.RelOptCluster
-
Deprecated.
- 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
- RelOptCostImpl.Factory - Class in org.apache.calcite.plan
-
Implementation of
RelOptCostFactory
that createsRelOptCostImpl
s. - 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 attemptedd.
- 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.
- RelOptMaterialization.ProjectFilterTable - Class in org.apache.calcite.plan
-
A table scan and optional project mapping and filter condition.
- 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 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.
- RelOptPredicateList(ImmutableList<RexNode>, ImmutableList<RexNode>, ImmutableList<RexNode>, ImmutableMap<RexNode, RexNode>) - Constructor for class org.apache.calcite.plan.RelOptPredicateList
- 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.
- RelOptQuery(RelOptPlanner, AtomicInteger, Map<String, RelNode>) - Constructor for class org.apache.calcite.plan.RelOptQuery
-
For use by RelOptCluster only.
- 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>, RelOptRuleOperandChildPolicy, ImmutableList<RelOptRuleOperand>) - Constructor for class org.apache.calcite.plan.RelOptRuleOperand
-
Private constructor.
- 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.
- RelOptRuleOperandChildPolicy() - Constructor for enum org.apache.calcite.plan.RelOptRuleOperandChildPolicy
- RelOptRuleOperandChildren - Class in org.apache.calcite.plan
-
Children of a
RelOptRuleOperand
and the policy for matching them. - RelOptRuleOperandChildren(RelOptRuleOperandChildPolicy, List<RelOptRuleOperand>) - Constructor for class org.apache.calcite.plan.RelOptRuleOperandChildren
- 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
- relOptSchema - Variable in class org.apache.calcite.rel.externalize.RelJsonReader
- 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
. - RelOptTableImpl(RelOptSchema, RelDataType, List<String>, Table, Function<Class, Expression>, Double) - Constructor for class org.apache.calcite.prepare.RelOptTableImpl
- RelOptTableImpl.MySchemaPlus - Class in org.apache.calcite.prepare
-
Implementation of
SchemaPlus
that wraps a regular schema and knows its name and parent. - 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.CorrelationCollector - Class in org.apache.calcite.plan
-
Shuttle that finds correlation variables inside a given relational expression, including those that are inside
sub-queries
. - 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.Side - Enum in org.apache.calcite.plan
-
Categorizes whether a bit set contains bits left and right of a line.
- 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.VariableSetVisitor - Class in org.apache.calcite.plan
-
Visitor that finds all variables used but not stopped in an expression.
- 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
- RelRecordType(StructKind, List<RelDataTypeField>) - Constructor for class org.apache.calcite.rel.type.RelRecordType
-
Creates a
RecordType
. - RelRecordType.SerializableRelRecordType - Class in org.apache.calcite.rel.type
-
Skinny object which has the same information content as a
RelRecordType
but skips redundant stuff like digest and the immutable list. - 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.
- RelReferentialConstraintImpl(List<String>, List<String>, List<IntPair>) - Constructor for class org.apache.calcite.rel.RelReferentialConstraintImpl
- RelRoot - Class in org.apache.calcite.rel
-
Root of a tree of
RelNode
. - RelRoot(RelNode, RelDataType, SqlKind, List<Pair<Integer, String>>, RelCollation) - Constructor for class org.apache.calcite.rel.RelRoot
-
Creates a RelRoot.
- RelRunner - Interface in org.apache.calcite.tools
-
Runs a relational expression.
- RelRunners - Class in org.apache.calcite.tools
-
Implementations of
RelRunner
. - RelRunners() - Constructor for class org.apache.calcite.tools.RelRunners
- rels - Variable in class org.apache.calcite.adapter.druid.DruidQuery
- rels - Variable in class org.apache.calcite.plan.RelOptRuleCall
- rels - Variable in class org.apache.calcite.plan.volcano.RelSet
- rels - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner.RuleProvenance
- RelSet - Class in org.apache.calcite.plan.volcano
-
A
RelSet
is an equivalence-set of expressions; that is, a set of expressions which have identical semantics. - RelSet(int, Set<CorrelationId>, Set<CorrelationId>) - Constructor for class org.apache.calcite.plan.volcano.RelSet
- relShuttle - Variable in class org.apache.calcite.plan.RelOptUtil.VariableUsedVisitor
- 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.RewriteRelVisitor - Class in org.apache.calcite.sql2rel
-
Visitor that flattens each relational expression in a tree.
- RelStructuredTypeFlattener.RewriteRexShuttle - Class in org.apache.calcite.sql2rel
-
Shuttle that rewrites scalar expressions.
- 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.
- RelSubset(RelOptCluster, RelSet, RelTraitSet) - Constructor for class org.apache.calcite.plan.volcano.RelSubset
- RelSubset.CheapestPlanReplacer - Class in org.apache.calcite.plan.volcano
-
Visitor which walks over a tree of
RelSet
s, replacing each node with the cheapest implementation of the expression. - RelTableRef(RelOptTable, int) - Constructor for class org.apache.calcite.rex.RexTableInputRef.RelTableRef
- 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.
- RelToSqlConverter.Frame - Class in org.apache.calcite.rel.rel2sql
-
Stack frame.
- 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
-
RelTraitPropagationVisitor traverses a RelNode and its unregistered children, making sure that each has a full complement of traits.
- RelTraitPropagationVisitor(RelOptPlanner, RelTraitSet) - Constructor for class org.apache.calcite.plan.RelTraitPropagationVisitor
- RelTraitSet - Class in org.apache.calcite.plan
-
RelTraitSet represents an ordered set of
RelTrait
s. - RelTraitSet(RelTraitSet.Cache, RelTrait[]) - Constructor for class org.apache.calcite.plan.RelTraitSet
-
Constructs a RelTraitSet with the given set of RelTraits.
- RelTraitSet.Cache - Class in org.apache.calcite.plan
-
Cache of trait sets.
- relType - Variable in class org.apache.calcite.jdbc.JavaTypeFactoryImpl.SyntheticRecordType
- relType - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter.ImplementTester
- RelType(String) - Constructor for class org.apache.calcite.rel.rules.CalcRelSplitter.RelType
- relTypes - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter
- 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
- remaining - Variable in class org.apache.calcite.rel.core.JoinInfo.NonEquiJoinInfo
- remainingNames - Variable in class org.apache.calcite.sql.validate.SqlValidatorScope.Resolve
-
Names not matched; empty if it was a full match.
- remap(ImmutableBitSet, int) - Static method in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
- remap(ImmutableBitSet, Iterable<ImmutableBitSet>) - Static method in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
- remap(ImmutableBitSet, List<Integer>) - Static method in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
- remap(ImmutableBitSet, ImmutableBitSet) - Static method in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
- remapJoinReferences(LoptMultiJoin, int, List<Integer>, int, int[], int, int, boolean) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Sets an adjustment array based on where column references for a particular factor end up as a result of a new join ordering.
- remark(T) - Static method in class org.apache.calcite.util.Bug
-
Use this method to flag temporary code.
- removableCasts - Variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- removableOuterJoinFactors - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Set of null-generating factors whose corresponding outer join can be removed from the query plan
- removableSelfJoin - Variable in class org.apache.calcite.rel.rules.LoptJoinTree
- RemovableSelfJoin(int, int, Map<Integer, Integer>) - Constructor for class org.apache.calcite.rel.rules.LoptMultiJoin.RemovableSelfJoin
- removableSelfJoinPairs - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Map consisting of all pairs of self-joins where the self-join can be removed because the join between the identical factors is an equality join on the same set of unique keys.
- remove() - Method in class org.apache.calcite.adapter.file.FileReader.FileReaderIterator
- remove() - Method in class org.apache.calcite.jdbc.CalciteMetaImpl.LimitIterator
- remove() - Method in class org.apache.calcite.linq4j.Linq4j.EnumeratorIterator
- remove() - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference.ExprsItr
- remove() - Method in class org.apache.calcite.util.ChunkList.ChunkListIterator
- 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() - Method in class org.apache.calcite.util.mapping.Mappings.FunctionMappingIter
- remove() - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping.MappingItr
- remove() - Method in class org.apache.calcite.util.Pair.AdjacentIterator
- remove() - Method in class org.apache.calcite.util.Pair.FirstAndIterator
- remove() - Method in class org.apache.calcite.util.Pair.LeftIterator
- remove() - Method in class org.apache.calcite.util.Pair.RightIterator
- remove() - Method in class org.apache.calcite.util.Pair.ZipIterator
- remove(int) - Method in class org.apache.calcite.runtime.AbstractImmutableList
- remove(int) - Method in class org.apache.calcite.util.CastingList
- remove(int) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.TokenList
- remove(Object) - Method in class org.apache.calcite.linq4j.EnumerableDefaults.WrapMap
- remove(Object) - Method in class org.apache.calcite.linq4j.LookupImpl
- remove(Object) - Method in class org.apache.calcite.runtime.AbstractImmutableList
- remove(Object) - Method in class org.apache.calcite.util.CompositeMap
- 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(Consumer) - Method in enum org.apache.calcite.runtime.Hook
-
Removes a handler from this Hook.
- remove(Enumerable<T>, C) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Default implementation of
ExtendedEnumerable.removeAll(Collection)
. - REMOVE_ALL - 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.runtime.AbstractImmutableList
- 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
- removeCast(RexNode) - Static method in class org.apache.calcite.plan.RexImplicationChecker.InputUsageFinder
- removeCast(RexNode) - Static method in class org.apache.calcite.plan.VisitorDataContext
- 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
- RemoveCorrelationForScalarAggregateRule(RelBuilderFactory) - Constructor for class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationForScalarAggregateRule
- RemoveCorrelationForScalarProjectRule(RelBuilderFactory) - Constructor for class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationForScalarProjectRule
- RemoveCorrelationRexShuttle(RexBuilder, boolean, RexInputRef, Set<Integer>) - Constructor for class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationRexShuttle
- removeCorrelationViaRule(RelNode) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- removeCorVarFromTree(LogicalCorrelate) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
-
Remove correlated variables from the tree at root corRel
- removeDistinct(RelDataType) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener.RewriteRexShuttle
- 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
-
Creates a simple RemoveEmptySingleRule.
- RemoveEmptySingleRule(Class<R>, Predicate<R>, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.PruneEmptyRules.RemoveEmptySingleRule
-
Creates a RemoveEmptySingleRule.
- removeExtraFilters(List<Integer>, int, RexNode) - Method in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
-
Removes from an expression any sub-expressions that reference key values that aren't contained in a key list passed in.
- removeFactor(Map<RexNode, RexNode>, RexNode) - Method in class org.apache.calcite.rex.RexUtil.CnfHelper
- removeFunction(String) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema
- removeFunction(String) - Method in class org.apache.calcite.jdbc.CalciteSchema
- RemoveIsNotDistinctFromRexShuttle(RexBuilder) - Constructor for class org.apache.calcite.rel.rules.FilterRemoveIsNotDistinctFromRule.RemoveIsNotDistinctFromRexShuttle
- removeJoin(LoptMultiJoin, SemiJoin, int, int) - Method in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
-
Determines whether a join of the dimension table in a semijoin can be removed.
- 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.
- removePossibleSemiJoin(Map<Integer, SemiJoin>, Integer, Integer) - Method in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
-
Removes a dimension table from a fact table's list of possible semijoins
- removeRule(RelOptRule) - Method in interface org.apache.calcite.jdbc.CalcitePrepare.SparkHandler.RuleSetBuilder
- removeRule(RelOptRule) - Method in class org.apache.calcite.plan.hep.HepPlanner
- removeRule(RelOptRule) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Removes a rule.
- removeRule(RelOptRule) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- RemoveSingleAggregateRule(RelBuilderFactory) - Constructor for class org.apache.calcite.sql2rel.RelDecorrelator.RemoveSingleAggregateRule
- removeStatement(Meta.StatementHandle) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerImpl
- 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.CachingCalciteSchema
- removeTable(String) - Method in class org.apache.calcite.jdbc.CalciteSchema
- removeThread(Consumer) - Method in enum org.apache.calcite.runtime.Hook
-
Removes a thread handler from this Hook.
- removeType(String) - Method in class org.apache.calcite.jdbc.CalciteSchema
- 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
-
Creates an equivalent AggregateCall that has a new name.
- rename(List<String>) - Method in class org.apache.calcite.tools.RelBuilder
-
Ensures that the field names match those given.
- rename(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Re-computes the digest of a
RelNode
. - renameColumns(SqlNodeList, SqlNode) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Wraps a query to rename its columns.
- renameIfNecessary(RelNode, RelDataType) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- reorder(SqlNode[]) - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall.PermutingMakeCall
-
Uses the data in
SqlJdbcFunctionCall.PermutingMakeCall.order
to reorder a SqlNode[] array. - repeat - Variable in class org.apache.calcite.util.Benchmark
- 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 - org.apache.calcite.sql.type.CompositeOperandTypeChecker.Composition
- repeatableSeed - Variable in class org.apache.calcite.plan.RelOptSamplingParameters
- repeatableSeed - Variable in class org.apache.calcite.sql.SqlSampleSpec.SqlTableSampleSpec
- replace - Variable in class org.apache.calcite.sql.SqlCreate
-
Whether "OR REPLACE" was specified.
- 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
-
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(List<T>, T, T) - Method in class org.apache.calcite.util.PartiallyOrderedSet
- 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(PrecedenceClimbingParser.Token, PrecedenceClimbingParser.Token, PrecedenceClimbingParser.Token) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- REPLACE - org.apache.calcite.util.BuiltInMethod
- REPLACE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
REPLACE(string, search, replace)
function. - replaceIf(RelTraitDef<T>, Supplier<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<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.
- replaceLast(List<E>, E, E) - Static method in class org.apache.calcite.rex.RexSimplify
-
Replaces the last occurrence of one specified value in a list with another.
- replacement - Variable in class org.apache.calcite.rel.rules.SubQueryRemoveRule.ReplaceSubQueryShuttle
- replacement - Variable in class org.apache.calcite.sql.advise.SqlAdvisorHint2
-
Replacement string
- replacement - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Result
- Replacement(MutableRel, MutableRel) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.Replacement
- replacementMap - Variable in class org.apache.calcite.plan.SubstitutionVisitor
- replacementValues - Variable in class org.apache.calcite.rel.metadata.RelMdExpressionLineage.RexReplacer
- replacePattern - Variable in class org.apache.calcite.adapter.file.FileRowConverter.CellReader
- replaceRecurse(MutableRel, MutableRel, MutableRel) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
- replaceRecurse(RelNode, RelNode, RelNode) - Static method in class org.apache.calcite.plan.RelOptUtil
- replaceRel(RelNode) - Method in class org.apache.calcite.plan.hep.HepRelVertex
-
Replaces the implementation for this expression with a new one.
- replaceRoot(RelNode) - Method in class org.apache.calcite.rel.RelVisitor
-
Replaces the root node of this traversal.
- replaceSublist(int, int, SqlNode) - Method in class org.apache.calcite.sql.parser.SqlParserUtil.OldTokenSequenceImpl
- replaceSublist(int, int, SqlNode) - Method in class org.apache.calcite.sql.parser.SqlParserUtil.TokenSequenceImpl
- 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.
- replaceSubQueries(SqlToRelConverter.Blackboard, SqlNode, RelOptUtil.Logic) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- ReplaceSubQueryShuttle(RexSubQuery, RexNode) - Constructor for class org.apache.calcite.rel.rules.SubQueryRemoveRule.ReplaceSubQueryShuttle
- replaceText - Variable in class org.apache.calcite.adapter.file.FileRowConverter.CellReader
- 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.
- replaceTop(RelNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Adds a rel node to the top of the stack while preserving the field names and aliases.
- replaceWith - Variable in class org.apache.calcite.adapter.file.FileRowConverter.CellReader
- replaceWithOriginalReferences(RexBuilder, RelNode, AbstractMaterializedViewRule.NodeLineage, RexNode) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
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 - org.apache.calcite.sql.validate.SqlMonikerType
- representation - Variable in class org.apache.calcite.adapter.clone.ArrayTable.Column
- representation - Variable in class org.apache.calcite.adapter.clone.ArrayTable.Content.ObjectEnumerator
- representation - Variable in class org.apache.calcite.adapter.clone.ArrayTable.ObjectDictionary
- RepresentationType() - Constructor for enum org.apache.calcite.adapter.clone.ArrayTable.RepresentationType
- representationValues - Variable in class org.apache.calcite.adapter.clone.ColumnLoader
- reps - Variable in class org.apache.calcite.adapter.jdbc.JdbcUtils.ObjectArrayRowBuilder
- request(QueryType, String, Sink, List<String>, List<ColumnMetaData.Rep>, DruidConnectionImpl.Page) - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
-
Executes a query request.
- requestCancel() - Method in class org.apache.calcite.util.CancelFlag
-
Requests a cancellation.
- requestedRootTraits - Variable in class org.apache.calcite.plan.hep.HepPlanner
- requestHeaders - Variable in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- requireAtLeastOneArg() - Method in interface org.apache.calcite.runtime.CalciteResource
- required - Variable in enum org.apache.calcite.config.CalciteConnectionProperty
- required() - Method in enum org.apache.calcite.config.CalciteConnectionProperty
- requiredCollation(RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- requiredColsMap - Variable in class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.RexFieldAccessReplacer
- requiredColumns - Variable in class org.apache.calcite.rel.core.Correlate
- requiredColumns - Variable in class org.apache.calcite.rel.mutable.MutableCorrelate
- requiredColumns - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.CorrelationUse
- requiredComparability - Variable in class org.apache.calcite.sql.type.ComparableOperandTypeChecker
- requireDefaultConstructor(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- requireNonNull(T) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Deprecated.
- requireParentheses(Expression, int, int) - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
-
If parentheses are required, writes this expression out with parentheses and returns true.
- requiresAliasForFromItems() - Method in class org.apache.calcite.sql.dialect.PostgresqlSqlDialect
- requiresAliasForFromItems() - Method in class org.apache.calcite.sql.SqlDialect
- 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 - Variable in class org.apache.calcite.sql.SqlAggFunction
- 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 - Variable in class org.apache.calcite.sql.SqlAggFunction
- 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 - Variable in class org.apache.calcite.sql.SqlAggFunction
- 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(RelSet, RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- rescaleBigDecimal(BigDecimal, int) - Static method in class org.apache.calcite.util.NumberUtil
- reservedFunctionNames - Variable in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
- reservedWords - Variable in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
- reservedWordsList - Variable in class org.apache.calcite.sql.advise.SqlAdvisor
- reservedWordsSet - Variable in class org.apache.calcite.sql.advise.SqlAdvisor
- reset() - Method in class org.apache.calcite.adapter.cassandra.CassandraEnumerator
- reset() - Method in class org.apache.calcite.adapter.clone.ArrayTable.Content.ArrayEnumerator
- reset() - Method in class org.apache.calcite.adapter.clone.ArrayTable.Content.ObjectEnumerator
- reset() - Method in class org.apache.calcite.adapter.csv.CsvEnumerator
- reset() - Method in class org.apache.calcite.adapter.csv.JsonEnumerator
- reset() - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl.BlockingQueueEnumerator
- reset() - Method in class org.apache.calcite.adapter.file.FileEnumerator
- reset() - Method in class org.apache.calcite.adapter.geode.rel.GeodeEnumerator
- reset() - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleEnumerator
- reset() - Method in class org.apache.calcite.adapter.mongodb.MongoEnumerator
- 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 class org.apache.calcite.linq4j.EnumerableDefaults.CastingEnumerator
- reset() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- reset() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.SkipWhileEnumerator
- reset() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileEnumerator
- reset() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileLongEnumerator
- 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.Linq4j.IterableEnumerator
- reset() - Method in class org.apache.calcite.linq4j.Linq4j.ListEnumerator
- reset() - Method in class org.apache.calcite.linq4j.Linq4j.SingletonEnumerator
- reset() - Method in class org.apache.calcite.linq4j.Linq4j.SingletonNullEnumerator
- 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.rex.RexMultisetUtil.RexCallMultisetOperatorCounter
- reset() - Method in class org.apache.calcite.runtime.ResultSetEnumerable.ResultSetEnumerator
- 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.
- 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.
- residue(RexNode, Range<C>, List<RexNode>, Class<C>) - Method in class org.apache.calcite.rex.RexSimplify
-
Weakens a term so that it checks only what is not implied by predicates.
- resize(int) - Method in class org.apache.calcite.util.Permutation
- resolve() - Method in class org.apache.calcite.sql.validate.AbstractNamespace
- resolve() - Method in class org.apache.calcite.sql.validate.AggregatingSelectScope
- 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.EmptyScope
- 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(List<String>, SqlNameMatcher, boolean, SqlValidatorScope.Resolved) - Method in class org.apache.calcite.sql.validate.WithScope
- resolve(RelDataTypeFactory, String, Collection<CalciteSchema.FunctionEntry>, List<RelDataType>) - Static method in class org.apache.calcite.schema.Schemas
- Resolve(SqlValidatorNamespace, boolean, SqlValidatorScope, SqlValidatorScope.Path, List<String>) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorScope.Resolve
- resolve_(CalciteSchema, List<String>, List<String>, SqlNameMatcher, SqlValidatorScope.Path, SqlValidatorScope.Resolved) - Method in class org.apache.calcite.sql.validate.EmptyScope
- resolveAgg(String) - Method in class org.apache.calcite.materialize.Lattice.Builder
- 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.EmptyScope
- resolveColumn(String, SqlNode) - Method in class org.apache.calcite.sql.validate.ListScope
- resolveColumn(String, SqlNode) - Method in class org.apache.calcite.sql.validate.OrderByScope
- 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.
- resolveColumnByAlias(String) - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Looks up a column in this lattice by alias.
- 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.AggregatingSelectScope
- Resolved(List<SqlNode>, List<SqlNode>, Iterable<ImmutableBitSet>, Map<Integer, Integer>) - Constructor for class org.apache.calcite.sql.validate.AggregatingSelectScope.Resolved
- ResolvedImpl() - Constructor for class org.apache.calcite.sql.validate.SqlValidatorScope.ResolvedImpl
- resolvedNamespace - Variable in class org.apache.calcite.sql.validate.IdentifierNamespace
-
The underlying namespace.
- resolveImpl(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- resolveInNamespace(SqlValidatorNamespace, boolean, List<String>, SqlNameMatcher, SqlValidatorScope.Path, SqlValidatorScope.Resolved) - Method in class org.apache.calcite.sql.validate.DelegatingScope
-
If a record type allows implicit references to fields, recursively looks into the fields.
- resolveMeasure(String, boolean, Object) - Method in class org.apache.calcite.materialize.Lattice.Builder
- resolveQualifiedColumn(String, String) - Method in class org.apache.calcite.materialize.Lattice.Builder
- resolves - Variable in class org.apache.calcite.sql.validate.SqlValidatorScope.ResolvedImpl
- 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.EmptyScope
- 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.
- resolveTable(List<String>, SqlNameMatcher, SqlValidatorScope.Path, SqlValidatorScope.Resolved) - Method in class org.apache.calcite.sql.validate.WithScope
- resolveWindow(SqlNode, SqlValidatorScope, boolean) - 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, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- RESOURCE - Static variable in class org.apache.calcite.util.Static
-
Resources.
- resourceBase - Variable in class org.apache.calcite.adapter.spark.HttpServer
- Resources - Class in org.apache.calcite.runtime
-
Defining wrapper classes around resources that allow the compiler to check whether the resources exist and have the argument types that your code expects.
- Resources() - Constructor for class org.apache.calcite.runtime.Resources
- Resources.BaseMessage - Annotation Type in org.apache.calcite.runtime
-
The message in the default locale.
- Resources.BooleanProp - Class in org.apache.calcite.runtime
-
Boolean property instance.
- Resources.BuiltinMethod - Enum in org.apache.calcite.runtime
- Resources.Default - Annotation Type in org.apache.calcite.runtime
-
Default value of a property.
- Resources.DoubleProp - Class in org.apache.calcite.runtime
-
Double property instance.
- Resources.Element - Class in org.apache.calcite.runtime
-
Element in a resource (either a resource or a property).
- Resources.EmptyPropertyAccessor - Enum in org.apache.calcite.runtime
- Resources.ExInst<T extends java.lang.Exception> - Class in org.apache.calcite.runtime
-
Sub-class of
Resources.Inst
that can throw an exception without caused by. - Resources.ExInstWithCause<T extends java.lang.Exception> - Class in org.apache.calcite.runtime
-
Sub-class of
Resources.Inst
that can throw an exception. - Resources.Inst - Class in org.apache.calcite.runtime
-
Resource instance.
- Resources.IntProp - Class in org.apache.calcite.runtime
-
Integer property instance.
- Resources.MyPropertyResourceBundle - Class in org.apache.calcite.runtime
-
Resource bundle based on properties.
- Resources.NoDefaultValueException - Exception in org.apache.calcite.runtime
-
Thrown when a default value is needed but a property does not have one.
- Resources.Prop - Class in org.apache.calcite.runtime
-
Property instance.
- Resources.PropertiesAccessor - Class in org.apache.calcite.runtime
-
Implementation of
Resources.PropertyAccessor
that reads from aProperties
. - Resources.Property - Annotation Type in org.apache.calcite.runtime
-
Property of a resource.
- Resources.PropertyAccessor - Interface in org.apache.calcite.runtime
-
Means by which a resource can get values of properties, given their name.
- Resources.Resource - Annotation Type in org.apache.calcite.runtime
-
The name of the property in the resource file.
- Resources.ShadowResourceBundle - Class in org.apache.calcite.runtime
-
ShadowResourceBundle
is an abstract base class forResourceBundle
classes which are backed by a properties file. - Resources.StringProp - Class in org.apache.calcite.runtime
-
String property instance.
- Resources.Validation - Enum in org.apache.calcite.runtime
-
Types of validation that can be performed on a resource.
- rest - Variable in class org.apache.calcite.runtime.ConsList
- restClient - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport.HttpFunction
- restClient - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- restClient() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- restrictedClusteringKeys - Variable in class org.apache.calcite.adapter.cassandra.CassandraFilter.Translator
- restructure - Variable in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- restructure(RelDataType) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- restructured - Variable in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- restructureFields(RelDataType) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- result - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- result - Variable in class org.apache.calcite.plan.SubstitutionVisitor.UnifyResult
- result - Variable in class org.apache.calcite.rel.metadata.CachingRelMetadataProvider.CacheEntry
- 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(long) - Method in class org.apache.calcite.interpreter.AggregateNode.LongSum
- result(PhysType, BlockStatement) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- result(PhysType, BlockStatement) - Method in class org.apache.calcite.adapter.spark.SparkRel.Implementor
- result(PhysType, BlockStatement) - Method in class org.apache.calcite.adapter.spark.SparkToEnumerableConverter.SparkImplementorImpl
- result(MutableRel) - Method in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRuleCall
- result(RelNode, Mapping) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
- 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(ElasticsearchJson.SearchHits, ElasticsearchJson.Aggregations, String, long) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Result
-
Constructor for this instance.
- 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(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 - org.apache.calcite.util.BuiltInMethod
- RESULT_SET_ENUMERABLE_OF_PREPARED - org.apache.calcite.util.BuiltInMethod
- RESULT_SET_GET_DATE2 - org.apache.calcite.util.BuiltInMethod
- RESULT_SET_GET_TIME2 - org.apache.calcite.util.BuiltInMethod
- RESULT_SET_GET_TIMESTAMP2 - org.apache.calcite.util.BuiltInMethod
- resultConvention - Variable in class org.apache.calcite.prepare.Prepare
-
Convention via which results should be returned by execution.
- resultCount - Variable in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.CountingSearchResultListener
- resultMethod - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- results - Variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleEnumerator
- results - Variable in class org.apache.calcite.plan.hep.HepRuleCall
- results - Variable in class org.apache.calcite.profile.ProfilerImpl.Run
- results - Variable in class org.apache.calcite.profile.SimpleProfiler.Run
- results - Variable in class org.apache.calcite.rel.rules.ReduceDecimalsRule.DecimalShuttle
- resultSelector - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.LookupResultEnumerable
- resultSelector - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- resultSelector(Function2<TKey, TAccumulate, TResult>) - Method in class org.apache.calcite.adapter.enumerable.SequencedAdderAggregateLambdaFactory
- 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.OrderedAggregateLambdaFactory
- resultSet - Variable in class org.apache.calcite.adapter.jdbc.JdbcUtils.ObjectArrayRowBuilder
- resultSet - Variable in class org.apache.calcite.profile.ProfilerImpl.Run
-
Column ordinals that have ever been placed on
ProfilerImpl.Run.spaceQueue
. - resultSet - Variable in class org.apache.calcite.runtime.ResultSetEnumerable.ResultSetEnumerator
- ResultSetEnumerable<T> - Class in org.apache.calcite.runtime
-
Executes a SQL statement and returns the result as an
Enumerable
. - ResultSetEnumerable(DataSource, String, Function1<ResultSet, Function0<T>>) - Constructor for class org.apache.calcite.runtime.ResultSetEnumerable
- ResultSetEnumerable(DataSource, String, Function1<ResultSet, Function0<T>>, ResultSetEnumerable.PreparedStatementEnricher) - Constructor for class org.apache.calcite.runtime.ResultSetEnumerable
- ResultSetEnumerable.PreparedStatementEnricher - Interface in org.apache.calcite.runtime
-
Consumer for decorating a
PreparedStatement
, that is, setting its parameters. - ResultSetEnumerable.ResultSetEnumerator<T> - Class in org.apache.calcite.runtime
-
Implementation of
Enumerator
that reads from aResultSet
. - ResultSetEnumerator(ResultSet, Function1<ResultSet, Function0<T>>) - Constructor for class org.apache.calcite.runtime.ResultSetEnumerable.ResultSetEnumerator
- 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.runtime.AbstractImmutableList
- 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.
- retrieveCursors() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- Return - 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, 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) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a return statement.
- 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.fun.SqlLeadLagAggFunction
- 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.
- RETURN_TYPE_INFERENCE - Static variable in class org.apache.calcite.sql.fun.SqlTimestampAddFunction
- RETURN_TYPE_INFERENCE - Static variable in class org.apache.calcite.sql.fun.SqlTimestampDiffFunction
-
Creates a SqlTimestampDiffFunction.
- returnAny - Variable in class org.apache.calcite.sql.fun.SqlJsonValueFunction
- 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.EnumerableAggregate.AggContextImpl
- returnsJustFirstInput() - Method in enum org.apache.calcite.sql.SemiJoinType
- 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.EnumerableAggregate.AggContextImpl
- returnTypeInference - Variable in class org.apache.calcite.sql.SqlOperator
-
used to infer the return type of a call to this operator
- ReturnTypes - Class in org.apache.calcite.sql.type
-
A collection of return-type inference strategies.
- ReturnTypes() - Constructor for class org.apache.calcite.sql.type.ReturnTypes
- reverse() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- reverse() - Method in class org.apache.calcite.linq4j.DefaultQueryable
- reverse() - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- reverse() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Inverts the order of the elements in a sequence.
- reverse() - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Inverts the order of the elements in a sequence.
- 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 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(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(Queryable<T>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- reverse(SqlOperator) - Method in class org.apache.calcite.plan.RexImplicationChecker.InputUsageFinder
- reverseDirection(RelFieldCollation.Direction) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.CassandraSortRule
-
Find the reverse of a given collation direction.
- reverseOperatorDirection(SqlOperator) - Static method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- reverseSubstitute(RelBuilder, Holder, List<List<SubstitutionVisitor.Replacement>>, List<RelNode>, int, int) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
- revise(Class<? extends RelNode>, MetadataDef<M>) - Method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
- revise(Class<? extends RelNode>, MetadataDef<M>) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Re-generates the handler for a given kind of metadata, adding support for
class_
if it is not already present. - rewrite(RelNode) - Method in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
-
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
- REWRITE_METHOD_NAME - Static variable in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
- rewriteAggCalls(List<AggregateCall>, List<Integer>, Map<Integer, Integer>) - Static method in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
- rewriteCall(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.DecimalShuttle
-
Rewrites a call, if required, or returns the original call
- 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.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
- rewriteCalls - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- rewriteExists(RexSubQuery, Set<CorrelationId>, RelOptUtil.Logic, RelBuilder) - Method in class org.apache.calcite.rel.rules.SubQueryRemoveRule
-
Rewrites an EXISTS RexSubQuery into a
Join
. - rewriteExpression(RexBuilder, RelMetadataQuery, RelNode, RelNode, List<RexNode>, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, AbstractMaterializedViewRule.EquivalenceClasses, boolean, RexNode) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
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>, AbstractMaterializedViewRule.EquivalenceClasses, boolean, List<RexNode>) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
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
- rewriteIn(RexSubQuery, Set<CorrelationId>, RelOptUtil.Logic, RelBuilder, int) - Method in class org.apache.calcite.rel.rules.SubQueryRemoveRule
-
Rewrites an IN RexSubQuery into a
Join
. - rewriteMerge(SqlMerge) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- rewriteQuery(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, RexNode, RexNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, AbstractMaterializedViewRule.EquivalenceClasses, AbstractMaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewAggregateRule
- rewriteQuery(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, RexNode, RexNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, AbstractMaterializedViewRule.EquivalenceClasses, AbstractMaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewJoinRule
- rewriteQuery(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, RexNode, RexNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, AbstractMaterializedViewRule.EquivalenceClasses, AbstractMaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
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(LogicalCalc) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalCorrelate) - 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(LogicalTableFunctionScan) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rewriteRel(LogicalTableModify) - 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
- RewriteRelVisitor() - Constructor for class org.apache.calcite.sql2rel.RelStructuredTypeFlattener.RewriteRelVisitor
- RewriteRexShuttle() - Constructor for class org.apache.calcite.sql2rel.RelStructuredTypeFlattener.RewriteRexShuttle
- rewriteScalarQuery(RexSubQuery, Set<CorrelationId>, RelBuilder, int, int) - Method in class org.apache.calcite.rel.rules.SubQueryRemoveRule
-
Rewrites a scalar sub-query into an
Aggregate
. - rewriteSingleValueExpr(SqlNode) - Method in class org.apache.calcite.sql.dialect.HsqldbSqlDialect
- rewriteSingleValueExpr(SqlNode) - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- rewriteSingleValueExpr(SqlNode) - Method in class org.apache.calcite.sql.SqlDialect
-
Rewrite SINGLE_VALUE into expression based on database variants E.g.
- rewriteSome(RexSubQuery, RelBuilder) - Method in class org.apache.calcite.rel.rules.SubQueryRemoveRule
-
Rewrites a SOME sub-query into a
Join
. - rewriteUpdateToMerge(SqlUpdate, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- rewriteUsingGroupingSets(RelOptRuleCall, Aggregate) - Method in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
- rewriteView(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, AbstractMaterializedViewRule.MatchModality, boolean, RelNode, Project, RelNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, AbstractMaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewAggregateRule
- rewriteView(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, AbstractMaterializedViewRule.MatchModality, boolean, RelNode, Project, RelNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, AbstractMaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewJoinRule
- rewriteView(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, AbstractMaterializedViewRule.MatchModality, boolean, RelNode, Project, RelNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, AbstractMaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
Rewrites the query using the given view query.
- RexAction - Interface in org.apache.calcite.rex
-
A
RexAction
is called when aRexPattern
finds a match. - 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.
- RexAnalyzer.VariableCollector - Class in org.apache.calcite.rex
-
Collects the variables (or other bindable sites) in an expression, and counts features (such as CAST) that
RexInterpreter
cannot handle. - 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. - rexBuilder - Variable in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.NotLikeConverter
- rexBuilder - Variable in class org.apache.calcite.adapter.enumerable.JavaRelImplementor
- rexBuilder - Variable in class org.apache.calcite.interpreter.JaninoRexCompiler
- rexBuilder - Variable in class org.apache.calcite.plan.RelOptCluster
- 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.prepare.CalcitePrepareImpl.EmptyScalarTranslator
- rexBuilder - Variable in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- rexBuilder - Variable in class org.apache.calcite.rel.rules.FilterRemoveIsNotDistinctFromRule.RemoveIsNotDistinctFromRexShuttle
- rexBuilder - Variable in class org.apache.calcite.rel.rules.JoinCommuteRule.VariableReplacer
- rexBuilder - Variable in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
- rexBuilder - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Rex builder used to create new expressions.
- rexBuilder - Variable in class org.apache.calcite.rex.RexProgramBuilder
- rexBuilder - Variable in class org.apache.calcite.rex.RexSimplify
- rexBuilder - Variable in class org.apache.calcite.rex.RexTransformer
- rexBuilder - Variable in class org.apache.calcite.rex.RexUtil.CnfHelper
- rexBuilder - Variable in class org.apache.calcite.rex.RexUtil.DnfHelper
- rexBuilder - Variable in class org.apache.calcite.rex.RexUtil.FixNullabilityShuttle
- rexBuilder - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationRexShuttle
- rexBuilder - Variable in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- rexBuilder - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- 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.core.TableFunctionScan
- 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
- 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
- RexCallBinding.RexCastCallBinding - Class in org.apache.calcite.rex
-
To be compatible with
SqlCall
, CAST needs to pretend that it has two arguments, the second of which is the target type. - RexCallMultisetOperatorCounter() - Constructor for class org.apache.calcite.rex.RexMultisetUtil.RexCallMultisetOperatorCounter
- RexCastCallBinding(RelDataTypeFactory, SqlOperator, List<? extends RexNode>, RelDataType, List<RelCollation>) - Constructor for class org.apache.calcite.rex.RexCallBinding.RexCastCallBinding
- 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.
- RexCopier - Class in org.apache.calcite.rex
-
Shuttle which creates a deep copy of a Rex expression.
- RexCopier(RexBuilder) - Constructor for class org.apache.calcite.rex.RexCopier
-
Creates a RexCopier.
- rexCorrelVariable - Variable in class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.RexFieldAccessReplacer
- RexCorrelVariable - Class in org.apache.calcite.rex
-
Reference to the current row of a correlating relational expression.
- RexCorrelVariable(CorrelationId, RelDataType) - Constructor for class org.apache.calcite.rex.RexCorrelVariable
- rexCorrelVariableToReplace - Variable in class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.RexFieldAccessReplacer
- 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
- RexExecutorImpl.DataContextInputGetter - Class in org.apache.calcite.rex
-
Implementation of
RexToLixTranslator.InputGetter
that reads the values of input fields by calling
.DataContext.get(java.lang.String)
("inputRecord") - RexExpander(RexBuilder) - Constructor for class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Constructs a RexExpander
- RexFieldAccess - Class in org.apache.calcite.rex
-
Access to a field of a row-expression.
- RexFieldAccess(RexNode, RelDataTypeField) - Constructor for class org.apache.calcite.rex.RexFieldAccess
- 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
- RexFieldCollation.Initializer - Class in org.apache.calcite.rex
-
Helper, used during initialization, that builds a canonizing map from sets of
SqlKind
to immutable sets ofSqlKind
. - 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, RexExecutorImpl, RelDataType) - Constructor for class org.apache.calcite.plan.RexImplicationChecker
- RexImplicationChecker.InputRefUsage<T1,T2> - Class in org.apache.calcite.plan
-
Usage of a
RexInputRef
in an expression. - RexImplicationChecker.InputUsageFinder - Class in org.apache.calcite.plan
-
Visitor that builds a usage map of inputs used by an expression.
- RexImpTable - Class in org.apache.calcite.adapter.enumerable
-
Contains implementations of Rex operators as Java code.
- RexImpTable() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable
- RexImpTable.BinaryImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for binary operators.
- RexImpTable.CaseImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the SQL
CASE
operator. - RexImpTable.CastImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the SQL
CAST
operator. - RexImpTable.CastOptimizedImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the SQL
CAST
function that optimizes if, say, the argument is already of the desired type. - RexImpTable.CoalesceImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the SQL
COALESCE
operator. - RexImpTable.CollectImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
COLLECT
aggregate function. - RexImpTable.CountImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
COUNT
aggregate function. - RexImpTable.CountWinImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
COUNT
windowed aggregate function. - RexImpTable.DatetimeArithmeticImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for various datetime arithmetic.
- RexImpTable.DenseRankImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
DENSE_RANK
windowed aggregate function. - RexImpTable.ExtractImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
EXTRACT(unit FROM datetime)
function. - RexImpTable.FirstLastValueImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
FIRST_VALUE
andLAST_VALUE
windowed aggregate functions. - RexImpTable.FirstValueImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
FIRST_VALUE
windowed aggregate function. - RexImpTable.FloorImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
FLOOR
andCEIL
functions. - RexImpTable.FusionImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
FUSION
aggregate function. - RexImpTable.GroupingImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
GROUPING
aggregate function. - RexImpTable.IsXxxImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implements "IS XXX" operations such as "IS NULL" or "IS NOT TRUE".
- RexImpTable.ItemImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
ITEM
SQL operator. - RexImpTable.JsonArrayAggImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
JSON_ARRAYAGG
aggregate function. - RexImpTable.JsonObjectAggImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
JSON_OBJECTAGG
aggregate function. - RexImpTable.LagImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
LAG
windowed aggregate function. - RexImpTable.LastValueImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
LAST_VALUE
windowed aggregate function. - RexImpTable.LeadImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
LEAD
windowed aggregate function. - RexImpTable.LeadLagImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
LEAD
andLAG
windowed aggregate functions. - RexImpTable.MethodImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for a function that generates calls to a given method.
- RexImpTable.MethodNameImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for SQL functions that generates calls to a given method name.
- RexImpTable.MinMaxImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
MIN
andMAX
aggregate functions. - RexImpTable.NotImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
NOT
operator. - RexImpTable.NthValueImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
NTH_VALUE
windowed aggregate function. - RexImpTable.NtileImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
NTILE
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.RankImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
RANK
windowed aggregate function. - RexImpTable.ReinterpretImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
REINTERPRET
internal SQL operator. - RexImpTable.RowNumberImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
ROW_NUMBER
windowed aggregate function. - RexImpTable.SingleValueImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
SINGLE_VALUE
aggregate function. - RexImpTable.SumImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
SUM
windowed aggregate function. - RexImpTable.SystemFunctionImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for SQL system functions.
- RexImpTable.TrimImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for the
TRIM
function. - RexImpTable.UnaryImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for unary operators.
- RexImpTable.UserDefinedAggReflectiveImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for user-defined aggregate functions.
- RexImpTable.ValueConstructorImplementor - Class in org.apache.calcite.adapter.enumerable
-
Implementor for a value-constructor.
- 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
- RexInputConverter(RexBuilder, List<RelDataTypeField>, 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. - RexInterpreter(Map<RexNode, Comparable>) - Constructor for class org.apache.calcite.rex.RexInterpreter
-
Creates an interpreter.
- RexInterpreter.Truthy - Enum in org.apache.calcite.rex
-
An enum that wraps boolean and unknown values and makes them comparable.
- RexLiteral - Class in org.apache.calcite.rex
-
Constant value in a row-expression.
- RexLiteral(Comparable, RelDataType, SqlTypeName) - Constructor for class org.apache.calcite.rex.RexLiteral
-
Creates a
RexLiteral
. - RexLocalRef - Class in org.apache.calcite.rex
-
Local variable.
- RexLocalRef(int, RelDataType) - Constructor for class org.apache.calcite.rex.RexLocalRef
-
Creates a local variable.
- RexMRAggCall(SqlAggFunction, RelDataType, List<RexNode>, int) - Constructor for class org.apache.calcite.rel.core.Match.RexMRAggCall
- RexMultisetUtil - Class in org.apache.calcite.rex
-
Utility class for various methods related to multisets.
- RexMultisetUtil() - Constructor for class org.apache.calcite.rex.RexMultisetUtil
- RexMultisetUtil.RexCallMultisetOperatorCounter - Class in org.apache.calcite.rex
-
A RexShuttle that traverse all RexNode and counts total number of RexCalls traversed and number of multiset calls traversed.
- RexNode - Class in org.apache.calcite.rex
-
Row expression.
- RexNode() - Constructor for class org.apache.calcite.rex.RexNode
- RexOver - Class in org.apache.calcite.rex
-
Call to an aggregate function over a window.
- RexOver(RelDataType, SqlAggFunction, List<RexNode>, RexWindow, boolean) - Constructor for class org.apache.calcite.rex.RexOver
-
Creates a RexOver.
- RexOver.Finder - Class in org.apache.calcite.rex
- RexOver.OverFound - Exception in org.apache.calcite.rex
-
Exception thrown when an OVER is found.
- RexPattern - Interface in org.apache.calcite.rex
-
A
RexPattern
represents an expression with holes in it. - RexPatternFieldRef - Class in org.apache.calcite.rex
-
Variable which 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, ImmutableList<RelDataTypeField>) - Constructor for class org.apache.calcite.rex.RexPermuteInputsShuttle
- 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.
- RexProgram.Checker - Class in org.apache.calcite.rex
-
Visitor which walks over a program and checks validity.
- RexProgram.ConstantFinder - Class in org.apache.calcite.rex
-
Walks over an expression and determines whether it is constant.
- RexProgram.ExpansionShuttle - Class in org.apache.calcite.rex
-
A RexShuttle used in the implementation of
RexProgram.expandLocalRef(org.apache.calcite.rex.RexLocalRef)
. - RexProgram.Marshaller - Class in org.apache.calcite.rex
-
Given an expression in a program, creates a clone of the expression with sub-expressions (represented by
RexLocalRef
s) fully expanded. - RexProgram.ReferenceCounter - Class in org.apache.calcite.rex
-
Visitor which marks which expressions are used.
- 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.
- RexProgramBuilder(RelDataType, RexBuilder, RexSimplify) - Constructor for class org.apache.calcite.rex.RexProgramBuilder
-
Creates a program-builder.
- RexProgramBuilder(RexBuilder, RelDataType, List<RexNode>, Iterable<? extends RexNode>, RexNode, RelDataType, boolean, RexSimplify) - Constructor for class org.apache.calcite.rex.RexProgramBuilder
-
Creates a program builder with the same contents as a program.
- RexProgramBuilder.RegisterInputShuttle - Class in org.apache.calcite.rex
-
Shuttle which walks over an expression, registering each sub-expression.
- RexProgramBuilder.RegisterMidputShuttle - Class in org.apache.calcite.rex
-
Extension to
RexProgramBuilder.RegisterInputShuttle
which allows expressions to be in terms of inputs or previous common sub-expressions. - RexProgramBuilder.RegisterOutputShuttle - Class in org.apache.calcite.rex
-
Shuttle which walks over an expression, registering each sub-expression.
- RexProgramBuilder.RegisterShuttle - Class in org.apache.calcite.rex
-
Shuttle that visits a tree of
RexNode
and registers them in a program. - RexProgramBuilder.UpdateRefShuttle - Class in org.apache.calcite.rex
-
Shuttle which rewires
RexLocalRef
using a list of updated references - RexRangeRef - Class in org.apache.calcite.rex
-
Reference to a range of columns.
- RexRangeRef(RelDataType, int) - Constructor for class org.apache.calcite.rex.RexRangeRef
-
Creates a range reference.
- rexRefs - Variable in class org.apache.calcite.rel.rules.PushProjector.InputSpecialOpFinder
- RexReplacer(Map<RexInputRef, RexNode>) - Constructor for class org.apache.calcite.rel.metadata.RelMdExpressionLineage.RexReplacer
- RexReplacer(RexSimplify, RexUnknownAs, List<RexNode>, List<RexNode>, List<Boolean>) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.RexReplacer
- RexShiftShuttle(int) - Constructor for class org.apache.calcite.rex.RexUtil.RexShiftShuttle
- 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.
- RexSimplify(RexBuilder, RelOptPredicateList, RexUnknownAs, boolean, boolean, RexExecutor) - Constructor for class org.apache.calcite.rex.RexSimplify
-
Internal constructor.
- RexSimplify.CaseBranch - Class in org.apache.calcite.rex
-
Object to describe a Case branch
- RexSimplify.Comparison - Class in org.apache.calcite.rex
-
Comparison between a
RexInputRef
orRexFieldAccess
and a literal. - RexSimplify.IsPredicate - Class in org.apache.calcite.rex
-
Represents an IS Predicate.
- RexSimplify.Predicate - Interface in org.apache.calcite.rex
-
Marker interface for predicates (expressions that evaluate to BOOLEAN).
- RexSimplify.SafeRexVisitor - Enum in org.apache.calcite.rex
-
Decides whether it is safe to flatten the given case part into AND/ORs
- RexSlot - Class in org.apache.calcite.rex
-
Abstract base class for
RexInputRef
andRexLocalRef
. - 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
- RexSqlStandardConvertletTable.EquivConvertlet - Class in org.apache.calcite.rex
- RexSubQuery - Class in org.apache.calcite.rex
-
Scalar expression that represents an IN, EXISTS or scalar sub-query.
- RexSubQuery(RelDataType, SqlOperator, ImmutableList<RexNode>, RelNode) - Constructor for class org.apache.calcite.rex.RexSubQuery
- RexTableInputRef - Class in org.apache.calcite.rex
-
Variable which references a column of a table occurrence in a relational plan.
- RexTableInputRef(RexTableInputRef.RelTableRef, int, RelDataType) - Constructor for class org.apache.calcite.rex.RexTableInputRef
- RexTableInputRef.RelTableRef - Class in org.apache.calcite.rex
-
Identifies uniquely a table by its qualified name and its entity number (occurrence)
- RexToCassandraTranslator(JavaTypeFactory, List<String>) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraRules.RexToCassandraTranslator
- RexToElasticsearchTranslator(JavaTypeFactory, List<String>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.RexToElasticsearchTranslator
- RexToGeodeTranslator(List<String>) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeRules.RexToGeodeTranslator
- RexToLixTranslator - Class in org.apache.calcite.adapter.enumerable
-
Translates
REX expressions
tolinq4j expressions
. - RexToLixTranslator(RexProgram, JavaTypeFactory, Expression, RexToLixTranslator.InputGetter, BlockBuilder, Map<? extends RexNode, Boolean>, RexBuilder, SqlConformance, RexToLixTranslator, Function1<String, RexToLixTranslator.InputGetter>) - Constructor for class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- RexToLixTranslator.AlwaysNull - Exception in org.apache.calcite.adapter.enumerable
-
Thrown in the unusual (but not erroneous) situation where the expression we are translating is the null literal but we have already checked that it is not null.
- 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)
. - RexToMongoTranslator(JavaTypeFactory, List<String>) - Constructor for class org.apache.calcite.adapter.mongodb.MongoRules.RexToMongoTranslator
- 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
- RexUnknownAs - Enum in org.apache.calcite.rex
-
Policy for whether a simplified expression may instead return another value.
- RexUnknownAs() - Constructor for enum org.apache.calcite.rex.RexUnknownAs
- RexUtil - Class in org.apache.calcite.rex
-
Utility methods concerning row-expressions.
- RexUtil() - Constructor for class org.apache.calcite.rex.RexUtil
- RexUtil.CnfHelper - Class in org.apache.calcite.rex
- RexUtil.CnfHelper.OverflowError - Exception in org.apache.calcite.rex
-
Exception to catch when we pass the limit.
- RexUtil.ConstantFinder - Class in org.apache.calcite.rex
-
Walks over an expression and determines whether it is constant.
- RexUtil.CorrelationFinder - Class in org.apache.calcite.rex
-
Visitor that throws
Util.FoundOne
if applied to an expression that contains aRexCorrelVariable
. - RexUtil.DnfHelper - Class in org.apache.calcite.rex
- RexUtil.ExpressionNormalizer - Class in org.apache.calcite.rex
-
Walks over expressions and builds a bank of common sub-expressions.
- RexUtil.ExpressionNormalizer.SubExprExistsException - Exception in org.apache.calcite.rex
-
Thrown if there is a sub-expression.
- 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.ForwardRefFinder - Class in org.apache.calcite.rex
-
Walks over an expression and throws an exception if it finds an
RexInputRef
with an ordinal beyond the number of fields in the input row type, or aRexLocalRef
with ordinal greater than that set usingRexUtil.ForwardRefFinder.setLimit(int)
. - RexUtil.ForwardRefFinder.IllegalForwardRefException - Exception in org.apache.calcite.rex
-
Thrown to abort a visit when we find an illegal forward reference.
- RexUtil.RexShiftShuttle - Class in org.apache.calcite.rex
-
Shuttle that adds
offset
to eachRexInputRef
in an expression. - 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 - Variable in class org.apache.calcite.rel.rules.ProjectCorrelateTransposeRule.RelNodesExprsHandler
- rexVisitor - Variable in class org.apache.calcite.sql2rel.CorrelationReferenceFinder
- rexVisitor(RelNode) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
- 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
-
Creates a RexWinAggCall.
- RexWindow - Class in org.apache.calcite.rex
-
Specification of the window of rows over which a
RexOver
windowed aggregate is evaluated. - RexWindow(List<RexNode>, List<RexFieldCollation>, RexWindowBound, RexWindowBound, boolean) - Constructor for class org.apache.calcite.rex.RexWindow
-
Creates a window.
- 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
- RexWindowBound.RexWindowBoundBounded - Class in org.apache.calcite.rex
-
Implements XX PRECEDING/FOLLOWING bound where XX is not UNBOUNDED.
- RexWindowBound.RexWindowBoundCurrentRow - Class in org.apache.calcite.rex
-
Implements CURRENT ROW bound.
- RexWindowBound.RexWindowBoundUnbounded - Class in org.apache.calcite.rex
-
Implements UNBOUNDED PRECEDING/FOLLOWING bound.
- RexWindowBoundBounded(RexNode) - Constructor for class org.apache.calcite.rex.RexWindowBound.RexWindowBoundBounded
- RexWindowBoundBounded(SqlKind, RexNode) - Constructor for class org.apache.calcite.rex.RexWindowBound.RexWindowBoundBounded
- RexWindowBoundCurrentRow() - Constructor for class org.apache.calcite.rex.RexWindowBound.RexWindowBoundCurrentRow
- RexWindowBoundUnbounded(SqlNode) - Constructor for class org.apache.calcite.rex.RexWindowBound.RexWindowBoundUnbounded
- right - Variable in class org.apache.calcite.rel.BiRel
- right - Variable in class org.apache.calcite.rel.mutable.MutableBiRel
- right - Variable in class org.apache.calcite.rel.rules.JoinPushThroughJoinRule
- right - Variable in class org.apache.calcite.rel.rules.LoptJoinTree.Node
- right - Variable in enum org.apache.calcite.sql.fun.SqlTrimFunction.Flag
- right - Variable in class org.apache.calcite.sql.SqlJoin
- right - Variable in class org.apache.calcite.tools.RelBuilder.Shifter
- right - Variable in class org.apache.calcite.util.Pair
- right - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Token
- right() - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- right(Iterable<? extends Map.Entry<L, R>>) - Static method in class org.apache.calcite.util.Pair
-
Returns an iterable over the right slice of an iterable.
- right(List<? extends Map.Entry<K, 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 - org.apache.calcite.example.maze.Maze.Direction
- RIGHT - org.apache.calcite.plan.RelOptUtil.Side
- RIGHT - org.apache.calcite.rel.core.JoinRelType
- RIGHT - org.apache.calcite.sql.JoinType
-
Right outer join.
- 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 class org.apache.calcite.util.mapping.IntPair
-
Function that returns the right (target) side of a pair.
- RIGHT_PROJECT - Static variable in class org.apache.calcite.rel.rules.JoinProjectTransposeRule
- RIGHT_PROJECT_INCLUDE_OUTER - Static variable in class org.apache.calcite.rel.rules.JoinProjectTransposeRule
- RIGHT_UNION - Static variable in class org.apache.calcite.rel.rules.JoinUnionTransposeRule
- rightBitmap - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Bitmap containing the fields in the right hand side of a join, in the case where the projection is being pushed past a join.
- rightChildPredicates - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- rightContext - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.JoinContext
- rightDestFields - Variable in class org.apache.calcite.plan.RelOptUtil.RexInputConverter
- rightEnumerator - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- rightFactor - Variable in class org.apache.calcite.rel.rules.LoptMultiJoin.RemovableSelfJoin
-
The right factor in a removable self-join, namely the factor that will be removed
- rightFactor - Variable in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.JoinVertex
- rightFields - Variable in class org.apache.calcite.rel.rules.JoinCommuteRule.VariableReplacer
- rightFields - Variable in class org.apache.calcite.rel.rules.PushProjector.InputSpecialOpFinder
- rightFieldsBitSet - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- rightInferredPredicates - Variable in class org.apache.calcite.plan.RelOptPredicateList
-
Predicates that were inferred from the left input.
- rightIterator - Variable in class org.apache.calcite.util.Pair.ZipIterator
- RightIterator(Iterator<? extends Map.Entry<L, R>>) - Constructor for class org.apache.calcite.util.Pair.RightIterator
- rightKeys - Variable in class org.apache.calcite.rel.core.EquiJoin
- rightKeys - Variable in class org.apache.calcite.rel.core.JoinInfo
- rightKeys - Variable in class org.apache.calcite.rel.mutable.MutableSemiJoin
- rightPrec - Variable in class org.apache.calcite.sql.SqlOperator
-
The precedence with which this operator binds to the expression to the right.
- rightPrec(int, boolean) - Static method in class org.apache.calcite.sql.SqlOperator
- rightPreserveExprs - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Expressions referenced in the projection/filter that should be preserved, corresponding to expressions on the right hand side of the join, if the projection is being pushed past a join.
- rights - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- 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 - 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise right-shift compound assignment operation, such as (a >>= b).
- rightSource - Variable in class org.apache.calcite.interpreter.JoinNode
- rightTrim(String, char) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Deprecated.
- rnd - Variable in class org.apache.calcite.benchmarks.StatementTest.HrConnection
- rollback(Meta.ConnectionHandle) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- ROLLBACK - org.apache.calcite.sql.SqlKind
-
ROLLBACK
session control statement. - 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.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.
- 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(int, RelBuilder, AggregateCall, TileKey) - Static method in class org.apache.calcite.rel.rules.AggregateStarTableRule
- ROLLUP - org.apache.calcite.rel.core.Aggregate.Group
- ROLLUP - 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
. - root - Variable in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- 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.hep.HepPlanner
- root - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
- root - Variable in class org.apache.calcite.prepare.PlannerImpl
- root - Variable in class org.apache.calcite.prepare.Prepare.PreparedExplain
- root - Variable in class org.apache.calcite.rel.mutable.MutableRelVisitor
- root - Variable in class org.apache.calcite.rel.RelVisitor
- root - Variable in class org.apache.calcite.rex.RexTransformer
- root - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.ExtendedExpander
- root - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.OrderExpressionExpander
- root - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- root() - Method in class org.apache.calcite.jdbc.CalciteSchema
- ROOT - Static variable in interface org.apache.calcite.DataContext
- rootNode - Variable in class org.apache.calcite.materialize.Lattice.Builder
- rootNode - Variable in class org.apache.calcite.materialize.Lattice
- rootRel - Variable in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
- rootRel - Variable in class org.apache.calcite.interpreter.Interpreter
- rootRel - Variable in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- rootSchema - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl.ContextImpl
- rootSchema - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl.DataContextImpl
- rootSchema - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl
- rootSchema - Variable in class org.apache.calcite.jdbc.CalcitePrepare.CalciteSignature
- rootSchema - Variable in class org.apache.calcite.materialize.Lattice.Builder
- rootSchema - Variable in class org.apache.calcite.materialize.Lattice
- rootSchema - Variable in class org.apache.calcite.materialize.MaterializationActor.Materialization
- rootSchema - Variable in class org.apache.calcite.prepare.CalciteCatalogReader
- rootSchema - Variable in class org.apache.calcite.schema.Schemas.DummyDataContext
- rootSchema(SchemaPlus) - Static method in class org.apache.calcite.prepare.PlannerImpl
- RootSchema() - Constructor for class org.apache.calcite.jdbc.CalciteConnectionImpl.RootSchema
- 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
- 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(Calendar, TimeUnitRange, boolean) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
-
Returns a copy of a calendar, optionally rounded up to the next time unit.
- ROUND - org.apache.calcite.runtime.GeoFunctions.CapStyle
- ROUND - org.apache.calcite.runtime.GeoFunctions.JoinStyle
- ROUND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ROUND_INT - org.apache.calcite.util.BuiltInMethod
- ROUND_LONG - org.apache.calcite.util.BuiltInMethod
- ROUND_ROBIN_DISTRIBUTED - 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.
- ROUND3 - Static variable in class org.apache.calcite.profile.Profiler.Distribution
- ROUND5 - Static variable in class org.apache.calcite.profile.Profiler.Distribution
- row - Variable in class org.apache.calcite.adapter.enumerable.EnumerableWindow.WindowRelInputGetter
- row(Maze.CellContent, StringBuilder, StringBuilder, int) - Method in class org.apache.calcite.example.maze.Maze
-
Returns a pair of strings representing a row of the maze.
- Row - Class in org.apache.calcite.interpreter
-
Row.
- Row(Object[]) - Constructor for class org.apache.calcite.interpreter.Row
-
Creates a Row.
- ROW - org.apache.calcite.adapter.enumerable.JavaRowFormat
-
See
Row
- ROW - org.apache.calcite.sql.SqlKind
-
The row-constructor function.
- ROW - org.apache.calcite.sql.type.SqlTypeName
- ROW - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ROW_AS_COPY - org.apache.calcite.util.BuiltInMethod
- ROW_COUNT - org.apache.calcite.util.BuiltInMethod
- ROW_NUMBER - 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 - org.apache.calcite.util.BuiltInMethod
- Row.RowBuilder - Class in org.apache.calcite.interpreter
-
Utility class to build row objects.
- rowBuilder - Variable in class org.apache.calcite.runtime.ResultSetEnumerable.ResultSetEnumerator
- RowBuilder(int) - Constructor for class org.apache.calcite.interpreter.Row.RowBuilder
- rowBuilderFactory - Variable in class org.apache.calcite.runtime.ResultSetEnumerable
- rowConverter - Variable in class org.apache.calcite.adapter.csv.CsvEnumerator
- RowConverter() - Constructor for class org.apache.calcite.adapter.csv.CsvEnumerator.RowConverter
- rowCount - Variable in class org.apache.calcite.adapter.clone.ArrayTable.Content.ArrayEnumerator
- rowCount - Variable in class org.apache.calcite.adapter.clone.ArrayTable.Content.ObjectEnumerator
- rowCount - Variable in class org.apache.calcite.plan.volcano.VolcanoCost
- rowCount - Variable in class org.apache.calcite.prepare.RelOptTableImpl
-
Estimate for the row count, or null.
- rowCount - Variable in class org.apache.calcite.profile.Profiler.Profile
- rowCount - Variable in class org.apache.calcite.profile.Profiler.RowCount
- rowCount - Variable in class org.apache.calcite.profile.ProfilerImpl.Run
- RowCount(int) - Constructor for class org.apache.calcite.profile.Profiler.RowCount
- rowCountEstimate - Variable in class org.apache.calcite.materialize.Lattice.Builder
- 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).
- rowCountHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- rowEnumerable - Variable in class org.apache.calcite.interpreter.Interpreter.NodeInfo
- 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.
- rowIterator - Variable in class org.apache.calcite.adapter.file.FileReader.FileReaderIterator
- RowKey(List<ElasticsearchJson.Bucket>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.RowKey
- RowKey(Map<String, Object>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.RowKey
- rowLength - Variable in class org.apache.calcite.interpreter.AggregateNode.ScalarAccumulatorDef
- rowMustBeNonNegativeIntegral() - Method in interface org.apache.calcite.runtime.CalciteResource
- RowNumberImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.RowNumberImplementor
- rowPhysType - Variable in class org.apache.calcite.adapter.enumerable.EnumerableWindow.WindowRelInputGetter
- rows - Variable in class org.apache.calcite.interpreter.ValuesNode
- rows - Variable in class org.apache.calcite.sql.ddl.SqlCreateTable.MutableArrayTable
- rowsPerMatch - Variable in class org.apache.calcite.sql.SqlMatchRecognize
- RowsPerMatchOption(String) - Constructor for enum org.apache.calcite.sql.SqlMatchRecognize.RowsPerMatchOption
- ROWTIME_COLUMN_NAME - Static variable in class org.apache.calcite.adapter.csv.CsvSchemaFactory
-
Name of the column that is implicitly created in a CSV stream table to hold the data arrival time.
- 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.adapter.cassandra.CassandraFilter.Translator
- rowType - Variable in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- rowType - Variable in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
- rowType - Variable in class org.apache.calcite.adapter.geode.rel.GeodeTable
- 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.materialize.MaterializationActor.Materialization
- rowType - Variable in class org.apache.calcite.plan.RelOptAbstractTable
- rowType - Variable in class org.apache.calcite.plan.RexImplicationChecker
- rowType - Variable in class org.apache.calcite.prepare.Prepare.PreparedExplain
- rowType - Variable in class org.apache.calcite.prepare.Prepare.PreparedResultImpl
- rowType - Variable in class org.apache.calcite.prepare.RelOptTableImpl
- 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.rel.rules.MultiJoin
- rowType - Variable in class org.apache.calcite.rex.RexExecutorImpl.DataContextInputGetter
- rowType - Variable in class org.apache.calcite.sql.validate.AbstractNamespace
-
Type of the output row, which comprises the name and type of each output column.
- rowType - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.Permute
- rowType - Variable in class org.apache.calcite.sql.validate.SqlValidatorScope.Step
- 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.
- rowWidthCost(RelNode) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Computes a cost for a join tree based on the row widths of the inputs into the join.
- rpad(String, int) - Static method in class org.apache.calcite.util.Util
-
Deprecated.Use
Spaces.padRight(String, int)
- RPAREN - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
-
right parenthesis
- rprec - Variable in enum org.apache.calcite.linq4j.tree.ExpressionType
- 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 - org.apache.calcite.sql.SqlKind
-
The "RTRIM" function (Oracle).
- RTRIM - org.apache.calcite.util.BuiltInMethod
- RTRIM - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
The "RTRIM(string)" function.
- rule - Variable in class org.apache.calcite.plan.hep.HepInstruction.RuleInstance
-
Explicitly specified rule, or rule looked up by planner from description.
- rule - Variable in class org.apache.calcite.plan.RelOptRuleCall
- rule - Variable in class org.apache.calcite.plan.RelOptRuleOperand
- rule - Variable in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRuleCall
- rule - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner.RuleProvenance
- rule - Variable in class org.apache.calcite.sql.type.SqlTypeTransformCascade
- RULE_LOGGER - Static variable in class org.apache.calcite.rel.rules.CalcRelSplitter
- 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.
- RuleAttemptedEvent(Object, RelNode, RelOptRuleCall, boolean) - Constructor for class org.apache.calcite.plan.RelOptListener.RuleAttemptedEvent
- ruleCall - Variable in class org.apache.calcite.plan.RelOptListener.RuleEvent
- ruleCallStack - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
- ruleClass - Variable in class org.apache.calcite.plan.hep.HepInstruction.RuleClass
- RuleClass() - Constructor for class org.apache.calcite.plan.hep.HepInstruction.RuleClass
- RuleCollection() - Constructor for class org.apache.calcite.plan.hep.HepInstruction.RuleCollection
- ruleDescExclusionFilter - Variable in class org.apache.calcite.plan.AbstractRelOptPlanner
- ruleDescription - Variable in class org.apache.calcite.plan.hep.HepInstruction.RuleInstance
-
Description to look for, or null if rule specified explicitly.
- RuleEvent(Object, RelNode, RelOptRuleCall) - Constructor for class org.apache.calcite.plan.RelOptListener.RuleEvent
- RuleInstance() - Constructor for class org.apache.calcite.plan.hep.HepInstruction.RuleInstance
- ruleMap - Variable in class org.apache.calcite.plan.SubstitutionVisitor
- RuleMatchImportanceComparator() - Constructor for class org.apache.calcite.plan.volcano.RuleQueue.RuleMatchImportanceComparator
- ruleNames - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Maps rule classes to their name, to ensure that the names are unique and conform to rules.
- 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).
- RuleProvenance(RelOptRule, ImmutableList<RelNode>, int) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlanner.RuleProvenance
- ruleQueue - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Holds rule calls waiting to be fired.
- RuleQueue - Class in org.apache.calcite.plan.volcano
-
Priority queue of relexps whose rules have not been called, and rule-matches which have not yet been acted upon.
- RuleQueue(VolcanoPlanner) - Constructor for class org.apache.calcite.plan.volcano.RuleQueue
- RuleQueue.PhaseMatchList - Class in org.apache.calcite.plan.volcano
-
PhaseMatchList represents a set of
rule-matches
for a particularphase of the planner's execution
. - RuleQueue.RelImportanceComparator - Class in org.apache.calcite.plan.volcano
-
Compares
RelNode
objects according to their cached 'importance'. - RuleQueue.RuleMatchImportanceComparator - Class in org.apache.calcite.plan.volcano
-
Compares
VolcanoRuleMatch
objects according to their importance. - rules - Variable in class org.apache.calcite.plan.hep.HepInstruction.RuleCollection
-
Collection of rules to apply.
- rules - Variable in class org.apache.calcite.plan.SubstitutionVisitor
- rules - Variable in class org.apache.calcite.sql.type.JavaToSqlTypeConversionRules
- rules - Variable in class org.apache.calcite.sql.type.SqlReturnTypeInferenceChain
- rules - Variable in class org.apache.calcite.tools.RuleSets.ListRuleSet
- rules() - Static method in class org.apache.calcite.adapter.spark.SparkRules
- rules(JdbcConvention) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules
- rules(JdbcConvention, RelBuilderFactory) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules
- 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.elasticsearch.ElasticsearchRules
- RULES - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeRules
- 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 - Variable in class org.apache.calcite.plan.hep.HepInstruction.CommonRelSubExprRules
- ruleSet - Variable in class org.apache.calcite.plan.hep.HepInstruction.ConverterRules
-
Actual rule set instantiated during planning by filtering all of the planner's rules, looking for the desired converters.
- ruleSet - Variable in class org.apache.calcite.plan.hep.HepInstruction.EndGroup
-
Actual rule set instantiated during planning by collecting grouped rules.
- ruleSet - Variable in class org.apache.calcite.plan.hep.HepInstruction.RuleClass
-
Actual rule set instantiated during planning by filtering all of the planner's rules through ruleClass.
- ruleSet - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Set of all registered rules.
- ruleSet - Variable in class org.apache.calcite.tools.Programs.RuleSetProgram
- RuleSet - Interface in org.apache.calcite.tools
-
A set rules associated with a particular type of invocation of the
Planner
. - RuleSetProgram(RuleSet) - Constructor for class org.apache.calcite.tools.Programs.RuleSetProgram
- 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.
- RuleSets() - Constructor for class org.apache.calcite.tools.RuleSets
- RuleSets.ListRuleSet - Class in org.apache.calcite.tools
-
Rule set that consists of a list of rules.
- run - Variable in class org.apache.calcite.profile.ProfilerImpl.Space
- run() - Method in class org.apache.calcite.adapter.druid.DruidQuery.DruidQueryNode
- run() - Method in class org.apache.calcite.adapter.enumerable.EnumerableInterpretable.EnumerableNode
- run() - Method in class org.apache.calcite.adapter.os.SqlShell
- run() - Method in class org.apache.calcite.interpreter.AggregateNode
- run() - Method in class org.apache.calcite.interpreter.FilterNode
- run() - Method in class org.apache.calcite.interpreter.JoinNode
- 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.SortNode
- run() - Method in class org.apache.calcite.interpreter.TableScanNode
- run() - Method in class org.apache.calcite.interpreter.UnionNode
- 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(RelOptPlanner, RelNode, RelTraitSet, List<RelOptMaterialization>, List<RelOptLattice>) - Method in class org.apache.calcite.tools.Programs.DecorrelateProgram
- run(RelOptPlanner, RelNode, RelTraitSet, List<RelOptMaterialization>, List<RelOptLattice>) - Method in class org.apache.calcite.tools.Programs.RuleSetProgram
- run(RelOptPlanner, RelNode, RelTraitSet, List<RelOptMaterialization>, List<RelOptLattice>) - Method in class org.apache.calcite.tools.Programs.SequenceProgram
- run(RelOptPlanner, RelNode, RelTraitSet, List<RelOptMaterialization>, List<RelOptLattice>) - Method in class org.apache.calcite.tools.Programs.TrimFieldsProgram
- run(RelNode) - Static method in class org.apache.calcite.tools.RelRunners
-
Runs a relational expression by creating a JDBC connection.
- Run(List<Profiler.Column>) - Constructor for class org.apache.calcite.profile.SimpleProfiler.Run
- Run(List<Profiler.Column>, Collection<ImmutableBitSet>) - Constructor for class org.apache.calcite.profile.ProfilerImpl.Run
-
Creates a Run.
- RUNNING - org.apache.calcite.sql.SqlKind
- RUNNING - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
RUNNING
function to be used withinMATCH_RECOGNIZE
. - 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A list of run-time variables.
S
- s - Variable in class org.apache.calcite.sql.advise.SqlSimpleParser.Token
- s - Variable in class org.apache.calcite.util.IntegerIntervalSet
- s - Variable in class org.apache.calcite.util.SourceStringReader
- SAFE_CHARS - Static variable in class org.apache.calcite.adapter.druid.DruidExpressions
-
Druid expression safe chars, must be sorted.
- safeArgList(StringBuilder, Method) - Static method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
-
Returns e.g.
- safeOps - Variable in enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- SafeRexVisitor() - Constructor for enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- SaffronProperties - Interface in org.apache.calcite.util
-
Provides an environment for debugging information, et cetera, used by saffron.
- SaffronProperties.Helper - Class in org.apache.calcite.util
-
Helper class.
- salary - Variable in class org.apache.calcite.benchmarks.StatementTest.Employee
- 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 all operand types must be the same.
- 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
- sameTypeOrNarrowsNullability(RelDataType, RelDataType) - Method in class org.apache.calcite.rex.RexSimplify
-
Return if the new type is the same and at most narrows the nullability.
- 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 - org.apache.calcite.rel.mutable.MutableRelType
- sampleOfTheGeneratedWindowedAggregate() - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindow
- samplePercentage - Variable in class org.apache.calcite.sql.SqlSampleSpec.SqlTableSampleSpec
- sampleValue(SqlNode) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Extracts the
SqlSampleSpec
value from a symbol literal. - samplingPercentage - Variable in class org.apache.calcite.plan.RelOptSamplingParameters
- 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 class org.apache.calcite.plan.RelCompositeTrait
- 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(RelTrait) - Method in class org.apache.calcite.rel.RelDistributions.RelDistributionImpl
- satisfies(RelTraitSet) - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns whether this trait set satisfies another trait set.
- scalar - Variable in class org.apache.calcite.interpreter.ProjectNode
- 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 - org.apache.calcite.adapter.enumerable.JavaRowFormat
- SCALAR - org.apache.calcite.plan.RelOptUtil.SubQueryType
- SCALAR - org.apache.calcite.runtime.SqlFunctions.FlatProductInputType
- SCALAR_EXECUTE1 - org.apache.calcite.util.BuiltInMethod
- SCALAR_EXECUTE2 - 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 - 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 - org.apache.calcite.piglet.Ast.Op
- ScalarAccumulator(AggregateNode.ScalarAccumulatorDef, Object[]) - Constructor for class org.apache.calcite.interpreter.AggregateNode.ScalarAccumulator
- ScalarAccumulatorDef(Scalar, Scalar, Scalar, int, int, DataContext) - Constructor for class org.apache.calcite.interpreter.AggregateNode.ScalarAccumulatorDef
- scalarCompiler - Variable in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
- ScalarFunction - Interface in org.apache.calcite.schema
-
Function that returns a scalar result.
- ScalarFunctionImpl - Class in org.apache.calcite.schema.impl
-
Implementation of
ScalarFunction
. - ScalarFunctionImpl(Method, CallImplementor) - Constructor for class org.apache.calcite.schema.impl.ScalarFunctionImpl
-
Private constructor.
- ScalarType(SqlParserPos, String) - Constructor for class org.apache.calcite.piglet.Ast.ScalarType
- scalarValueRequiredInStrictModeOfJsonValueFunc(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- scale - Variable in class org.apache.calcite.piglet.Ast.NumericLiteral
- scale - Variable in class org.apache.calcite.sql.SqlDataTypeSpec
- scale - Variable in class org.apache.calcite.sql.SqlNumericLiteral
- scale - Variable in class org.apache.calcite.sql.type.BasicSqlType
- SCALE_NOT_SPECIFIED - Static variable in interface org.apache.calcite.rel.type.RelDataType
- scaleA - Variable in class org.apache.calcite.rel.rules.ReduceDecimalsRule.BinaryArithmeticExpander
- scaleB - Variable in class org.apache.calcite.rel.rules.ReduceDecimalsRule.BinaryArithmeticExpander
- scaleDown(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(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.
- scaleFactor - Variable in class org.apache.calcite.adapter.tpcds.TpcdsSchema
- scaleFactor - Variable in class org.apache.calcite.adapter.tpch.TpchSchema
- scaleIntervalToNumber(RelDataType, RelDataType, Expression) - Static method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- scaleUp(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 - Variable in class org.apache.calcite.plan.RelOptMaterialization.ProjectFilterTable
- 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.clone.ArrayTable
- 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.csv.JsonTable
- scan(DataContext) - Method in class org.apache.calcite.adapter.geode.simple.GeodeSimpleScannableTable
- scan(DataContext) - Method in class org.apache.calcite.adapter.java.ReflectiveSchema.ReflectiveTable
- scan(DataContext) - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- scan(DataContext) - Method in class org.apache.calcite.example.maze.MazeTable
- scan(DataContext) - Method in interface org.apache.calcite.schema.ScannableTable
-
Returns an enumerator over the rows in this Table.
- 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 - org.apache.calcite.adapter.druid.QueryType
- scanFactory - Variable in class org.apache.calcite.tools.RelBuilder
- SCANNABLE - org.apache.calcite.adapter.csv.CsvTable.Flavor
- SCANNABLE_TABLE_SCAN - org.apache.calcite.util.BuiltInMethod
- ScannableTable - Interface in org.apache.calcite.schema
-
Table that can be scanned without creating an intermediate relational expression.
- ScanQuery(String, List<Interval>, DruidJsonFilter, List<VirtualColumn>, List<String>, Integer) - Constructor for class org.apache.calcite.adapter.druid.DruidQuery.ScanQuery
- ScanToProjectUnifyRule() - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.ScanToProjectUnifyRule
- schema - Variable in class org.apache.calcite.adapter.cassandra.CassandraTable
- schema - Variable in class org.apache.calcite.adapter.druid.DruidTable
- schema - Variable in class org.apache.calcite.adapter.java.ReflectiveSchema.MethodTableMacro
- schema - Variable in class org.apache.calcite.adapter.jdbc.JdbcSchema
- 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.materialize.MaterializationActor.QueryKey
- schema - Variable in class org.apache.calcite.piglet.Ast.ValuesStmt
- 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.prepare.RelOptTableImpl.MySchemaPlus
- schema - Variable in class org.apache.calcite.prepare.RelOptTableImpl
- 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.sql.SqlDescribeSchema
- schema(CalcitePrepare.Context, boolean, SqlIdentifier) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Returns the schema in which to create an object.
- 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 - org.apache.calcite.config.CalciteConnectionProperty
-
Name of initial schema.
- SCHEMA - org.apache.calcite.piglet.Ast.Op
- SCHEMA - org.apache.calcite.sql.validate.SqlMonikerType
- SCHEMA_FACTORY - org.apache.calcite.config.CalciteConnectionProperty
-
Schema factory.
- SCHEMA_GET_SUB_SCHEMA - org.apache.calcite.util.BuiltInMethod
- SCHEMA_GET_TABLE - org.apache.calcite.util.BuiltInMethod
- SCHEMA_PLUS_UNWRAP - org.apache.calcite.util.BuiltInMethod
- SCHEMA_TYPE - 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
- schemaFactory(Class<T>, T) - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- SchemaFactory - Interface in org.apache.calcite.schema
-
Factory for
Schema
objects. - SchemaImpl(Lattice, StatisticsProvider) - Constructor for class org.apache.calcite.materialize.TileSuggester.SchemaImpl
- schemaInvalidType(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- schemaNames - Variable in class org.apache.calcite.sql.validate.CatalogScope
- SchemaNamespace - Class in org.apache.calcite.sql.validate
-
Namespace based on a schema.
- SchemaNamespace(SqlValidatorImpl, ImmutableList<String>) - Constructor for class org.apache.calcite.sql.validate.SchemaNamespace
-
Creates a SchemaNamespace.
- schemaNotFound(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- schemaPath - Variable in class org.apache.calcite.schema.impl.ViewTable
- schemaPath - Variable in class org.apache.calcite.schema.impl.ViewTableMacro
-
Typically null.
- schemaPaths - Variable in class org.apache.calcite.prepare.CalciteCatalogReader
- SchemaPlus - Interface in org.apache.calcite.schema
-
Extension to the
Schema
interface. - SchemaPlusImpl() - Constructor for class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- 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() - Method in class org.apache.calcite.schema.Schemas.PathImpl
- schemas(String) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- Schemas - Class in org.apache.calcite.schema
-
Utility functions for schemas.
- Schemas() - Constructor for class org.apache.calcite.schema.Schemas
- SCHEMAS_ENUMERABLE_FILTERABLE - org.apache.calcite.util.BuiltInMethod
- SCHEMAS_ENUMERABLE_PROJECTABLE_FILTERABLE - org.apache.calcite.util.BuiltInMethod
- SCHEMAS_ENUMERABLE_SCANNABLE - org.apache.calcite.util.BuiltInMethod
- SCHEMAS_QUERYABLE - org.apache.calcite.util.BuiltInMethod
- Schemas.DummyDataContext - Class in org.apache.calcite.schema
-
Dummy data context that has no variables.
- Schemas.PathImpl - Class in org.apache.calcite.schema
-
Implementation of
Path
. - schemaStack - Variable in class org.apache.calcite.model.ModelHandler
- schemaType() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- 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.SqlAlter
-
Scope of the operation.
- scope - Variable in class org.apache.calcite.sql.SqlCallBinding
- scope - Variable in class org.apache.calcite.sql.validate.CollectNamespace
- scope - Variable in class org.apache.calcite.sql.validate.ProcedureNamespace
- scope - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.DeriveTypeVisitor
- scope - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.IdInfo
- scope - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternVarVisitor
- scope - Variable in class org.apache.calcite.sql.validate.SqlValidatorScope.Resolve
- scope - Variable in class org.apache.calcite.sql.validate.TableConstructorNamespace
- scope - Variable in class org.apache.calcite.sql.validate.UnnestNamespace
- scope - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Collection of
RelNode
objects which correspond to a SELECT statement. - 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. - ScopeChild - Class in org.apache.calcite.sql.validate
-
One of the inputs of a
SqlValidatorScope
. - ScopeChild(int, String, SqlValidatorNamespace, boolean) - Constructor for class org.apache.calcite.sql.validate.ScopeChild
-
Creates a ScopeChild.
- scopes - Variable in class org.apache.calcite.sql.validate.AggChecker
- scopes - Variable in class org.apache.calcite.sql.validate.SqlScopedShuttle
- scopes - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Maps
query node
objects to theSqlValidatorScope
scope created from them. - scriptedFieldPrefix() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
-
In ES 5.x scripted fields start with
params._source.foo
while in ES2.x_source.foo
. - scroll() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
-
Fetches search results given a scrollId.
- scrollId - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Result
- scrollId - Variable in class org.apache.calcite.adapter.elasticsearch.Scrolling.AutoClosingIterator
-
Keeps last value of
scrollId
in memory so scroll can be released upon termination - scrollId() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Result
- Scrolling - Class in org.apache.calcite.adapter.elasticsearch
-
"Iterator" which retrieves results lazily and in batches.
- Scrolling(ElasticsearchTransport) - Constructor for class org.apache.calcite.adapter.elasticsearch.Scrolling
- Scrolling.AutoClosingIterator - Class in org.apache.calcite.adapter.elasticsearch
-
Observes when existing iterator has ended and clears context (scroll) if any.
- Scrolling.SequentialIterator - Class in org.apache.calcite.adapter.elasticsearch
-
Iterator which consumes current
scrollId
until full search result is fetched orlimit
is reached. - search - Variable in class org.apache.calcite.adapter.splunk.SplunkQuery
- search - Variable in class org.apache.calcite.adapter.splunk.SplunkTableScan
- search() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- search(Map<String, String>) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
-
Search request using HTTP post.
- searchEscape(String) - Static method in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- SearchHit(String, Map<String, Object>, Map<String, Object>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHit
- SearchHit(String, Map<String, Object>, Map<String, Object>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHit
- searchHits() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Result
- searchHits() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult
- SearchHits(long, List<ElasticsearchJson.SearchHit>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHits
- SearchHits(long, List<ElasticsearchSearchResult.SearchHit>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHits
- SearchResultListener - Interface in org.apache.calcite.adapter.splunk.search
-
Called each time a search returns a record.
- SECOND - org.apache.calcite.adapter.druid.Granularity.Type
- SECOND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
SECOND
operator. - seed - Variable in class org.apache.calcite.example.maze.MazeTable
- seek - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.IsXxxImplementor
- seek - Variable in class org.apache.calcite.rex.LogicVisitor
- seekType - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.FirstLastValueImplementor
- SeekType() - Constructor for enum org.apache.calcite.adapter.enumerable.WinAggImplementor.SeekType
- seen - Variable in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor.TypeRegistrar
- seen - Variable in class org.apache.calcite.materialize.Lattice.Builder.Fixer
- select - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- select - Variable in class org.apache.calcite.sql.validate.AggregatingSelectScope
- select - Variable in class org.apache.calcite.sql.validate.GroupByScope
- select - Variable in class org.apache.calcite.sql.validate.OrderByScope
- select - Variable in class org.apache.calcite.sql.validate.SelectNamespace
- select - Variable in class org.apache.calcite.sql.validate.SelectScope
- select - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.ExtendedExpander
- select - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.OrderExpressionExpander
- 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(Queryable<T>, FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- select(FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- select(FunctionExpression<Function1<T, TResult>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- select(FunctionExpression<Function1<TSource, TResult>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Projects each element of a sequence into a new form.
- SELECT - org.apache.calcite.adapter.druid.QueryType
- SELECT - org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- SELECT - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- SELECT - org.apache.calcite.sql.SqlAccessEnum
- SELECT - org.apache.calcite.sql.SqlKind
-
SELECT statement or sub-query.
- SELECT - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
SELECT query (or UPDATE or DELETE).
- SELECT - org.apache.calcite.util.BuiltInMethod
- SELECT_LIST - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
The SELECT clause of a SELECT statement.
- SELECT_MANY - org.apache.calcite.util.BuiltInMethod
- SELECT2 - org.apache.calcite.util.BuiltInMethod
- selectedElement - Variable in class org.apache.calcite.adapter.file.FileRowConverter.CellReader
- selectFields - Variable in class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
- selectFields - Variable in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- SELECTIVITY - org.apache.calcite.util.BuiltInMethod
- selectivityHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- selectList - Variable in class org.apache.calcite.sql.SqlSelect
- selectListExtraIndentFlag - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- selectListItemsOnSeparateLines - Variable in class org.apache.calcite.sql.pretty.SqlFormatOptions
- selectListItemsOnSeparateLines - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- 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<Function1<T, Enumerable<TResult>>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Function2<T, Integer, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- selectMany(FunctionExpression<Function1<T, Enumerable<TResult>>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- selectMany(FunctionExpression<Function1<T, Enumerable<TResult>>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- selectMany(FunctionExpression<Function1<TSource, Enumerable<TResult>>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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.linq4j.DefaultQueryable
- selectMany(FunctionExpression<Function2<T, Integer, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- selectMany(FunctionExpression<Function2<TSource, Integer, Enumerable<TCollection>>>, FunctionExpression<Function2<TSource, TCollection, TResult>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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<Function1<T, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Function2<T, Integer, Enumerable<TResult>>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- selectManyN(FunctionExpression<Function1<T, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- selectManyN(FunctionExpression<Function1<T, Enumerable<TCollection>>>, FunctionExpression<Function2<T, TCollection, TResult>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- selectManyN(FunctionExpression<Function1<TSource, Enumerable<TCollection>>>, FunctionExpression<Function2<TSource, TCollection, TResult>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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.linq4j.DefaultQueryable
- selectManyN(FunctionExpression<Function2<T, Integer, Enumerable<TResult>>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- selectManyN(FunctionExpression<Function2<TSource, Integer, Enumerable<TResult>>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<Function2<T, Integer, TResult>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- selectN(FunctionExpression<Function2<T, Integer, TResult>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- selectN(FunctionExpression<Function2<T, Integer, TResult>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- selectN(FunctionExpression<Function2<TSource, Integer, TResult>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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 - Variable in class org.apache.calcite.adapter.file.FileReader
- selector - Variable in class org.apache.calcite.adapter.file.FileRowConverter.CellReader
- selector - Variable in class org.apache.calcite.linq4j.function.Functions.SelectorEqualityComparer
- 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
- SELECTOR - org.apache.calcite.adapter.druid.DruidJsonFilter.Type
- selectorComparer(Function1<T, T2>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns an
EqualityComparer
that uses a selector function. - SelectorEqualityComparer(Function1<T, T2>) - Constructor for class org.apache.calcite.linq4j.function.Functions.SelectorEqualityComparer
- SelectScope - Class in org.apache.calcite.sql.validate
-
The name-resolution scope of a SELECT clause.
- SelectScope(SqlValidatorScope, SqlValidatorScope, SqlSelect) - Constructor for class org.apache.calcite.sql.validate.SelectScope
-
Creates a scope corresponding to a SELECT clause.
- selectScopes - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Maps a
SqlSelect
node to the scope used by its SELECT and HAVING clauses. - SelfPopulatingList(String, int) - Constructor for class org.apache.calcite.rex.RexSlot.SelfPopulatingList
- SelfSplitter() - Constructor for class org.apache.calcite.sql.SqlSplittableAggFunction.SelfSplitter
- SEMI - org.apache.calcite.linq4j.CorrelateJoinType
-
Semi-join.
- SEMI - org.apache.calcite.sql.SemiJoinType
-
Semi-join
- SEMI_JOIN - org.apache.calcite.util.BuiltInMethod
- SEMI_STRICT - 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
SemiJoin
. - 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
-
Returns elements of
outer
for which there is a member ofinner
with a matching key. - semiJoin(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
SemiJoin
. - SemiJoin - Class in org.apache.calcite.rel.core
-
Relational expression that joins two relational expressions according to some condition, but outputs only columns from the left input, and eliminates duplicates.
- SemiJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList) - Constructor for class org.apache.calcite.rel.core.SemiJoin
-
Creates a SemiJoin.
- SEMIJOIN - org.apache.calcite.rel.mutable.MutableRelType
- semiJoinDone - Variable in class org.apache.calcite.rel.logical.LogicalJoin
- semiJoinFactory - Variable in class org.apache.calcite.tools.RelBuilder
- SemiJoinFactoryImpl() - Constructor for class org.apache.calcite.rel.core.RelFactories.SemiJoinFactoryImpl
- SemiJoinFilterTransposeRule - Class in org.apache.calcite.rel.rules
- SemiJoinFilterTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.SemiJoinFilterTransposeRule
-
Creates a SemiJoinFilterTransposeRule.
- SemiJoinJoinTransposeRule - Class in org.apache.calcite.rel.rules
- SemiJoinJoinTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.SemiJoinJoinTransposeRule
-
Creates a SemiJoinJoinTransposeRule.
- SemiJoinProjectTransposeRule - Class in org.apache.calcite.rel.rules
- SemiJoinProjectTransposeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.SemiJoinProjectTransposeRule
-
Creates a SemiJoinProjectTransposeRule.
- SemiJoinRemoveRule - Class in org.apache.calcite.rel.rules
-
Planner rule that removes a
SemiJoin
s from a join tree. - SemiJoinRemoveRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.SemiJoinRemoveRule
-
Creates a SemiJoinRemoveRule.
- SemiJoinRule - Class in org.apache.calcite.rel.rules
- SemiJoinRule(Class<Join>, Class<Aggregate>, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.SemiJoinRule
- SemiJoinRule(Class<Project>, Class<Join>, Class<Aggregate>, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.SemiJoinRule
- SemiJoinRule.JoinToSemiJoinRule - Class in org.apache.calcite.rel.rules
-
SemiJoinRule that matches a Join with an empty Aggregate as its right child.
- 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.
- SemiJoinType - Enum in org.apache.calcite.sql
-
Enumeration representing different join types used in correlation relations.
- SemiJoinType() - Constructor for enum org.apache.calcite.sql.SemiJoinType
- 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.AggregateNode.Accumulator
- send(Row) - Method in class org.apache.calcite.interpreter.AggregateNode.AccumulatorList
- send(Row) - Method in class org.apache.calcite.interpreter.AggregateNode.CountAccumulator
- send(Row) - Method in class org.apache.calcite.interpreter.AggregateNode.FilterAccumulator
- send(Row) - Method in class org.apache.calcite.interpreter.AggregateNode.Grouping
- send(Row) - Method in class org.apache.calcite.interpreter.AggregateNode.ScalarAccumulator
- send(Row) - Method in class org.apache.calcite.interpreter.AggregateNode.UdaAccumulator
- send(Row) - Method in class org.apache.calcite.interpreter.Interpreter.DuplicatingSink
- send(Row) - Method in class org.apache.calcite.interpreter.Interpreter.ListSink
- 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.
- sendContext - Variable in class org.apache.calcite.interpreter.AggregateNode.ScalarAccumulatorDef
- sep - Variable in class org.apache.calcite.adapter.os.Processes.SeparatedLinesEnumerable
- 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.
- SeparatedLinesEnumerable(Supplier<Process>, char) - Constructor for class org.apache.calcite.adapter.os.Processes.SeparatedLinesEnumerable
- sepIndent - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
-
Indent of separators with respect to this frame's indent.
- 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 - Static variable in class org.apache.calcite.linq4j.tree.ParameterExpression
- 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(Program...) - Static method in class org.apache.calcite.tools.Programs
-
Creates a program that executes a sequence of programs.
- Sequence - org.apache.calcite.linq4j.tree.GotoExpressionKind
-
A GotoExpression that evaluates an expression and carries on.
- SEQUENCE - org.apache.calcite.schema.Schema.TableType
-
Sequence table.
- SEQUENCE - org.apache.calcite.sql.type.CompositeOperandTypeChecker.Composition
- SEQUENCE_CURRENT_VALUE - org.apache.calcite.util.BuiltInMethod
- SEQUENCE_NEXT_VALUE - org.apache.calcite.util.BuiltInMethod
- sequenceCurrentValue(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the
CURRENT VALUE OF sequence
operator. - SEQUENCED_ADDER_AGGREGATE_LAMBDA_FACTORY - org.apache.calcite.util.BuiltInMethod
- SequencedAdderAggregateLambdaFactory<TSource,TAccumulate,TResult,TKey> - Class in org.apache.calcite.adapter.enumerable
-
Implementation of
AggregateLambdaFactory
that applies a sequence of accumulator adders to input source. - SequencedAdderAggregateLambdaFactory(Function0<TAccumulate>, List<Function2<TAccumulate, TSource, TAccumulate>>) - Constructor for class org.apache.calcite.adapter.enumerable.SequencedAdderAggregateLambdaFactory
- SequencedAdderAggregateLambdaFactory.AccumulatorAdderSeq - Class in org.apache.calcite.adapter.enumerable
-
Decorator class of a sequence of accumulator adder functions.
- 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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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
- sequenceEqual(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- sequenceNextValue(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the
NEXT VALUE OF sequence
operator. - SequenceProgram(ImmutableList<Program>) - Constructor for class org.apache.calcite.tools.Programs.SequenceProgram
- SequentialIterator(ElasticsearchJson.Result, ElasticsearchTransport, long) - Constructor for class org.apache.calcite.adapter.elasticsearch.Scrolling.SequentialIterator
- SerializableCharset - Class in org.apache.calcite.util
-
Serializable wrapper around a
Charset
. - SerializableCharset(Charset) - Constructor for class org.apache.calcite.util.SerializableCharset
-
Creates a SerializableCharset.
- SerializableRelRecordType(List<RelDataTypeField>) - Constructor for class org.apache.calcite.rel.type.RelRecordType.SerializableRelRecordType
- serialVersionUID - Static variable in exception org.apache.calcite.runtime.CalciteContextException
-
SerialVersionUID created with JDK 1.5 serialver tool.
- serialVersionUID - Static variable in exception org.apache.calcite.runtime.CalciteException
-
SerialVersionUID created with JDK 1.5 serialver tool.
- serialVersionUID - Static variable in class org.apache.calcite.sql.parser.SqlParserPos
- serialVersionUID - Static variable in exception org.apache.calcite.sql.validate.SqlValidatorException
- server - Variable in class org.apache.calcite.adapter.spark.HttpServer
- server - Variable in class org.apache.calcite.chinook.ChinookAvaticaServer
- server - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl
- session - Variable in class org.apache.calcite.adapter.cassandra.CassandraSchema
- SESSION - org.apache.calcite.sql.SqlKind
-
The
SESSION
group function. - SESSION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
SESSION
group function. - SESSION_END - 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_KEY - Static variable in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- SESSION_START - 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. - sessionKey - Variable in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- set - Variable in class org.apache.calcite.plan.volcano.RelSubset
-
The set this subset belongs to.
- set - Variable in class org.apache.calcite.util.graph.BreadthFirstIterator
- 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.InverseMapping
- 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.PartialFunctionImpl
- set(int, int) - Method in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- set(int, int) - Method in class org.apache.calcite.util.mapping.Mappings.SurjectionWithInverse
-
Creates a mapping between a source and a target.
- 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, E) - Method in class org.apache.calcite.runtime.AbstractImmutableList
- set(int, E) - Method in class org.apache.calcite.util.CastingList
- set(int, Object) - Method in class org.apache.calcite.interpreter.Row.RowBuilder
-
Set the value of a particular column.
- set(int, SqlNode) - Method in class org.apache.calcite.sql.SqlNodeList
- set(int, PrecedenceClimbingParser.Token) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.TokenList
- 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.ChunkList.ChunkListIterator
- 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.sql.pretty.SqlPrettyWriter.Bean
- set(CalciteConnectionProperty, String) - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
-
Returns a copy of this configuration with one property changed.
- SET - org.apache.calcite.adapter.enumerable.WinAggImplementor.SeekType
-
Row position in the frame.
- SET_OP - 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_OPTION - 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.
- 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.mapping.Mappings.PartialFunctionImpl
- 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
- setAsciiStream(int, InputStream) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- setAsciiStream(int, InputStream, long) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- setBinaryStream(int, InputStream) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- setBinaryStream(int, InputStream, long) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- setBlob(int, InputStream) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- setBlob(int, InputStream, long) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- setBlock(BlockBuilder) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- setCache(boolean) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema
- setCache(boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema
- setCache(boolean) - Method in class org.apache.calcite.jdbc.SimpleCalciteSchema
- setCacheEnabled(boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- setCacheEnabled(boolean) - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- setCacheEnabled(boolean) - Method in interface org.apache.calcite.schema.SchemaPlus
- setCallRewrite(boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Enables or disables rewrite of "macro-like" calls such as COALESCE.
- setCallRewrite(boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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
-
Sets whether the WHEN, THEN and ELSE clauses of a CASE expression appear at the start of a new line.
- setCaseSensitive(boolean) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- setCharacterStream(int, Reader) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- setCharacterStream(int, Reader, long) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- 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
-
Sets whether a clause (FROM, WHERE, GROUP BY, HAVING, WINDOW, ORDER BY) starts a new line.
- setClob(int, Reader) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- setClob(int, Reader, long) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- setColumnReferenceExpansion(boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Enables or disables expansion of column references.
- setColumnReferenceExpansion(boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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
-
Sets configuration identical to a given
SqlParser.Config
. - setConformance(SqlConformance) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Sets the SQL language conformance level.
- setConformance(SqlConformance) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- setCorrelates(Function1<String, RexToLixTranslator.InputGetter>) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- setCurrent(RelNode, LogicalCorrelate) - Method in class org.apache.calcite.sql2rel.RelDecorrelator
- setDataContext(DataContext) - Method in class org.apache.calcite.rex.RexExecutable
- 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
- setDefaultNullCollation(NullCollation) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Sets how NULL values should be collated if an ORDER BY item does not contain NULLS FIRST or NULLS LAST.
- setDefaultNullCollation(NullCollation) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- setDestdir(String) - Method in class org.apache.calcite.util.javac.JaninoCompiler.JaninoCompilerArgs
- setDestdir(String) - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- setDynamicParam(PreparedStatement, int, Object) - Static method in class org.apache.calcite.runtime.ResultSetEnumerable
-
Assigns a value to a dynamic parameter in a prepared statement, calling the appropriate
setXxx
method based on the type of the value. - setDynamicParamCountInExplain(int) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Sets the number of dynamic parameters in the current EXPLAIN PLAN statement.
- setElement(Object[], int, Object) - Static method in class org.apache.calcite.util.ChunkList
- 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
- setFactorJoinKeys(LoptMultiJoin, List<RexNode>, ImmutableBitSet, int, int, ImmutableBitSet.Builder) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Locates from a list of filters those that correspond to a particular join tree.
- setFactorWeight(int, int, int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Sets an individual weight if the new weight is better than the current one
- 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.rel.rel2sql.SqlImplementor.Builder
- setFetch(SqlNode) - Method in class org.apache.calcite.sql.SqlSelect
- 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
- 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.rel.rel2sql.SqlImplementor.Builder
- setGroupBy(SqlNodeList) - Method in class org.apache.calcite.sql.SqlSelect
- setHaving(SqlNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- setHaving(SqlNode) - Method in class org.apache.calcite.sql.SqlSelect
- setIdentifierExpansion(boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Enables or disables expansion of identifiers other than column references.
- setIdentifierExpansion(boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- setIdentifierMaxLength(int) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Sets the maximum length for sql identifier.
- setIdentifierMaxLength(int) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- 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.
- setImportance(RelNode, double) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- setImportance(RelNode, double) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Sets the importance of a relational expression.
- setImportance(RelNode, double) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- setIndentation(int) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setIndentation(int) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Sets the number of spaces indentation.
- setIndentString(String) - Method in class org.apache.calcite.util.XmlOutput
-
Sets the string to print for each level of indentation.
- setInitialImportance() - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- setInput(int, MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableBiRel
- setInput(int, MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableLeafRel
- setInput(int, MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableMultiRel
- setInput(int, MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableRel
- setInput(int, MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableSingleRel
- setInternal(int, int) - Method in class org.apache.calcite.util.Permutation
- setJoinAdjustments(int[], int, int, int, int, int) - Method in class org.apache.calcite.rel.rules.SemiJoinJoinTransposeRule
-
Sets an array to reflect how much each index corresponding to a field needs to be adjusted.
- setJoinFilterRefs() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Sets bitmaps indicating which factors and fields each join filter references
- setJoinKey(ImmutableBitSet.Builder, ImmutableBitSet.Builder, int, int, int, int, boolean) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Sets a join key if only one of the specified input references corresponds to a specified factor as determined by its field numbers.
- 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, SemiJoin) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Indicates the semijoin that allows the join of a dimension table to be removed
- setKeywordsLowercase(boolean) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setKeywordsLowerCase(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Sets whether to print keywords (SELECT, AS, etc.) in lower-case.
- 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
- setLimit(int) - Method in class org.apache.calcite.rex.RexUtil.ForwardRefFinder
- 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
- 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.
- 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.
- setNCharacterStream(int, Reader) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- setNCharacterStream(int, Reader, long) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- setNClob(int, Reader) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- setNClob(int, Reader, long) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- setNClob(int, NClob) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- 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
- setNext(Object[], Object[]) - Static method in class org.apache.calcite.util.ChunkList
- setNString(int, String) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- setNullable(Map<? extends RexNode, Boolean>) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Creates a read-only copy of this translator that records that a given expression is nullable.
- setNullable(RexNode, boolean) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Creates a read-only copy of this translator that records that a given expression is nullable.
- setOccupied(Object[], int) - Static method in class org.apache.calcite.util.ChunkList
- 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.rel.rel2sql.SqlImplementor.Builder
- setOffset(SqlNode) - Method in class org.apache.calcite.sql.SqlSelect
- setOp(boolean, SqlKind, int) - Method in class org.apache.calcite.tools.RelBuilder
- 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<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 - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Set operation.
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.fun.SqlCase
- 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.SqlMatchRecognize
- setOperand(int, SqlNode) - Method in class org.apache.calcite.sql.SqlMerge
- 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.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
- setOperand(SqlNode, SqlNode, SqlValidator) - Static method in class org.apache.calcite.sql.SqlWindow
- setOperator(SqlOperator) - Method in class org.apache.calcite.sql.SqlBasicCall
- setOpFactory - Variable in class org.apache.calcite.tools.RelBuilder
- SetOpFactoryImpl() - Constructor for class org.apache.calcite.rel.core.RelFactories.SetOpFactoryImpl
- 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
. - 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.rel.rel2sql.SqlImplementor.Builder
- setOrderBy(SqlNodeList) - Method in class org.apache.calcite.sql.SqlSelect
- 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.
- setOriginalSql(String) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Sets the SQL text that is being parsed.
- setOriginalStatement(String) - Method in exception org.apache.calcite.runtime.CalciteContextException
- setParent(RelOptRuleOperand) - Method in class org.apache.calcite.plan.RelOptRuleOperand
-
Sets the parent operand.
- setParentTrojan(ResourceBundle) - Method in class org.apache.calcite.runtime.Resources.MyPropertyResourceBundle
- setParserFactory(SqlParserImplFactory) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- setPartitionList(SqlNodeList) - Method in class org.apache.calcite.sql.SqlWindow
- setPath(ImmutableList<ImmutableList<String>>) - Method in class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- setPath(ImmutableList<ImmutableList<String>>) - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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 org.apache.calcite.runtime.CalciteContextException
-
Sets a textual position at which this exception was detected.
- setPosition(int, int, int, int) - Method in exception org.apache.calcite.runtime.CalciteContextException
-
Sets a textual range at which this exception was detected.
- setPrev(Object[], Object[]) - Static method in class org.apache.calcite.util.ChunkList
- setQuoteAllIdentifiers(boolean) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setQuoteAllIdentifiers(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Sets whether to quote all identifiers, even those which would be correct according to the rules of the
SqlDialect
if quotation marks were omitted. - setQuotedCasing(Casing) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Sets the casing policy for quoted identifiers.
- setQuotedCasing(Casing) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- setQuoting(Quoting) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- setRel(RelNode) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
-
Sets the output of this event.
- setReplace(boolean) - Method in class org.apache.calcite.sql.SqlCreate
- setResultSet(Iterator<Object>) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerStatementImpl
- setResultSet(Iterator<Object>) - Method in interface org.apache.calcite.server.CalciteServerStatement
- setRight(SqlNode) - Method in class org.apache.calcite.sql.SqlJoin
- setRoot(List<RelNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- setRoot(List<RelNode>, RelNode, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- 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, 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.
- setRowId(int, RowId) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- 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.
- sets - Variable in class org.apache.calcite.sql.type.SqlTypeAssignmentRules.Builder
- 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
-
Sets whether to use a fix for SELECT list indentations.
- setSelectListItemsOnSeparateLines(boolean) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setSelectListItemsOnSeparateLines(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Sets whether each item in a SELECT list, GROUP BY list, or ORDER BY list is on its own line.
- setSettings(Properties) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Sets settings from a properties object.
- setSignature(Meta.Signature) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerStatementImpl
- 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 class org.apache.calcite.interpreter.Interpreter.DuplicatingSink
- setSourceEnumerable(Enumerable<Row>) - Method in class org.apache.calcite.interpreter.Interpreter.ListSink
- 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
- setSQLXML(int, SQLXML) - Method in class org.apache.calcite.jdbc.CalciteJdbc41Factory.CalciteJdbc41PreparedStatement
- 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
-
Sets the sub-query style.
- setTabSize(int) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Sets the tab stop size.
- setterMethods - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter.Bean
- setThreadLocal() - Static method in class org.apache.calcite.materialize.MaterializationService
-
Used by tests, to ensure that they see their own service.
- setThreadLocale(Locale) - Static method in class org.apache.calcite.runtime.Resources
-
Sets the locale for the current thread.
- setTimeoutIfPossible(Statement) - Method in class org.apache.calcite.runtime.ResultSetEnumerable
- setType(RelDataType) - Method in class org.apache.calcite.sql.validate.AbstractNamespace
- setType(RelDataType) - Method in class org.apache.calcite.sql.validate.DelegatingNamespace
- setType(RelDataType) - Method in class org.apache.calcite.sql.validate.FieldNamespace
- 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.SqlAbstractParserImpl
-
Sets the casing policy for unquoted identifiers.
- setUnquotedCasing(Casing) - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- setup() - Method in class org.apache.calcite.benchmarks.ParserBenchmark
- setUpperBound(SqlNode) - Method in class org.apache.calcite.sql.SqlWindow
- setValidatedNodeType(SqlNode, RelDataType) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Deprecated.This method should not be in the
SqlValidator
interface. The validator should drive the type-derivation process, and store nodes' types when they have been derived. - 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(Enumerable<V>) - Method in class org.apache.calcite.linq4j.GroupingImpl
- 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
- setVerbose(boolean) - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- setWhere(SqlNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- setWhere(SqlNode) - Method in class org.apache.calcite.sql.SqlSelect
- setWhereListItemsOnSeparateLines(boolean) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setWhereListItemsOnSeparateLines(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Sets whether to print a newline before each AND or OR (whichever is higher level) in WHERE clauses.
- 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
- setWindowListItemsOnSeparateLines(boolean) - Method in class org.apache.calcite.sql.pretty.SqlFormatOptions
- setWindowNewline(boolean) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- ShadowResourceBundle() - Constructor for class org.apache.calcite.runtime.Resources.ShadowResourceBundle
-
Creates a
ShadowResourceBundle
, and reads resources from a.properties
file with the same name as the current class. - 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(Date) - Static method in class org.apache.calcite.adapter.jdbc.JdbcUtils.ObjectArrayRowBuilder
- shift(Time) - Static method in class org.apache.calcite.adapter.jdbc.JdbcUtils.ObjectArrayRowBuilder
- shift(Timestamp) - Static method in class org.apache.calcite.adapter.jdbc.JdbcUtils.ObjectArrayRowBuilder
- 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 - org.apache.calcite.sql.SqlDialect.CalendarPolicy
- Shifter(RelNode, CorrelationId, RelNode) - Constructor for class org.apache.calcite.tools.RelBuilder.Shifter
- shiftFilter(int, int, int, RexBuilder, List<RelDataTypeField>, int, List<RelDataTypeField>, RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil
- shiftRightFilter(Join, RelNode, MultiJoin, RexNode) - Method in class org.apache.calcite.rel.rules.JoinToMultiJoinRule
-
Shifts a filter originating from the right child of the LogicalJoin to the right, to reflect the filter now being applied on the resulting MultiJoin.
- SHORT - org.apache.calcite.adapter.csv.CsvFieldType
- SHORT - org.apache.calcite.adapter.file.FileFieldType
- SHORT - org.apache.calcite.linq4j.tree.Primitive
- shortestPaths - Variable in class org.apache.calcite.util.graph.Graphs.FrozenGraph
- 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
- should(QueryBuilders.QueryBuilder) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.BoolQueryBuilder
- 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
- shouldCheckForRollUp(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- shouldClauses - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.BoolQueryBuilder
- 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
- shouldExpandIdentifiers() - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Returns expansion of identifiers.
- shouldExpandIdentifiers() - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- shouldLift(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- shouldMergeProject() - Method in class org.apache.calcite.tools.RelBuilder
-
Whether to attempt to merge consecutive
Project
operators. - shouldTrim(RelNode) - Method in class org.apache.calcite.prepare.Prepare
- shuffle(Random, int[]) - Method in class org.apache.calcite.example.maze.Maze
-
Randomly permutes the members of an array.
- shuffleUp(int[], int) - Method in class org.apache.calcite.util.Permutation
- shuttle - Variable in class org.apache.calcite.sql2rel.DeduplicateCorrelateVariables.DeduplicateCorrelateVariablesShuttle
- 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>) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
Replaces all the possible sub-expressions by input references to the input node.
- shuttleReferences(RexBuilder, RexNode, Multimap<RexNode, Integer>, RelNode, Mapping) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
Replaces all the possible sub-expressions by input references to the input node.
- shuttleReferences(RexBuilder, RexNode, Mapping) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
Replaces all the input references by the position in the input column set.
- Side() - Constructor for enum org.apache.calcite.plan.RelOptUtil.Side
- Side() - Constructor for class org.apache.calcite.rel.rules.AggregateJoinTransposeRule.Side
- sign - Variable in class org.apache.calcite.sql.SqlIntervalLiteral.IntervalValue
- 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 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- signature - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerStatementImpl
- signature() - Method in class org.apache.calcite.adapter.druid.DruidQuery
-
Returns a string describing the operations inside this query.
- signatures - Variable in enum org.apache.calcite.sql.type.SqlTypeName
-
Bitwise-or of flags indicating allowable precision/scale combinations.
- signed - Variable in class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- 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.
- similar(String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SIMILAR
function. - similar(String, String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
SIMILAR
function with escape. - SIMILAR - org.apache.calcite.sql.SqlKind
-
The "SIMILAR" operator.
- SIMILAR - org.apache.calcite.util.BuiltInMethod
- SIMILAR_TO - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- similarEscapeRuleChecking(String, char) - Static method in class org.apache.calcite.runtime.Like
- 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(SqlDialect.DatabaseProduct) - Static method in class org.apache.calcite.sql.SqlDialectFactoryImpl
-
Returns a basic dialect for a given product, or null if none is known.
- simple(SqlOperator) - Method in class org.apache.calcite.sql.SqlJdbcFunctionCall.JdbcToInternalLookupTable
- SIMPLE - org.apache.calcite.rel.core.Aggregate.Group
- SIMPLE - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Simple list.
- SIMPLE_SQLS - Static variable in class org.apache.calcite.prepare.CalcitePrepareImpl
- SimpleCalciteSchema - Class in org.apache.calcite.jdbc
-
A concrete implementation of
CalciteSchema
that maintains minimal state. - SimpleCalciteSchema(CalciteSchema, Schema, String) - Constructor for class org.apache.calcite.jdbc.SimpleCalciteSchema
-
Creates a SimpleCalciteSchema.
- SimpleCalciteSchema(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.SimpleCalciteSchema
- simpleContext(RelOptCluster) - 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
- SimpleGeom(Geometry) - Constructor for class org.apache.calcite.runtime.GeoFunctions.SimpleGeom
- simpleList(BlockStatement) - Static method in class org.apache.calcite.prepare.CalcitePrepareImpl.EmptyScalarTranslator
- SimpleMakeCall(SqlOperator) - Constructor for class org.apache.calcite.sql.SqlJdbcFunctionCall.SimpleMakeCall
- simpleName - Variable in enum org.apache.calcite.adapter.csv.CsvFieldType
- simpleName(List<String>) - Method in class org.apache.calcite.materialize.LatticeSpace
- simpleName(LatticeTable) - Method in class org.apache.calcite.materialize.LatticeSpace
-
Derives a unique name for a table, qualifying with schema name only if necessary.
- simpleName(RelOptTable) - Method in class org.apache.calcite.materialize.LatticeSpace
- simpleNames - Variable in class org.apache.calcite.materialize.LatticeSpace
- simplePrepare(CalcitePrepare.Context, String) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
-
Quickly prepares a simple SQL statement, circumventing the usual preparation process.
- SimpleProfiler - Class in org.apache.calcite.profile
-
Basic implementation of
Profiler
. - SimpleProfiler() - Constructor for class org.apache.calcite.profile.SimpleProfiler
- SimpleProfiler.Run - Class in org.apache.calcite.profile
-
A run of the profiler.
- SimpleProfiler.Space - Class in org.apache.calcite.profile
-
Work space for a particular combination of columns.
- SimpleQueryExpression(PredicateAnalyzer.NamedFieldExpression) - Constructor for class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.SimpleQueryExpression
- simpleTableNames - Variable in class org.apache.calcite.materialize.LatticeSpace
- simplifier - Variable in class org.apache.calcite.tools.RelBuilder
- simplify - Variable in class org.apache.calcite.plan.SubstitutionVisitor
- simplify - Variable in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference
- simplify - Variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule.RexReplacer
- simplify - Variable in class org.apache.calcite.rex.RexProgramBuilder
- simplify - Variable in class org.apache.calcite.rex.RexUtil.ExprSimplifier
-
Deprecated.
- simplify - Variable in class org.apache.calcite.tools.RelBuilder
- simplify() - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns a trait set similar to this one but with all composite traits flattened.
- simplify(String) - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Query
- 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.
- simplify(RexNode, RexUnknownAs) - Method in class org.apache.calcite.rex.RexSimplify
-
Internal method to simplify an 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.
- simplifyAnd(RexCall, RexUnknownAs) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyAnd2(List<RexNode>, List<RexNode>) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyAnd2(RexBuilder, List<RexNode>, List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- simplifyAnd2ForUnknownAsFalse(List<RexNode>, List<RexNode>) - Method in class org.apache.calcite.rex.RexSimplify
-
As
RexSimplify.simplifyAnd2(List, List)
but we assume that if the expression returns UNKNOWN it will be interpreted as FALSE. - simplifyAnd2ForUnknownAsFalse(List<RexNode>, List<RexNode>, Class<C>) - Method in class org.apache.calcite.rex.RexSimplify
- 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
-
Simplifies a conjunction of boolean expressions.
- simplifyAnds(Iterable<? extends RexNode>, RexUnknownAs) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyAnds(RexBuilder, Iterable<? extends RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- simplifyAnds(RexBuilder, Iterable<? extends RexNode>, boolean) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- simplifyAndTerms(List<RexNode>) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyBooleanCase(RexBuilder, List<RexSimplify.CaseBranch>, RexUnknownAs, RelDataType) - Static method in class org.apache.calcite.rex.RexSimplify
- simplifyBooleanCaseGeneric(RexBuilder, List<RexSimplify.CaseBranch>, RelDataType) - Static method in class org.apache.calcite.rex.RexSimplify
-
Generic boolean case simplification.
- simplifyCase(RexCall, RexUnknownAs) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyCast(RexCall) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyCeilFloor(RexCall) - Method in class org.apache.calcite.rex.RexSimplify
-
Tries to simplify CEIL/FLOOR function on top of CEIL/FLOOR.
- simplifyCoalesce(RexCall) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyComparison(RexCall, RexUnknownAs) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyComparison(RexCall, RexUnknownAs, Class<C>) - Method in class org.apache.calcite.rex.RexSimplify
- 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.
- simplifyIs(RexCall) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyIs2(SqlKind, RexNode) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyIsNotNull(RexNode) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyIsNull(RexNode) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyIsPredicate(SqlKind, RexNode) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyJoin(RelNode, ImmutableList<RexNode>, JoinRelType) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Simplifies outer joins if filter above would reject nulls.
- simplifyList(List<RexNode>, RexUnknownAs) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyList(List<SqlSimpleParser.Token>, String) - Static method in class org.apache.calcite.sql.advise.SqlSimpleParser.Query
- simplifyNot(RexCall, RexUnknownAs) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyOr(RexBuilder, RexCall) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- simplifyOr(RexCall) - Method in class org.apache.calcite.rex.RexSimplify
-
Simplifies OR(x, x) into x, and similar.
- simplifyOr(RexCall, RexUnknownAs) - Method in class org.apache.calcite.rex.RexSimplify
- simplifyOrs(List<RexNode>) - Method in class org.apache.calcite.rex.RexSimplify
-
Simplifies a list of terms and combines them into an OR.
- simplifyOrs(List<RexNode>, RexUnknownAs) - Method in class org.apache.calcite.rex.RexSimplify
-
Simplifies a list of terms and combines them into an OR.
- simplifyOrs(RexBuilder, List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Deprecated.
- simplifyOrTerms(List<RexNode>) - Method in class org.apache.calcite.rex.RexSimplify
- 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 getCompletionHints()
- 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. - simplifyUsingPredicates(RexNode, Class<C>) - Method in class org.apache.calcite.rex.RexSimplify
- simplyProjects(RelNode, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- 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 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- 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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- single(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- single(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- single(FunctionExpression<Predicate1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Returns the only element of a sequence that satisfies a specified condition, and throws an exception if more than one such element exists.
- SINGLE_QUOTE - Static variable in class org.apache.calcite.util.StackWriter
- SINGLE_VALUE - 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. - SingleColumnRowConverter(CsvFieldType, int) - Constructor for class org.apache.calcite.adapter.csv.CsvEnumerator.SingleColumnRowConverter
- singleGroupResultSelector(Function1<TAccumulate, TResult>) - Method in class org.apache.calcite.adapter.enumerable.SequencedAdderAggregateLambdaFactory
- 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.OrderedAggregateLambdaFactory
- 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 interface org.apache.calcite.linq4j.ExtendedQueryable
-
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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- singleOrDefault(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- singleOrDefault(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- singleOrDefault(FunctionExpression<Predicate1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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.
- singlePartition - Variable in class org.apache.calcite.adapter.cassandra.CassandraFilter
- 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 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 interface org.apache.calcite.sql.SqlSplittableAggFunction
-
Generates an expression for the value of the aggregate function when applied to a single row.
- SINGLETON - 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_ENUMERABLE - org.apache.calcite.util.BuiltInMethod
- SINGLETON_NULL - Static variable in class org.apache.calcite.util.ImmutableNullableList
- 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.
- singletonArrayIterator(Comparator<V>, List<V>) - Static method in class org.apache.calcite.runtime.SortedMultiMap
-
Shortcut method if the partition key is empty.
- SingletonCollector(ProfilerImpl.Space, int, int) - Constructor for class org.apache.calcite.profile.ProfilerImpl.SingletonCollector
- singletonDistributionList - Variable in class org.apache.calcite.profile.Profiler.Profile
- 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. - SingletonEnumerator(E) - Constructor for class org.apache.calcite.linq4j.Linq4j.SingletonEnumerator
- singletonGetter(String, Class) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchEnumerators
- singletonGetter(String, Class) - Static method in class org.apache.calcite.adapter.mongodb.MongoEnumerator
- singletonNullEnumerator() - Static method in class org.apache.calcite.linq4j.Linq4j
-
Returns an
Enumerator
that has one null element. - SingletonNullEnumerator() - Constructor for class org.apache.calcite.linq4j.Linq4j.SingletonNullEnumerator
- singletonSpaces - Variable in class org.apache.calcite.profile.ProfilerImpl.Run
-
List of spaces that have one column.
- singletonSpaces - Variable in class org.apache.calcite.profile.SimpleProfiler.Run
- SingleValueImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.SingleValueImplementor
- sink - Variable in class org.apache.calcite.adapter.druid.DruidQuery.DruidQueryNode
- sink - Variable in class org.apache.calcite.adapter.enumerable.EnumerableInterpretable.EnumerableNode
- sink - Variable in class org.apache.calcite.interpreter.AbstractSingleNode
- sink - Variable in class org.apache.calcite.interpreter.JoinNode
- sink - Variable in class org.apache.calcite.interpreter.UnionNode
- sink - Variable in class org.apache.calcite.interpreter.ValuesNode
- 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.Interpreter.CompilerImpl
- Sink - Interface in org.apache.calcite.interpreter
-
Sink to which to send rows.
- sinks - Variable in class org.apache.calcite.interpreter.Interpreter.NodeInfo
- size - Variable in class org.apache.calcite.adapter.clone.ArrayTable.Content
- size - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonColumn
- size - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonSegmentMetadata
- size - Variable in class org.apache.calcite.linq4j.function.Functions.GeneratingList
- size - Variable in enum org.apache.calcite.linq4j.tree.Primitive
-
The size of a value of this type, in bits.
- size - Variable in class org.apache.calcite.profile.ProfilerImpl.SurpriseQueue
- size - Variable in class org.apache.calcite.util.ChunkList
- size - Variable in class org.apache.calcite.util.ImmutableIntList.AbstractIndexedListIterator
- size - Variable in class org.apache.calcite.util.mapping.Mappings.IdentityMapping
- size() - Method in class org.apache.calcite.adapter.clone.ColumnLoader
- 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.linq4j.function.Functions.GeneratingList
- size() - Method in class org.apache.calcite.linq4j.LookupImpl
- size() - Method in class org.apache.calcite.linq4j.Ord.OrdArrayList
- size() - Method in class org.apache.calcite.linq4j.Ord.OrdList
- size() - Method in class org.apache.calcite.plan.RelCompositeTrait
-
Returns the number of traits.
- 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.ComparableEmptyList
- size() - Method in class org.apache.calcite.runtime.FlatLists.ComparableListImpl
- 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.schema.Schemas.PathImpl
- size() - Method in class org.apache.calcite.sql.parser.SqlParserUtil.OldTokenSequenceImpl
- size() - Method in class org.apache.calcite.sql.parser.SqlParserUtil.TokenSequenceImpl
- 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.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.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.InverseMapping
- 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.PartialFunctionImpl
- 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.PrecedenceClimbingParser.TokenList
- size() - Method in class org.apache.calcite.util.UnmodifiableArrayList
- size() - Method in class org.apache.calcite.util.Util.TransformingList
- size(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- size(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ByteStringDictionary
- size(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.Constant
- size(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectArray
- size(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectDictionary
- size(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveArray
- size(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveDictionary
- size(Object) - Method in interface org.apache.calcite.adapter.clone.ArrayTable.Representation
-
Returns the number of elements in a data set.
- size(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.StringDictionary
- sizeHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- sketch - Variable in class org.apache.calcite.profile.ProfilerImpl.HllCollector
- sketchThreshold - Variable in class org.apache.calcite.profile.ProfilerImpl.CompositeCollector
- sketchThreshold - Variable in class org.apache.calcite.profile.ProfilerImpl.SingletonCollector
- skip(int) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- skip(int) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- skip(int) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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 interface org.apache.calcite.linq4j.ExtendedQueryable
-
Bypasses a specified number of elements in a sequence and then returns the remaining elements.
- skip(int) - Method in class org.apache.calcite.linq4j.Linq4j.ListEnumerable
- 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(Queryable<T>, int) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- SKIP - org.apache.calcite.util.BuiltInMethod
- SKIP_PAST_LAST_ROW - org.apache.calcite.sql.SqlMatchRecognize.AfterOption
- SKIP_TO_FIRST - org.apache.calcite.sql.SqlKind
-
The "SKIP TO FIRST" qualifier of restarting point in a MATCH_RECOGNIZE clause.
- SKIP_TO_FIRST - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- SKIP_TO_LAST - org.apache.calcite.sql.SqlKind
-
The "SKIP TO LAST" qualifier of restarting point in a MATCH_RECOGNIZE clause.
- SKIP_TO_LAST - Static variable in class org.apache.calcite.sql.SqlMatchRecognize
- SKIP_TO_NEXT_ROW - 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. - skipLines - Variable in class org.apache.calcite.adapter.csv.CsvStreamReader
- skipMatch(VolcanoRuleMatch) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Returns whether to skip a match.
- skippingGroup() - Method in class org.apache.calcite.plan.hep.HepPlanner
- 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(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- skipWhile(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- skipWhile(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- skipWhile(FunctionExpression<Predicate1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Bypasses elements in a sequence as long as a specified condition is true and then returns the remaining elements.
- SkipWhileEnumerator(Enumerator<TSource>, Predicate2<TSource, Integer>) - Constructor for class org.apache.calcite.linq4j.EnumerableDefaults.SkipWhileEnumerator
- 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(Queryable<T>, FunctionExpression<Predicate2<T, Integer>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- skipWhileN(FunctionExpression<Predicate2<T, Integer>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- skipWhileN(FunctionExpression<Predicate2<T, Integer>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- skipWhileN(FunctionExpression<Predicate2<TSource, Integer>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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 - 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 - org.apache.calcite.util.BuiltInMethod
- SlimDataContext() - Constructor for class org.apache.calcite.jdbc.CalciteConnectionImpl.SlimDataContext
- Slot() - Constructor for class org.apache.calcite.linq4j.tree.BlockBuilder.Slot
- Slot() - Constructor for class org.apache.calcite.rel.type.RelDataTypeImpl.Slot
- slotCount - Variable in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRule
- SlotCounter() - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.SlotCounter
- 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 - org.apache.calcite.sql.type.SqlTypeName
- smart - Variable in class org.apache.calcite.rel.rules.FilterJoinRule
-
Whether to try to strengthen join-type.
- snapshot - Variable in class org.apache.calcite.adapter.jdbc.JdbcSchema
- snapshot(CalciteSchema, SchemaVersion) - Method in class org.apache.calcite.jdbc.CachingCalciteSchema
- snapshot(CalciteSchema, SchemaVersion) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Returns a snapshot representation of this CalciteSchema.
- snapshot(CalciteSchema, SchemaVersion) - Method in class org.apache.calcite.jdbc.SimpleCalciteSchema
- snapshot(SchemaVersion) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- snapshot(SchemaVersion) - Method in class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- snapshot(SchemaVersion) - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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.
- 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
-
should keep alives 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
-
should the address 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
- solution - Variable in class org.apache.calcite.example.maze.MazeTable
- solve(int, int) - Method in class org.apache.calcite.example.maze.Maze
- 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
-
Creates a list of child operands that matches child relational expressions in the order they appear.
- some(RelNode, ImmutableList<RexNode>, SqlQuantifyOperator) - Static method in class org.apache.calcite.rex.RexSubQuery
-
Creates a SOME sub-query.
- some(SqlKind) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Returns the operator for
SOME comparisonKind
. - SOME - org.apache.calcite.plan.RelOptRuleOperandChildPolicy
-
Signifies that the operand's children must precisely match its child operands, in order.
- SOME - org.apache.calcite.sql.SqlKind
-
The "SOME" quantification operator (also called "ANY").
- 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 - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
-
Sorting clauses.
- 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(Iterable<RexNode>) - Method in class org.apache.calcite.tools.RelBuilder.AggCallImpl
- sort(Iterable<RexNode>) - Method in class org.apache.calcite.tools.RelBuilder.AggCallImpl2
- 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(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.AggCallImpl
- sort(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder.AggCallImpl2
- 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, 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 - org.apache.calcite.rel.mutable.MutableRelType
- SORT - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- 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_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts a
Sort
to empty if its child is empty. - SORT_PROJECT_TRANSPOSE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- sortAndAccumulate(Iterable<TSource>, TAccumulate) - Method in class org.apache.calcite.adapter.enumerable.SourceSorter
- 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.
- sortBooleanArray(boolean[], int, int) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- SORTED_MULTI_MAP_ARRAYS - org.apache.calcite.util.BuiltInMethod
- SORTED_MULTI_MAP_PUT_MULTI - org.apache.calcite.util.BuiltInMethod
- SORTED_MULTI_MAP_SINGLETON - org.apache.calcite.util.BuiltInMethod
- 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.tools.RelBuilder
- SortExchangeFactoryImpl() - Constructor for class org.apache.calcite.rel.core.RelFactories.SortExchangeFactoryImpl
- sortFactory - Variable in class org.apache.calcite.tools.RelBuilder
- SortFactoryImpl() - Constructor for class org.apache.calcite.rel.core.RelFactories.SortFactoryImpl
- sortField - Variable in class org.apache.calcite.adapter.clone.ColumnLoader
- 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
-
Creates a SortJoinTransposeRule.
- 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. - 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
-
Creates a SortProjectTransposeRule.
- 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
-
Creates a SortProjectTransposeRule with an operand.
- 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() - Constructor for class org.apache.calcite.rel.rules.SortRemoveConstantKeysRule
- SortRemoveRule - Class in org.apache.calcite.rel.rules
-
Planner rule that removes a
Sort
if its input is already sorted. - SortRemoveRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.SortRemoveRule
-
Creates a SortRemoveRule.
- SortUnionTransposeRule - Class in org.apache.calcite.rel.rules
- SortUnionTransposeRule(boolean) - Constructor for class org.apache.calcite.rel.rules.SortUnionTransposeRule
- SortUnionTransposeRule(Class<? extends Sort>, Class<? extends Union>, boolean, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.SortUnionTransposeRule
-
Creates a SortUnionTransposeRule.
- sortUnique(List<IntPair>) - Static method in class org.apache.calcite.materialize.LatticeSpace
-
Returns a list of
IntPair
that is sorted and unique. - source - Variable in class org.apache.calcite.adapter.clone.ColumnLoader.Kev
- source - Variable in class org.apache.calcite.adapter.csv.CsvTable
- source - Variable in class org.apache.calcite.adapter.csv.JsonTable
- source - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHit
- source - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHit
- source - Variable in class org.apache.calcite.adapter.file.FileReader
- source - Variable in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.SplunkResultEnumerator
-
Where to find the singleton field, or whether to map.
- source - Variable in class org.apache.calcite.interpreter.AbstractSingleNode
- source - Variable in class org.apache.calcite.materialize.LatticeSuggester.Hop
- source - Variable in class org.apache.calcite.piglet.Ast.Assignment1
- source - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner.DirectProvenance
- source - Variable in class org.apache.calcite.sql.SqlInsert
- source - Variable in class org.apache.calcite.sql.SqlMerge
- source - Variable in class org.apache.calcite.util.graph.DefaultEdge
- source - Variable in class org.apache.calcite.util.javac.JaninoCompiler.JaninoCompilerArgs
- source - Variable in class org.apache.calcite.util.mapping.IntPair
- source - Variable in class org.apache.calcite.util.mapping.Mappings.OverridingSourceMapping
- source - Variable in class org.apache.calcite.util.mapping.Mappings.OverridingTargetMapping
- source() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHit
- source() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHit
- source() - Method in class org.apache.calcite.materialize.LatticeSuggester.StepRef
- source() - Method in class org.apache.calcite.materialize.Step
- source(E) - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- 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.Interpreter.CompilerImpl
- 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.RelMdMaxRowCount
- 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_GROOVY - Static variable in interface org.apache.calcite.adapter.elasticsearch.ElasticsearchConstants
- SOURCE_PAINLESS - Static variable in interface org.apache.calcite.adapter.elasticsearch.ElasticsearchConstants
- SOURCE_SORTER - org.apache.calcite.util.BuiltInMethod
- sourceCount - Variable in class org.apache.calcite.util.mapping.AbstractSourceMapping
- sourceCount - Variable in class org.apache.calcite.util.mapping.AbstractTargetMapping
- sourceCount - Variable in class org.apache.calcite.util.mapping.Mappings.PartialFunctionImpl
- sourceExpressionList - Variable in class org.apache.calcite.rel.core.TableModify
- sourceExpressionList - Variable in class org.apache.calcite.rel.mutable.MutableTableModify
- sourceExpressionList - Variable in class org.apache.calcite.sql.SqlUpdate
- sourceOrFields() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHit
- sourceOrFields() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHit
- sourceQualifiedName - Variable in class org.apache.calcite.rel.RelReferentialConstraintImpl
- sources - Variable in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl.SplunkResultEnumerator
- sources - Variable in class org.apache.calcite.interpreter.UnionNode
- sources - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.Permute
- sources - Variable in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- sources - Variable in class org.apache.calcite.util.Permutation
- Sources - Class in org.apache.calcite.util
-
Utilities for
Source
. - Sources() - Constructor for class org.apache.calcite.util.Sources
- Sources.FileSource - Class in org.apache.calcite.util
-
Implementation of
Source
. - sourceSchema - Variable in class org.apache.calcite.adapter.clone.CloneSchema
- sourceSelect - Variable in class org.apache.calcite.sql.SqlDelete
- sourceSelect - Variable in class org.apache.calcite.sql.SqlMerge
- sourceSelect - Variable in class org.apache.calcite.sql.SqlUpdate
- 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
OrderedAggregateLambdaFactory
. - SourceSorter(Function2<TAccumulate, TSource, TAccumulate>, Function1<TSource, TSortKey>, Comparator<TSortKey>) - Constructor for class org.apache.calcite.adapter.enumerable.SourceSorter
- sourceSorters - Variable in class org.apache.calcite.adapter.enumerable.OrderedAggregateLambdaFactory
- 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.
- space - Variable in class org.apache.calcite.materialize.LatticeSuggester.Query
- space - Variable in class org.apache.calcite.materialize.LatticeSuggester
- space - Variable in class org.apache.calcite.profile.ProfilerImpl.Collector
- Space(Multimap<Method, MetadataHandler>) - Constructor for class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider.Space
- Space(ProfilerImpl.Run, ImmutableBitSet, Iterable<Profiler.Column>) - Constructor for class org.apache.calcite.profile.ProfilerImpl.Space
- Space(ImmutableBitSet, Iterable<Profiler.Column>) - Constructor for class org.apache.calcite.profile.SimpleProfiler.Space
- SPACE - Static variable in interface org.apache.calcite.example.maze.Maze.CellContent
- Space2(Class<Metadata>, ImmutableMultimap<Method, MetadataHandler>) - Constructor for class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider.Space2
- SPACED - org.apache.calcite.adapter.os.SqlShell.Format
- spaceQueue - Variable in class org.apache.calcite.profile.ProfilerImpl.Run
-
Combinations of columns that we will compute next pass.
- spacer - Variable in class org.apache.calcite.piglet.Ast.UnParser
- spacer - Variable in class org.apache.calcite.rel.externalize.RelWriterImpl
- spaces - Variable in class org.apache.calcite.profile.SimpleProfiler.Run
- Span - Class in org.apache.calcite.sql.parser
-
Builder for
SqlParserPos
. - Span() - Constructor for class org.apache.calcite.sql.parser.Span
-
Use one of the
Span.of()
methods. - spark - Variable in class org.apache.calcite.interpreter.InterpretableRel.InterpreterImplementor
- spark() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- spark() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- spark() - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl.ContextImpl
- spark() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.Context
-
Returns the spark handler.
- SPARK - 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_CALC_RULE - Static variable in class org.apache.calcite.adapter.spark.SparkRules
- SPARK_CONTEXT - org.apache.calcite.DataContext.Variable
-
The Spark engine.
- SPARK_VALUES_RULE - Static variable in class org.apache.calcite.adapter.spark.SparkRules
- 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.
- SparkCalcRule() - Constructor for class org.apache.calcite.adapter.spark.SparkRules.SparkCalcRule
- sparkContext - Variable in class org.apache.calcite.adapter.spark.SparkHandlerImpl
- sparkContext() - Method in class org.apache.calcite.adapter.spark.SparkHandlerImpl
- sparkContext() - Method in class org.apache.calcite.jdbc.CalcitePrepare.Dummy.TrivialSparkHandler
- sparkContext() - Method in interface org.apache.calcite.jdbc.CalcitePrepare.SparkHandler
- sparkHandler - Static variable in class org.apache.calcite.jdbc.CalcitePrepare.Dummy
- SparkHandlerImpl - Class in org.apache.calcite.adapter.spark
-
Implementation of
CalcitePrepare.SparkHandler
. - SparkHandlerImpl() - Constructor for class org.apache.calcite.adapter.spark.SparkHandlerImpl
-
Creates a SparkHandlerImpl.
- SparkImplementorImpl(EnumerableRelImplementor) - Constructor for class org.apache.calcite.adapter.spark.SparkToEnumerableConverter.SparkImplementorImpl
- SparkMethod - Enum in org.apache.calcite.adapter.spark
-
Built-in methods in the Spark adapter.
- SparkMethod(Class, String, Class...) - Constructor for enum org.apache.calcite.adapter.spark.SparkMethod
- 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() - Constructor for class org.apache.calcite.adapter.spark.SparkRules
- SparkRules.EnumerableToSparkConverterRule - Class in org.apache.calcite.adapter.spark
-
Planner rule that converts from enumerable to Spark convention.
- SparkRules.SparkCalc - Class in org.apache.calcite.adapter.spark
-
Implementation of
Calc
in Spark convention. - SparkRules.SparkCalcRule - Class in org.apache.calcite.adapter.spark
-
Rule to convert a
LogicalCalc
to anSparkRules.SparkCalc
. - SparkRules.SparkToEnumerableConverterRule - Class in org.apache.calcite.adapter.spark
-
Planner rule that converts from Spark to enumerable 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() - Constructor for class org.apache.calcite.adapter.spark.SparkRuntime
- SparkRuntime.CalciteFlatMapFunction<T,R> - Class in org.apache.calcite.adapter.spark
-
Combines linq4j
Function
and SparkFlatMapFunction
. - 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
- SparkToEnumerableConverter.SparkImplementorImpl - Class in org.apache.calcite.adapter.spark
-
Implementation of
SparkRel.Implementor
. - SparkToEnumerableConverterRule() - Constructor for class org.apache.calcite.adapter.spark.SparkRules.SparkToEnumerableConverterRule
- SparkValues(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, RelTraitSet) - Constructor for class org.apache.calcite.adapter.spark.SparkRules.SparkValues
- SparkValuesRule() - Constructor for class org.apache.calcite.adapter.spark.SparkRules.SparkValuesRule
- SPATIAL_REFERENCE - Static variable in class org.apache.calcite.runtime.GeoFunctions
- special - Variable in enum org.apache.calcite.sql.type.SqlTypeName
-
Returns true if not of a "pure" standard sql type.
- 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 - 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 - org.apache.calcite.util.PrecedenceClimbingParser.Type
- SpecialIdentifier(SqlParserPos) - Constructor for class org.apache.calcite.piglet.Ast.SpecialIdentifier
- SpecialOp(Object, int, int, PrecedenceClimbingParser.Special) - Constructor for class org.apache.calcite.util.PrecedenceClimbingParser.SpecialOp
- SPECIFIC - org.apache.calcite.sql.SqlFunctionCategory.Property
- SPECIFIC_USER - org.apache.calcite.chinook.EnvironmentFairy.User
- SPECIFIC_USER_PREFERRED_ALBUMS - Static variable in class org.apache.calcite.chinook.PreferredAlbumsTableFactory
- SPECIFIC_USER_PREFERRED_GENRES - Static variable in class org.apache.calcite.chinook.PreferredGenresTableFactory
- spiral - Variable in class org.apache.calcite.example.maze.Maze
- split - Variable in class org.apache.calcite.rel.rules.AggregateJoinTransposeRule.Side
- 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(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(RexNode, ImmutableBitSet, List<RexNode>, List<RexNode>) - Static method in class org.apache.calcite.rel.rules.JoinPushThroughJoinRule
-
Splits a condition into conjunctions that do or do not intersect with a given bit set.
- split(SqlNode) - Static method in class org.apache.calcite.sql.validate.IdentifierNamespace
- SPLIT_COUNT - 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(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
- splitCorrelatedFilterCondition(LogicalFilter, RexNode, List<RexInputRef>, List<RexNode>, List<RexNode>) - Static method in class org.apache.calcite.plan.RelOptUtil
- splitCorrelatedFilterCondition(LogicalFilter, RexNode, List<RexNode>, 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(RexBuilder, DruidQuery, List<RexNode>, List<RexNode>, int) - Static method in class org.apache.calcite.adapter.druid.DruidRules.DruidFilterRule
-
Given a list of conditions that contain Druid valid operations and a list that contains those that contain any non-supported operation, it outputs a triple with three different categories: 1-l) condition filters on the timestamp column, 2-m) condition filters that can be pushed to Druid, 3-r) condition filters that cannot be pushed to Druid.
- 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
- 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>, List<RelNode>, RexNode, List<List<RexNode>>, List<Integer>, List<SqlOperator>, List<RexNode>) - Static method in class org.apache.calcite.plan.RelOptUtil
- 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(RexBuilder, int, RexNode, List<Integer>, List<Integer>, List<Boolean>, List<RexNode>) - Static method in class org.apache.calcite.plan.RelOptUtil
- splitLeftAndRightColumns(int, ImmutableBitSet) - Static method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
-
Splits a column set between left and right sets.
- splitOr(RexBuilder, RexNode, RexNode) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
- splitPredicates(RexBuilder, RexNode) - Static method in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
Classifies each of the predicates in the list into one of these three categories: 1-l) column equality predicates, or 2-m) range predicates, comprising <, ≤, >, ≥, and = between a reference and a constant, or 3-r) residual predicates, all the rest
- splitProjects(RexBuilder, RelNode, List<RexNode>) - Static method in class org.apache.calcite.adapter.druid.DruidRules.DruidProjectRule
- 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.SplunkQuery
- 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
- SplunkDriver.MockSplunkConnection - Class in org.apache.calcite.adapter.splunk
-
Connection that looks up responses from a static map.
- SplunkDriver.WrappingSplunkConnection - Class in org.apache.calcite.adapter.splunk
-
Connection that records requests and responses.
- SplunkDriverVersion - Class in org.apache.calcite.adapter.splunk
-
Version information for Calcite JDBC Driver for Splunk.
- SplunkDriverVersion() - Constructor for class org.apache.calcite.adapter.splunk.SplunkDriverVersion
-
Creates a SplunkDriverVersion.
- SplunkPushDownRule - Class in org.apache.calcite.adapter.splunk
-
Planner rule to push filters and projections to Splunk.
- 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
-
Creates a SplunkPushDownRule.
- 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.
- splunkTable - Variable in class org.apache.calcite.adapter.splunk.SplunkTableScan
- SplunkTable - Class in org.apache.calcite.adapter.splunk
-
Table based on Splunk.
- SplunkTable() - Constructor for class org.apache.calcite.adapter.splunk.SplunkTable
- SplunkTable.SplunkTableQueryable<T> - Class in org.apache.calcite.adapter.splunk
-
Implementation of
Queryable
backed by aSplunkTable
. - SplunkTableQueryable(QueryProvider, SchemaPlus, SplunkTable, String) - Constructor for class org.apache.calcite.adapter.splunk.SplunkTable.SplunkTableQueryable
- 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
- SQID - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
-
single-quoted string literal, e.g.
- sql - Variable in class org.apache.calcite.benchmarks.ParserBenchmark
- 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.materialize.MaterializationActor.Materialization
- sql - Variable in class org.apache.calcite.materialize.MaterializationActor.QueryKey
- 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.prepare.Prepare.Materialization
-
The query that derives the data.
- sql - Variable in class org.apache.calcite.runtime.ResultSetEnumerable
- sql - Variable in class org.apache.calcite.sql.advise.SqlSimpleParser.Tokenizer
- sql - Variable in class org.apache.calcite.sql.parser.SqlParserUtil.StringAndPos
- sql - Variable in enum org.apache.calcite.sql.SqlJsonConstructorNullClause
- sql - Variable in enum org.apache.calcite.sql.SqlKind
- sql - Variable in enum org.apache.calcite.sql.SqlMatchRecognize.AfterOption
- sql - Variable in enum org.apache.calcite.sql.SqlMatchRecognize.RowsPerMatchOption
- sql - Variable in enum org.apache.calcite.sql.SqlWindow.Bound
- sql - Variable in class org.apache.calcite.sql.util.SqlString
- sql() - Method in enum org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- 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, 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_92_RESERVED_WORD_SET - Static variable in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
- SQL_ADVISOR - org.apache.calcite.DataContext.Variable
-
Advisor that suggests completion hints for SQL statements.
- SQL_BIGINT - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_BINARY - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_BOOLEAN - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_CHAR - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_DATE - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_DECIMAL - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_DOUBLE - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_FLOAT - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTEGER - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_DAY - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_DAY_TO_HOUR - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_DAY_TO_MINUTE - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_DAY_TO_SECOND - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_HOUR - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_HOUR_TO_MINUTE - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_HOUR_TO_SECOND - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_MINUTE - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_MINUTE_TO_SECOND - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_MONTH - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_SECOND - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_YEAR - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_INTERVAL_YEAR_TO_MONTH - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_NUMERIC - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_REAL - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_SERVER - org.apache.calcite.config.Lex
-
Lexical policy similar to Microsoft SQL Server.
- SQL_SERVER_2008 - org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that instructs Calcite to use SQL semantics consistent with Microsoft SQL Server version 2008.
- SQL_SIMILAR_SPECIALS - Static variable in class org.apache.calcite.runtime.Like
- SQL_SMALLINT - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_TIME - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_TIME_WITH_LOCAL_TIME_ZONE - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_TIMESTAMP - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_TIMESTAMP_WITH_LOCAL_TIME_ZONE - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_TINYINT - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_VARBINARY - org.apache.calcite.sql.SqlJdbcDataTypeName
- SQL_VARCHAR - 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_LOGGER - Static variable in class org.apache.calcite.sql2rel.RelDecorrelator
- 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).
- sql92ReservedWords - Variable in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
- 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.
- SqlAbstractParserImpl - Class in org.apache.calcite.sql.parser
-
Abstract base for parsers generated from CommonParser.jj.
- SqlAbstractParserImpl() - Constructor for class org.apache.calcite.sql.parser.SqlAbstractParserImpl
- SqlAbstractParserImpl.ExprContext - Enum in org.apache.calcite.sql.parser
-
Type-safe enum for context of acceptable expressions.
- SqlAbstractParserImpl.Metadata - Interface in org.apache.calcite.sql.parser
-
Metadata about the parser.
- SqlAbstractParserImpl.MetadataImpl - Class in org.apache.calcite.sql.parser
-
Default implementation of the
SqlAbstractParserImpl.Metadata
interface. - SqlAbstractStringLiteral - Class in org.apache.calcite.sql
-
Abstract base for character and binary string literals.
- SqlAbstractStringLiteral(Object, SqlTypeName, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlAbstractStringLiteral
- 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
-
Enumeration representing different access types
- SqlAccessEnum() - Constructor for enum org.apache.calcite.sql.SqlAccessEnum
- 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
-
An inner class that represents error message 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, SqlConformance) - 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.
- 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.
- SqlArgumentAssignmentOperator - Class in org.apache.calcite.sql.fun
-
Operator that assigns an argument to a function call to a particular named parameter.
- SqlArgumentAssignmentOperator() - Constructor for class org.apache.calcite.sql.fun.SqlArgumentAssignmentOperator
- 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
- 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
. - SqlAttributeDefinition(SqlParserPos, SqlIdentifier, SqlDataTypeSpec, SqlNode, SqlCollation) - Constructor for class org.apache.calcite.sql.ddl.SqlAttributeDefinition
- SqlAvgAggFunction - Class in org.apache.calcite.sql.fun
-
Avg
is an aggregator which returns the average of the values which go into it. - SqlAvgAggFunction(String, SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlAvgAggFunction
- 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.
- SqlBaseContextVariable - Class in org.apache.calcite.sql.fun
-
Base class for functions such as "PI", "USER", "CURRENT_ROLE", and "CURRENT_PATH".
- SqlBaseContextVariable(String, SqlReturnTypeInference, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.fun.SqlBaseContextVariable
-
Creates a SqlBaseContextVariable.
- SqlBasicCall - Class in org.apache.calcite.sql
-
Implementation of
SqlCall
that keeps its operands in an array. - SqlBasicCall(SqlOperator, SqlNode[], SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlBasicCall
- SqlBasicCall(SqlOperator, SqlNode[], SqlParserPos, boolean, SqlLiteral) - Constructor for class org.apache.calcite.sql.SqlBasicCall
- 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. - 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.AndFinder - Class in org.apache.calcite.sql.fun
-
Finds an AND operator in an expression.
- 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
- 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. - SqlCaseOperator() - Constructor for class org.apache.calcite.sql.fun.SqlCaseOperator
- SqlCastFunction - Class in org.apache.calcite.sql.fun
-
SqlCastFunction.
- SqlCastFunction() - 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. - SqlCheckConstraint(SqlParserPos, SqlIdentifier, SqlNode) - Constructor for class org.apache.calcite.sql.ddl.SqlCheckConstraint
-
Creates a SqlCheckConstraint; use
SqlDdlNodes.check(org.apache.calcite.sql.parser.SqlParserPos, org.apache.calcite.sql.SqlIdentifier, org.apache.calcite.sql.SqlNode)
. - 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.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
- SqlColumnDeclaration - Class in org.apache.calcite.sql.ddl
-
Parse tree for
UNIQUE
,PRIMARY KEY
constraints. - SqlColumnDeclaration(SqlParserPos, SqlIdentifier, SqlDataTypeSpec, SqlNode, ColumnStrategy) - Constructor for class org.apache.calcite.sql.ddl.SqlColumnDeclaration
- 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
- 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.
- SqlConformanceEnum() - Constructor for enum org.apache.calcite.sql.validate.SqlConformanceEnum
- SqlConvertFunction - Class in org.apache.calcite.sql.fun
-
Common base for the
CONVERT
andTRANSLATE
functions. - SqlConvertFunction(String) - 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. - SqlCreateForeignSchema(SqlParserPos, boolean, boolean, SqlIdentifier, SqlNode, SqlNode, SqlNodeList) - Constructor for class org.apache.calcite.sql.ddl.SqlCreateForeignSchema
-
Creates a SqlCreateForeignSchema.
- 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. - SqlCreateMaterializedView(SqlParserPos, boolean, boolean, SqlIdentifier, SqlNodeList, SqlNode) - Constructor for class org.apache.calcite.sql.ddl.SqlCreateMaterializedView
-
Creates a SqlCreateView.
- SqlCreateMaterializedView.MaterializedViewTable - Class in org.apache.calcite.sql.ddl
-
A table that implements a materialized view.
- SqlCreateSchema - Class in org.apache.calcite.sql.ddl
-
Parse tree for
CREATE SCHEMA
statement. - SqlCreateSchema(SqlParserPos, boolean, boolean, SqlIdentifier) - Constructor for class org.apache.calcite.sql.ddl.SqlCreateSchema
-
Creates a SqlCreateSchema.
- 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.
- SqlCreateTable.AbstractModifiableTable - Class in org.apache.calcite.sql.ddl
-
Abstract base class for implementations of
ModifiableTable
. - SqlCreateTable.ColumnDef - Class in org.apache.calcite.sql.ddl
-
Column definition.
- SqlCreateTable.MutableArrayTable - Class in org.apache.calcite.sql.ddl
-
Table backed by a Java list.
- SqlCreateType - Class in org.apache.calcite.sql.ddl
-
Parse tree for
CREATE TYPE
statement. - SqlCreateType(SqlParserPos, boolean, SqlIdentifier, SqlNodeList, SqlDataTypeSpec) - Constructor for class org.apache.calcite.sql.ddl.SqlCreateType
-
Creates a SqlCreateType.
- SqlCreateView - Class in org.apache.calcite.sql.ddl
-
Parse tree for
CREATE VIEW
statement. - SqlCreateView(SqlParserPos, boolean, SqlIdentifier, SqlNodeList, SqlNode) - Constructor for class org.apache.calcite.sql.ddl.SqlCreateView
-
Creates a SqlCreateView.
- 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(SqlIdentifier, int, int, String, TimeZone, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlDataTypeSpec
-
Creates a type specification representing a regular, non-collection type.
- SqlDataTypeSpec(SqlIdentifier, SqlIdentifier, int, int, String, TimeZone, Boolean, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlDataTypeSpec
-
Creates a type specification that has no base type.
- SqlDataTypeSpec(SqlIdentifier, SqlIdentifier, int, int, String, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlDataTypeSpec
-
Creates a type specification representing a collection type.
- SqlDataTypeSpec(SqlIdentifier, SqlIdentifier, SqlIdentifier, int, int, String, TimeZone, Boolean, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlDataTypeSpec
-
Creates a type specification.
- SqlDateLiteral - Class in org.apache.calcite.sql
-
A SQL literal representing a DATE value, such as
DATE '2004-10-22'
. - SqlDateLiteral(DateString, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlDateLiteral
- 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.
- SqlDatetimePlusOperator() - Constructor for class org.apache.calcite.sql.fun.SqlDatetimePlusOperator
- SqlDatetimeSubtractionOperator - Class in org.apache.calcite.sql.fun
-
A special operator for the subtraction of two DATETIMEs.
- SqlDatetimeSubtractionOperator() - 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() - Constructor for class org.apache.calcite.sql.ddl.SqlDdlNodes
- SqlDdlNodes.FileType - Enum in org.apache.calcite.sql.ddl
-
File type for CREATE FUNCTION.
- SqlDefaultOperator - Class in org.apache.calcite.sql.fun
-
Operator that indicates that an argument to a function call is to take its default value.
- SqlDefaultOperator() - Constructor for class org.apache.calcite.sql.fun.SqlDefaultOperator
- 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.
- 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.ContextImpl - Class in org.apache.calcite.sql
-
Implementation of Context.
- SqlDialect.DatabaseProduct - Enum in org.apache.calcite.sql
-
Rough list of flavors of database.
- SqlDialect.FakeUtil - Class in org.apache.calcite.sql
-
A few utility functions copied from org.apache.calcite.util.Util.
- 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
- SqlDotOperator - Class in org.apache.calcite.sql.fun
-
The dot operator
.
, used to access a field of a record. - SqlDotOperator() - Constructor for class org.apache.calcite.sql.fun.SqlDotOperator
- 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. - SqlDropMaterializedView(SqlParserPos, boolean, SqlIdentifier) - Constructor for class org.apache.calcite.sql.ddl.SqlDropMaterializedView
-
Creates a SqlDropMaterializedView.
- SqlDropObject - Class in org.apache.calcite.sql.ddl
-
Base class for parse trees of
DROP TABLE
,DROP VIEW
,DROP MATERIALIZED VIEW
andDROP TYPE
statements. - SqlDropObject(SqlOperator, SqlParserPos, boolean, SqlIdentifier) - Constructor for class org.apache.calcite.sql.ddl.SqlDropObject
-
Creates a SqlDropObject.
- SqlDropSchema - Class in org.apache.calcite.sql.ddl
-
Parse tree for
DROP TABLE
statement. - SqlDropSchema(SqlParserPos, boolean, boolean, SqlIdentifier) - Constructor for class org.apache.calcite.sql.ddl.SqlDropSchema
-
Creates a SqlDropSchema.
- SqlDropTable - Class in org.apache.calcite.sql.ddl
-
Parse tree for
DROP TABLE
statement. - SqlDropTable(SqlParserPos, boolean, SqlIdentifier) - Constructor for class org.apache.calcite.sql.ddl.SqlDropTable
-
Creates a SqlDropTable.
- SqlDropType - Class in org.apache.calcite.sql.ddl
-
Parse tree for
DROP TYPE
statement. - SqlDropType(SqlParserPos, boolean, SqlIdentifier) - Constructor for class org.apache.calcite.sql.ddl.SqlDropType
- SqlDropView - Class in org.apache.calcite.sql.ddl
-
Parse tree for
DROP VIEW
statement. - SqlDropView(SqlParserPos, boolean, SqlIdentifier) - Constructor for class org.apache.calcite.sql.ddl.SqlDropView
-
Creates a SqlDropView.
- 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
- SqlExecutableStatement - Interface in org.apache.calcite.sql
-
Mix-in interface for
SqlNode
that allows DDL commands to be executed directly. - 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. - SqlExplainFormat() - Constructor for enum org.apache.calcite.sql.SqlExplainFormat
- SqlExplainLevel - Enum in org.apache.calcite.sql
-
SqlExplainLevel defines detail levels for EXPLAIN PLAN.
- SqlExplainLevel() - Constructor for enum org.apache.calcite.sql.SqlExplainLevel
- SqlExtendOperator - Class in org.apache.calcite.sql.fun
-
EXTEND
operator. - SqlExtendOperator() - Constructor for class org.apache.calcite.sql.fun.SqlExtendOperator
- SqlExtractFunction - Class in org.apache.calcite.sql.fun
-
The SQL
EXTRACT
operator. - SqlExtractFunction() - 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
-
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 builtin 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.
- SqlFunctionCategory(String, String, SqlFunctionCategory.Property...) - Constructor for enum org.apache.calcite.sql.SqlFunctionCategory
- SqlFunctionCategory.Property - Enum in org.apache.calcite.sql
-
Property of a SqlFunctionCategory.
- SqlFunctions - Class in org.apache.calcite.runtime
-
Helper methods to implement SQL functions in generated code.
- SqlFunctions() - Constructor for class org.apache.calcite.runtime.SqlFunctions
- SqlFunctions.FlatProductInputType - Enum in org.apache.calcite.runtime
-
Type of argument passed into
SqlFunctions.flatProduct(int[], boolean, org.apache.calcite.runtime.SqlFunctions.FlatProductInputType[])
. - SqlFunctions.PathContext - Class in org.apache.calcite.runtime
-
Returned path context of JsonApiCommonSyntax, public for testing.
- SqlFunctions.PathMode - Enum in org.apache.calcite.runtime
-
Path spec has two different modes: lax mode and strict mode.
- SqlFunctions.ProductComparableListEnumerator<E extends java.lang.Comparable> - Class in org.apache.calcite.runtime
-
Enumerates over the cartesian product of the given lists, returning a comparable list for each row.
- 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.
- SqlGroupIdFunction - Class in org.apache.calcite.sql.fun
-
The
GROUP_ID()
function. - SqlGroupIdFunction() - Constructor for class org.apache.calcite.sql.fun.SqlGroupIdFunction
- SqlGroupingFunction - Class in org.apache.calcite.sql.fun
-
The
GROUPING
function. - SqlGroupingFunction(String) - Constructor for class org.apache.calcite.sql.fun.SqlGroupingFunction
- SqlGroupingIdFunction - Class in org.apache.calcite.sql.fun
-
Deprecated.Now that
GROUPING
has the same functionality, this function is deprecated. - SqlGroupingIdFunction() - Constructor for class org.apache.calcite.sql.fun.SqlGroupingIdFunction
-
Deprecated.
- 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
- sqlIdentifier - Variable in class org.apache.calcite.sql.SqlFunction
- sqlIdentifier - Variable in class org.apache.calcite.sql.type.ObjectSqlType
- SqlIdentifier - Class in org.apache.calcite.sql
-
A
SqlIdentifier
is an identifier, possibly compound. - SqlIdentifier(String, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlIdentifier
-
Creates a simple identifier, for example
foo
. - SqlIdentifier(String, SqlCollation, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlIdentifier
-
Creates a simple identifier, for example
foo
, with a collation. - SqlIdentifier(List<String>, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlIdentifier
- SqlIdentifier(List<String>, SqlCollation, SqlParserPos, List<SqlParserPos>) - Constructor for class org.apache.calcite.sql.SqlIdentifier
-
Creates a compound identifier, for example
foo.bar
. - 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.JoinContext - 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
- SqlInOperator(SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlInOperator
-
Creates a 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.
- SqlInsertKeyword() - Constructor for enum org.apache.calcite.sql.SqlInsertKeyword
- 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
- 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(SqlIntervalLiteral.IntervalValue, SqlTypeName, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlIntervalLiteral
- SqlIntervalLiteral.IntervalValue - Class in org.apache.calcite.sql
-
A Interval value.
- SqlIntervalQualifier - Class in org.apache.calcite.sql
-
Represents an INTERVAL qualifier.
- 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 or map. - SqlItemOperator() - 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. - SqlJdbcDataTypeName(TimeUnitRange) - Constructor for enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SqlJdbcDataTypeName(SqlTypeName) - Constructor for enum org.apache.calcite.sql.SqlJdbcDataTypeName
- SqlJdbcDataTypeName(SqlTypeName, TimeUnitRange) - Constructor for enum org.apache.calcite.sql.SqlJdbcDataTypeName
- 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.JdbcToInternalLookupTable - Class in org.apache.calcite.sql
-
Lookup table between JDBC functions and internal representation
- SqlJdbcFunctionCall.MakeCall - Interface in org.apache.calcite.sql
-
Converts a call to a JDBC function to a call to a regular function.
- SqlJdbcFunctionCall.PermutingMakeCall - Class in org.apache.calcite.sql
-
Implementation of
SqlJdbcFunctionCall.MakeCall
that can re-order or ignore operands. - 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
-
SqlJoinOperator
describes the syntax of the SQLJOIN
operator. - SqlJoinOperator() - Constructor for class org.apache.calcite.sql.SqlJoin.SqlJoinOperator
- SqlJsonApiCommonSyntaxOperator - Class in org.apache.calcite.sql.fun
-
The JSON API common syntax including a path specification, which is for JSON querying and processing.
- SqlJsonApiCommonSyntaxOperator() - Constructor for class org.apache.calcite.sql.fun.SqlJsonApiCommonSyntaxOperator
- SqlJsonArrayAggAggFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_OBJECTAGG
aggregate function. - SqlJsonArrayAggAggFunction(String, 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 that how do Json constructors handle null
- SqlJsonConstructorNullClause(String) - Constructor for enum org.apache.calcite.sql.SqlJsonConstructorNullClause
- 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.
- SqlJsonEmptyOrError() - Constructor for enum org.apache.calcite.sql.SqlJsonEmptyOrError
- SqlJsonEncoding - Enum in org.apache.calcite.sql
-
Supported json encodings that could be passed to a
JsonValueExpression
. - SqlJsonEncoding(String) - Constructor for enum org.apache.calcite.sql.SqlJsonEncoding
- SqlJsonExistsErrorBehavior - Enum in org.apache.calcite.sql
-
Categorizing Json exists error behaviors.
- SqlJsonExistsErrorBehavior() - Constructor for enum org.apache.calcite.sql.SqlJsonExistsErrorBehavior
- SqlJsonExistsFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_EXISTS
function. - SqlJsonExistsFunction() - Constructor for class org.apache.calcite.sql.fun.SqlJsonExistsFunction
- SqlJsonObjectAggAggFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_OBJECTAGG
aggregate function. - SqlJsonObjectAggAggFunction(String, 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
- SqlJsonQueryEmptyOrErrorBehavior - Enum in org.apache.calcite.sql
-
Categorizing Json query empty or error behaviors.
- SqlJsonQueryEmptyOrErrorBehavior() - Constructor for enum org.apache.calcite.sql.SqlJsonQueryEmptyOrErrorBehavior
- 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.
- SqlJsonQueryWrapperBehavior() - Constructor for enum org.apache.calcite.sql.SqlJsonQueryWrapperBehavior
- SqlJsonValueEmptyOrErrorBehavior - Enum in org.apache.calcite.sql
-
Categorizing Json value empty or error behaviors.
- SqlJsonValueEmptyOrErrorBehavior() - Constructor for enum org.apache.calcite.sql.SqlJsonValueEmptyOrErrorBehavior
- 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(String, boolean) - Constructor for class org.apache.calcite.sql.fun.SqlJsonValueExpressionOperator
- SqlJsonValueFunction - Class in org.apache.calcite.sql.fun
-
The
JSON_VALUE
function. - SqlJsonValueFunction(String, boolean) - Constructor for class org.apache.calcite.sql.fun.SqlJsonValueFunction
- SqlKeyConstraint - Class in org.apache.calcite.sql.ddl
-
Parse tree for
UNIQUE
,PRIMARY KEY
constraints. - SqlKeyConstraint(SqlParserPos, SqlIdentifier, SqlNodeList) - Constructor for class org.apache.calcite.sql.ddl.SqlKeyConstraint
-
Creates a SqlKeyConstraint.
- sqlKind - Variable in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundBounded
- SqlKind - Enum in org.apache.calcite.sql
-
Enumerates the possible types of
SqlNode
. - SqlKind() - Constructor for enum org.apache.calcite.sql.SqlKind
- SqlKind(String) - Constructor for enum org.apache.calcite.sql.SqlKind
- SqlLateralOperator - Class in org.apache.calcite.sql
-
An operator describing a LATERAL specification.
- SqlLateralOperator(SqlKind) - Constructor for class org.apache.calcite.sql.SqlLateralOperator
- SqlLatticeStatisticProvider - Class in org.apache.calcite.materialize
-
Implementation of
LatticeStatisticProvider
that gets statistics by executing "SELECT COUNT(DISTINCT ...) ..." SQL queries. - SqlLatticeStatisticProvider(Lattice) - Constructor for class org.apache.calcite.materialize.SqlLatticeStatisticProvider
-
Creates a SqlLatticeStatisticProvider.
- 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
- SqlLikeOperator - Class in org.apache.calcite.sql.fun
-
An operator describing the
LIKE
andSIMILAR
operators. - SqlLikeOperator(String, SqlKind, boolean) - Constructor for class org.apache.calcite.sql.fun.SqlLikeOperator
-
Creates a SqlLikeOperator.
- 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.
- SqlLiteralChainOperator - Class in org.apache.calcite.sql.fun
-
Internal operator, by which the parser represents a continued string literal.
- SqlLiteralChainOperator() - Constructor for class org.apache.calcite.sql.fun.SqlLiteralChainOperator
- 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
- 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
- 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.
- SqlMatchRecognizeOperator() - Constructor for class org.apache.calcite.sql.SqlMatchRecognize.SqlMatchRecognizeOperator
- 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(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.
- SqlModality() - Constructor for enum org.apache.calcite.sql.validate.SqlModality
- 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.
- SqlMonikerType() - Constructor for enum org.apache.calcite.sql.validate.SqlMonikerType
- 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.
- SqlMonotonicity() - Constructor for enum org.apache.calcite.sql.validate.SqlMonotonicity
- 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) - 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
- 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
. - SqlNameMatchers() - Constructor for class org.apache.calcite.sql.validate.SqlNameMatchers
- SqlNameMatchers.BaseMatcher - Class in org.apache.calcite.sql.validate
-
Partial implementation of
SqlNameMatcher
. - SqlNameMatchers.LiberalNameMatcher - Class in org.apache.calcite.sql.validate
-
Matcher that remembers the requests that were made of it.
- 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 - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.ValidationError
- SqlNode - Class in org.apache.calcite.sql
-
A
SqlNode
is a SQL parse tree. - SqlNode(SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlNode
-
Creates a node.
- 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 an empty
SqlNodeList
. - SqlNodeToRexConverter - Interface in org.apache.calcite.sql2rel
- SqlNodeToRexConverterImpl - Class in org.apache.calcite.sql2rel
-
Standard implementation of
SqlNodeToRexConverter
. - SqlNodeToRexConverterImpl(SqlRexConvertletTable) - Constructor for class org.apache.calcite.sql2rel.SqlNodeToRexConverterImpl
- 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.
- SqlNullSemantics() - Constructor for enum org.apache.calcite.sql.SqlNullSemantics
- 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
- SqlOperandCountRanges.RangeImpl - Class in org.apache.calcite.sql.type
-
Implementation of
SqlOperandCountRange
. - 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 - Variable in class org.apache.calcite.sql.SqlOperatorBinding
- 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.
- SqlOperatorTable - Interface in org.apache.calcite.sql
-
SqlOperatorTable defines a directory interface for enumerating and looking up SQL operators and functions.
- 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
- SqlOrderBy.Operator - Class in org.apache.calcite.sql
-
Definition of
ORDER BY
operator. - SqlOverlapsOperator - Class in org.apache.calcite.sql.fun
-
SqlOverlapsOperator represents the SQL:1999 standard
OVERLAPS
function. - SqlOverlapsOperator(SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlOverlapsOperator
- 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 in org.apache.calcite.sql.parser
-
SqlParseException defines a checked exception corresponding to
SqlParser
. - SqlParseException(String, SqlParserPos, int[][], String[], Throwable) - Constructor for exception org.apache.calcite.sql.parser.SqlParseException
-
Creates a SqlParseException.
- SqlParser - Class in org.apache.calcite.sql.parser
-
A
SqlParser
parses a SQL statement. - SqlParser(SqlAbstractParserImpl, SqlParser.Config) - Constructor for class org.apache.calcite.sql.parser.SqlParser
- 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
-
Builder for a
SqlParser.Config
. - SqlParser.ConfigImpl - Class in org.apache.calcite.sql.parser
-
Implementation of
SqlParser.Config
. - 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.
- SqlParserUtil - Class in org.apache.calcite.sql.parser
-
Utility methods relating to parsing SQL.
- SqlParserUtil() - Constructor for class org.apache.calcite.sql.parser.SqlParserUtil
- SqlParserUtil.Format - Class in org.apache.calcite.sql.parser
-
Pre-initialized
DateFormat
objects, to be used within the current thread, becauseDateFormat
is not thread-safe. - SqlParserUtil.OldTokenSequenceImpl - Class in org.apache.calcite.sql.parser
-
Implementation of
SqlSpecialOperator.TokenSequence
. - SqlParserUtil.ParsedCollation - Class in org.apache.calcite.sql.parser
-
The components of a collation definition, per the SQL standard.
- SqlParserUtil.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.
- SqlParserUtil.TokenSequenceImpl - Class in org.apache.calcite.sql.parser
-
Implementation of
SqlSpecialOperator.TokenSequence
based on an existing parser. - SqlParserUtil.ToTreeListItem - Class in org.apache.calcite.sql.parser
-
Class that holds a
SqlOperator
and aSqlParserPos
. - SqlPositionFunction - Class in org.apache.calcite.sql.fun
-
The
POSITION
function. - SqlPositionFunction() - Constructor for class org.apache.calcite.sql.fun.SqlPositionFunction
- 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(SqlDialect) - Constructor for class org.apache.calcite.sql.pretty.SqlPrettyWriter
- SqlPrettyWriter(SqlDialect, boolean) - Constructor for class org.apache.calcite.sql.pretty.SqlPrettyWriter
- SqlPrettyWriter(SqlDialect, boolean, PrintWriter) - Constructor for class org.apache.calcite.sql.pretty.SqlPrettyWriter
- SqlPrettyWriter.Bean - Class in org.apache.calcite.sql.pretty
-
Helper class which exposes the get/set methods of an object as properties.
- 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.
- SqlQualified(SqlValidatorScope, int, SqlValidatorNamespace, SqlIdentifier) - Constructor for class org.apache.calcite.sql.validate.SqlQualified
- SqlQuantifyOperator - Class in org.apache.calcite.sql.fun
-
Definition of the SQL
ALL
andSOME
operators. - SqlQuantifyOperator(SqlKind, SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlQuantifyOperator
-
Creates a SqlQuantifyOperator.
- SqlRandFunction - Class in org.apache.calcite.sql.fun
-
The
RAND
function. - SqlRandFunction() - Constructor for class org.apache.calcite.sql.fun.SqlRandFunction
- 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. - SqlReturnTypeInferenceChain(SqlReturnTypeInference...) - Constructor for class org.apache.calcite.sql.type.SqlReturnTypeInferenceChain
-
Creates a SqlReturnTypeInferenceChain from an array of rules.
- 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. - SqlRollupOperator - Class in org.apache.calcite.sql.fun
-
Operator that appears in a
GROUP BY
clause:CUBE
,ROLLUP
,GROUPING SETS
. - SqlRollupOperator(String, SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlRollupOperator
- 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
- 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) - 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.
- SqlSelectKeyword() - Constructor for enum org.apache.calcite.sql.SqlSelectKeyword
- SqlSelectOperator - Class in org.apache.calcite.sql
-
An operator describing a query.
- SqlSelectOperator() - Constructor for class org.apache.calcite.sql.SqlSelectOperator
- SqlSequenceValueOperator - Class in org.apache.calcite.sql.fun
-
Operator that returns the current or next value of a sequence.
- SqlSequenceValueOperator(SqlKind) - Constructor for class org.apache.calcite.sql.fun.SqlSequenceValueOperator
-
Creates a SqlSequenceValueOperator.
- 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.
- SqlShell - Class in org.apache.calcite.adapter.os
-
Command that executes its arguments as a SQL query against Calcite's OS adapter.
- SqlShell(InputStreamReader, PrintWriter, PrintWriter, String...) - Constructor for class org.apache.calcite.adapter.os.SqlShell
- SqlShell.Format - Enum in org.apache.calcite.adapter.os
-
Output format.
- 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. - sqlSimilarRewriteCharEnumeration(String, StringBuilder, int, char) - Static method in class org.apache.calcite.runtime.Like
- 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
- SqlSimpleParser.Query - Class in org.apache.calcite.sql.advise
- SqlSimpleParser.Token - Class in org.apache.calcite.sql.advise
- SqlSimpleParser.Tokenizer - Class in org.apache.calcite.sql.advise
- SqlSimpleParser.TokenType - Enum in org.apache.calcite.sql.advise
- 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. - 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
- 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
- SqlStateCodes(String, String, String) - Constructor for enum org.apache.calcite.sql.SqlStateCodes
-
Deprecated.
- SqlStatisticProvider - Interface in org.apache.calcite.materialize
-
Estimates row counts for tables and columns.
- 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 - 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
- SqlSubstitutionSampleSpec(String) - Constructor for class org.apache.calcite.sql.SqlSampleSpec.SqlSubstitutionSampleSpec
- SqlSubstringFunction - Class in org.apache.calcite.sql.fun
-
Definition of the "SUBSTRING" builtin SQL function.
- SqlSubstringFunction() - Constructor for class org.apache.calcite.sql.fun.SqlSubstringFunction
-
Creates the SqlSubstringFunction.
- 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
. - SqlSyntax() - Constructor for enum org.apache.calcite.sql.SqlSyntax
- SqlTableSampleSpec(boolean, float) - Constructor for class org.apache.calcite.sql.SqlSampleSpec.SqlTableSampleSpec
- SqlTableSampleSpec(boolean, float, int) - Constructor for class org.apache.calcite.sql.SqlSampleSpec.SqlTableSampleSpec
- 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
- SqlTimeLiteral - Class in org.apache.calcite.sql
-
A SQL literal representing a TIME value, for example
TIME '14:33:44.567'
. - SqlTimeLiteral(TimeString, int, boolean, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlTimeLiteral
- SqlTimeoutException - Exception in org.apache.calcite.jdbc
-
Indicates that an operation timed out.
- SqlTimeoutException() - Constructor for exception org.apache.calcite.jdbc.SqlTimeoutException
- SqlTimestampAddFunction - Class in org.apache.calcite.sql.fun
-
The
TIMESTAMPADD
function, which adds an interval to a datetime (TIMESTAMP, TIME or DATE). - SqlTimestampAddFunction() - Constructor for class org.apache.calcite.sql.fun.SqlTimestampAddFunction
-
Creates a SqlTimestampAddFunction.
- SqlTimestampDiffFunction - Class in org.apache.calcite.sql.fun
-
The
TIMESTAMPDIFF
function, which calculates the difference between two timestamps. - SqlTimestampDiffFunction() - Constructor for class org.apache.calcite.sql.fun.SqlTimestampDiffFunction
- SqlTimestampLiteral - Class in org.apache.calcite.sql
-
A SQL literal representing a TIMESTAMP value, for example
TIMESTAMP '1969-07-21 03:15 GMT'
. - SqlTimestampLiteral(TimestampString, int, boolean, SqlParserPos) - Constructor for class org.apache.calcite.sql.SqlTimestampLiteral
- sqlToRegexLike(String, char) - Static method in class org.apache.calcite.runtime.Like
-
Translates a SQL LIKE pattern to Java regex pattern.
- sqlToRegexLike(String, CharSequence) - Static method in class org.apache.calcite.runtime.Like
-
Translates a SQL LIKE pattern to Java regex pattern, with optional escape string.
- sqlToRegexSimilar(String, char) - Static method in class org.apache.calcite.runtime.Like
-
Translates SQL SIMILAR pattern to Java regex pattern.
- sqlToRegexSimilar(String, CharSequence) - Static method in class org.apache.calcite.runtime.Like
-
Translates a SQL SIMILAR pattern to Java regex pattern, with optional escape string.
- SqlToRelConverter - Class in org.apache.calcite.sql2rel
- SqlToRelConverter(RelOptTable.ViewExpander, SqlValidator, Prepare.CatalogReader, RelOptCluster, SqlRexConvertletTable) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter
-
Deprecated.
- SqlToRelConverter(RelOptTable.ViewExpander, SqlValidator, Prepare.CatalogReader, RelOptCluster, SqlRexConvertletTable, SqlToRelConverter.Config) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter
- SqlToRelConverter(RelOptTable.ViewExpander, SqlValidator, Prepare.CatalogReader, RelOptPlanner, RexBuilder, SqlRexConvertletTable) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter
-
Deprecated.
- SqlToRelConverter.AggConverter - Class in org.apache.calcite.sql2rel
-
Converts expressions to aggregates.
- SqlToRelConverter.AggregateFinder - Class in org.apache.calcite.sql2rel
-
Visitor that collects all aggregate functions in a
SqlNode
tree. - 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.ConfigBuilder - Class in org.apache.calcite.sql2rel
-
Builder for a
SqlToRelConverter.Config
. - SqlToRelConverter.ConfigImpl - Class in org.apache.calcite.sql2rel
-
Implementation of
SqlToRelConverter.Config
. - SqlToRelConverter.CorrelationUse - Class in org.apache.calcite.sql2rel
-
Use of a row as a correlating variable by a given relational expression.
- SqlToRelConverter.DeferredLookup - Class in org.apache.calcite.sql2rel
-
Deferred lookup.
- SqlToRelConverter.HistogramShuttle - Class in org.apache.calcite.sql2rel
-
Shuttle which walks over a tree of
RexNode
s and applies 'over' to all agg functions. - SqlToRelConverter.LookupContext - Class in org.apache.calcite.sql2rel
-
Context to find a relational expression to a field offset.
- SqlToRelConverter.NoOpSubQueryConverter - Class in org.apache.calcite.sql2rel
-
A default implementation of SubQueryConverter that does no conversion.
- SqlToRelConverter.SubQuery - Class in org.apache.calcite.sql2rel
-
A sub-query, whether it needs to be translated using 2- or 3-valued logic.
- sqlToRelConverterConfig - Variable in class org.apache.calcite.prepare.PlannerImpl
- sqlToRelConverterConfig - Variable in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- sqlToRelConverterConfig - Variable in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- sqlToRelConverterConfig(SqlToRelConverter.Config) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- SqlTranslate3Function - Class in org.apache.calcite.sql.fun
-
Definition of the "TRANSLATE" built-in SQL function that takes 3 arguments.
- SqlTranslate3Function() - Constructor for class org.apache.calcite.sql.fun.SqlTranslate3Function
-
Creates the SqlTranslate3Function.
- SqlTrimFunction - Class in org.apache.calcite.sql.fun
-
Definition of the "TRIM" builtin SQL function.
- SqlTrimFunction(String, SqlKind, SqlTypeTransformCascade, 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".
- sqlType - Variable in enum org.apache.calcite.adapter.druid.DruidType
-
The corresponding SQL type.
- sqlType - Variable in enum org.apache.calcite.adapter.pig.PigDataType
- sqlType(RelDataTypeFactory, int, int, int, String) - Method in class org.apache.calcite.adapter.jdbc.JdbcSchema
- SqlTypeAssignmentRules - Class in org.apache.calcite.sql.type
-
Rules that determine whether a type is assignable from another type.
- SqlTypeAssignmentRules(Map<SqlTypeName, ImmutableSet<SqlTypeName>>) - Constructor for class org.apache.calcite.sql.type.SqlTypeAssignmentRules
- SqlTypeAssignmentRules.Builder - Class in org.apache.calcite.sql.type
-
Keeps state while maps are building build.
- 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
- SqlTypeFactoryImpl.UnknownSqlType - Class in org.apache.calcite.sql.type
-
The unknown type.
- SqlTypeFamily - Enum in org.apache.calcite.sql.type
-
SqlTypeFamily provides SQL type categorization.
- SqlTypeFamily() - Constructor for enum org.apache.calcite.sql.type.SqlTypeFamily
- SqlTypeName - Enum in org.apache.calcite.sql.type
-
Enumeration of the type names which can be used to construct a SQL type.
- SqlTypeName(int, boolean, int, SqlTypeFamily) - Constructor for enum org.apache.calcite.sql.type.SqlTypeName
- SqlTypeName.Limit - Enum in org.apache.calcite.sql.type
-
Limit.
- SqlTypeName.PrecScale - Interface in org.apache.calcite.sql.type
-
Flags indicating precision/scale combinations.
- 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
- SqlUnnestOperator - Class in org.apache.calcite.sql
-
The
UNNEST
operator. - SqlUnnestOperator(boolean) - Constructor for class org.apache.calcite.sql.SqlUnnestOperator
- 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, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, AggregateFunction, boolean, boolean, Optionality, RelDataTypeFactory) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
-
Creates a SqlUserDefinedAggFunction.
- SqlUserDefinedFunction - Class in org.apache.calcite.sql.validate
-
User-defined scalar function.
- SqlUserDefinedFunction(SqlIdentifier, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, List<RelDataType>, Function) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedFunction
-
Creates a
SqlUserDefinedFunction
. - SqlUserDefinedFunction(SqlIdentifier, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, List<RelDataType>, Function, SqlFunctionCategory) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedFunction
-
Constructor used internally and by derived classes.
- SqlUserDefinedTableFunction - Class in org.apache.calcite.sql.validate
-
User-defined table function.
- SqlUserDefinedTableFunction(SqlIdentifier, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, List<RelDataType>, TableFunction) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedTableFunction
- SqlUserDefinedTableMacro - Class in org.apache.calcite.sql.validate
-
User-defined table macro.
- SqlUserDefinedTableMacro(SqlIdentifier, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, List<RelDataType>, TableMacro) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedTableMacro
- SqlUserDefinedTableMacro.NonLiteralException - Exception in org.apache.calcite.sql.validate
-
Thrown when a non-literal occurs in an argument to a user-defined table macro.
- 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. - SqlUtil.Genealogist - Class in org.apache.calcite.sql
-
Walks over a
SqlNode
tree and returns the ancestry stack when it finds a given node. - sqlValidator - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
- SqlValidator - Interface in org.apache.calcite.sql.validate
-
Validates the parse tree of a SQL statement, and provides semantic information about the parse tree.
- SqlValidatorCatalogReader - Interface in org.apache.calcite.sql.validate
-
Supplies catalog information for
SqlValidator
. - SqlValidatorException - Exception in org.apache.calcite.sql.validate
-
Exception thrown while validating a SQL statement.
- SqlValidatorException(String, Throwable) - Constructor for exception org.apache.calcite.sql.validate.SqlValidatorException
-
Creates a new SqlValidatorException object.
- SqlValidatorImpl - Class in org.apache.calcite.sql.validate
-
Default implementation of
SqlValidator
. - SqlValidatorImpl(SqlOperatorTable, SqlValidatorCatalogReader, RelDataTypeFactory, SqlConformance) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Creates a validator.
- SqlValidatorImpl.DeleteNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for a DELETE statement.
- SqlValidatorImpl.DeriveTypeVisitor - Class in org.apache.calcite.sql.validate
-
Visitor which derives the type of a given
SqlNode
. - SqlValidatorImpl.DmlNamespace - Class in org.apache.calcite.sql.validate
-
Common base class for DML statement namespaces.
- SqlValidatorImpl.Expander - Class in org.apache.calcite.sql.validate
-
Converts an expression into canonical form by fully-qualifying any identifiers.
- SqlValidatorImpl.ExtendedExpander - Class in org.apache.calcite.sql.validate
-
Shuttle which walks over an expression in the GROUP BY/HAVING clause, replacing usages of aliases or ordinals with the underlying expression.
- 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.InsertNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for an INSERT statement.
- SqlValidatorImpl.MergeNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for a MERGE statement.
- SqlValidatorImpl.NavigationExpander - Class in org.apache.calcite.sql.validate
-
Shuttle that expands navigation expressions in a MATCH_RECOGNIZE clause.
- SqlValidatorImpl.NavigationModifier - Class in org.apache.calcite.sql.validate
-
Modify the nodes in navigation function such as FIRST, LAST, PREV AND NEXT.
- SqlValidatorImpl.NavigationReplacer - Class in org.apache.calcite.sql.validate
-
Shuttle that replaces
A as A.price > PREV(B.price)
withPREV(A.price, 0) > LAST(B.price, 0)
. - SqlValidatorImpl.OrderExpressionExpander - Class in org.apache.calcite.sql.validate
-
Shuttle which walks over an expression in the ORDER BY clause, replacing usages of aliases with the underlying expression.
- SqlValidatorImpl.PatternValidator - Class in org.apache.calcite.sql.validate
-
Within one navigation function, the pattern var should be same
- SqlValidatorImpl.PatternVarVisitor - Class in org.apache.calcite.sql.validate
-
retrieve pattern variables defined
- SqlValidatorImpl.Permute - Class in org.apache.calcite.sql.validate
-
Permutation of fields in NATURAL JOIN or USING.
- SqlValidatorImpl.Status - Enum in org.apache.calcite.sql.validate
-
Validation status.
- SqlValidatorImpl.UpdateNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for an UPDATE statement.
- SqlValidatorImpl.ValidationError - Class in org.apache.calcite.sql.validate
-
Throws a validator exception with access to the validator context.
- SqlValidatorImpl.ValidationErrorFunction - Class in org.apache.calcite.sql.validate
-
Throws a validator exception with access to the validator context.
- 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. - SqlValidatorUtil - Class in org.apache.calcite.sql.validate
-
Utility methods related to validation.
- SqlValidatorUtil() - Constructor for class org.apache.calcite.sql.validate.SqlValidatorUtil
- SqlValidatorUtil.DeepCopier - Class in org.apache.calcite.sql.validate
-
Deprecated.
- SqlValidatorUtil.GroupAnalyzer - Class in org.apache.calcite.sql.validate
-
Builds a list of GROUP BY expressions.
- 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.Bound - Enum in org.apache.calcite.sql
-
An enumeration of types of bounds in a window:
CURRENT ROW
,UNBOUNDED PRECEDING
, andUNBOUNDED FOLLOWING
. - SqlWindow.SqlWindowOperator - Class in org.apache.calcite.sql
-
An operator describing a window specification.
- SqlWindowOperator() - Constructor for class org.apache.calcite.sql.SqlWindow.SqlWindowOperator
- 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
- SqlWith.SqlWithOperator - Class in org.apache.calcite.sql
-
SqlWithOperator is used to represent a WITH clause of a query.
- 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
- 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
- SqlWithItem.SqlWithItemOperator - Class in org.apache.calcite.sql
-
SqlWithItemOperator is used to represent an item in a WITH clause of a query.
- SqlWithItemOperator() - Constructor for class org.apache.calcite.sql.SqlWithItem.SqlWithItemOperator
- SqlWithOperator() - Constructor for class org.apache.calcite.sql.SqlWith.SqlWithOperator
- SqlWriter - Interface in org.apache.calcite.sql
-
A
SqlWriter
is the target to construct a SQL statement from a parse tree. - SqlWriter(Lattice, SqlDialect, StringBuilder, SqlImplementor.SimpleContext) - Constructor for class org.apache.calcite.materialize.Lattice.SqlWriter
- 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.
- SQLXML - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- SQRT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- SQUARE - org.apache.calcite.runtime.GeoFunctions.CapStyle
- 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.
- sr() - Method in interface org.apache.calcite.runtime.GeoFunctions.Geom
- sr() - Method in class org.apache.calcite.runtime.GeoFunctions.MapGeom
- sr() - Method in class org.apache.calcite.runtime.GeoFunctions.SimpleGeom
- srcFields - Variable in class org.apache.calcite.plan.RelOptUtil.RexInputConverter
- 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. - sslSocketFactory - Variable in class org.apache.calcite.runtime.TrustAllSslSocketFactory
- ST_AsText(GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_AsWKT(GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_Boundary(GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns the boundary of
geom
. - ST_Buffer(GeoFunctions.Geom, double) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Computes a buffer around
geom
. - ST_Buffer(GeoFunctions.Geom, double, int) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Computes a buffer around
geom
with . - ST_Buffer(GeoFunctions.Geom, double, String) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Computes a buffer around
geom
. - ST_Contains(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns whether
geom1
containsgeom2
. - ST_ContainsProperly(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns whether
geom1
containsgeom2
but does not intersect its boundary. - ST_Covers(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns whether no point in
geom2
is outsidegeom1
. - ST_Crosses(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns whether
geom1
crossesgeom2
. - ST_Disjoint(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns whether
geom1
andgeom2
are disjoint. - ST_Distance(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns the distance between
geom1
andgeom2
. - ST_DWithin(GeoFunctions.Geom, GeoFunctions.Geom, double) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns whether
geom1
andgeom2
are withindistance
of each other. - ST_Envelope(GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns the minimum bounding box of
geom
(which may be a GEOMETRYCOLLECTION). - ST_EnvelopesIntersect(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns whether the envelope of
geom1
intersects the envelope ofgeom2
. - ST_Equals(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns whether
geom1
equalsgeom2
. - ST_GeometryType(GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns the type of
geom
. - ST_GeometryTypeCode(GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns the OGC SFS type code of
geom
. - ST_GeomFromText(String) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_GeomFromText(String, int) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_Intersects(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns whether
geom1
intersectsgeom2
. - ST_Is3D(GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns whether
geom
has at least one z-coordinate. - ST_LineFromText(String) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_LineFromText(String, int) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_MakeLine(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Creates a line-string from the given POINTs (or MULTIPOINTs).
- ST_MakeLine(GeoFunctions.Geom, GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_MakeLine(GeoFunctions.Geom, GeoFunctions.Geom, GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_MakeLine(GeoFunctions.Geom, GeoFunctions.Geom, GeoFunctions.Geom, GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_MakeLine(GeoFunctions.Geom, GeoFunctions.Geom, GeoFunctions.Geom, GeoFunctions.Geom, GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_MakePoint(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_MakePoint(BigDecimal, BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_MLineFromText(String) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_MLineFromText(String, int) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_MPointFromText(String) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_MPointFromText(String, int) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_MPolyFromText(String) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_MPolyFromText(String, int) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_OrderingEquals(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns whether
geom1
equalsgeom2
and their coordinates and component Geometries are listed in the same order. - ST_Overlaps(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns
geom1
overlapsgeom2
. - ST_Point(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Constructs a 2D point from coordinates.
- ST_Point(BigDecimal, BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Constructs a 3D point from coordinates.
- ST_PointFromText(String) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_PointFromText(String, int) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_PolyFromText(String) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_PolyFromText(String, int) - Static method in class org.apache.calcite.runtime.GeoFunctions
- ST_SetSRID(GeoFunctions.Geom, int) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns a copy of
geom
with a new SRID. - ST_Touches(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns whether
geom1
touchesgeom2
. - ST_Transform(GeoFunctions.Geom, int) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Transforms
geom
from one coordinate reference system (CRS) to the CRS specified bysrid
. - ST_Union(GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Computes the union of the geometries in
geomCollection
. - ST_Union(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Computes the union of
geom1
andgeom2
. - ST_Within(GeoFunctions.Geom, GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns whether
geom1
is withingeom2
. - ST_X(GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns the x-value of the first coordinate of
geom
. - ST_Y(GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns the y-value of the first coordinate of
geom
. - ST_Z(GeoFunctions.Geom) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns the z-value of the first coordinate of
geom
. - stack - Variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- stack - Variable in class org.apache.calcite.rel.RelShuttleImpl
- stack - Variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- stack - Variable in class org.apache.calcite.tools.RelBuilder
- Stacks - Class in org.apache.calcite.util
-
Deprecated.
- Stacks() - Constructor for class org.apache.calcite.util.Stacks
-
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.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_STREAMS - org.apache.calcite.runtime.Hook
-
Called to get stdin, stdout, stderr.
- StandardConvertletTable - Class in org.apache.calcite.sql2rel
-
Standard implementation of
SqlRexConvertletTable
. - StandardConvertletTable() - Constructor for class org.apache.calcite.sql2rel.StandardConvertletTable
- StandardConvertletTable.AvgVarianceConvertlet - Class in org.apache.calcite.sql2rel
-
Convertlet that handles
AVG
andVARIANCE
windowed aggregate functions. - StandardConvertletTable.FloorCeilConvertlet - Class in org.apache.calcite.sql2rel
-
Convertlet that handles
FLOOR
andCEIL
functions. - StandardConvertletTable.GreatestConvertlet - Class in org.apache.calcite.sql2rel
-
Convertlet that converts
GREATEST
andLEAST
. - StandardConvertletTable.RegrCovarianceConvertlet - Class in org.apache.calcite.sql2rel
-
Convertlet that handles
COVAR_POP
,COVAR_SAMP
,REGR_SXX
,REGR_SYY
windowed aggregate functions. - StandardConvertletTable.TimestampAddConvertlet - Class in org.apache.calcite.sql2rel
-
Convertlet that handles the
TIMESTAMPADD
function. - StandardConvertletTable.TimestampDiffConvertlet - Class in org.apache.calcite.sql2rel
-
Convertlet that handles the
TIMESTAMPDIFF
function. - StandardConvertletTable.TrimConvertlet - Class in org.apache.calcite.sql2rel
-
Convertlet that converts
LTRIM
andRTRIM
toTRIM
. - standardName - Variable in enum org.apache.calcite.sql.SqlJsonEncoding
- star - Variable in enum org.apache.calcite.adapter.pig.PigAggFunction
- 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 - 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.rel.core.Match
- STAR - Static variable in class org.apache.calcite.sql.validate.MatchRecognizeScope
- starRelOptTable - Variable in class org.apache.calcite.plan.RelOptLattice
- starRelOptTable - Variable in class org.apache.calcite.plan.RelOptMaterialization
- starRelOptTable - Variable in class org.apache.calcite.prepare.CalciteMaterializer.Callback
- starRelOptTable - Variable in class org.apache.calcite.prepare.Prepare.Materialization
-
Star table identified.
- starRequiresRecordType() - Method in interface org.apache.calcite.runtime.CalciteResource
- start - Variable in class org.apache.calcite.sql.advise.SqlSimpleParser.Tokenizer
- start - Variable in class org.apache.calcite.sql.type.MatchReturnTypeInference
- start - Variable in class org.apache.calcite.util.ChunkList.ChunkListIterator
-
Offset in the list of the first element of this chunk.
- start() - Method in class org.apache.calcite.adapter.spark.HttpServer
- start() - Method in class org.apache.calcite.interpreter.Interpreter
- start() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.MergeJoinEnumerator
- START - org.apache.calcite.adapter.enumerable.WinAggImplementor.SeekType
-
Start of window.
- starTable - Variable in class org.apache.calcite.plan.RelOptMaterialization
- starTable - Variable in class org.apache.calcite.prepare.CalciteMaterializer.Callback
- StarTable - Class in org.apache.calcite.schema.impl
-
Virtual table that is composed of two or more tables joined together.
- StarTable(Lattice, ImmutableList<Table>) - Constructor for class org.apache.calcite.schema.impl.StarTable
-
Creates a StarTable.
- StarTable.StarTableScan - Class in org.apache.calcite.schema.impl
-
Relational expression that scans a
StarTable
. - starTableEntry - Variable in class org.apache.calcite.jdbc.CalciteSchema.LatticeEntryImpl
- StarTableScan(RelOptCluster, RelOptTable) - Constructor for class org.apache.calcite.schema.impl.StarTable.StarTableScan
- startCol - Variable in class org.apache.calcite.materialize.LatticeNode
- startCol - Variable in class org.apache.calcite.materialize.MutableNode
- startColumnNum - Variable in class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
- started - Variable in class org.apache.calcite.linq4j.EnumerableDefaults.SkipWhileEnumerator
- 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 - Variable in class org.apache.calcite.adapter.enumerable.impl.WinAggResetContextImpl
- 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.
- startLineNum - Variable in class org.apache.calcite.sql.advise.SqlAdvisor.ValidateErrorInfo
- 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) - 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.
- startList(SqlWriter.FrameType, String, String, String) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter
-
Starts a list.
- startOrdinal - Variable in class org.apache.calcite.sql.SqlSpecialOperator.ReduceResult
- startPrecision - Variable in class org.apache.calcite.sql.SqlIntervalQualifier
- startsAt(SqlParserPos) - Method in class org.apache.calcite.sql.parser.SqlParserPos
- startsBefore(SqlParserPos) - Method in class org.apache.calcite.sql.parser.SqlParserPos
- startsWith(List<E>, List<E>) - Static method in class org.apache.calcite.util.Util
-
Returns whether one list is a prefix of another.
- 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.
- stashedParameters - Variable in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- state - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- state - Variable in class org.apache.calcite.prepare.PlannerImpl
- State() - Constructor for enum org.apache.calcite.prepare.PlannerImpl.State
- STATE_0_CLOSED - org.apache.calcite.prepare.PlannerImpl.State
- STATE_1_RESET - org.apache.calcite.prepare.PlannerImpl.State
- STATE_2_READY - org.apache.calcite.prepare.PlannerImpl.State
- STATE_3_PARSED - org.apache.calcite.prepare.PlannerImpl.State
- STATE_4_VALIDATED - org.apache.calcite.prepare.PlannerImpl.State
- STATE_5_CONVERTED - org.apache.calcite.prepare.PlannerImpl.State
- STATE_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Allow an object to alter its behavior when its internal state changes.
- stateClass - Variable in enum org.apache.calcite.sql.SqlStateCodes
-
Deprecated.
- 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
- statementMap - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl.CalciteServerImpl
- statements - Variable in class org.apache.calcite.adapter.pig.PigRel.Implementor
-
An ordered list of Pig Latin statements.
- statements - Variable in class org.apache.calcite.linq4j.tree.BlockBuilder
- statements - Variable in class org.apache.calcite.linq4j.tree.BlockStatement
- StatementTest - Class in org.apache.calcite.benchmarks
-
Compares
Statement
vsPreparedStatement
. - StatementTest() - Constructor for class org.apache.calcite.benchmarks.StatementTest
- StatementTest.Department - Class in org.apache.calcite.benchmarks
-
Department record.
- StatementTest.Employee - Class in org.apache.calcite.benchmarks
-
Employee record.
- StatementTest.HrConnection - Class in org.apache.calcite.benchmarks
-
Connection to be used during tests.
- StatementTest.HrPreparedStatement - Class in org.apache.calcite.benchmarks
-
Tests performance of reused execution of prepared statement.
- StatementTest.HrSchema - Class in org.apache.calcite.benchmarks
-
Pojo schema containing "emps" and "depts" tables.
- stateSize - Variable in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- stateSubClass - Variable in enum org.apache.calcite.sql.SqlStateCodes
-
Deprecated.
- Static - Class in org.apache.calcite.util
-
Definitions of objects to be statically imported.
- Static() - Constructor for class org.apache.calcite.util.Static
- statistic - Variable in class org.apache.calcite.adapter.java.ReflectiveSchema.FieldTable
- Statistic - Interface in org.apache.calcite.schema
-
Statistics about a
Table
. - statistician - Variable in class org.apache.calcite.util.Benchmark
- Statistician(String) - Constructor for class org.apache.calcite.util.Benchmark.Statistician
- statisticProvider - Variable in class org.apache.calcite.materialize.Lattice.Builder
- statisticProvider - Variable in class org.apache.calcite.materialize.Lattice
- statisticProvider - Variable in class org.apache.calcite.materialize.LatticeSpace
- 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 - Variable in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- statisticProvider - Variable in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- 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 - Variable in class org.apache.calcite.profile.SimpleProfiler.Run
- statistics() - Method in class org.apache.calcite.profile.Profiler.Profile
- Statistics - Class in org.apache.calcite.schema
-
Utility functions regarding
Statistic
. - Statistics() - Constructor for class org.apache.calcite.schema.Statistics
- statisticsProvider - Variable in class org.apache.calcite.materialize.TileSuggester.SchemaImpl
- StatisticsProviderImpl(Lattice) - Constructor for class org.apache.calcite.materialize.TileSuggester.StatisticsProviderImpl
- status - Variable in class org.apache.calcite.sql.validate.AbstractNamespace
-
Whether this scope is currently being validated.
- Status() - Constructor for enum org.apache.calcite.sql.validate.SqlValidatorImpl.Status
- STDDEV - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
STDDEV
aggregate function. - STDDEV_POP - org.apache.calcite.sql.fun.SqlAvgAggFunction.Subtype
-
Deprecated.
- STDDEV_POP - 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 - org.apache.calcite.sql.fun.SqlAvgAggFunction.Subtype
-
Deprecated.
- STDDEV_SAMP - 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 - org.apache.calcite.DataContext.Variable
-
Writer to the standard error (stderr).
- StdFrameworkConfig(Context, SqlRexConvertletTable, SqlOperatorTable, ImmutableList<Program>, ImmutableList<RelTraitDef>, SqlParser.Config, SqlToRelConverter.Config, SchemaPlus, RelOptCostFactory, RelDataTypeSystem, RexExecutor, boolean, SqlStatisticProvider, RelOptTable.ViewExpander) - Constructor for class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- STDIN - 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.
- StdinTableFunction() - Constructor for class org.apache.calcite.adapter.os.StdinTableFunction
- STDOUT - org.apache.calcite.DataContext.Variable
-
Writer to the standard output (stdout).
- step - Variable in class org.apache.calcite.materialize.LatticeSuggester.StepRef
- step - Variable in class org.apache.calcite.materialize.MutableNode
- Step - Class in org.apache.calcite.materialize
-
Edge in the join graph.
- Step(LatticeTable, LatticeTable, List<IntPair>) - Constructor for class org.apache.calcite.materialize.Step
- Step(SqlValidatorScope.Path, RelDataType, int, String, StructKind) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorScope.Step
- Step.Factory - Class in org.apache.calcite.materialize
-
Creates
Step
instances. - 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
- stepNames() - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.Path
-
Returns a list ["step1", "step2"].
- stepRef(LatticeSuggester.TableRef, LatticeSuggester.TableRef, List<IntPair>) - Method in class org.apache.calcite.materialize.LatticeSuggester.Query
- StepRef(LatticeSuggester.TableRef, LatticeSuggester.TableRef, Step, int) - Constructor for class org.apache.calcite.materialize.LatticeSuggester.StepRef
- stepRefCount - Variable in class org.apache.calcite.materialize.LatticeSuggester.Query
- steps - Variable in class org.apache.calcite.materialize.Path
- 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.adapter.spark.HttpServer
- stop() - Method in class org.apache.calcite.chinook.ChinookAvaticaServer
- STORED - org.apache.calcite.schema.ColumnStrategy
-
Column is computed and stored.
- str() - Method in class org.apache.calcite.runtime.Resources.Inst
- strategy - Variable in class org.apache.calcite.sql.ddl.SqlColumnDeclaration
- strategy - Variable in class org.apache.calcite.sql.ddl.SqlCreateTable.ColumnDef
- STRATEGY_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Define a family of algorithms, encapsulate each one, and make them interchangeable.
- stream - Variable in class org.apache.calcite.adapter.csv.CsvEnumerator.ArrayRowConverter
- 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() - Method in class org.apache.calcite.adapter.csv.CsvStreamScannableTable
- stream() - Method in interface org.apache.calcite.schema.StreamableTable
-
Returns an enumerator over the rows in this Table.
- STREAM - org.apache.calcite.schema.Schema.TableType
-
Stream.
- STREAM - org.apache.calcite.sql.SqlSelectKeyword
- STREAM - 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() - Constructor for class org.apache.calcite.rel.stream.StreamRules
- StreamRules.DeltaAggregateTransposeRule - Class in org.apache.calcite.rel.stream
- StreamRules.DeltaFilterTransposeRule - Class in org.apache.calcite.rel.stream
- StreamRules.DeltaJoinTransposeRule - Class in org.apache.calcite.rel.stream
- StreamRules.DeltaProjectTransposeRule - Class in org.apache.calcite.rel.stream
- StreamRules.DeltaSortTransposeRule - Class in org.apache.calcite.rel.stream
- StreamRules.DeltaTableScanRule - Class in org.apache.calcite.rel.stream
- 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.DeltaUnionTransposeRule - Class in org.apache.calcite.rel.stream
- streamSetOpInconsistentInputs() - Method in interface org.apache.calcite.runtime.CalciteResource
- strength - Variable in class org.apache.calcite.sql.parser.SqlParserUtil.ParsedCollation
- 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 - org.apache.calcite.adapter.enumerable.NullPolicy
-
Returns null if and only if one of the arguments are null.
- STRICT - org.apache.calcite.runtime.SqlFunctions.PathMode
- STRICT - Static variable in interface org.apache.calcite.sql.validate.SqlValidator
-
Whether to follow the SQL standard strictly.
- STRICT_2003 - 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 - 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 - 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.sql.SqlMatchRecognize
- STRICTLY_ASCENDING - org.apache.calcite.rel.RelFieldCollation.Direction
-
Strictly ascending direction: A value is always followed by a greater value.
- STRICTLY_DECREASING - org.apache.calcite.sql.validate.SqlMonotonicity
- STRICTLY_DESCENDING - org.apache.calcite.rel.RelFieldCollation.Direction
-
Strictly descending direction: A value is always followed by a lesser value.
- STRICTLY_INCREASING - 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.sql.SqlMatchRecognize
- 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.plan.RelTraitSet
- STRING - org.apache.calcite.adapter.csv.CsvFieldType
- STRING - org.apache.calcite.adapter.druid.DruidType
- STRING - org.apache.calcite.adapter.file.FileFieldType
- STRING - org.apache.calcite.sql.SqlFunctionCategory
- STRING - org.apache.calcite.sql.type.SqlTypeFamily
- STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_CONCAT - org.apache.calcite.util.BuiltInMethod
- STRING_DICTIONARY - org.apache.calcite.adapter.clone.ArrayTable.RepresentationType
-
Compressed string table.
- STRING_EQUIVALENCE - Static variable in class org.apache.calcite.rel.mutable.MutableRel
-
Equivalence that compares objects by their
Object.toString()
method. - STRING_FUNCTIONS - Static variable in class org.apache.calcite.sql.SqlJdbcFunctionCall
-
List of all string function names defined by JDBC.
- 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_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_STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- STRING_TO_BOOLEAN - org.apache.calcite.util.BuiltInMethod
- STRING_TO_DATE - org.apache.calcite.util.BuiltInMethod
- STRING_TO_QUERY - org.apache.calcite.runtime.Hook
-
Converts a SQL string to a
CalcitePrepare.Query
object. - STRING_TO_TIME - org.apache.calcite.util.BuiltInMethod
- STRING_TO_TIME_WITH_LOCAL_TIME_ZONE - org.apache.calcite.util.BuiltInMethod
- STRING_TO_TIMESTAMP - org.apache.calcite.util.BuiltInMethod
- STRING_TO_TIMESTAMP_WITH_LOCAL_TIME_ZONE - org.apache.calcite.util.BuiltInMethod
- STRING_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- StringAndPos(String, int, SqlParserPos) - Constructor for class org.apache.calcite.sql.parser.SqlParserUtil.StringAndPos
- StringConcatFunction - Class in org.apache.calcite.chinook
-
Example query for checking query projections
- StringConcatFunction() - Constructor for class org.apache.calcite.chinook.StringConcatFunction
- StringDictionary() - Constructor for class org.apache.calcite.adapter.clone.ArrayTable.StringDictionary
- stringEncodeXML(String, PrintWriter) - Static method in class org.apache.calcite.util.XmlOutput
-
Encode a String for XML output, displaying it to a PrintWriter.
- StringEscaper() - Constructor for class org.apache.calcite.util.XmlOutput.StringEscaper
-
Identity transform
- stringFragsOnSameLine() - Method in interface org.apache.calcite.runtime.CalciteResource
- stringHasXMLSpecials(String) - Static method in class org.apache.calcite.util.XmlOutput
-
Returns whether a string contains any XML special characters.
- stringList(Object) - Static method in class org.apache.calcite.model.ModelHandler
- stringListList(List) - Static method in class org.apache.calcite.model.ModelHandler
- stringLiteral(String) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- StringProp(Resources.PropertyAccessor, Method) - Constructor for class org.apache.calcite.runtime.Resources.StringProp
- 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.
- stringToList(String) - Static method in class org.apache.calcite.util.Util
- StringUtils - Class in org.apache.calcite.adapter.splunk.util
-
Utility methods for encoding and decoding strings for Splunk REST calls.
- StringUtils() - Constructor for class org.apache.calcite.adapter.splunk.util.StringUtils
- stringValue - Variable in class org.apache.calcite.util.NlsString
- stringValue() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.LiteralExpression
- stringValue(RexNode) - Static method in class org.apache.calcite.rex.RexLiteral
- stringValue(Resources.StringProp) - Method in enum org.apache.calcite.runtime.Resources.EmptyPropertyAccessor
- stringValue(Resources.StringProp) - Method in class org.apache.calcite.runtime.Resources.PropertiesAccessor
- stringValue(Resources.StringProp) - Method in interface org.apache.calcite.runtime.Resources.PropertyAccessor
- stringValue(Resources.StringProp, String) - Method in enum org.apache.calcite.runtime.Resources.EmptyPropertyAccessor
- stringValue(Resources.StringProp, String) - Method in class org.apache.calcite.runtime.Resources.PropertiesAccessor
- stringValue(Resources.StringProp, String) - Method in interface org.apache.calcite.runtime.Resources.PropertyAccessor
- stringValue(SqlNode) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Deprecated.
- strip(Iterable<PartiallyOrderedSet.Node<E>>) - Static method in class org.apache.calcite.util.PartiallyOrderedSet
-
Converts an iterable of nodes into the list of the elements inside.
- strip(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.
- 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.
- stripCastFromString(RexNode) - Static method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Removes cast from string.
- stripDot(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- stripDoubleQuotes(String) - Static method in class org.apache.calcite.util.Util
-
Converts double-quoted Java strings to their contents.
- stripFilter(RexNode) - Static method in class org.apache.calcite.adapter.druid.DruidRules.DruidAggregateProjectRule
- stripGenerics(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- stripHep(RelNode) - Static method in class org.apache.calcite.sql2rel.RelDecorrelator
- stripLeadingSign(String) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- stripOver(SqlNode) - Static method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- stripPrefix(String, int) - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter.Bean
- stripQuotes(String) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules
- stripQuotes(String) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRules.RexToGeodeTranslator
- stripQuotes(String) - Method in class org.apache.calcite.adapter.mongodb.MongoRules.RexToMongoTranslator
- strong - Variable in class org.apache.calcite.rel.rules.PushProjector.InputSpecialOpFinder
- strong - Variable in class org.apache.calcite.rex.RexSimplify
- 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.
- strongBitmap - Variable in class org.apache.calcite.rel.rules.PushProjector
-
Bitmap containing the fields that should be strong, i.e.
- stronger(String, Object, Object) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
- stronger(String, Object, Object) - Method in class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
-
Returns whether
v0
is a stronger value for operatorkey
thanv1
. - strongFields - Variable in class org.apache.calcite.rel.rules.PushProjector.InputSpecialOpFinder
- STRUCT_ACCESS - 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.
- StructKind() - Constructor for enum org.apache.calcite.rel.type.StructKind
- structured - Variable in class org.apache.calcite.sql.fun.SqlJsonValueExpressionOperator
- STRUCTURED - 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
- SUB - org.apache.calcite.runtime.Hook
-
Called by the planner after substituting a materialization.
- SUB_QUERY - 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.
- SubExprExistsException(RexNode) - Constructor for exception org.apache.calcite.rex.RexUtil.ExpressionNormalizer.SubExprExistsException
- subList(int, int) - Method in class org.apache.calcite.runtime.AbstractImmutableList
- SUBMULTISET_OF - 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.
- subordinate - Variable in class org.apache.calcite.plan.volcano.ChainedPhaseRuleMappingInitializer
- subprogram - Variable in class org.apache.calcite.plan.hep.HepInstruction.Subprogram
- Subprogram() - Constructor for class org.apache.calcite.plan.hep.HepInstruction.Subprogram
- subquery(RelMetadataProvider) - Static method in class org.apache.calcite.tools.Programs
-
Deprecated.
- subQuery - Variable in class org.apache.calcite.rel.rules.SubQueryRemoveRule.ReplaceSubQueryShuttle
- subQuery(RelMetadataProvider) - Static method in class org.apache.calcite.tools.Programs
- SubQuery(SqlNode, RelOptUtil.Logic) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.SubQuery
- subQueryConverter - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- SubQueryConverter - Interface in org.apache.calcite.sql2rel
-
SubQueryConverter provides the interface for classes that convert sub-queries into equivalent expressions.
- SubQueryFilterRemoveRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.SubQueryRemoveRule.SubQueryFilterRemoveRule
- SubQueryFinder() - Constructor for class org.apache.calcite.rex.RexUtil.SubQueryFinder
- SubQueryJoinRemoveRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.SubQueryRemoveRule.SubQueryJoinRemoveRule
- subQueryList - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
List of
IN
andEXISTS
nodes inside thisSELECT
statement (but not inside sub-queries). - SubQueryProjectRemoveRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.SubQueryRemoveRule.SubQueryProjectRemoveRule
- SubQueryRemoveRule - Class in org.apache.calcite.rel.rules
-
Transform that converts IN, EXISTS and scalar sub-queries into joins.
- SubQueryRemoveRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.SubQueryRemoveRule
-
Creates a SubQueryRemoveRule.
- SubQueryRemoveRule.ReplaceSubQueryShuttle - Class in org.apache.calcite.rel.rules
-
Shuttle that replaces occurrences of a given
RexSubQuery
with a replacement expression. - SubQueryRemoveRule.SubQueryFilterRemoveRule - Class in org.apache.calcite.rel.rules
-
Rule that converts a sub-queries from filter expressions into
Correlate
instances. - SubQueryRemoveRule.SubQueryJoinRemoveRule - Class in org.apache.calcite.rel.rules
-
Rule that converts sub-queries from join expressions into
Correlate
instances. - SubQueryRemoveRule.SubQueryProjectRemoveRule - Class in org.apache.calcite.rel.rules
-
Rule that converts sub-queries from project expressions into
Correlate
instances. - subQueryStyle - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- SubQueryStyle() - Constructor for enum org.apache.calcite.sql.SqlWriter.SubQueryStyle
- SubQueryType() - Constructor for enum org.apache.calcite.plan.RelOptUtil.SubQueryType
- 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.
- SubSchemaCache(CalciteSchema, Set<String>) - Constructor for class org.apache.calcite.jdbc.CachingCalciteSchema.SubSchemaCache
- 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
- subsetImportances - Variable in class org.apache.calcite.plan.volcano.RuleQueue
-
The importance of each subset.
- subsetList - Variable in class org.apache.calcite.sql.SqlMatchRecognize
- subsets - Variable in class org.apache.calcite.plan.volcano.RelSet
- subsets - Variable in class org.apache.calcite.rel.core.Match
- substitute(RelNode, RelOptMaterialization) - Static method in class org.apache.calcite.plan.RelOptMaterializations
- substitute(RexCall, int, RexNode) - Static method in class org.apache.calcite.rel.rules.ReduceExpressionsRule
-
Converts op(arg0, ..., argOrdinal, ..., argN) to op(arg0,..., node, ..., argN).
- substituteSubQuery(SqlToRelConverter.Blackboard, SqlToRelConverter.SubQuery) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- SubstituteVariableVisitor(Map<ParameterExpression, Expression>) - Constructor for class org.apache.calcite.linq4j.tree.BlockBuilder.SubstituteVariableVisitor
- 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.AggregateOnProjectToAggregateUnifyRule - Class in org.apache.calcite.plan
-
Implementation of
SubstitutionVisitor.UnifyRule
that matches aMutableAggregate
on aMutableProject
query to anMutableAggregate
target. - SubstitutionVisitor.AggregateToAggregateUnifyRule - Class in org.apache.calcite.plan
-
Implementation of
SubstitutionVisitor.UnifyRule
that matches aLogicalAggregate
to aLogicalAggregate
, provided that they have the same child. - SubstitutionVisitor.AnyOperand - Class in org.apache.calcite.plan
-
Operand to a
SubstitutionVisitor.UnifyRule
that matches a relational expression of a given type. - SubstitutionVisitor.FilterOnProjectRule - Class in org.apache.calcite.plan
-
Rule that converts a
LogicalFilter
on top of aLogicalProject
into a trivial filter (on a boolean column). - SubstitutionVisitor.FilterToFilterUnifyRule - Class in org.apache.calcite.plan
-
Implementation of
SubstitutionVisitor.UnifyRule
that matches aMutableFilter
. - SubstitutionVisitor.FilterToProjectUnifyRule - Class in org.apache.calcite.plan
- SubstitutionVisitor.InternalOperand - Class in org.apache.calcite.plan
-
Operand to a
SubstitutionVisitor.UnifyRule
that matches a relational expression of a given type. - SubstitutionVisitor.MatchFailed - Exception 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.ProjectToFilterUnifyRule - Class in org.apache.calcite.plan
- SubstitutionVisitor.ProjectToProjectUnifyRule - Class in org.apache.calcite.plan
-
Implementation of
SubstitutionVisitor.UnifyRule
that matchesLogicalProject
. - SubstitutionVisitor.QueryOperand - Class in org.apache.calcite.plan
-
Operand that assigns a particular relational expression to a variable.
- SubstitutionVisitor.Replacement - Class in org.apache.calcite.plan
-
Represents a replacement action: before → after.
- SubstitutionVisitor.ScanToProjectUnifyRule - Class in org.apache.calcite.plan
-
Implementation of
SubstitutionVisitor.UnifyRule
that matchesLogicalTableScan
. - SubstitutionVisitor.SlotCounter - Class in org.apache.calcite.plan
-
Visitor that counts how many
SubstitutionVisitor.QueryOperand
andSubstitutionVisitor.TargetOperand
in an operand tree. - SubstitutionVisitor.TargetOperand - Class in org.apache.calcite.plan
-
Operand that checks that a relational expression matches the corresponding relational expression that was passed to a
SubstitutionVisitor.QueryOperand
. - SubstitutionVisitor.TrivialRule - Class in org.apache.calcite.plan
-
Implementation of
SubstitutionVisitor.UnifyRule
that matches if the query is already equal to the target. - 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
-
Oracle'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(ByteString, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SUBSTRING(binary FROM ...) function.
- substring(ByteString, int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL SUBSTRING(binary FROM ...
- SUBSTRING - 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])
. - 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
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
A subtraction operation, such as (a - b), without overflow checking, for numeric operands.
- SUBTRACT_MONTHS - 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 - 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 - 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
An arithmetic subtraction operation, such as (a - b), that has overflow checking, for numeric operands.
- subtractMonths(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Finds the number of months between two dates, each represented as the number of days since the epoch.
- subtractMonths(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
- Subtype() - Constructor for enum org.apache.calcite.sql.fun.SqlAvgAggFunction.Subtype
-
Deprecated.
- Subtype() - Constructor for enum org.apache.calcite.sql.fun.SqlCovarAggFunction.Subtype
-
Deprecated.
- subUnit(TimeUnitRange) - Method in class org.apache.calcite.rex.RexInterpreter
- succeed() - Method in interface org.apache.calcite.util.Litmus
-
Called when test succeeds.
- SUCCEEDS - org.apache.calcite.sql.SqlKind
-
The "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
-
Combines an iterable of parser positions to create a position which spans from the beginning of the first to the end of the last.
- sum(Iterable<SqlParserPos>, int, int, int, int) - Static method in class org.apache.calcite.sql.parser.SqlParserPos
-
Computes the parser position which is the sum of an array of parser positions and of a parser position represented by (line, column, endLine, endColumn).
- 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(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 - org.apache.calcite.sql.SqlKind
-
The
SUM
aggregate function. - SUM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
SUM
aggregate function. - sum_(List<SqlParserPos>) - Static method in class org.apache.calcite.sql.parser.SqlParserPos
-
Combines a list of parser positions to create a position which spans from the beginning of the first to the end of the last.
- SUM0 - 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(Queryable<T>, FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- sumBigDecimal(FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- sumBigDecimal(FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- sumBigDecimal(FunctionExpression<BigDecimalFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- sumDouble(FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- sumDouble(FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- sumDouble(FunctionExpression<DoubleFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- sumFloat(FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- sumFloat(FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- sumFloat(FunctionExpression<FloatFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Computes the sum of the sequence of Float values that is obtained by invoking a projection function on each element of the input sequence.
- SumImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.SumImplementor
- 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(Queryable<T>, FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- sumInteger(FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- sumInteger(FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- sumInteger(FunctionExpression<IntegerFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- sumLong(FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- sumLong(FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- sumLong(FunctionExpression<LongFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- sumNullableBigDecimal(FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- sumNullableBigDecimal(FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- sumNullableBigDecimal(FunctionExpression<NullableBigDecimalFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- sumNullableDouble(FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- sumNullableDouble(FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- sumNullableDouble(FunctionExpression<NullableDoubleFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- sumNullableFloat(FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- sumNullableFloat(FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- sumNullableFloat(FunctionExpression<NullableFloatFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- sumNullableInteger(FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- sumNullableInteger(FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- sumNullableInteger(FunctionExpression<NullableIntegerFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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(Queryable<T>, FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- sumNullableLong(FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- sumNullableLong(FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- sumNullableLong(FunctionExpression<NullableLongFunction1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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
- supplier - Variable in class org.apache.calcite.adapter.clone.ArrayTable
- supplierFor(Method) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable.JsonArrayAggImplementor
- supplierFor(Method) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable.JsonObjectAggImplementor
- SUPPORTED_AGGREGATES - Static variable in class org.apache.calcite.rel.rules.AggregateUnionTransposeRule
- SUPPORTED_AGGREGATIONS - Static variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchAggregate
- SUPPORTED_DATE_TIME_ROLLUP_UNITS - Static variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.MaterializedViewAggregateRule
- SUPPORTED_OPS - Static variable in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- supportedFunctions - Variable in class org.apache.calcite.sql.dialect.JethroDataSqlDialect.JethroInfo
- supportedRexCall(RexCall) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor
- 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.SqlDialect
- supportsAliasedValues() - Method in class org.apache.calcite.sql.dialect.OracleSqlDialect
- 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.
- supportsCharSet() - Method in class org.apache.calcite.sql.dialect.Db2SqlDialect
- 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.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
- 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.SqlDialect
-
Returns whether this dialect supports a given function or operator.
- supportsModality(SqlModality) - Method in class org.apache.calcite.prepare.RelOptTableImpl
- supportsModality(SqlModality) - Method in class org.apache.calcite.sql.validate.AbstractNamespace
- 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
- 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.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. - supportsWindowFunctions() - Method in class org.apache.calcite.sql.dialect.AccessSqlDialect
- 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).
- SURFACE - org.apache.calcite.runtime.GeoFunctions.Type
- SURJECTION - org.apache.calcite.util.mapping.MappingType
- SurjectionWithInverse(int, int) - Constructor for class org.apache.calcite.util.mapping.Mappings.SurjectionWithInverse
- surprise() - Method in class org.apache.calcite.profile.Profiler.Distribution
- surprise() - Method in class org.apache.calcite.profile.ProfilerImpl.Space
- surprise(double, double) - Static method in class org.apache.calcite.profile.SimpleProfiler
-
Returns a measure of how much an actual value differs from expected.
- SurpriseQueue(int, int) - Constructor for class org.apache.calcite.profile.ProfilerImpl.SurpriseQueue
- surprises - Variable in class org.apache.calcite.profile.ProfilerImpl.Run
- sw - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- 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(List<IntPair>) - Static method in class org.apache.calcite.materialize.LatticeSpace
-
Returns a list of
IntPair
, transposing source and target fields, and ensuring the result is sorted and unique. - swap(PredicateAnalyzer.Expression, PredicateAnalyzer.Expression) - Static method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor
-
Swap order of operands such that the literal expression is always on the right.
- 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
-
Function that swaps source and target fields of an
IntPair
. - SWAP_OUTER - Static variable in class org.apache.calcite.rel.rules.JoinCommuteRule
-
Instance of the rule that swaps outer joins as well as inner joins.
- 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, 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. - swapFilter(RexBuilder, LoptMultiJoin, LoptJoinTree, LoptJoinTree, RexNode) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Adjusts a filter to reflect swapping of join inputs
- swapInputs(RelMetadataQuery, LoptMultiJoin, LoptJoinTree, LoptJoinTree, boolean) - Method in class org.apache.calcite.rel.rules.LoptOptimizeJoinRule
-
Swaps the operands to a join, so the smaller input is on the right.
- swapOuter - Variable in class org.apache.calcite.rel.rules.JoinCommuteRule
- swapped - Variable in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor.SwapResult
- SwapResult(boolean, PredicateAnalyzer.TerminalExpression, PredicateAnalyzer.LiteralExpression) - Constructor for class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor.SwapResult
- 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 - 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
- switchTo(String) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl
-
Change parser state.
- SYBASE - 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(SqlParserPos) - Method in enum org.apache.calcite.sql.fun.SqlTrimFunction.Flag
-
Creates a parse-tree node representing an occurrence of this flag at a particular position in the parsed text.
- symbol(SqlParserPos) - Method in enum org.apache.calcite.sql.JoinConditionType
-
Creates a parse-tree node representing an occurrence of this join type at a particular position in the parsed text.
- symbol(SqlParserPos) - Method in enum org.apache.calcite.sql.JoinType
-
Creates a parse-tree node representing an occurrence of this condition type keyword at a particular position in the parsed text.
- symbol(SqlParserPos) - Method in enum org.apache.calcite.sql.SemiJoinType
-
Creates a parse-tree node representing an occurrence of this condition type keyword at a particular position in the parsed text.
- symbol(SqlParserPos) - Method in enum org.apache.calcite.sql.SqlExplain.Depth
-
Creates a parse-tree node representing an occurrence of this symbol at a particular position in the parsed text.
- symbol(SqlParserPos) - Method in enum org.apache.calcite.sql.SqlExplainFormat
-
Creates a parse-tree node representing an occurrence of this symbol at a particular position in the parsed text.
- symbol(SqlParserPos) - Method in enum org.apache.calcite.sql.SqlExplainLevel
-
Creates a parse-tree node representing an occurrence of this symbol at a particular position in the parsed text.
- symbol(SqlParserPos) - Method in enum org.apache.calcite.sql.SqlInsertKeyword
-
Creates a parse-tree node representing an occurrence of this keyword at a particular position in the parsed text.
- symbol(SqlParserPos) - Method in enum org.apache.calcite.sql.SqlJdbcDataTypeName
-
Creates a parse-tree node representing an occurrence of this keyword at a particular position in the parsed text.
- symbol(SqlParserPos) - Method in enum org.apache.calcite.sql.SqlMatchRecognize.AfterOption
-
Creates a parse-tree node representing an occurrence of this symbol at a particular position in the parsed text.
- symbol(SqlParserPos) - Method in enum org.apache.calcite.sql.SqlMatchRecognize.RowsPerMatchOption
- symbol(SqlParserPos) - Method in enum org.apache.calcite.sql.SqlSelectKeyword
-
Creates a parse-tree node representing an occurrence of this keyword at a particular position in the parsed text.
- symbol(SqlParserPos) - Method in enum org.apache.calcite.sql.SqlWindow.Bound
-
Creates a parse-tree node representing an occurrence of this bound type at a particular position in the parsed text.
- SYMBOL - 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.
- 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 - 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
- syncResults(Meta.StatementHandle, QueryState, long) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- SYNONYM - org.apache.calcite.schema.Schema.TableType
-
A synonym.
- SyntheticRecordType(RelDataType, String) - Constructor for class org.apache.calcite.jdbc.JavaTypeFactoryImpl.SyntheticRecordType
- syntheticType - Variable in class org.apache.calcite.jdbc.JavaTypeFactoryImpl.RecordFieldImpl
- syntheticTypes - Variable in class org.apache.calcite.jdbc.JavaTypeFactoryImpl
- SYSTEM - org.apache.calcite.sql.SqlFunctionCategory
- SYSTEM_FUNCTIONS - Static variable in class org.apache.calcite.sql.SqlJdbcFunctionCall
-
List of all system function names defined by JDBC.
- SYSTEM_INDEX - org.apache.calcite.schema.Schema.TableType
-
System index.
- SYSTEM_TABLE - org.apache.calcite.schema.Schema.TableType
-
A table maintained by the system.
- SYSTEM_TOAST_INDEX - org.apache.calcite.schema.Schema.TableType
-
System TOAST index.
- SYSTEM_TOAST_TABLE - org.apache.calcite.schema.Schema.TableType
-
System TOAST table.
- SYSTEM_USER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
SYSTEM_USER
function. - SYSTEM_VIEW - org.apache.calcite.schema.Schema.TableType
-
System view.
- systemExit(int) - Static method in class org.apache.calcite.util.Unsafe
-
Calls
System.exit(int)
. - systemFieldList - Variable in class org.apache.calcite.rel.logical.LogicalJoin
- systemFieldList - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- SystemFunctionImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.SystemFunctionImplementor
T
- t - Variable in class org.apache.calcite.jdbc.CachingCalciteSchema.AbstractCached
- t - Variable in class org.apache.calcite.materialize.LatticeSuggester.BaseColRef
- t - Variable in class org.apache.calcite.materialize.LatticeTable
- t0 - Variable in class org.apache.calcite.runtime.FlatLists.Flat1List
- t0 - Variable in class org.apache.calcite.runtime.FlatLists.Flat2List
- t0 - Variable in class org.apache.calcite.runtime.FlatLists.Flat3List
- t0 - Variable in class org.apache.calcite.runtime.FlatLists.Flat4List
- t0 - Variable in class org.apache.calcite.runtime.FlatLists.Flat5List
- t0 - Variable in class org.apache.calcite.runtime.FlatLists.Flat6List
- t1 - Variable in class org.apache.calcite.runtime.FlatLists.Flat2List
- t1 - Variable in class org.apache.calcite.runtime.FlatLists.Flat3List
- t1 - Variable in class org.apache.calcite.runtime.FlatLists.Flat4List
- t1 - Variable in class org.apache.calcite.runtime.FlatLists.Flat5List
- t1 - Variable in class org.apache.calcite.runtime.FlatLists.Flat6List
- t2 - Variable in class org.apache.calcite.runtime.FlatLists.Flat3List
- t2 - Variable in class org.apache.calcite.runtime.FlatLists.Flat4List
- t2 - Variable in class org.apache.calcite.runtime.FlatLists.Flat5List
- t2 - Variable in class org.apache.calcite.runtime.FlatLists.Flat6List
- t3 - Variable in class org.apache.calcite.runtime.FlatLists.Flat4List
- t3 - Variable in class org.apache.calcite.runtime.FlatLists.Flat5List
- t3 - Variable in class org.apache.calcite.runtime.FlatLists.Flat6List
- t4 - Variable in class org.apache.calcite.runtime.FlatLists.Flat5List
- t4 - Variable in class org.apache.calcite.runtime.FlatLists.Flat6List
- t5 - Variable in class org.apache.calcite.runtime.FlatLists.Flat6List
- table - Variable in class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
- table - Variable in class org.apache.calcite.adapter.druid.DruidQuery
- table - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.Implementor
- table - Variable in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- table - Variable in class org.apache.calcite.adapter.mongodb.MongoRel.Implementor
- 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.jdbc.CalciteSchema.TableEntryImpl
- 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.Lattice.Vertex
- table - Variable in class org.apache.calcite.materialize.LatticeNode
- table - Variable in class org.apache.calcite.materialize.LatticeSuggester.TableRef
- table - Variable in class org.apache.calcite.materialize.MutableNode
- table - Variable in class org.apache.calcite.materialize.TileSuggester.AttributeImpl
- table - Variable in class org.apache.calcite.materialize.TileSuggester.SchemaImpl
- table - Variable in class org.apache.calcite.model.JsonMaterialization
- table - Variable in class org.apache.calcite.prepare.RelOptTableImpl
- 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.mutable.MutableTableModify
- table - Variable in class org.apache.calcite.rex.RexTableInputRef.RelTableRef
- table - Variable in class org.apache.calcite.schema.impl.AbstractTableQueryable
- table - Variable in class org.apache.calcite.schema.impl.ModifiableViewTable
- table - Variable in class org.apache.calcite.sql.SqlDescribeTable
- table - Variable in class org.apache.calcite.sql.validate.DelegatingSqlValidatorTable
- table - Variable in class org.apache.calcite.sql.validate.TableNamespace
- table(String, DruidConnectionImpl) - Method in class org.apache.calcite.adapter.druid.DruidSchema
- 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 - org.apache.calcite.schema.Schema.TableType
-
A regular table.
- TABLE - org.apache.calcite.sql.validate.SqlMonikerType
- TABLE_FUNCTION - org.apache.calcite.sql.SqlFunctionCategory.Property
- TABLE_FUNCTION_SCAN - org.apache.calcite.rel.mutable.MutableRelType
- TABLE_INPUT_REF - 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_MAP - Static variable in class org.apache.calcite.jdbc.MetadataSchema
- TABLE_MODIFY - org.apache.calcite.rel.mutable.MutableRelType
- TABLE_REFERENCES - org.apache.calcite.util.BuiltInMethod
- TABLE_ROW_COUNTS - Static variable in class org.apache.calcite.adapter.tpcds.TpcdsSchema
- TABLE_SCAN - org.apache.calcite.rel.mutable.MutableRelType
- TableAccessMap - Class in org.apache.calcite.plan
-
TableAccessMap
represents the tables accessed by a query plan, with READ/WRITE information. - TableAccessMap() - Constructor for class org.apache.calcite.plan.TableAccessMap
-
Constructs a permanently empty TableAccessMap.
- TableAccessMap(List<String>, TableAccessMap.Mode) - Constructor for class org.apache.calcite.plan.TableAccessMap
-
Constructs a TableAccessMap for a single table
- TableAccessMap(RelNode) - Constructor for class org.apache.calcite.plan.TableAccessMap
-
Constructs a TableAccessMap for all tables accessed by a RelNode and its descendants.
- TableAccessMap.Mode - Enum in org.apache.calcite.plan
-
Access mode.
- TableAccessMap.TableRelVisitor - Class in org.apache.calcite.plan
-
Visitor that finds all tables in a tree.
- tableAliases() - Method in class org.apache.calcite.materialize.LatticeSuggester.DerivedColRef
- tableCardinality(List<String>) - Method in enum org.apache.calcite.materialize.MapSqlStatisticProvider
- tableCardinality(List<String>) - Method in interface org.apache.calcite.materialize.SqlStatisticProvider
- TableConstructorNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for a table constructor
VALUES (expr, expr, ...)
. - TableConstructorNamespace(SqlValidatorImpl, SqlCall, SqlValidatorScope, SqlNode) - Constructor for class org.apache.calcite.sql.validate.TableConstructorNamespace
-
Creates a TableConstructorNamespace.
- tableElement - Variable in class org.apache.calcite.adapter.file.FileReader
- 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.
- tableFactory - Variable in class org.apache.calcite.materialize.MaterializationService
- 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.
- TableFunctionImpl - Class in org.apache.calcite.schema.impl
-
Implementation of
TableFunction
based on a method. - TableFunctionImpl(Method, CallImplementor) - Constructor for class org.apache.calcite.schema.impl.TableFunctionImpl
-
Private constructor; use
TableFunctionImpl.create(java.lang.Class<?>)
. - 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<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.
- TableImpl() - Constructor for class org.apache.calcite.materialize.TileSuggester.TableImpl
- tableKey() - Method in class org.apache.calcite.adapter.file.FileReader
- tableList - Variable in class org.apache.calcite.sql.util.ChainedSqlOperatorTable
- tableMacro - Variable in class org.apache.calcite.sql.validate.SqlUserDefinedTableMacro
- TableMacro - Interface in org.apache.calcite.schema
-
Function that returns a
Table
. - TableMacroImpl - Class in org.apache.calcite.schema.impl
-
Implementation of
TableMacro
based on a method. - TableMacroImpl(Method) - Constructor for class org.apache.calcite.schema.impl.TableMacroImpl
-
Private constructor; use
TableMacroImpl.create(java.lang.Class<?>)
. - tableMap - Variable in class org.apache.calcite.adapter.csv.CsvSchema
- tableMap - Variable in class org.apache.calcite.adapter.druid.DruidSchema
- tableMap - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSchema
- tableMap - Variable in class org.apache.calcite.adapter.geode.rel.GeodeSchema
- tableMap - Variable in class org.apache.calcite.adapter.geode.simple.GeodeSimpleSchema
- tableMap - Variable in class org.apache.calcite.adapter.java.ReflectiveSchema
- tableMap - Variable in class org.apache.calcite.adapter.jdbc.JdbcSchema
- tableMap - Variable in class org.apache.calcite.adapter.pig.PigSchema
- tableMap - Variable in class org.apache.calcite.adapter.tpcds.TpcdsSchema
- tableMap - Variable in class org.apache.calcite.adapter.tpch.TpchSchema
- tableMap - Variable in class org.apache.calcite.jdbc.CalciteSchema
-
Tables explicitly defined in this schema.
- tableMap - Variable in class org.apache.calcite.materialize.LatticeSpace
- 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.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
- tableNameNotFound(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- tableNameNotFoundDidYouMean(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- tableNames() - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
-
Reads data source names from Druid.
- TableNamespace - Class in org.apache.calcite.sql.validate
-
Namespace based on a table from the catalog.
- TableNamespace(SqlValidatorImpl, SqlValidatorTable) - Constructor for class org.apache.calcite.sql.validate.TableNamespace
- TableNamespace(SqlValidatorImpl, SqlValidatorTable, List<RelDataTypeField>) - Constructor for class org.apache.calcite.sql.validate.TableNamespace
-
Creates a TableNamespace.
- 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
- tablePath - Variable in class org.apache.calcite.schema.impl.ModifiableViewTable
- tableRef - Variable in class org.apache.calcite.rex.RexTableInputRef
- tableRef - Variable in class org.apache.calcite.sql.SqlMatchRecognize
- tableRef(TableScan) - Method in class org.apache.calcite.materialize.LatticeSuggester.Query
- TableRef(LatticeTable, int) - Constructor for class org.apache.calcite.materialize.LatticeSuggester.TableRef
- tableReferencesHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- tableRefs - Variable in class org.apache.calcite.materialize.LatticeSuggester.DerivedColRef
- tableRefs - Variable in class org.apache.calcite.materialize.LatticeSuggester.Frame
- tableRefs - Variable in class org.apache.calcite.materialize.LatticeSuggester.Query
- tableRel - Variable in class org.apache.calcite.plan.RelOptMaterialization
- tableRel - Variable in class org.apache.calcite.prepare.Prepare.Materialization
-
Relational expression for the table.
- TableRelVisitor() - Constructor for class org.apache.calcite.plan.TableAccessMap.TableRelVisitor
- tables - Variable in class org.apache.calcite.adapter.file.FileSchema
- tables - Variable in class org.apache.calcite.materialize.Lattice.DerivedColumn
- 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(String) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- tables(MetaImpl.MetaSchema) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- tables(MetaImpl.MetaSchema, Predicate1<String>) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- TABLES - org.apache.calcite.model.ModelHandler.ExtraOperand
-
Tables defined in this schema.
- TABLESAMPLE - org.apache.calcite.sql.SqlKind
-
TABLESAMPLE 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, RelOptTable) - Constructor for class org.apache.calcite.rel.core.TableScan
- TableScan(RelInput) - Constructor for class org.apache.calcite.rel.core.TableScan
-
Creates a TableScan by parsing serialized output.
- TableScanFactoryImpl() - Constructor for class org.apache.calcite.rel.core.RelFactories.TableScanFactoryImpl
- TableScanNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
TableScan
. - TableScanNode(Compiler, TableScan, Enumerable<Row>) - Constructor for class org.apache.calcite.interpreter.TableScanNode
- TableScanRule - Class in org.apache.calcite.rel.rules
-
Planner rule that converts a
LogicalTableScan
to the result of callingRelOptTable.toRel(org.apache.calcite.plan.RelOptTable.ToRelContext)
. - TableScanRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.TableScanRule
-
Creates a TableScanRule.
- tableScope - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
The name-resolution scope of a LATERAL TABLE clause.
- TableScope - Class in org.apache.calcite.sql.validate
-
The name-resolution scope of a LATERAL TABLE clause.
- TableScope(SqlValidatorScope, SqlNode) - Constructor for class org.apache.calcite.sql.validate.TableScope
-
Creates a scope corresponding to a LATERAL TABLE clause.
- TableType() - Constructor for enum org.apache.calcite.schema.Schema.TableType
- tableTypes() - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- tagStack - Variable in class org.apache.calcite.util.XmlOutput
- tagsWritten - Variable in class org.apache.calcite.util.XmlOutput
- tailer - Variable in class org.apache.calcite.adapter.csv.CsvStreamReader
- take(int) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- take(int) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- take(int) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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 interface org.apache.calcite.linq4j.ExtendedQueryable
-
Returns a specified number of contiguous elements from the start of a sequence.
- take(int) - Method in class org.apache.calcite.linq4j.Linq4j.ListEnumerable
- 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(Queryable<T>, int) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- TAKE - 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(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- takeWhile(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- takeWhile(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- takeWhile(FunctionExpression<Predicate1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Returns elements from a sequence as long as a specified condition is true.
- TakeWhileEnumerator(Enumerator<TSource>, Predicate2<TSource, Integer>) - Constructor for class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileEnumerator
- 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.
- TakeWhileLongEnumerator(Enumerator<TSource>, Predicate2<TSource, Long>) - Constructor for class org.apache.calcite.linq4j.EnumerableDefaults.TakeWhileLongEnumerator
- 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(Queryable<T>, FunctionExpression<Predicate2<T, Integer>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- takeWhileN(FunctionExpression<Predicate2<T, Integer>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- takeWhileN(FunctionExpression<Predicate2<T, Integer>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- takeWhileN(FunctionExpression<Predicate2<TSource, Integer>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Returns elements from a sequence as long as a specified condition is true.
- 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 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- target - Variable in class org.apache.calcite.adapter.java.ReflectiveSchema
- target - Variable in class org.apache.calcite.materialize.LatticeSuggester.Hop
- target - Variable in class org.apache.calcite.piglet.Ast.Assignment
- target - Variable in class org.apache.calcite.plan.Contexts.WrapContext
- target - Variable in class org.apache.calcite.plan.SubstitutionVisitor
- 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 - Variable in class org.apache.calcite.util.mapping.Mappings.OverridingSourceMapping
- target - Variable in class org.apache.calcite.util.mapping.Mappings.OverridingTargetMapping
- target() - Method in class org.apache.calcite.materialize.LatticeSuggester.StepRef
- target() - Method in class org.apache.calcite.materialize.Step
- target(int) - Static method in class org.apache.calcite.plan.SubstitutionVisitor.AbstractUnifyRule
-
Creates an operand that matches a relational expression in the target.
- target(E) - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- target(Iterable<IntPair>, int, int) - Static method in class org.apache.calcite.util.mapping.Mappings
- target(IntFunction<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
. - targetColumnList - Variable in class org.apache.calcite.sql.SqlUpdate
- targetCount - Variable in class org.apache.calcite.plan.SubstitutionVisitor.SlotCounter
- targetCount - Variable in class org.apache.calcite.util.mapping.AbstractSourceMapping
- targetCount - Variable in class org.apache.calcite.util.mapping.AbstractTargetMapping
- targetCount - Variable in class org.apache.calcite.util.mapping.Mappings.PartialFunctionImpl
- targetExpression - Variable in class org.apache.calcite.linq4j.tree.MethodCallExpression
- targetLeaves - Variable in class org.apache.calcite.plan.SubstitutionVisitor
-
Nodes in
SubstitutionVisitor.target
that have no children. - targetOperand - Variable in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRule
- TargetOperand(int) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.TargetOperand
- targetQualifiedName - Variable in class org.apache.calcite.rel.RelReferentialConstraintImpl
- targets - Variable in class org.apache.calcite.util.mapping.Mappings.PartialFunctionImpl
- targets - Variable in class org.apache.calcite.util.mapping.Mappings.PartialMapping
- targets - Variable in class org.apache.calcite.util.Permutation
- targetSet - Variable in class org.apache.calcite.plan.volcano.VolcanoRuleMatch
- targetSubset - Variable in class org.apache.calcite.plan.volcano.VolcanoRuleMatch
- targetTable - Variable in class org.apache.calcite.sql.SqlDelete
- targetTable - Variable in class org.apache.calcite.sql.SqlInsert
- targetTable - Variable in class org.apache.calcite.sql.SqlMerge
- targetTable - Variable in class org.apache.calcite.sql.SqlUpdate
- TCP_NODELAY - Static variable in class org.apache.calcite.runtime.SocketFactoryImpl
-
do not buffer send(s) iff true
- Template - Class in org.apache.calcite.util
-
String template.
- Template(String, List<String>, Locale) - Constructor for class org.apache.calcite.util.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.
- TEMPORARY_INDEX - org.apache.calcite.schema.Schema.TableType
-
Temporary index.
- TEMPORARY_SEQUENCE - org.apache.calcite.schema.Schema.TableType
-
Temporary sequence.
- TEMPORARY_TABLE - org.apache.calcite.schema.Schema.TableType
-
Temporary table.
- TEMPORARY_VIEW - org.apache.calcite.schema.Schema.TableType
-
Temporary view.
- temporaryGroupExprList - Variable in class org.apache.calcite.sql.validate.AggregatingSelectScope
-
Use while under construction.
- TEN - org.apache.calcite.util.mapping.MappingType
- TERADATA - 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.
- terminal - Variable in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor.SwapResult
- termQuery(String, boolean) - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, char) - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A Query that matches documents containing a single character term.
- termQuery(String, double) - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, float) - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, int) - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, long) - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, Object) - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, String) - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A Query that matches documents containing a term.
- TermQueryBuilder(String, Object) - Constructor for class org.apache.calcite.adapter.elasticsearch.QueryBuilders.TermQueryBuilder
- termsQuery(String, Iterable<?>) - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
A filer for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, Iterable<?>) - Constructor for class org.apache.calcite.adapter.elasticsearch.QueryBuilders.TermsQueryBuilder
- TernaryExpression - Class in org.apache.calcite.linq4j.tree
-
Represents an expression that has a ternary operator.
- TernaryExpression(ExpressionType, Type, Expression, Expression, Expression) - Constructor for class org.apache.calcite.linq4j.tree.TernaryExpression
- 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(RexNode) - Method in class org.apache.calcite.rel.rules.PushProjector.OperatorExprCondition
- test(T) - Method in class org.apache.calcite.runtime.PredicateImpl
-
Deprecated.Overrides
java.util.function.Predicate#test
in JDK8 and higher. - 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.
- testPrecondition() - Method in class org.apache.calcite.benchmarks.PreconditionTest
- TEXT - org.apache.calcite.sql.SqlExplainFormat
-
Indicates that the plan should be output as a piece of indented text.
- 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>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(OrderedQueryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- thenBy(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- thenBy(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.EnumerableOrderedQueryable
- 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.linq4j.DefaultQueryable
- thenBy(FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.EnumerableOrderedQueryable
- 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>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(OrderedQueryable<T>, FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- thenByDescending(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- thenByDescending(FunctionExpression<Function1<T, TKey>>) - Method in class org.apache.calcite.linq4j.EnumerableOrderedQueryable
- 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.linq4j.DefaultQueryable
- thenByDescending(FunctionExpression<Function1<T, TKey>>, Comparator<TKey>) - Method in class org.apache.calcite.linq4j.EnumerableOrderedQueryable
- 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.
- thenList - Variable in class org.apache.calcite.sql.fun.SqlCase
- THETA_JOIN - org.apache.calcite.util.BuiltInMethod
- THETA_SKETCH - org.apache.calcite.adapter.druid.DruidType
- thetaJoin(Enumerable<TSource>, Enumerable<TInner>, Predicate2<TSource, TInner>, Function2<TSource, TInner, TResult>, boolean, boolean) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Correlates the elements of two sequences based on a predicate.
- thisOperands - Variable in class org.apache.calcite.sql.SqlJdbcFunctionCall
- THOUSAND - Static variable in class org.apache.calcite.adapter.os.FilesTableFunction
- THOUSAND - Static variable in class org.apache.calcite.sql.SqlIntervalQualifier
- THREAD_CONTEXT_STACK - Static variable in interface org.apache.calcite.jdbc.CalcitePrepare
- 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_INSTANCE - Static variable in class org.apache.calcite.materialize.MaterializationService
-
For testing.
- THREAD_INSTANCES - Static variable in class org.apache.calcite.rel.rules.DateRangeRules.ExtractFinder
- THREAD_LOCAL - Static variable in interface org.apache.calcite.prepare.Prepare.CatalogReader
- THREAD_PROVIDERS - Static variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- THREAD_SEQUENCES - Static variable in class org.apache.calcite.runtime.SqlFunctions
-
Holds, for each thread, a map from sequence name to sequence current value.
- THREAD_TRIM - Static variable in class org.apache.calcite.prepare.Prepare
- threadHandlers - Variable in enum org.apache.calcite.runtime.Hook
- THRESHOLD_SCORE - Static variable in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
- Throw - 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.
- throwableHolder - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.BlockingQueueEnumerator
- throwIfUnchecked(Throwable) - Static method in class org.apache.calcite.util.Util
-
As
Throwables
.throwIfUnchecked(Throwable)
, which was introduced in Guava 20, but we don't require Guava version 20 yet. - ThrowStatement - Class in org.apache.calcite.linq4j.tree
-
Represents a
throw
statement. - ThrowStatement(Expression) - Constructor for class org.apache.calcite.linq4j.tree.ThrowStatement
- Tile(ImmutableList<Lattice.Measure>, ImmutableList<Lattice.Column>) - Constructor for class org.apache.calcite.materialize.Lattice.Tile
- tileBuilder - Variable in class org.apache.calcite.model.ModelHandler
- 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.
- tileListBuilder - Variable in class org.apache.calcite.materialize.Lattice.Builder
- 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
- tilesByDimensionality - Variable in class org.apache.calcite.materialize.MaterializationActor
-
Tiles grouped by dimensionality.
- 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
- TileSuggester.AttributeImpl - Class in org.apache.calcite.materialize
-
Implementation of
Attribute
based on aLattice.Column
. - TileSuggester.SchemaImpl - Class in org.apache.calcite.materialize
-
Implementation of
Schema
based on aLattice
. - TileSuggester.StatisticsProviderImpl - Class in org.apache.calcite.materialize
-
Implementation of
StatisticsProvider
that asks the lattice. - TileSuggester.TableImpl - Class in org.apache.calcite.materialize
-
Implementation of
Table
based on aLattice
. - time - Variable in class org.apache.calcite.sql.parser.SqlParserUtil.Format
- TIME - org.apache.calcite.adapter.csv.CsvFieldType
- TIME - org.apache.calcite.adapter.file.FileFieldType
- TIME - org.apache.calcite.sql.type.SqlTypeFamily
- TIME - org.apache.calcite.sql.type.SqlTypeName
- 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_DATE_FUNCTIONS - Static variable in class org.apache.calcite.sql.SqlJdbcFunctionCall
-
List of all time/date function names defined by JDBC.
- TIME_FORMAT_DATE - Static variable in class org.apache.calcite.adapter.csv.CsvEnumerator
- TIME_FORMAT_TIME - Static variable in class org.apache.calcite.adapter.csv.CsvEnumerator
- TIME_FORMAT_TIMESTAMP - Static variable in class org.apache.calcite.adapter.csv.CsvEnumerator
- 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_STRING_TO_TIME_WITH_LOCAL_TIME_ZONE - org.apache.calcite.util.BuiltInMethod
- TIME_TO_INT - org.apache.calcite.util.BuiltInMethod
- TIME_TO_INT_OPTIONAL - org.apache.calcite.util.BuiltInMethod
- TIME_UNIT_CODES - Static variable in class org.apache.calcite.rel.rules.DateRangeRules
- TIME_UNIT_PARENTS - Static variable in class org.apache.calcite.rel.rules.DateRangeRules
- TIME_UNITS - Static variable in class org.apache.calcite.rex.RexLiteral
- TIME_WITH_LOCAL_TIME_ZONE - org.apache.calcite.sql.type.SqlTypeName
- TIME_WITH_LOCAL_TIME_ZONE_TO_STRING - org.apache.calcite.util.BuiltInMethod
- TIME_WITH_LOCAL_TIME_ZONE_TO_TIME - org.apache.calcite.util.BuiltInMethod
- TIME_WITH_LOCAL_TIME_ZONE_TO_TIMESTAMP - org.apache.calcite.util.BuiltInMethod
- TIME_WITH_LOCAL_TIME_ZONE_TO_TIMESTAMP_WITH_LOCAL_TIME_ZONE - org.apache.calcite.util.BuiltInMethod
- TIME_WITH_TIMEZONE - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- TIME_ZONE - org.apache.calcite.config.CalciteConnectionProperty
-
Time zone, for example 'gmt-3'.
- TIME_ZONE - org.apache.calcite.DataContext.Variable
-
Time zone in which the current statement is executing.
- TIME_ZONE - org.apache.calcite.util.BuiltInMethod
- TIME_ZONE_GET_OFFSET - org.apache.calcite.util.BuiltInMethod
- TIMEDATE - 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
- TIMES - org.apache.calcite.sql.SqlKind
-
The arithmetic multiplication operator, "*".
- TIMESERIES - org.apache.calcite.adapter.druid.QueryType
- timestamp - Variable in class org.apache.calcite.plan.volcano.RelSubset
-
Timestamp for metadata validity
- timestamp - Variable in class org.apache.calcite.rel.metadata.CachingRelMetadataProvider.CacheEntry
- timestamp - Variable in class org.apache.calcite.sql.parser.SqlParserUtil.Format
- TIMESTAMP - org.apache.calcite.adapter.csv.CsvFieldType
- TIMESTAMP - org.apache.calcite.adapter.file.FileFieldType
- TIMESTAMP - org.apache.calcite.sql.type.SqlTypeFamily
- TIMESTAMP - org.apache.calcite.sql.type.SqlTypeName
- TIMESTAMP_ADD - org.apache.calcite.sql.SqlKind
-
The "TIMESTAMP_ADD" function (ODBC, SQL Server, MySQL).
- TIMESTAMP_ADD - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
TIMESTAMPADD
function. - TIMESTAMP_DIFF - org.apache.calcite.sql.SqlKind
-
The "TIMESTAMP_DIFF" function (ODBC, SQL Server, MySQL).
- TIMESTAMP_DIFF - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
TIMESTAMPDIFF
function. - TIMESTAMP_FORMAT - Static variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- TIMESTAMP_STRING_TO_TIMESTAMP_WITH_LOCAL_TIME_ZONE - org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_TO_LONG - org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_TO_LONG_OFFSET - org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_TO_LONG_OPTIONAL - org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_TO_LONG_OPTIONAL_OFFSET - org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_WITH_LOCAL_TIME_ZONE - org.apache.calcite.sql.type.SqlTypeName
- TIMESTAMP_WITH_LOCAL_TIME_ZONE_TO_DATE - org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_WITH_LOCAL_TIME_ZONE_TO_STRING - org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_WITH_LOCAL_TIME_ZONE_TO_TIME - org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_WITH_LOCAL_TIME_ZONE_TO_TIME_WITH_LOCAL_TIME_ZONE - org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_WITH_LOCAL_TIME_ZONE_TO_TIMESTAMP - org.apache.calcite.util.BuiltInMethod
- TIMESTAMP_WITH_TIMEZONE - Static variable in interface org.apache.calcite.sql.type.ExtraSqlTypes
- TimestampAddConvertlet() - Constructor for class org.apache.calcite.sql2rel.StandardConvertletTable.TimestampAddConvertlet
- timestampColumn - Variable in class org.apache.calcite.adapter.druid.DruidTable.MapRelProtoDataType
- TimestampDiffConvertlet() - Constructor for class org.apache.calcite.sql2rel.StandardConvertletTable.TimestampDiffConvertlet
- timestampFieldName - Variable in class org.apache.calcite.adapter.druid.DruidTable
- timestampMethod - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable.FloorImplementor
- 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.
- timestampValue(RexLiteral) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- 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.
- TimeString(String, boolean) - Constructor for class org.apache.calcite.util.TimeString
-
Internal constructor, no validation.
- timeUnit - Variable in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- timeUnit - Variable in class org.apache.calcite.sql.fun.SqlDatePartFunction
- timeUnitRange - Variable in class org.apache.calcite.sql.SqlIntervalQualifier
- timeUnitRanges - Variable in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- timeUnits - Variable in class org.apache.calcite.rel.rules.DateRangeRules.ExtractFinder
- 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 - Variable in class org.apache.calcite.adapter.druid.Granularities.PeriodGranularity
- timeZone - Variable in class org.apache.calcite.adapter.druid.TimeExtractionFunction
- timeZone - Variable in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- timeZone - Variable in class org.apache.calcite.sql.SqlDataTypeSpec
- timeZone - Variable in class org.apache.calcite.util.TimestampWithTimeZoneString
- timeZone - Variable in class org.apache.calcite.util.TimeWithTimeZoneString
- timeZone(DataContext) - Static method in class org.apache.calcite.runtime.SqlFunctions
- TIMEZONE - Static variable in enum org.apache.calcite.config.CalciteConnectionProperty
-
Deprecated.
- timingTracer - Variable in class org.apache.calcite.prepare.Prepare
- TINY - Static variable in class org.apache.calcite.plan.volcano.VolcanoCost
- TINYINT - org.apache.calcite.sql.type.SqlTypeName
- to(Object, boolean) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- 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_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 type and the returned type is the multiset's element type.
- 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_STRING_FUNCTION1 - Static variable in class org.apache.calcite.linq4j.function.Functions
- 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.
- toAggCall(Map<String, Object>) - Method in class org.apache.calcite.rel.externalize.RelJsonReader
- toAggregation(String, Map<String, Object>) - Method in class org.apache.calcite.rel.externalize.RelJson
- 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.EmptyImmutableIntList
- toArray() - Method in class org.apache.calcite.util.ImmutableIntList
- toArray(Iterable<T>, T[]) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- 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.util.ImmutableIntList.EmptyImmutableIntList
- 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. - toBetweenDruidFilter(RexNode, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidJsonFilter
- toBigDecimal(Number) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toBigDecimal(Number) - Static method in class org.apache.calcite.util.NumberUtil
- 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
. - toBitSet(List<Lattice.Column>) - Static method in class org.apache.calcite.materialize.Lattice.Column
-
Converts a list of columns to a bit set of their ordinals.
- 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(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).
- toBoolean(String) - Static method in class org.apache.calcite.util.ConversionUtil
-
Converts a string into a boolean
- toBoundDruidFilter(RexNode, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidJsonFilter
- 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
- toCaseOperands(RexBuilder, List<RexSimplify.CaseBranch>) - Static method in class org.apache.calcite.rex.RexSimplify.CaseBranch
- toCastExpression(RexCall) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor
- 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
- toClassArray(Collection<Type>) - 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).
- toCnf(RexNode) - Method in class org.apache.calcite.rex.RexUtil.CnfHelper
- toCnf2(RexNode) - Method in class org.apache.calcite.rex.RexUtil.CnfHelper
- toCollation(List<Map<String, Object>>) - Method in class org.apache.calcite.rel.externalize.RelJson
- toCollection(Iterable<T>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- toColumns(Iterable<Integer>) - Method in class org.apache.calcite.profile.ProfilerImpl.Run
- toColumns(Iterable<Integer>) - Method in class org.apache.calcite.profile.SimpleProfiler.Run
- toComparable() - Method in enum org.apache.calcite.rex.RexInterpreter.Truthy
- toDistribution(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).
- toDnf(RexNode) - Method in class org.apache.calcite.rex.RexUtil.DnfHelper
- toDnfs(List<RexNode>) - Method in class org.apache.calcite.rex.RexUtil.DnfHelper
- todo() - Static method in class org.apache.calcite.linq4j.Extensions
- todo() - Static method in class org.apache.calcite.runtime.GeoFunctions
- TODO_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Use this to flag temporary code.
- 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(RelOptCost) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Converts a cost to a scalar quantity.
- toDruidColumn(RexNode, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
- 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 Calcite rexNode to Druid Expression when 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
- toDruidExpressionFilter(RexNode, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidJsonFilter
- toDruidExpressions(DruidQuery, RelDataType, List<RexNode>) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
-
Translate a list of Calcite
RexNode
to Druid expressions. - toDruidFilters(RexNode, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidJsonFilter
- toDruidGranularity(TimeUnitRange) - Static method in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
-
Translates Calcite TimeUnitRange to Druid
Granularity
- toDruidLiteral(RexNode, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidJsonFilter
- toElasticAggregate(AggregateCall) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchAggregate
-
Most of the aggregations can be retrieved with single stats function.
- toEnumerable(Object) - Static method in class org.apache.calcite.adapter.java.ReflectiveSchema
- toEnumerable(Expression) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
- toEqualityKindDruidFilter(RexNode, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidJsonFilter
- 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.
- toFunctionBlock(Node) - Static method in class org.apache.calcite.linq4j.tree.Blocks
- toFunctionBlock(Node, boolean) - Static method in class org.apache.calcite.linq4j.tree.Blocks
- 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
- toImmutableList() - Static method in class org.apache.calcite.util.Util
-
Returns a
Collector
that accumulates the input elements into a GuavaImmutableList
via aImmutableList.Builder
. - toIndexesTableExpression(SqlString) - Method in class org.apache.calcite.adapter.jdbc.JdbcToEnumerableConverter
- toInKindDruidFilter(RexNode, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidJsonFilter
- toInputRefs(List<? extends RexNode>) - Static method in class org.apache.calcite.rel.logical.LogicalWindow
- 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(Time) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts the Java type used for UDF parameters of SQL TIME type (
Time
) to internal representation (int). - toInt(Date) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts the Java type used for UDF parameters of SQL DATE type (
Date
) to internal representation (int). - toInt(Date, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
- 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.
- toInternal(RelDataType) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
- toInterval(List<Range<Long>>) - Static method in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
- toIntOptional(Time) - 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
- toIsNullKindDruidFilter(RexNode, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidJsonFilter
- toISOPeriodFormat(Granularity.Type) - Static method in class org.apache.calcite.adapter.druid.DruidDateTimeUtils
- 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(Comparable, SqlTypeName) - Static method in class org.apache.calcite.rex.RexLiteral
- toJoinType() - Method in enum org.apache.calcite.sql.SemiJoinType
- toJson(Object) - Method in class org.apache.calcite.rel.externalize.RelJson
- toJson(AggregateCall) - Method in class org.apache.calcite.rel.externalize.RelJson
- toJson(CorrelationId) - Method in class org.apache.calcite.rel.externalize.RelJson
- toJson(RelCollationImpl) - Method in class org.apache.calcite.rel.externalize.RelJson
- toJson(RelDataType) - Method in class org.apache.calcite.rel.externalize.RelJson
- toJson(RelDataTypeField) - Method in class org.apache.calcite.rel.externalize.RelJson
- toJson(RexNode) - Method in class org.apache.calcite.rel.externalize.RelJson
- toJson(SqlOperator) - 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.
- Token(SqlSimpleParser.TokenType) - Constructor for class org.apache.calcite.sql.advise.SqlSimpleParser.Token
- Token(SqlSimpleParser.TokenType, String) - Constructor for class org.apache.calcite.sql.advise.SqlSimpleParser.Token
- Token(PrecedenceClimbingParser.Type, Object, int, int) - Constructor for class org.apache.calcite.util.PrecedenceClimbingParser.Token
- tokenImages - Variable in exception org.apache.calcite.sql.parser.SqlParseException
- 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
- tokenList - Variable in class org.apache.calcite.sql.advise.SqlSimpleParser.Query
- tokenList - Variable in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
-
Immutable list of all tokens, in alphabetical order.
- TokenList() - Constructor for class org.apache.calcite.util.PrecedenceClimbingParser.TokenList
- tokens - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- TokenSequenceImpl(PrecedenceClimbingParser) - Constructor for class org.apache.calcite.sql.parser.SqlParserUtil.TokenSequenceImpl
- tokenSet - Variable in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
-
Set of all tokens.
- TokenType() - Constructor for enum org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- 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. - toLinq4j() - Method in enum org.apache.calcite.sql.SemiJoinType
- 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.linq4j.Linq4j.ListEnumerable
- toList() - Method in class org.apache.calcite.runtime.AbstractImmutableList
- toList() - Method in class org.apache.calcite.runtime.ConsList
- toList() - Method in class org.apache.calcite.runtime.FlatLists.AbstractFlatList
- toList() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Converts this bit set to a list.
- toList(Iterable<? extends T>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- 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(T[]) - Static method in class org.apache.calcite.linq4j.tree.Expressions
- toList(T[]) - Static method in class org.apache.calcite.linq4j.tree.Types
-
Returns a list backed by a copy of an array.
- toListMapPairs(Map<String, String>) - Static method in class org.apache.calcite.adapter.geode.rel.GeodeToEnumerableConverter
- toLong(Number) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toLong(Object) - Method in class org.apache.calcite.adapter.clone.ColumnLoader.ValueSet
- toLong(Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toLong(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toLong(Timestamp) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts the Java type used for UDF parameters of SQL TIMESTAMP type (
Timestamp
) to internal representation (long). - toLong(Date) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toLong(Date, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toLongArray() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Converts this bit set to an array of little-endian words.
- toLongOptional(Timestamp, TimeZone) - Static method in class org.apache.calcite.runtime.SqlFunctions
- toLongOptional(Date) - 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. - toLookup_(Map<TKey, List<TElement>>, Enumerable<TSource>, Function1<TSource, TKey>, Function1<TSource, TElement>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- toMap(Iterable<ElasticsearchJson.Bucket>) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.RowKey
- toMap(Iterable<Pair<K, 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
- toMeasure(AggregateCall) - Method in class org.apache.calcite.materialize.Lattice
- 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 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.sql.ddl.SqlCreateTable.AbstractModifiableTable
- toMongo(SqlAggFunction, List<String>, List<Integer>) - Method in class org.apache.calcite.adapter.mongodb.MongoAggregate
- toMutable(RelNode) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- toMutables(List<RelNode>) - Static method in class org.apache.calcite.rel.mutable.MutableRels
- toNamedField(RexLiteral) - Static method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor
- 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 an SqlNode array to a SqlNodeList
- toNotDruidFilter(DruidJsonFilter) - Static method in class org.apache.calcite.adapter.druid.DruidJsonFilter
- toObject(FileFieldType, String) - Method in class org.apache.calcite.adapter.file.FileRowConverter.FieldDef
- took - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Result
- took - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult
- took() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.Result
- 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 org.apache.calcite.util.mapping.Mappings.TooManyElementsException
- toOp(String, Map<String, Object>) - Method in class org.apache.calcite.rel.externalize.RelJson
- toOp(RelDataTypeFactory, SqlIdentifier, Function) - Static method in class org.apache.calcite.prepare.CalciteCatalogReader
-
Converts a function to a
SqlOperator
. - toOp(SqlIdentifier, Function) - Method in class org.apache.calcite.prepare.CalciteCatalogReader
- toOrdinals(Iterable<Profiler.Column>) - Static method in class org.apache.calcite.profile.Profiler.Column
- top - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- top - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- TOP_DOWN - 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 - org.apache.calcite.adapter.druid.QueryType
- toPair(Object) - Static method in class org.apache.calcite.adapter.clone.ArrayTable
- TopBottomNode(boolean) - Constructor for class org.apache.calcite.util.PartiallyOrderedSet.TopBottomNode
- toPigAggFunc(AggregateCall) - Method in class org.apache.calcite.adapter.pig.PigAggregate
- topNode - Variable in class org.apache.calcite.util.PartiallyOrderedSet
-
Synthetic node to hold all nodes that have no parents.
- 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
- toPos(Iterable<SqlNode>) - Static method in class org.apache.calcite.sql.parser.SqlParserPos
- toPos(SqlNode[]) - Static method in class org.apache.calcite.sql.parser.SqlParserPos
- 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(Function1<T, Boolean>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Converts a 1-parameter function to a predicate.
- 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.
- toQuery() - Method in class org.apache.calcite.adapter.druid.DruidQuery.ScanQuery
- toQuery(CalcitePrepare.Context, String) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
-
Wraps the SQL string in a
CalcitePrepare.Query
object, giving theHook.STRING_TO_QUERY
hook chance to override. - toQueryGranularity(DimensionSpec) - Static method in class org.apache.calcite.adapter.druid.ExtractionDimensionSpec
- toRel(Queryable<T>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- toRel(RelOptTable) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- 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, 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.FileTable
- 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.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.adapter.splunk.SplunkTable
- 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
. - toRelContext - Variable in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- toRelContext() - Method in class org.apache.calcite.prepare.LixToRelTranslator
- toRelContext(RelOptTable.ViewExpander, RelOptCluster) - Static method in class org.apache.calcite.plan.ViewExpanders
-
Converts a
ViewExpander
to aToRelContext
. - toRex(Iterable<Ast.Node>) - Method in class org.apache.calcite.piglet.Handler
- toRex(List<Expression>) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.EmptyScalarTranslator
- toRex(BlockStatement) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.EmptyScalarTranslator
- toRex(BlockStatement) - Method in interface org.apache.calcite.prepare.CalcitePrepareImpl.ScalarTranslator
- toRex(Expression) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.EmptyScalarTranslator
- toRex(Expression) - Method in interface org.apache.calcite.prepare.CalcitePrepareImpl.ScalarTranslator
- toRex(FunctionExpression, RelNode...) - Method in class org.apache.calcite.prepare.LixToRelTranslator
- toRex(Ast.Node) - Method in class org.apache.calcite.piglet.Handler
- toRex(RelInput, Object) - Method in class org.apache.calcite.rel.externalize.RelJson
- toRex(RelNode, FunctionExpression) - Method in class org.apache.calcite.prepare.LixToRelTranslator
- toRex(RexNode, Range<Calendar>) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- toRexList(BlockStatement) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.EmptyScalarTranslator
- toRexList(BlockStatement) - Method in interface org.apache.calcite.prepare.CalcitePrepareImpl.ScalarTranslator
- toRexList(FunctionExpression, RelNode...) - Method in class org.apache.calcite.prepare.LixToRelTranslator
- toRexList(RelInput, List) - Method in class org.apache.calcite.rel.externalize.RelJson
- 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(Elements, int[]) - Method in class org.apache.calcite.adapter.file.FileRowConverter
-
Converts a row of JSoup Elements to an array of java objects.
- toRows(PhysType, Expression) - Method in class org.apache.calcite.adapter.enumerable.EnumerableTableScan
- 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
- toSimpleDruidFilter(RexNode, RelDataType, DruidQuery) - Static method in class org.apache.calcite.adapter.druid.DruidJsonFilter
- toSortRex(List<RexNode>, Pair<Ast.Identifier, Ast.Direction>) - Method in class org.apache.calcite.piglet.Handler
- toSql(List<RelDataType>) - Method in class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
- 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(RelFieldCollation) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
-
Converts a collation to an ORDER BY item.
- 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(RelDataType) - Method in class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
- toSql(RelDataTypeFactory, List<RelDataType>) - Static method in class org.apache.calcite.prepare.CalciteCatalogReader
- toSql(RelDataTypeFactory, RelDataType) - Static method in class org.apache.calcite.adapter.enumerable.RexImpTable
- toSql(RelDataTypeFactory, RelDataType) - Static method in class org.apache.calcite.jdbc.JavaTypeFactoryImpl
-
Converts a type in Java format to a SQL-oriented type.
- toSql(RelDataTypeFactory, RelDataType) - Static method in class org.apache.calcite.prepare.CalciteCatalogReader
- toSql(RexProgram, List<RexNode>) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- toSql(RexProgram, RexFieldCollation) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
- 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(RexProgram, RexOver) - 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(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.clone.ArrayTable.BitSlicedPrimitiveArray
- toString() - Method in class org.apache.calcite.adapter.clone.ArrayTable.ByteStringDictionary
- toString() - Method in class org.apache.calcite.adapter.clone.ArrayTable.Column
- toString() - Method in class org.apache.calcite.adapter.clone.ArrayTable.Constant
- toString() - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectArray
- toString() - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectDictionary
- toString() - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveArray
- toString() - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveDictionary
- toString() - Method in class org.apache.calcite.adapter.clone.ArrayTable.StringDictionary
- 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.csv.JsonTable
- toString() - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl.Page
- toString() - Method in class org.apache.calcite.adapter.druid.DruidQuery.QuerySpec
- toString() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
- toString() - Method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- toString() - Method in class org.apache.calcite.adapter.file.FileTable
- 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.java.ReflectiveSchema.FieldTable
- toString() - Method in class org.apache.calcite.adapter.java.ReflectiveSchema.MethodTableMacro
- toString() - Method in class org.apache.calcite.adapter.java.ReflectiveSchema
- toString() - Method in class org.apache.calcite.adapter.jdbc.JdbcTable.JdbcTableQueryable
- 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.os.Processes.ProcessFactory
- toString() - Method in class org.apache.calcite.adapter.splunk.SplunkQuery
- toString() - Method in class org.apache.calcite.adapter.splunk.SplunkTable
- toString() - Method in class org.apache.calcite.benchmarks.StatementTest.Department
- toString() - Method in class org.apache.calcite.benchmarks.StatementTest.Employee
- toString() - Method in class org.apache.calcite.benchmarks.StatementTest.HrSchema
- 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.GroupingImpl
- 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.linq4j.tree.ExpressionWriter
- toString() - Method in class org.apache.calcite.linq4j.tree.Types.ParameterizedTypeImpl
- 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.LatticeSuggester.Frame
- toString() - Method in class org.apache.calcite.materialize.LatticeSuggester.StepRef
- toString() - Method in class org.apache.calcite.materialize.LatticeSuggester.TableRef
- 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.Step
- toString() - Method in class org.apache.calcite.materialize.TileKey
- toString() - Method in class org.apache.calcite.materialize.TileSuggester.AttributeImpl
- 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 class org.apache.calcite.plan.RelCompositeTrait
- 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.RelOptRule
-
Returns the description of this rule.
- 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.plan.volcano.VolcanoCost
- toString() - Method in class org.apache.calcite.plan.volcano.VolcanoRuleMatch
- toString() - Method in class org.apache.calcite.profile.Profiler.Column
- toString() - Method in class org.apache.calcite.profile.ProfilerImpl.SurpriseQueue
- toString() - Method in class org.apache.calcite.rel.AbstractRelNode
- 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.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.RelDistributions.RelDistributionImpl
- 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.AbstractMaterializedViewRule.Edge
- toString() - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.RelType
- toString() - Method in class org.apache.calcite.rel.rules.LoptMultiJoin.Edge
- toString() - Method in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.JoinVertex
- toString() - Method in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.LeafVertex
- 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.RexNode
- toString() - Method in class org.apache.calcite.rex.RexProgram
- toString() - Method in class org.apache.calcite.rex.RexSimplify.CaseBranch
- toString() - Method in class org.apache.calcite.rex.RexTableInputRef.RelTableRef
- toString() - Method in class org.apache.calcite.rex.RexWindow
- toString() - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundBounded
- toString() - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundCurrentRow
- toString() - Method in class org.apache.calcite.rex.RexWindowBound.RexWindowBoundUnbounded
- 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.GeoFunctions.MapGeom
- toString() - Method in class org.apache.calcite.runtime.GeoFunctions.SimpleGeom
- toString() - Method in class org.apache.calcite.runtime.SqlFunctions.PathContext
- 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 class org.apache.calcite.sql.fun.SqlJsonArrayAggAggFunction
- toString() - Method in class org.apache.calcite.sql.fun.SqlJsonObjectAggAggFunction
- 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.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.SqlJsonValueEmptyOrErrorBehavior
- 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 enum org.apache.calcite.sql.SqlWindow.Bound
- 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.CorDef
- toString() - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMap
- toString() - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorRef
- toString() - Method in class org.apache.calcite.tools.RelBuilder.GroupKeyImpl
- 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.CaseInsensitiveComparator.Key
- 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.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.PartiallyOrderedSet.Node
- toString() - Method in class org.apache.calcite.util.PartiallyOrderedSet.TopBottomNode
- 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.Sources.FileSource
- 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(boolean, RexLiteral) - Method in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- 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 zeroes to a given precision.
- toString(int) - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
-
Converts this TimestampWithTimeZoneString to a string, truncated or padded with zeroes to a given precision.
- toString(int) - Method in class org.apache.calcite.util.TimeString
-
Converts this TimestampString to a string, truncated or padded with zeroes to a given precision.
- toString(int) - Method in class org.apache.calcite.util.TimeWithTimeZoneString
-
Converts this TimeWithTimeZoneString to a string, truncated or padded with zeroes to a given precision.
- toString(Ordering<V>, Ordering<E>) - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
-
Returns the string representation of this graph, using the given orderings to ensure that the output order of vertices and edges is deterministic.
- toString(Iterable<T>, String, String, String) - Static method in class org.apache.calcite.util.Util
-
Converts an iterable to a string.
- toString(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.BitSlicedPrimitiveArray
- toString(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ByteStringDictionary
- toString(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.Constant
- toString(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectArray
- toString(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.ObjectDictionary
- toString(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveArray
- toString(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.PrimitiveDictionary
- toString(Object) - Method in interface org.apache.calcite.adapter.clone.ArrayTable.Representation
-
Converts a data set to a string.
- toString(Object) - Method in class org.apache.calcite.adapter.clone.ArrayTable.StringDictionary
- toString(Object) - Static method in class org.apache.calcite.model.JsonLattice
-
Converts a string or a list of strings to a string.
- toString(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
CAST(DECIMAL AS VARCHAR).
- 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) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Converts a relational expression to a string, showing just basic attributes.
- toString(RelNode, SqlExplainLevel) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Converts a relational expression to a string.
- toString(SqlOperator) - Method in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- 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) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- toStruct(RelDataType, SqlNode) - Method in class org.apache.calcite.sql.validate.AbstractNamespace
-
Converts a type to a struct if it is not already.
- total - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHits
- total - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHits
- total() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHits
- total() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHits
- totalCount - Variable in class org.apache.calcite.rex.RexMultisetUtil.RexCallMultisetOperatorCounter
- totalRowCount - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.Page
- toTile(Aggregate) - Method in class org.apache.calcite.materialize.TileSuggester
- 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(JavaTypeFactory) - Method in enum org.apache.calcite.adapter.csv.CsvFieldType
- toType(JavaTypeFactory) - Method in enum org.apache.calcite.adapter.file.FileFieldType
- toType(Ast.BagType) - Method in class org.apache.calcite.piglet.Handler
- toType(Ast.MapType) - Method in class org.apache.calcite.piglet.Handler
- toType(Ast.ScalarType) - Method in class org.apache.calcite.piglet.Handler
- toType(Ast.Schema) - Method in class org.apache.calcite.piglet.Handler
- toType(Ast.TupleType) - Method in class org.apache.calcite.piglet.Handler
- toType(Ast.Type) - Method in class org.apache.calcite.piglet.Handler
- toType(RelDataTypeFactory, Object) - Method in class org.apache.calcite.rel.externalize.RelJson
- toUnchecked(Exception) - Static method in class org.apache.calcite.runtime.SqlFunctions
- 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)
Typical values: Hello, world! 12.34 {null} 1969-04-29 - toValue() - Method in class org.apache.calcite.sql.SqlNumericLiteral
- TpcdsQueryableTable(Table) - Constructor for class org.apache.calcite.adapter.tpcds.TpcdsSchema.TpcdsQueryableTable
- 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.
- TpcdsSchema.TpcdsQueryableTable<E extends com.teradata.tpcds.Table> - Class in org.apache.calcite.adapter.tpcds
-
Definition of a table in the TPC-DS schema.
- TpcdsSchemaFactory - Class in org.apache.calcite.adapter.tpcds
-
Factory that creates a
TpcdsSchema
. - TpcdsSchemaFactory() - Constructor for class org.apache.calcite.adapter.tpcds.TpcdsSchemaFactory
- tpcdsTable - Variable in class org.apache.calcite.adapter.tpcds.TpcdsSchema.TpcdsQueryableTable
- TpchQueryableTable(TpchTable<E>) - Constructor for class org.apache.calcite.adapter.tpch.TpchSchema.TpchQueryableTable
- TpchSchema - Class in org.apache.calcite.adapter.tpch
-
Schema that provides TPC-H tables, populated according to a particular scale factor.
- TpchSchema(double, int, int, boolean) - Constructor for class org.apache.calcite.adapter.tpch.TpchSchema
- TpchSchema.TpchQueryableTable<E extends io.airlift.tpch.TpchEntity> - Class in org.apache.calcite.adapter.tpch
-
Definition of a table in the TPC-H schema.
- TpchSchemaFactory - Class in org.apache.calcite.adapter.tpch
-
Factory that creates a
TpchSchema
. - TpchSchemaFactory() - Constructor for class org.apache.calcite.adapter.tpch.TpchSchemaFactory
- tpchTable - Variable in class org.apache.calcite.adapter.tpch.TpchSchema.TpchQueryableTable
- 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
- trace(List<MultiJoinOptimizeBushyRule.Vertex>, List<LoptMultiJoin.Edge>, List<LoptMultiJoin.Edge>, int, PrintWriter) - Method in class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule
- traceLevelExpressions(RexNode[], int[], int[], int) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter
-
Traces the given array of level expression lists at the finer level.
- TRACER - Static variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- traceResponse(InputStream) - Method in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- traceTime(String) - Method in class org.apache.calcite.util.trace.CalciteTimingTracer
-
Publishes an event with the time elapsed since the previous event.
- trackNullsPerRow - Variable in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- TRAILING - org.apache.calcite.sql.fun.SqlTrimFunction.Flag
- trait - Variable in class org.apache.calcite.plan.RelOptRuleOperand
- trait(int) - Method in class org.apache.calcite.plan.RelCompositeTrait
-
Returns the
i
th trait. - traitDef - Variable in class org.apache.calcite.plan.RelCompositeTrait
- traitDef - Variable in class org.apache.calcite.rel.convert.ConverterImpl
- traitDefs - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Holds the currently registered RelTraitDefs.
- traitDefs - Variable in class org.apache.calcite.prepare.PlannerImpl
-
Holds the trait definitions to be registered with planner.
- traitDefs - Variable in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- traitDefs - Variable in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- traitDefs(List<RelTraitDef>) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- traitDefs(RelTraitDef...) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- traitList() - Method in class org.apache.calcite.plan.RelCompositeTrait
-
Returns an immutable list of the traits in this composite trait.
- 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
-
Creates a TraitMatchingRule.
- traits - Variable in class org.apache.calcite.plan.AbstractRelOptPlanner
- traits - Variable in class org.apache.calcite.plan.RelCompositeTrait
- traits - Variable in class org.apache.calcite.plan.RelTraitSet
- traits - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter
- traitSet - Variable in class org.apache.calcite.rel.AbstractRelNode
-
The 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) - Method in interface org.apache.calcite.runtime.GeoFunctions.Geom
- transform(int) - Method in class org.apache.calcite.runtime.GeoFunctions.MapGeom
- transform(int) - Method in class org.apache.calcite.runtime.GeoFunctions.SimpleGeom
- 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(List<F>, Function<F, T>) - Static method in class org.apache.calcite.util.Util
-
Transforms a list, applying a function to each element.
- transform(Enumerator<F>, Function1<F, E>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Applies a function to each element of an Enumerator.
- 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.
- transformableOperators - Variable in class org.apache.calcite.rex.RexTransformer
- transformAggCalls(RelNode, int, List<AggregateCall>) - Method in class org.apache.calcite.rel.rules.AggregateUnionTransposeRule
- TransformedEnumerator<F,E> - Class in org.apache.calcite.linq4j
-
Enumerator that applies a transform to each value from a backing enumerator.
- TransformedEnumerator(Enumerator<F>) - Constructor for class org.apache.calcite.linq4j.TransformedEnumerator
- TransformingList(List<F>, Function<F, T>) - Constructor for class org.apache.calcite.util.Util.TransformingList
- transformNullSemantics() - Method in class org.apache.calcite.rex.RexTransformer
- transformNullSemantics(RexNode) - Method in class org.apache.calcite.rex.RexTransformer
- transformRex(List<RexNode>, List<RelDataTypeField>, List<RelDataTypeField>) - Static method in class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor
- transformRex(RexNode, List<RelDataTypeField>, List<RelDataTypeField>) - Static method in class org.apache.calcite.plan.MaterializedViewSubstitutionVisitor
- transforms - Variable in class org.apache.calcite.sql.type.SqlTypeTransformCascade
- 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.hep.HepRuleCall
- transformTo(RelNode, Map<RelNode, RelNode>) - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Registers that a rule has produced an equivalent relational expression.
- transformTo(RelNode, Map<RelNode, RelNode>) - Method in class org.apache.calcite.plan.volcano.VolcanoRuleCall
- 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.
- TRANSLATABLE - org.apache.calcite.adapter.csv.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.AbstractNamespace
- translate(String) - Method in class org.apache.calcite.sql.validate.AliasNamespace
- translate(String) - Method in class org.apache.calcite.sql.validate.WithItemNamespace
- translate(Queryable<T>) - Method in class org.apache.calcite.prepare.LixToRelTranslator
- translate(Expression) - Method in class org.apache.calcite.prepare.LixToRelTranslator
- translate(RexNode) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- translate(RexNode, Type) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- translate(RexNode, RexImpTable.NullAs) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- translate(RexNode, RexImpTable.NullAs, Type) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- TRANSLATE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
TRANSLATE(char_value USING translation_name)
function alters the character set of a string value from one base character set to another. - translate0(RexNode, RexImpTable.NullAs, Type) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Translates an expression that is not in the cache.
- translate3(String, String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TRANSLATE(string, search_chars, replacement_chars)
function. - TRANSLATE3 - org.apache.calcite.util.BuiltInMethod
- TRANSLATE3 - Static variable in class org.apache.calcite.sql.fun.OracleSqlOperatorTable
-
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. - translateAgg(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- translateAgg(SqlCall, SqlNode, SqlNodeList, SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- translateAnd(RexNode) - Method in class org.apache.calcite.adapter.cassandra.CassandraFilter.Translator
-
Translate a conjunctive predicate to a CQL string.
- translateAnd(RexNode) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
-
Translates a condition that may be an AND of other conditions.
- translateAnd(RexNode) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
-
Translate a conjunctive predicate to a OQL string.
- translateAnd(RexNode) - Method in class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
-
Translates a condition that may be an AND of other conditions.
- translateBinary(String, String, RexCall) - Method in class org.apache.calcite.adapter.cassandra.CassandraFilter.Translator
-
Translates a call to a binary operator, reversing arguments if necessary.
- translateBinary(String, String, RexCall) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
-
Translates a call to a binary operator, reversing arguments if necessary.
- translateBinary(String, String, RexCall) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
-
Translates a call to a binary operator, reversing arguments if necessary.
- translateBinary(String, String, RexCall) - Method in class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
-
Translates a call to a binary operator, reversing arguments if necessary.
- translateBinary2(String, RexNode, RexNode) - Method in class org.apache.calcite.adapter.cassandra.CassandraFilter.Translator
-
Translates a call to a binary operator.
- translateBinary2(String, RexNode, RexNode) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
-
Translates a call to a binary operator.
- translateBinary2(String, RexNode, RexNode) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
-
Translates a call to a binary operator.
- translateBinary2(String, RexNode, RexNode) - Method in class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
-
Translates a call to a binary operator.
- translateBound(RexToLixTranslator, ParameterExpression, Expression, Expression, Expression, Expression, Window.Group, boolean, PhysType, Expression, Expression, Expression) - Method in class org.apache.calcite.adapter.enumerable.EnumerableWindow
- translateCall(RexCall, RexImpTable.NullAs) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Translates a call to an operator or function.
- translateCast(RelDataType, RelDataType, Expression) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- translateCastToTimeExtract(RexNode, TimeZone) - Static method in class org.apache.calcite.adapter.druid.TimeExtractionFunction
- 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.
- translateCondition(RexProgram, JavaTypeFactory, BlockBuilder, RexToLixTranslator.InputGetter, Function1<String, RexToLixTranslator.InputGetter>, SqlConformance) - Static method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- translateConstructor(List<RexNode>, SqlKind) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- translateIn(RelOptUtil.Logic, RelNode, RexNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- translateInSet(List<RexNode>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
-
Creates OQL IN SET predicate string
- 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.
- translateMatch(RexNode) - Method in class org.apache.calcite.adapter.cassandra.CassandraFilter.Translator
-
Produce the CQL predicate string for the given condition.
- translateMatch(RexNode) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.PredicateAnalyzerTranslator
- translateMatch(RexNode) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
- translateMatch(RexNode) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
-
Produce the OQL predicate string for the given condition.
- translateMatch(RexNode) - Method in class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
- translateMatch2(RexNode) - Method in class org.apache.calcite.adapter.cassandra.CassandraFilter.Translator
-
Translate a binary relation.
- translateMatch2(RexNode) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
- translateMatch2(RexNode) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
-
Translate a binary relation.
- translateMatch2(RexNode) - Method in class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
- translateOp2(String, String, RexLiteral) - Method in class org.apache.calcite.adapter.cassandra.CassandraFilter.Translator
-
Combines a field name, operator, and literal to produce a predicate string.
- translateOp2(String, String, RexLiteral) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
- translateOp2(String, String, RexLiteral) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
-
Combines a field name, operator, and literal to produce a predicate string.
- translateOp2(String, String, RexLiteral) - Method in class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
- translateOr(List<RexNode>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
- translateOr(RexNode) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
- translateOr(RexNode) - Method in class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
- translateParameter(RexDynamicParam, RexImpTable.NullAs, Type) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
-
Translates a parameter.
- translateProjects(RexProgram, JavaTypeFactory, SqlConformance, 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. - translationTable - Variable in class org.apache.calcite.util.XmlOutput.StringEscaper
- translationVector - Variable in class org.apache.calcite.util.XmlOutput.StringEscaper
- translator - Variable in class org.apache.calcite.prepare.QueryableRelBuilder
- Translator(List<String>) - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchFilter.Translator
- Translator(List<String>) - Constructor for class org.apache.calcite.adapter.mongodb.MongoFilter.Translator
- Translator(RelDataType) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
- Translator(RelDataType, List<String>, List<String>, List<RelFieldCollation>) - Constructor for class org.apache.calcite.adapter.cassandra.CassandraFilter.Translator
- transport - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
- transport - Variable in class org.apache.calcite.adapter.elasticsearch.Scrolling.SequentialIterator
- transport - Variable in class org.apache.calcite.adapter.elasticsearch.Scrolling
- 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(int) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
- 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) - Method in class org.apache.calcite.util.Sources.FileSource
- trim(String, String) - Static method in class org.apache.calcite.adapter.csv.CsvSchema
-
Looks for a suffix on a string and returns either the string with the suffix removed or the original string.
- trim(String, String) - Static method in class org.apache.calcite.adapter.file.FileSchema
-
Looks for a suffix on a string and returns either the string with the suffix removed or the original string.
- 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 - org.apache.calcite.sql.SqlKind
-
The "TRIM" function.
- TRIM - org.apache.calcite.util.BuiltInMethod
- TRIM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The "TRIM" function.
- trim_(ByteString, boolean, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
TRIM
function applied to binary string. - 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.
- TrimConvertlet(SqlTrimFunction.Flag) - Constructor for class org.apache.calcite.sql2rel.StandardConvertletTable.TrimConvertlet
- trimError() - Method in interface org.apache.calcite.runtime.CalciteResource
- trimFields(Aggregate, 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(SetOp, ImmutableBitSet, Set<RelDataTypeField>) - Method in class org.apache.calcite.sql2rel.RelFieldTrimmer
-
Variant of
RelFieldTrimmer.trimFields(RelNode, ImmutableBitSet, Set)
forSetOp
(including UNION and UNION ALL). - 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
. - trimFieldsDispatcher - Variable in class org.apache.calcite.sql2rel.RelFieldTrimmer
- TrimFieldsProgram() - Constructor for class org.apache.calcite.tools.Programs.TrimFieldsProgram
- TrimImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.TrimImplementor
- TRIMMED - org.apache.calcite.runtime.Hook
-
Called after de-correlation and field trimming, but before optimization.
- 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.
- trimOrNull(String) - Method in class org.apache.calcite.util.Sources.FileSource
- trimOrNull(String, String) - Static method in class org.apache.calcite.adapter.csv.CsvSchema
-
Looks for a suffix on a string and returns either the string with the suffix removed or null.
- trimOrNull(String, String) - Static method in class org.apache.calcite.adapter.file.FileSchema
-
Looks for a suffix on a string and returns either the string with the suffix removed or null.
- trimOrNull(String, String) - Static method in class org.apache.calcite.util.Sources
-
Looks for a suffix on a path and returns either the path with the suffix removed or null.
- TrimResult(RelNode, Mapping) - Constructor for class org.apache.calcite.sql2rel.RelFieldTrimmer.TrimResult
-
Creates a TrimResult.
- trimUnusedFields - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- trimUnusedFields - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigImpl
- 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. - trivial - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.Permute
- TrivialRule() - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.TrivialRule
- TrivialSparkHandler() - Constructor for class org.apache.calcite.jdbc.CalcitePrepare.Dummy.TrivialSparkHandler
- TROJAN - Static variable in class org.apache.calcite.jdbc.CalciteConnectionImpl
- TRUE - org.apache.calcite.adapter.enumerable.RexImpTable.NullAs
-
If one of the arguments is null, the function returns true.
- TRUE - 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 - org.apache.calcite.rex.RexInterpreter.Truthy
- TRUE - 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 - 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 - org.apache.calcite.plan.RelOptUtil.Logic
-
Nulls are not possible.
- TRUE_FALSE_UNKNOWN - org.apache.calcite.plan.RelOptUtil.Logic
-
Three-valued boolean logic.
- TRUE_PREDICATE - Static variable in class org.apache.calcite.rel.rules.FilterJoinRule
-
Predicate that always returns true.
- 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
. - 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 - org.apache.calcite.util.BuiltInMethod
- TRUNCATE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- TRUNCATE_OR_PAD - org.apache.calcite.util.BuiltInMethod
- 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(...
- TrustAllSslSocketFactory - Class in org.apache.calcite.runtime
-
Socket factory that trusts all SSL connections.
- TrustAllSslSocketFactory() - Constructor for class org.apache.calcite.runtime.TrustAllSslSocketFactory
- TrustAllSslSocketFactory.DummyTrustManager - Class in org.apache.calcite.runtime
-
Implementation of
X509TrustManager
that trusts all certificates. - Truthy() - Constructor for enum org.apache.calcite.rex.RexInterpreter.Truthy
- Try - org.apache.calcite.linq4j.tree.ExpressionType
-
A try-catch expression.
- 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.
- 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, - tryParse(String, List<SqlMoniker>) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
-
Tries to parse a SQL statement.
- 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(T) - 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_OFF - Static variable in class org.apache.calcite.adapter.os.GitCommitsTableFunction
-
An example of the timestamp + offset at the end of author and committer fields.
- TUMBLE - org.apache.calcite.sql.SqlKind
-
The
TUMBLE
group function. - TUMBLE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
TUMBLE
group function. - TUMBLE_END - 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_START - 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. - tuple(List<Ast.Node>, RelDataType) - Method in class org.apache.calcite.piglet.Handler
- TUPLE - org.apache.calcite.piglet.Ast.Op
- TUPLE_TYPE - org.apache.calcite.piglet.Ast.Op
- tupleList - Variable in class org.apache.calcite.piglet.Ast.ValuesStmt
- tupleList(int, Object[]) - Method in class org.apache.calcite.tools.RelBuilder
- tuples - Variable in class org.apache.calcite.rel.core.Values
- tuples(Ast.ValuesStmt, RelDataType) - Method in class org.apache.calcite.piglet.Handler
- TupleType(SqlParserPos, List<Ast.FieldSchema>) - Constructor for class org.apache.calcite.piglet.Ast.TupleType
- TWO - Static variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- type - Variable in class org.apache.calcite.adapter.druid.ComplexMetric
-
The type of this metric
- type - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonAggregator
- type - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl.JsonColumn
- type - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter
- type - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonAggregation
- type - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonLimit
- type - Variable in class org.apache.calcite.adapter.druid.DruidQuery.JsonPostAggregation
- type - Variable in class org.apache.calcite.adapter.druid.Granularities.PeriodGranularity
- type - Variable in class org.apache.calcite.adapter.druid.VirtualColumn.Builder
- type - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping
- type - Variable in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CastExpression
- type - Variable in class org.apache.calcite.adapter.file.FileRowConverter.CellReader
- type - Variable in class org.apache.calcite.adapter.file.FileRowConverter.FieldDef
- type - Variable in enum org.apache.calcite.config.CalciteConnectionProperty
- type - Variable in class org.apache.calcite.jdbc.JavaTypeFactoryImpl.RecordFieldImpl
- 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.piglet.Ast.FieldSchema
- 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.rel.RelDistributions.RelDistributionImpl
- type - Variable in class org.apache.calcite.rel.type.RelDataTypeFieldImpl
- type - Variable in class org.apache.calcite.rex.RexCall
- type - Variable in class org.apache.calcite.rex.RexCallBinding.RexCastCallBinding
- type - Variable in class org.apache.calcite.rex.RexLiteral
-
The real type of this literal, as reported by
RexLiteral.getType()
. - type - Variable in class org.apache.calcite.rex.RexRangeRef
- 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.advise.SqlSimpleParser.Token
- type - Variable in class org.apache.calcite.sql.ddl.SqlCreateForeignSchema
- type - Variable in class org.apache.calcite.sql.ddl.SqlCreateTable.ColumnDef
- type - Variable in class org.apache.calcite.sql.fun.SqlHistogramAggFunction
-
Deprecated.
- type - Variable in class org.apache.calcite.sql.fun.SqlSingleValueAggFunction
-
Deprecated.
- type - Variable in class org.apache.calcite.sql.fun.SqlSumAggFunction
-
Deprecated.
- type - Variable in class org.apache.calcite.sql.validate.AbstractNamespace
-
As
AbstractNamespace.rowType
, but not necessarily a struct. - type - Variable in class org.apache.calcite.sql.validate.ParameterNamespace
- type - Variable in class org.apache.calcite.sql.validate.SqlMonikerImpl
- type - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Token
- type() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchMapping
- type() - Method in enum org.apache.calcite.config.CalciteConnectionProperty
- type(Geometry) - Static method in class org.apache.calcite.runtime.GeoFunctions
-
Returns the OGC type of a geometry.
- type(Expression) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl.EmptyScalarTranslator
- type(RelNode, ImmutableList<RexNode>) - Static method in class org.apache.calcite.rex.RexSubQuery
- type(RelDataTypeFactory, Column) - Method in class org.apache.calcite.adapter.tpcds.TpcdsSchema.TpcdsQueryableTable
- Type() - Constructor for enum org.apache.calcite.adapter.druid.DruidJsonFilter.Type
- Type() - Constructor for enum org.apache.calcite.adapter.druid.Granularity.Type
- Type() - Constructor for enum org.apache.calcite.model.JsonSchema.Type
- Type() - Constructor for enum org.apache.calcite.util.PrecedenceClimbingParser.Type
- Type(int) - Constructor for enum org.apache.calcite.runtime.GeoFunctions.Type
- Type(String) - Constructor for enum org.apache.calcite.rel.RelDistribution.Type
- Type(SqlParserPos, Ast.Op) - Constructor for class org.apache.calcite.piglet.Ast.Type
- TYPE - org.apache.calcite.schema.Schema.TableType
-
Type.
- TYPE - org.apache.calcite.sql.SqlExplain.Depth
- TYPE - Static variable in interface org.apache.calcite.adapter.elasticsearch.ElasticsearchConstants
- TYPE_NAME_TO_PRECEDENCE_LIST - Static variable in class org.apache.calcite.sql.type.SqlTypeExplicitPrecedenceList
-
Map from SqlTypeName to corresponding precedence list.
- TYPE_REF - Static variable in class org.apache.calcite.rel.externalize.RelJsonReader
- TYPE_SYSTEM - org.apache.calcite.config.CalciteConnectionProperty
-
Type system.
- typeA - Variable in class org.apache.calcite.rel.rules.ReduceDecimalsRule.BinaryArithmeticExpander
- typeArguments - Variable in class org.apache.calcite.linq4j.tree.Types.ParameterizedTypeImpl
- 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 - 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.
- typeB - Variable in class org.apache.calcite.rel.rules.ReduceDecimalsRule.BinaryArithmeticExpander
- 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
- Typed - Interface in org.apache.calcite.runtime
-
Adds type information to a
Enumerable
. - TYPED_GET_ELEMENT_TYPE - org.apache.calcite.util.BuiltInMethod
- TYPED_TABLE - org.apache.calcite.schema.Schema.TableType
-
A typed table.
- TYPED_VIEW - org.apache.calcite.schema.Schema.TableType
-
A typed view.
- TypeDumper(PrintWriter) - Constructor for class org.apache.calcite.plan.RelOptUtil.TypeDumper
- 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
An exact type test.
- typeFactory - Variable in class org.apache.calcite.adapter.cassandra.CassandraRules.RexToCassandraTranslator
- typeFactory - Variable in class org.apache.calcite.adapter.clone.ColumnLoader
- typeFactory - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.RexToElasticsearchTranslator
- typeFactory - Variable in class org.apache.calcite.adapter.enumerable.EnumerableAggregate.AggContextImpl
- typeFactory - Variable in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- typeFactory - Variable in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- typeFactory - Variable in class org.apache.calcite.adapter.mongodb.MongoRules.RexToMongoTranslator
- typeFactory - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl.DataContextImpl
- typeFactory - Variable in class org.apache.calcite.jdbc.CalciteConnectionImpl
- typeFactory - Variable in class org.apache.calcite.jdbc.CalcitePrepare.ParseResult
- typeFactory - Variable in class org.apache.calcite.plan.RelOptCluster
- 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.prepare.LixToRelTranslator
- typeFactory - Variable in class org.apache.calcite.prepare.PlannerImpl
- typeFactory - Variable in class org.apache.calcite.rel.rules.CalcRelSplitter
- typeFactory - Variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- typeFactory - Variable in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
- typeFactory - Variable in class org.apache.calcite.rel.type.RelDataTypeHolder
- typeFactory - Variable in class org.apache.calcite.rex.RexBuilder
- typeFactory - Variable in class org.apache.calcite.rex.RexExecutorImpl.DataContextInputGetter
- typeFactory - Variable in class org.apache.calcite.sql.SqlOperatorBinding
- typeFactory - Variable in class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
-
This field is is technical debt; see [CALCITE-2082] Remove RelDataTypeFactory argument from SqlUserDefinedAggFunction constructor.
- typeFactory - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- typeFactory - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationRexShuttle
- typeFactory - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- TypeFinder(Collection<Type>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor.TypeFinder
- typeIs(Expression, Type) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a TypeBinaryExpression.
- TypeIs - org.apache.calcite.linq4j.tree.ExpressionType
-
A type test, such as obj is SampleType in C# or TypeOf obj is SampleType in Visual Basic.
- typeList - Variable in class org.apache.calcite.rex.RexUtil.FixNullabilityShuttle
- typeMap - Variable in class org.apache.calcite.jdbc.CalciteSchema
- typeMatchesInferred(AggregateCall, Litmus) - Method in class org.apache.calcite.rel.core.Aggregate
-
Returns whether the inferred type of an
AggregateCall
matches the type it was given when it was created. - typeName - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
- typeName - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- typeName - Variable in class org.apache.calcite.rex.RexLiteral
-
An indication of the broad type of this literal -- even if its type isn't a SQL type.
- typeName - Variable in class org.apache.calcite.sql.fun.SqlAbstractTimeFunction
- typeName - Variable in class org.apache.calcite.sql.SqlDataTypeSpec
- typeName - Variable in enum org.apache.calcite.sql.SqlJdbcDataTypeName
- typeName - Variable in class org.apache.calcite.sql.SqlLiteral
-
The type with which this literal was declared.
- typeName - Variable in class org.apache.calcite.sql.type.AbstractSqlType
- typeName() - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- typeNames - Variable in class org.apache.calcite.sql.type.MatchReturnTypeInference
- typeNames - Variable in class org.apache.calcite.sql.type.SqlTypeExplicitPrecedenceList
- 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
- TypeRegistrar(List<MemberDeclaration>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor.TypeRegistrar
- types - Variable in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor.TypeFinder
- types - Variable in class org.apache.calcite.adapter.jdbc.JdbcUtils.ObjectArrayRowBuilder
- types - Variable in class org.apache.calcite.model.JsonMapSchema
-
Types in this schema.
- types - Variable in class org.apache.calcite.rel.type.RelCrossType
- types - Variable in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
- types - Variable in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl.Key
- types - Variable in class org.apache.calcite.sql.ExplicitOperatorBinding
- 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() - Constructor for class org.apache.calcite.linq4j.tree.Types
- Types.ArrayType - Class in org.apache.calcite.linq4j.tree
-
Array type.
- Types.MapType - Class in org.apache.calcite.linq4j.tree
-
Map type.
- Types.ParameterizedTypeImpl - Class in org.apache.calcite.linq4j.tree
-
Implementation of
ParameterizedType
. - 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. - typeSystem - Variable in class org.apache.calcite.rel.type.DelegatingTypeSystem
- typeSystem - Variable in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- typeSystem - Variable in class org.apache.calcite.sql.type.BasicSqlType
- typeSystem - Variable in class org.apache.calcite.sql.type.IntervalSqlType
- typeSystem - Variable in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- typeSystem - Variable in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- typeSystem(Class<T>, T) - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- typeSystem(Class<T>, T) - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- typeSystem(RelDataTypeSystem) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- typeValueSize(RelDataType, Comparable) - Method in class org.apache.calcite.rel.metadata.RelMdSize
-
Estimates the average size (in bytes) of a value of a type.
U
- UdaAccumulator(AggregateNode.UdaAccumulatorFactory) - Constructor for class org.apache.calcite.interpreter.AggregateNode.UdaAccumulator
- UdaAccumulatorFactory(AggregateFunctionImpl, AggregateCall, boolean) - Constructor for class org.apache.calcite.interpreter.AggregateNode.UdaAccumulatorFactory
- UID - Static variable in interface org.apache.calcite.adapter.elasticsearch.ElasticsearchConstants
- 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.
- UnaryExpression(ExpressionType, Type, Expression) - Constructor for class org.apache.calcite.linq4j.tree.UnaryExpression
- UnaryImplementor(ExpressionType) - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.UnaryImplementor
- 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 - 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 expression 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 like: expression Unary_Operator
- UnarySuffixOperatorConversion(SqlOperator, String) - Constructor for class org.apache.calcite.adapter.druid.UnarySuffixOperatorConversion
- unbound(RexNode) - Method in class org.apache.calcite.rex.RexInterpreter
- UNBOUNDED_FOLLOWING - org.apache.calcite.sql.SqlWindow.Bound
- UNBOUNDED_PRECEDING - org.apache.calcite.sql.SqlWindow.Bound
- unboundedFollowingWindowNotSupported() - Method in interface org.apache.calcite.runtime.CalciteResource
- UnboundMetadata<M extends 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 - org.apache.calcite.linq4j.tree.ExpressionType
-
An unbox value type operation, such as unbox and unbox.any instructions in MSIL.
- unchain(SqlNode) - Static method in class org.apache.calcite.sql.SqlLiteral
-
Converts a chained string literals into regular literals; returns regular literals unchanged.
- 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) - 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.
- UNCOLLECT - org.apache.calcite.rel.mutable.MutableRelType
- UNDERFLOW - org.apache.calcite.sql.type.SqlTypeName.Limit
- underlyingProvider - Variable in class org.apache.calcite.rel.metadata.CachingRelMetadataProvider
- undoReplacement(List<SubstitutionVisitor.Replacement>) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
- 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, MutableAggregate) - Static method in class org.apache.calcite.plan.SubstitutionVisitor
- UnifyResult(SubstitutionVisitor.UnifyRuleCall, MutableRel) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.UnifyResult
- 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.linq4j.DefaultQueryable
- union(Enumerable<T>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- union(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- union(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.DefaultQueryable
- union(Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- 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<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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<TSource>, EqualityComparer<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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(Queryable<T>, Enumerable<T>, EqualityComparer<T>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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<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 - org.apache.calcite.rel.mutable.MutableRelType
- UNION - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- UNION - org.apache.calcite.sql.SqlKind
-
Union
- UNION - 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
LogicalUnion
. - 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
-
Creates a UnionEliminatorRule.
- unionGroups - Variable in class org.apache.calcite.interpreter.AggregateNode
- UnionMergeRule - Class in org.apache.calcite.rel.rules
- UnionMergeRule(Class<? extends SetOp>, String, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.UnionMergeRule
-
Creates a UnionMergeRule.
- UnionMergeRule(Class<? extends Union>, RelFactories.SetOpFactory) - Constructor for class org.apache.calcite.rel.rules.UnionMergeRule
-
Deprecated.
- UnionNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
Union
. - UnionNode(Compiler, Union) - Constructor for class org.apache.calcite.interpreter.UnionNode
- 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
-
Creates a UnionPullUpConstantsRule.
- unionRewritingPullProgram - Variable in class org.apache.calcite.rel.rules.AbstractMaterializedViewRule
-
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
-
Creates a UnionToDistinctRule.
- unique - Variable in class org.apache.calcite.profile.ProfilerImpl.Space
- unique - Variable in class org.apache.calcite.profile.SimpleProfiler.Space
- 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 - org.apache.calcite.sql.SqlKind
-
UNIQUE
constraint. - UNIQUE - Static variable in class org.apache.calcite.sql.ddl.SqlKeyConstraint
- UNIQUE_KEYS - org.apache.calcite.util.BuiltInMethod
- uniqueColumnNames() - Method in class org.apache.calcite.materialize.Lattice
- uniqueKey - Variable in class org.apache.calcite.sql2rel.RelDecorrelator.CorRef
- uniqueKeysHandler - Variable in class org.apache.calcite.rel.metadata.RelMetadataQuery
- uniqueList - Variable in class org.apache.calcite.profile.Profiler.Profile
- uniques - Variable in class org.apache.calcite.profile.ProfilerImpl.Run
- 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<String>) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Deprecated.
- uniquify(List<String>, boolean) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Makes sure that the names in a list are unique.
- uniquify(List<String>, SqlValidatorUtil.Suggester) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Deprecated.
- uniquify(List<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 - Class in org.apache.calcite.runtime
-
Synthetic record with zero fields.
- Unit() - Constructor for class org.apache.calcite.runtime.Unit
- UNIX_DATE_CEIL - org.apache.calcite.util.BuiltInMethod
- UNIX_DATE_EXTRACT - org.apache.calcite.util.BuiltInMethod
- UNIX_DATE_FLOOR - org.apache.calcite.util.BuiltInMethod
- UNIX_DATE_TO_STRING - org.apache.calcite.util.BuiltInMethod
- UNIX_TIME_TO_STRING - org.apache.calcite.util.BuiltInMethod
- UNIX_TIMESTAMP_CEIL - org.apache.calcite.util.BuiltInMethod
- UNIX_TIMESTAMP_FLOOR - org.apache.calcite.util.BuiltInMethod
- UNIX_TIMESTAMP_TO_STRING - org.apache.calcite.util.BuiltInMethod
- UNKNOWN - org.apache.calcite.adapter.elasticsearch.ElasticsearchVersion
- UNKNOWN - org.apache.calcite.rex.RexInterpreter.Truthy
- UNKNOWN - 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 - org.apache.calcite.runtime.SqlFunctions.PathMode
- UNKNOWN - org.apache.calcite.sql.SqlDialect.DatabaseProduct
-
Placeholder for the unknown database.
- UNKNOWN - org.apache.calcite.sql.SqlJsonExistsErrorBehavior
- UNKNOWN - Static variable in class org.apache.calcite.schema.Statistics
-
Returns a
Statistic
that knows nothing about a table. - UNKNOWN_AS_FALSE - org.apache.calcite.plan.RelOptUtil.Logic
-
Two-valued logic where UNKNOWN is treated as FALSE.
- UNKNOWN_AS_TRUE - org.apache.calcite.plan.RelOptUtil.Logic
-
Two-valued logic where UNKNOWN is treated as TRUE.
- unknownAs - Variable in class org.apache.calcite.rel.rules.ReduceExpressionsRule.RexReplacer
- unknownAs - Variable in class org.apache.calcite.rex.RexUtil.ExprSimplifier
-
Deprecated.
- unknownAsMap - Variable in class org.apache.calcite.rex.RexUtil.ExprSimplifier
-
Deprecated.
- 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
- UnknownProvenance() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlanner.UnknownProvenance
- UnknownSqlType(RelDataTypeFactory) - Constructor for class org.apache.calcite.sql.type.SqlTypeFactoryImpl.UnknownSqlType
- unknownTargetColumn(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- unknownType - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
The type of dynamic parameters until a type is imposed on them.
- unmapRuleDescription(RelOptRule) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
-
Removes the mapping between a rule and its description.
- 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.
- UnmodifiableArrayList(E[]) - Constructor for class org.apache.calcite.util.UnmodifiableArrayList
- unnest - Variable in class org.apache.calcite.sql.validate.UnnestNamespace
- UNNEST - org.apache.calcite.sql.SqlKind
-
The "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. - UnnestNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for UNNEST.
- UnnestNamespace(SqlValidatorImpl, SqlCall, SqlValidatorScope, SqlNode) - Constructor for class org.apache.calcite.sql.validate.UnnestNamespace
- unordered(RelOptRuleOperand, RelOptRuleOperand...) - Static method in class org.apache.calcite.plan.RelOptRule
-
Creates a list of child operands that matches child relational expressions in any order.
- UNORDERED - org.apache.calcite.plan.RelOptRuleOperandChildPolicy
-
Signifies that the rule matches any one of its parents' children.
- UNORDERED - org.apache.calcite.rel.type.RelDataTypeComparability
- unpack(PredicateAnalyzer.TerminalExpression) - Static method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.CastExpression
- unparse(StringBuilder) - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Query
- unparse(StringBuilder) - Method in class org.apache.calcite.sql.advise.SqlSimpleParser.Token
- 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.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.SqlAbstractDateTimeLiteral
- unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlAlter
- 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.SqlCollation
- 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.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.SqlLiteral
- 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.SqlSelect
- 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.SqlUpdate
- 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.SqlArgumentAssignmentOperator
- 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.SqlDefaultOperator
- 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.SqlExtendOperator
- 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.SqlItemOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.fun.SqlJsonApiCommonSyntaxOperator
- 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.SqlJsonValueExpressionOperator
- 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.SqlRollupOperator
- 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.SqlSubstringFunction
- 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.SqlTrimFunction
- 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.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.SqlOrderBy.Operator
- 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.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.SqlWindow.SqlWindowOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlWith.SqlWithOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlWithinGroupOperator
- unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.calcite.sql.SqlWithItem.SqlWithItemOperator
- 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
- 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.SqlDialect
- unparseCube(SqlWriter, SqlCall) - Static method in class org.apache.calcite.sql.fun.SqlRollupOperator
- 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.MssqlSqlDialect
- unparseDateTimeLiteral(SqlWriter, SqlAbstractDateTimeLiteral, int, int) - Method in class org.apache.calcite.sql.SqlDialect
- unparseEmptyOrErrorBehavior(SqlWriter, SqlJsonQueryEmptyOrErrorBehavior) - Method in class org.apache.calcite.sql.fun.SqlJsonQueryFunction
- unparseEnum(SqlWriter, SqlLiteral) - Method in class org.apache.calcite.sql.fun.SqlJsonValueFunction
- unparseFetchUsingAnsi(SqlWriter, SqlNode, SqlNode) - 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) - Method in class org.apache.calcite.sql.SqlDialect
-
Unparses offset/fetch using "LIMIT fetch OFFSET offset" syntax.
- unparseFloor(SqlWriter, SqlCall) - Method in class org.apache.calcite.sql.dialect.MssqlSqlDialect
-
Unparses datetime floor for Microsoft SQL Server.
- unparseFloor(SqlWriter, SqlCall) - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
-
Unparses datetime floor for MySQL.
- unparseFloorWithUnit(SqlWriter, SqlCall, int, String) - Method in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- unparseFunctionSyntax(SqlOperator, SqlWriter, SqlCall) - Static method in class org.apache.calcite.sql.SqlUtil
-
Unparses a call to an operator which has function syntax.
- unparseListClause(SqlWriter, SqlNode) - Method in class org.apache.calcite.sql.SqlOperator
- unparseListClause(SqlWriter, SqlNode, SqlKind) - Method in class org.apache.calcite.sql.SqlOperator
- 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.MysqlSqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.dialect.RedshiftSqlDialect
- unparseOffsetFetch(SqlWriter, SqlNode, SqlNode) - Method in class org.apache.calcite.sql.SqlDialect
-
Converts an offset and fetch into SQL.
- UnParser() - Constructor for class org.apache.calcite.piglet.Ast.UnParser
- 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
- 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.MssqlSqlDialect
- unparseSqlIntervalLiteral(SqlWriter, SqlIntervalLiteral, int, int) - Method in class org.apache.calcite.sql.SqlDialect
-
Converts an interval literal to a SQL string.
- unparseSqlIntervalLiteralMssql(SqlWriter, SqlIntervalLiteral, int) - Method in class org.apache.calcite.sql.dialect.MssqlSqlDialect
- 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.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.SqlDialect
-
Converts an interval qualifier to a SQL string.
- UNQUOTED_CASING - org.apache.calcite.config.CalciteConnectionProperty
-
How identifiers are stored if they are not quoted.
- unquotedCasing - Variable in enum org.apache.calcite.config.Lex
- unquotedCasing - Variable in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
- unquotedCasing - Variable in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- unquotedCasing() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
- unquotedCasing() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- unquotedCasing() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
- unquotedCasing() - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigImpl
- unquoteStringLiteral(String) - Method in class org.apache.calcite.sql.SqlDialect
-
Converts a string literal back into a string.
- Unsafe - Class in org.apache.calcite.util
-
Contains methods that call JDK methods that the forbidden APIs checker does not approve of.
- Unsafe() - Constructor for class org.apache.calcite.util.Unsafe
- UNSPECIFIED - org.apache.calcite.rel.RelFieldCollation.NullDirection
- 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
- unsupportedCount - Variable in class org.apache.calcite.rex.RexAnalyzer.VariableCollector
- unsupportedIntervalLiteral(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- UNVALIDATED - org.apache.calcite.sql.validate.SqlValidatorImpl.Status
-
Validation has not started for this scope.
- unwrap() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.Wrapped
- 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.ddl.SqlCreateMaterializedView.MaterializedViewTable
- unwrap(Class<C>) - Method in class org.apache.calcite.sql.ddl.SqlCreateTable.MutableArrayTable
- unwrap(Class<C>) - Method in class org.apache.calcite.sql.validate.DelegatingSqlValidatorCatalogReader
- unwrap(Class<T>) - Method in class org.apache.calcite.jdbc.CalciteConnectionImpl
- unwrap(Class<T>) - Method in class org.apache.calcite.jdbc.CalciteSchema.SchemaPlusImpl
- unwrap(Class<T>) - Method in class org.apache.calcite.jdbc.CalciteStatement
- unwrap(Class<T>) - Method in class org.apache.calcite.plan.Contexts.ChainContext
- unwrap(Class<T>) - Method in class org.apache.calcite.plan.Contexts.EmptyContext
- unwrap(Class<T>) - Method in class org.apache.calcite.plan.Contexts.WrapContext
- unwrap(Class<T>) - Method in class org.apache.calcite.plan.RelOptAbstractTable
- unwrap(Class<T>) - Method in class org.apache.calcite.prepare.RelOptTableImpl.MySchemaPlus
- 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.SqlCountAggFunction
- unwrap(Class<T>) - Method in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
- 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.AbstractNamespace
- 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(Object, Class<T>) - Static method in class org.apache.calcite.sql2rel.SqlToRelConverter
- 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. - unwrapper() - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- UP - org.apache.calcite.example.maze.Maze.Direction
- upAs(EqualityComparer<T>, T) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults.Wrapped
- update - Variable in class org.apache.calcite.sql.util.SqlShuttle.CallCopyingArgHandler
- UPDATE - org.apache.calcite.rel.core.TableModify.Operation
- UPDATE - org.apache.calcite.sql.SqlAccessEnum
- UPDATE - 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 - 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.
- updateBinaryOpUsage(RexCall) - Method in class org.apache.calcite.plan.RexImplicationChecker.InputUsageFinder
- updateCall - Variable in class org.apache.calcite.sql.SqlMerge
- updateColumnList - Variable in class org.apache.calcite.rel.core.TableModify
- updateColumnList - Variable in class org.apache.calcite.rel.mutable.MutableTableModify
- updateImportance(RelSubset, Double) - Method in class org.apache.calcite.plan.volcano.RuleQueue
- UpdateNamespace(SqlValidatorImpl, SqlUpdate, SqlNode, SqlValidatorScope) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.UpdateNamespace
- UpdateRefShuttle(List<RexLocalRef>) - Constructor for class org.apache.calcite.rex.RexProgramBuilder.UpdateRefShuttle
- updateRelInMap(SortedSetMultimap<RelNode, CorrelationId>) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- updateRelInMap(SortedMap<CorrelationId, LogicalCorrelate>) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener
- updateSetListNewline - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- updateUnaryOpUsage(RexCall) - Method in class org.apache.calcite.plan.RexImplicationChecker.InputUsageFinder
- updateUsage(SqlOperator, RexInputRef, RexNode) - Method in class org.apache.calcite.plan.RexImplicationChecker.InputUsageFinder
- updateVertex(HepRelVertex, RelNode) - Method in class org.apache.calcite.plan.hep.HepPlanner
- 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 - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonBound
- upper(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL UPPER(string) function.
- UPPER - org.apache.calcite.util.BuiltInMethod
- UPPER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- UPPER_HINT_TOKEN - Static variable in class org.apache.calcite.sql.advise.SqlAdvisor
- 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 - Variable in class org.apache.calcite.rel.logical.LogicalWindow.WindowKey
- upperBound - Variable in class org.apache.calcite.rex.RexWindow
- upperBound - Variable in class org.apache.calcite.sql.SqlWindow
-
The upper bound of the window.
- upperBound - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.HistogramShuttle
- 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.
- upperStrict - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonBound
- ups - Variable in class org.apache.calcite.example.maze.Maze
- UPSERT - org.apache.calcite.sql.SqlInsertKeyword
- uri() - Method in class org.apache.calcite.adapter.spark.HttpServer
-
Returns the URI of this HTTP server ("http://host:port").
- url - Variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- url - Variable in class org.apache.calcite.adapter.druid.DruidSchema
- url - Variable in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- url - Variable in class org.apache.calcite.util.Sources.FileSource
- url() - Method in interface org.apache.calcite.util.Source
- url() - Method in class org.apache.calcite.util.Sources.FileSource
- url(String) - Static method in class org.apache.calcite.util.Sources
- URL_ARG_ESCAPER - Static variable in class org.apache.calcite.util.XmlOutput.StringEscaper
- URL_ESCAPER - Static variable in class org.apache.calcite.util.XmlOutput.StringEscaper
- urlToFile(URL) - Method in class org.apache.calcite.util.Sources.FileSource
- usageCount - Variable in class org.apache.calcite.plan.RexImplicationChecker.InputRefUsage
- usageList - Variable in class org.apache.calcite.plan.RexImplicationChecker.InputRefUsage
- usageMap - Variable in class org.apache.calcite.plan.RexImplicationChecker.InputUsageFinder
- use(List<LatticeNode>) - Method in class org.apache.calcite.materialize.LatticeChildNode
- use(List<LatticeNode>) - Method in class org.apache.calcite.materialize.LatticeNode
- use(List<LatticeNode>) - Method in class org.apache.calcite.materialize.LatticeRootNode
- 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.
- UseCounter() - Constructor for class org.apache.calcite.linq4j.tree.BlockBuilder.UseCounter
- 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
-
Returns whether a decimal multiplication should be implemented by casting arguments to double values.
- useDoubleMultiplication(RelDataType, RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- useGroupingSets - Variable in class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
- useInSetQueryClause(List<RexNode>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeFilter.Translator
-
Check if we can use IN SET Query clause to improve query performance
- useLattices(RelNode, List<RelOptLattice>) - Static method in class org.apache.calcite.plan.RelOptMaterializations
-
Returns a list of RelNode transformed from all possible lattice uses.
- 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.
- User() - Constructor for enum org.apache.calcite.chinook.EnvironmentFairy.User
- USER - Static variable in class org.apache.calcite.chinook.EnvironmentFairy
- USER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
USER
function. - USER_DEFINED - org.apache.calcite.sql.SqlFunctionCategory.Property
- USER_DEFINED_CONSTRUCTOR - org.apache.calcite.sql.SqlFunctionCategory
- USER_DEFINED_FUNCTION - org.apache.calcite.sql.SqlFunctionCategory
- USER_DEFINED_PROCEDURE - org.apache.calcite.sql.SqlFunctionCategory
- USER_DEFINED_SPECIFIC_FUNCTION - org.apache.calcite.sql.SqlFunctionCategory
- USER_DEFINED_TABLE_FUNCTION - org.apache.calcite.sql.SqlFunctionCategory
- USER_DEFINED_TABLE_SPECIFIC_FUNCTION - org.apache.calcite.sql.SqlFunctionCategory
- UserDefinedAggReflectiveImplementor(AggregateFunctionImpl) - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.UserDefinedAggReflectiveImplementor
- userDefinedFunctionInFilter(Filter) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcFilterRule
- userDefinedFunctionInProject(Project) - Static method in class org.apache.calcite.adapter.jdbc.JdbcRules.JdbcProjectRule
- username - Variable in class org.apache.calcite.adapter.splunk.search.SplunkConnectionImpl
- usesTable(List<String>, Set<RelOptTable>, Graphs.FrozenGraph<List<String>, DefaultEdge>) - Static method in class org.apache.calcite.plan.RelOptMaterializations
-
Returns whether
table
uses one or more of the tables inusedTables
. - useStar(CalciteSchema, Prepare.Materialization) - Method in class org.apache.calcite.prepare.CalciteMaterializer
-
Converts a relational expression to use a
StarTable
defined inschema
. - useStar(CalciteSchema, RelNode) - Method in class org.apache.calcite.prepare.CalciteMaterializer
-
Converts a relational expression to use a
StarTable
defined inschema
. - USING - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- USING - org.apache.calcite.sql.JoinConditionType
-
Join clause has a USING condition, for example "FROM EMP JOIN DEPT USING (DEPTNO)"
- usingList - Variable in class org.apache.calcite.sql.ddl.SqlCreateFunction
- usingNames(SqlJoin) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.Permute
-
Returns the set of field names in the join condition specified by USING or implicitly by NATURAL, de-duplicated and in order.
- usingScope - Variable in class org.apache.calcite.sql.validate.CollectScope
- usingScope - Variable in class org.apache.calcite.sql.validate.JoinScope
- UTC_TIMESTAMP - org.apache.calcite.DataContext.Variable
- UTC_TIMESTAMP_FORMAT - Static variable in class org.apache.calcite.adapter.druid.DruidConnectionImpl
- UTF16 - org.apache.calcite.sql.SqlJsonEncoding
- UTF32 - org.apache.calcite.sql.SqlJsonEncoding
- UTF8 - org.apache.calcite.sql.SqlJsonEncoding
- Util - Class in org.apache.calcite.util
-
Miscellaneous utility functions.
- Util() - Constructor for class org.apache.calcite.util.Util
- Util.FilteringIterator<T> - Class in org.apache.calcite.util
-
Iterator that applies a predicate to each element.
- Util.FoundOne - Exception 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. - Util.RandomAccessTransformingList<F,T> - Class in org.apache.calcite.util
-
Extension to
Util.TransformingList
that implementsRandomAccess
. - Util.TransformingList<F,T> - Class in org.apache.calcite.util
-
List that returns the same number of elements as a backing list, applying a transformation function to each one.
- Utilities - Class in org.apache.calcite.runtime
-
Utility methods called by generated code.
- Utilities() - Constructor for class org.apache.calcite.runtime.Utilities
- uuid - Variable in class org.apache.calcite.materialize.MaterializationKey
V
- v - Variable in class org.apache.calcite.util.DateString
- v - Variable in class org.apache.calcite.util.TimestampString
- v - Variable in class org.apache.calcite.util.TimestampWithTimeZoneString
- v - Variable in class org.apache.calcite.util.TimeString
- v - Variable in class org.apache.calcite.util.TimeWithTimeZoneString
- valid - Variable in class org.apache.calcite.rex.RexProgramBuilder.RegisterInputShuttle
- valid(SqlKind) - Method in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
- VALID - org.apache.calcite.sql.validate.SqlValidatorImpl.Status
-
Validation has completed (perhaps unsuccessfully).
- VALID_SIG - Static variable in class org.apache.calcite.adapter.druid.DruidQuery
- VALID_TIME_EXTRACT - Static variable in class org.apache.calcite.adapter.druid.TimeExtractionFunction
- VALID_TIME_FLOOR - Static variable in class org.apache.calcite.adapter.druid.TimeExtractionFunction
- validate(Object) - Static method in class org.apache.calcite.runtime.Resources
-
Applies all validations to all resource methods in the given resource object.
- validate(Object, EnumSet<Resources.Validation>) - Static method in class org.apache.calcite.runtime.Resources
-
Applies the given validations to all resource methods in the given resource object.
- validate(String) - Method in class org.apache.calcite.sql.advise.SqlAdvisor
-
Attempts to parse and validate a SQL statement.
- validate(EnumSet<Resources.Validation>) - Method in class org.apache.calcite.runtime.Resources.ExInst
- validate(EnumSet<Resources.Validation>) - Method in class org.apache.calcite.runtime.Resources.ExInstWithCause
- validate(EnumSet<Resources.Validation>) - Method in class org.apache.calcite.runtime.Resources.Inst
- validate(DruidType) - Method in class org.apache.calcite.adapter.druid.ComplexMetric
- validate(TimeUnit) - Method in class org.apache.calcite.sql.dialect.MysqlSqlDialect
- validate(RelDataType) - Method in class org.apache.calcite.sql.validate.AbstractNamespace
- 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(RexNode, int) - Method in class org.apache.calcite.rex.RexProgramBuilder
- validate(RexNode, RexNode) - Method in class org.apache.calcite.plan.RexImplicationChecker
- 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
- validateAccess(SqlNode, SqlValidatorTable, SqlAccessEnum) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates access to a table.
- validateAggregateParams(SqlCall, SqlNode, SqlNodeList, SqlValidatorScope) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates parameters for aggregate function.
- validateAggregateParams(SqlCall, SqlNode, SqlNodeList, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateAndGetType(SqlNode) - Method in class org.apache.calcite.prepare.PlannerImpl
- validateAndGetType(SqlNode) - Method in interface org.apache.calcite.tools.Planner
-
Validates a SQL statement.
- 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.SqlDotOperator
- 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.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.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.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.SqlWith.SqlWithOperator
- 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.
- validateColumnListParams(SqlFunction, List<RelDataType>, List<SqlNode>) - Method in interface org.apache.calcite.sql.validate.SqlValidator
-
Validates a COLUMN_LIST parameter
- validateColumnListParams(SqlFunction, List<RelDataType>, List<SqlNode>) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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
- validateDefinitions(SqlMatchRecognize, MatchRecognizeScope) - 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
- validatedSqlNode - Variable in class org.apache.calcite.prepare.PlannerImpl
- 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.
- validateException(Callable<Exception>) - Method in class org.apache.calcite.runtime.Resources.ExInstWithCause
- 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.EmptyScope
- validateExpr(SqlNode) - Method in class org.apache.calcite.sql.validate.GroupByScope
- 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(SqlNode, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates 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
- validateFeature(Feature, SqlParserPos) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates that a particular feature is enabled.
- validateFrameBoundary(SqlNode, boolean, SqlTypeFamily, SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.SqlWindow
- 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.
- validateGroupByItem(SqlSelect, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates an item in the GROUP BY clause of a SELECT statement.
- validateGroupClause(SqlSelect) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates the GROUP BY clause of a SELECT statement.
- validateGroupingSets(SqlValidatorScope, AggregatingSelectScope, SqlCall) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- validateGroupItem(SqlValidatorScope, AggregatingSelectScope, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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
- 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.AbstractNamespace
-
Validates this scope and returns the type of the records it returns.
- 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.FieldNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.IdentifierNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.JoinNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.MatchRecognizeNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.ParameterNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.ProcedureNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.SchemaNamespace
- 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.TableNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.UnnestNamespace
- validateImpl(RelDataType) - Method in class org.apache.calcite.sql.validate.WithItemNamespace
- 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.
- validateKeys(RelNode, List<Integer>, List<Integer>, List<Integer>) - Method in class org.apache.calcite.rel.rules.LoptSemiJoinOptimizer
-
Validates the candidate semijoin keys corresponding to the fact table.
- 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
- validateLiteralAsDouble(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
- validateMeasure(SqlMatchRecognize, MatchRecognizeScope, boolean) - 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(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates that a query can deliver the modality it promises.
- 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.
- validateNoAggs(AggFinder, SqlNode, String) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Throws an error if there is an aggregate or windowed aggregate in the given clause.
- validateNodeFeature(SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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.
- validateOrderItem(SqlSelect, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Validates an item in the ORDER BY clause of a SELECT statement.
- 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.RelMetadataQuery
- 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.RelMetadataQuery
- validateScopedExpression(SqlNode, SqlValidatorScope) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
- 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
- validateUnnest(SqlCall, SqlValidatorScope, RelDataType) - 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
- validateUsingCol(SqlIdentifier, SqlNode) - 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
- validating - Variable in class org.apache.calcite.rex.RexProgramBuilder
- validatingSqlMerge - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- Validation() - Constructor for enum org.apache.calcite.runtime.Resources.Validation
- validationError(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- ValidationError(SqlNode, Resources.ExInst<SqlValidatorException>) - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.ValidationError
- validationErrorFunction - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
- ValidationErrorFunction() - Constructor for class org.apache.calcite.sql.validate.SqlValidatorImpl.ValidationErrorFunction
- ValidationException - Exception in org.apache.calcite.tools
-
An Exception thrown when attempting to validate a SQL parse tree.
- ValidationException(String) - Constructor for exception org.apache.calcite.tools.ValidationException
-
Creates a ValidationException with the specified detail message.
- ValidationException(String, Throwable) - Constructor for exception org.apache.calcite.tools.ValidationException
-
Creates a ValidationException with the specified detail message and cause.
- ValidationException(Throwable) - Constructor for exception org.apache.calcite.tools.ValidationException
-
Creates a ValidationException with the specified cause.
- validator - Variable in class org.apache.calcite.prepare.PlannerImpl
- validator - Variable in class org.apache.calcite.sql.advise.SqlAdvisor
- validator - Variable in class org.apache.calcite.sql.SqlCallBinding
- validator - Variable in class org.apache.calcite.sql.validate.AbstractNamespace
- validator - Variable in class org.apache.calcite.sql.validate.AggChecker
- validator - Variable in class org.apache.calcite.sql.validate.DelegatingScope
- validator - Variable in class org.apache.calcite.sql.validate.EmptyScope
- validator - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.Expander
- validator - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
- validatorContext(int, int, int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- validatorContextPoint(int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- validatorException - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl.ValidationError
- 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.SqlDotOperator
- validRexOperands(int, Litmus) - Method in class org.apache.calcite.sql.fun.SqlInOperator
- 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.adapter.druid.DruidJsonFilter.JsonSelector
- value - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RegexpQueryBuilder
- value - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.TermQueryBuilder
- value - Variable in class org.apache.calcite.interpreter.AggregateNode.UdaAccumulator
- value - Variable in class org.apache.calcite.linq4j.tree.ConstantExpression
- value - Variable in class org.apache.calcite.piglet.Ast.Identifier
- value - Variable in class org.apache.calcite.piglet.Ast.Literal
- value - Variable in class org.apache.calcite.plan.RelOptCostImpl
- value - Variable in class org.apache.calcite.rex.RexLiteral
-
The value of this literal.
- value - Variable in class org.apache.calcite.rex.RexSimplify.CaseBranch
- value - Variable in class org.apache.calcite.schema.impl.LongSchemaVersion
- value - Variable in class org.apache.calcite.sql.fun.SqlCase
- value - Variable in class org.apache.calcite.sql.SqlLiteral
-
The value of this literal.
- value - Variable in class org.apache.calcite.sql.SqlSetOption
-
Value of the option.
- value - Variable in class org.apache.calcite.util.CaseInsensitiveComparator.Key
- value() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.MultiValue
-
For single value.
- value() - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.LiteralExpression
- value() - Method in annotation type org.apache.calcite.adapter.java.Map
-
Value type.
- value() - Method in annotation type org.apache.calcite.runtime.Resources.BaseMessage
- value() - Method in annotation type org.apache.calcite.runtime.Resources.Default
- value() - Method in annotation type org.apache.calcite.runtime.Resources.Property
- value() - Method in annotation type org.apache.calcite.runtime.Resources.Resource
- value(int) - Method in class org.apache.calcite.adapter.jdbc.JdbcUtils.ObjectArrayRowBuilder
-
Gets a value from a given column in a JDBC result set.
- value(String) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchSearchResult.SearchHit
-
Finds specific attribute from ES search result
- value(RexNode) - Static method in class org.apache.calcite.rex.RexLiteral
- value(SqlNode) - Static method in class org.apache.calcite.sql.ddl.SqlCreateForeignSchema
-
Returns the value of a literal, converting
NlsString
into String. - 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 - Variable in enum org.apache.calcite.config.CalciteConnectionProperty
- valueClass() - Method in enum org.apache.calcite.config.CalciteConnectionProperty
- ValueConstructorImplementor() - Constructor for class org.apache.calcite.adapter.enumerable.RexImpTable.ValueConstructorImplementor
- valueFromPath(Map<String, Object>, String) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHit
-
Returns property from nested maps given a path like
a.b.c
. - valueIsNullable - Variable in class org.apache.calcite.linq4j.tree.Types.MapType
- valueIsNullable() - Method 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
- valueMatchesType(Object, SqlTypeName) - Static method in class org.apache.calcite.sql.SqlLiteral
- 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.clone.ArrayTable.RepresentationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.csv.CsvFieldType
-
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.DruidJsonFilter.Type
-
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.Granularities.AllGranularity
-
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.elasticsearch.ElasticsearchMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.adapter.elasticsearch.ElasticsearchVersion
-
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.FileFieldType
-
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.SqlShell.Format
-
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.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.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.example.maze.Maze.Direction
-
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.CorrelateJoinType
-
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.materialize.MapSqlStatisticProvider
-
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.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.Side
-
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
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.plan.volcano.VolcanoPlannerPhase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.prepare.PlannerImpl.State
-
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.TableModify.Operation
-
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.mutable.MutableRelType
-
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.AbstractMaterializedViewRule.MatchModality
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator.Constancy
-
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.RexInterpreter.Truthy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
-
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.runtime.GeoFunctions.CapStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.runtime.GeoFunctions.JoinStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.runtime.GeoFunctions.Type
-
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.Resources.BuiltinMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.runtime.Resources.EmptyPropertyAccessor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.runtime.Resources.Validation
-
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.PathMode
-
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.advise.SqlSimpleParser.TokenType
-
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.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.parser.SqlAbstractParserImpl.ExprContext
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.SemiJoinType
-
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.Property
-
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.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.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.SqlWindow.Bound
-
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.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.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.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.
- valueOrNull(String) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.SearchHit
- values - Variable in class org.apache.calcite.adapter.clone.ColumnLoader.ValueSet
- values - Variable in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonInFilter
- values - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.MultiValue
- values - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.TermsQueryBuilder
- values - Variable in class org.apache.calcite.interpreter.AggregateNode.ScalarAccumulator
- values - Variable in class org.apache.calcite.interpreter.Context
-
Values of incoming columns from all inputs.
- values - Variable in class org.apache.calcite.interpreter.Row.RowBuilder
- values - Variable in class org.apache.calcite.interpreter.Row
- values - Variable in class org.apache.calcite.linq4j.GroupingImpl
- values - Variable in class org.apache.calcite.linq4j.tree.Evaluator
- values - Variable in class org.apache.calcite.plan.VisitorDataContext
- values - Variable in class org.apache.calcite.prepare.CalcitePrepareImpl.LambdaScalarTranslator
- values - Variable in class org.apache.calcite.profile.Profiler.Distribution
- values - Variable in class org.apache.calcite.profile.ProfilerImpl.CompositeCollector
- values - Variable in class org.apache.calcite.profile.ProfilerImpl.SingletonCollector
- values - Variable in class org.apache.calcite.profile.SimpleProfiler.Space
- values - Variable in class org.apache.calcite.rel.externalize.RelJsonWriter
- values - Variable in class org.apache.calcite.rel.externalize.RelWriterImpl
- values - Variable in class org.apache.calcite.sql.validate.TableConstructorNamespace
- 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.clone.ArrayTable.RepresentationType
-
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.CsvFieldType
-
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.DruidJsonFilter.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.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.Granularities.AllGranularity
-
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() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson.MultiValue
- values() - Static method in enum org.apache.calcite.adapter.elasticsearch.ElasticsearchMethod
-
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.elasticsearch.ElasticsearchVersion
-
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.FileFieldType
-
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.SqlShell.Format
-
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.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.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.example.maze.Maze.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.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.CorrelateJoinType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.apache.calcite.linq4j.EnumerableDefaults.WrapMap
- values() - Method in class org.apache.calcite.linq4j.LookupImpl
- 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.materialize.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.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.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.Side
-
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
-
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.volcano.VolcanoPlannerPhase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.prepare.PlannerImpl.State
-
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.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.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.mutable.MutableRelType
-
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.AbstractMaterializedViewRule.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.rules.ReduceExpressionsRule.ReducibleExprLocator.Constancy
-
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.RexInterpreter.Truthy
-
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.RexSimplify.SafeRexVisitor
-
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.runtime.GeoFunctions.CapStyle
-
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.GeoFunctions.JoinStyle
-
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.GeoFunctions.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.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.Resources.BuiltinMethod
-
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.Resources.EmptyPropertyAccessor
-
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.Resources.Validation
-
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.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.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.advise.SqlSimpleParser.TokenType
-
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.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.parser.SqlAbstractParserImpl.ExprContext
-
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.SemiJoinType
-
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.Property
-
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.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.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.SqlWindow.Bound
-
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.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.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.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(Iterable<? extends List<RexLiteral>>, RelDataType) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Values
with a specified row type. - values(String[], Object...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
Values
. - 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, 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 - org.apache.calcite.piglet.Ast.Op
- VALUES - org.apache.calcite.rel.mutable.MutableRelType
- VALUES - org.apache.calcite.sql.SqlKind
-
The "VALUES" operator.
- VALUES - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
VALUES clause.
- VALUES - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- VALUES_MAP - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- valuesEnumerable() - Method in class org.apache.calcite.linq4j.LookupImpl
-
Returns an enumerable over the values in this lookup, in map order.
- valueSet - Variable in class org.apache.calcite.profile.ProfilerImpl.Space
-
Assigned by
ProfilerImpl.Collector.finish()
. - ValueSet(Class) - Constructor for class org.apache.calcite.adapter.clone.ColumnLoader.ValueSet
- valuesFactory - Variable in class org.apache.calcite.tools.RelBuilder
- ValuesFactoryImpl() - Constructor for class org.apache.calcite.rel.core.RelFactories.ValuesFactoryImpl
- 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
-
Creates a ValuesReduceRule.
- ValuesReduceRule.MyRexShuttle - Class in org.apache.calcite.rel.rules
-
Shuttle that converts inputs to literals.
- ValuesStmt(SqlParserPos, Ast.Identifier, Ast.Schema, List<List<Ast.Node>>) - Constructor for class org.apache.calcite.piglet.Ast.ValuesStmt
- valueType - Variable in class org.apache.calcite.linq4j.tree.Types.MapType
- valueType - Variable in class org.apache.calcite.piglet.Ast.MapType
- valueType - Variable in class org.apache.calcite.sql.type.MapSqlType
- valueTypes - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- VAR_POP - org.apache.calcite.sql.fun.SqlAvgAggFunction.Subtype
-
Deprecated.
- VAR_POP - 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 - org.apache.calcite.sql.fun.SqlAvgAggFunction.Subtype
-
Deprecated.
- VAR_SAMP - 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 - org.apache.calcite.sql.type.SqlTypeName
- VARCHAR - org.apache.calcite.sql.type.SqlTypeName
- 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)".
- 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(Holder<RexCorrelVariable>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a correlation variable for the current input, and writes it into a Holder.
- Variable(String, Class) - Constructor for enum org.apache.calcite.DataContext.Variable
- VariableCollector() - Constructor for class org.apache.calcite.rex.RexAnalyzer.VariableCollector
- variableFields - Variable in class org.apache.calcite.plan.RelOptUtil.VariableUsedVisitor
- VariableReplacer(RexBuilder, RelDataType, RelDataType) - Constructor for class org.apache.calcite.rel.rules.JoinCommuteRule.VariableReplacer
- variables - Variable in class org.apache.calcite.linq4j.tree.BlockBuilder
- variables - Variable in class org.apache.calcite.plan.RelOptUtil.VariableSetVisitor
- variables - Variable in class org.apache.calcite.plan.RelOptUtil.VariableUsedVisitor
- variables - Variable in class org.apache.calcite.rex.RexAnalyzer
- VariableSetVisitor() - Constructor for class org.apache.calcite.plan.RelOptUtil.VariableSetVisitor
- variablesPropagated - Variable in class org.apache.calcite.plan.volcano.RelSet
-
Variables that are set by relational expressions in this set and available for use by parent and child expressions.
- variablesSet - Variable in class org.apache.calcite.rel.core.Join
- variablesSet - Variable in class org.apache.calcite.rel.logical.LogicalFilter
- variablesSet - Variable in class org.apache.calcite.rel.mutable.MutableJoin
- variablesUsed - Variable in class org.apache.calcite.plan.volcano.RelSet
-
Variables that are used by relational expressions in this set.
- 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. - verify(RexNode, RexUnknownAs, Function<RexSimplify, RexNode>) - Method in class org.apache.calcite.rex.RexSimplify
- 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.adapter.elasticsearch.ElasticsearchTable
- version - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
- version - Variable in class org.apache.calcite.model.JsonRoot
-
Schema model version number.
- version() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTransport
-
Detects current Elastic Search version by connecting to a existing instance.
- Vertex(int, ImmutableBitSet, double) - Constructor for class org.apache.calcite.rel.rules.MultiJoinOptimizeBushyRule.Vertex
- Vertex(LatticeTable, String) - Constructor for class org.apache.calcite.materialize.Lattice.Vertex
- VertexInfo() - Constructor for class org.apache.calcite.util.graph.DefaultDirectedGraph.VertexInfo
- vertexMap - Variable in class org.apache.calcite.util.graph.DefaultDirectedGraph
- vertexSet() - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- vertexSet() - Method in interface org.apache.calcite.util.graph.DirectedGraph
- VERTICA - 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.adapter.cassandra.CassandraTable
- view - Variable in class org.apache.calcite.model.JsonMaterialization
- VIEW - org.apache.calcite.schema.Schema.TableType
-
A relation whose contents are calculated by evaluating a SQL expression.
- VIEW - org.apache.calcite.sql.validate.SqlMonikerType
- VIEW_PARTIAL - org.apache.calcite.rel.rules.AbstractMaterializedViewRule.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 - Variable in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- viewExpander - Variable in class org.apache.calcite.tools.Frameworks.StdFrameworkConfig
- viewExpander(RelOptTable.ViewExpander) - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- ViewExpanderImpl() - Constructor for class org.apache.calcite.prepare.PlannerImpl.ViewExpanderImpl
-
Deprecated.
- ViewExpanders - Class in org.apache.calcite.plan
-
Utilities for
RelOptTable.ViewExpander
andRelOptTable.ToRelContext
. - ViewExpanders() - Constructor for class org.apache.calcite.plan.ViewExpanders
- 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
- ViewPartialRewriting(RelNode, Project, RelNode) - Constructor for class org.apache.calcite.rel.rules.AbstractMaterializedViewRule.ViewPartialRewriting
- viewPath - Variable in class org.apache.calcite.schema.impl.ViewTable
- viewPath - Variable in class org.apache.calcite.schema.impl.ViewTableMacro
- viewSchemaPath - Variable in class org.apache.calcite.materialize.MaterializationActor.Materialization
- viewSchemaPath - Variable in class org.apache.calcite.model.JsonMaterialization
- viewSchemaPath - Variable in class org.apache.calcite.prepare.Prepare.Materialization
-
The schema path for the query.
- viewSql - Variable in class org.apache.calcite.schema.impl.ViewTable
- 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 - org.apache.calcite.schema.ColumnStrategy
-
Column is computed and not stored.
- virtualCall(SqlAbstractParserImpl, String) - Method in class org.apache.calcite.sql.parser.SqlAbstractParserImpl.MetadataImpl
-
Uses reflection to invoke a method on this parser.
- 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
- virtualColumnList - Variable in class org.apache.calcite.adapter.druid.DruidQuery.ScanQuery
- visit(String, IntegerIntervalSet.Handler) - Static method in class org.apache.calcite.util.IntegerIntervalSet
- visit(JdbcTableScan) - Method in class org.apache.calcite.adapter.jdbc.JdbcImplementor
- 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.BlockBuilder.InlineVariableVisitor
- 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.adapter.enumerable.EnumerableRelImplementor.TypeFinder
- 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 class org.apache.calcite.linq4j.tree.BlockBuilder.UseCounter
- 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(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 class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor.TypeFinder
- 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 class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor.TypeFinder
- 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.BlockBuilder.SubstituteVariableVisitor
- visit(ParameterExpression) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder.UseCounter
- 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 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(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.BlockBuilder.InlineVariableVisitor
- 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(SubstitutionVisitor.Operand) - Method in class org.apache.calcite.plan.SubstitutionVisitor.SlotCounter
- visit(Aggregate) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Aggregate) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visit(Calc) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visit(Filter) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Filter) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visit(Intersect) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visit(Join) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Join) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visit(Match) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visit(Minus) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visit(Project) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Project) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visit(Sort) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Sort) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visit(TableFunctionScan) - Method in class org.apache.calcite.prepare.CalciteMaterializer.RelNullShuttle
- 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
- visit(TableScan) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(TableScan) - Method in class org.apache.calcite.prepare.CalciteMaterializer.RelNullShuttle
- visit(TableScan) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- 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(Union) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Union) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visit(Values) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(Values) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- visit(Window) - Method in class org.apache.calcite.interpreter.Nodes.CoreCompiler
- visit(LogicalAggregate) - Method in class org.apache.calcite.prepare.CalciteMaterializer.RelNullShuttle
- 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(LogicalCorrelate) - Method in class org.apache.calcite.prepare.CalciteMaterializer.RelNullShuttle
- 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.RelDecorrelator.CorelMapBuilder
- visit(LogicalExchange) - Method in class org.apache.calcite.prepare.CalciteMaterializer.RelNullShuttle
- 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.prepare.CalciteMaterializer.RelNullShuttle
- 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(LogicalFilter) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
- visit(LogicalIntersect) - Method in class org.apache.calcite.prepare.CalciteMaterializer.RelNullShuttle
- 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.prepare.CalciteMaterializer.RelNullShuttle
- 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(LogicalJoin) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
- visit(LogicalMatch) - Method in class org.apache.calcite.prepare.CalciteMaterializer.RelNullShuttle
- 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.prepare.CalciteMaterializer.RelNullShuttle
- 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.prepare.CalciteMaterializer.RelNullShuttle
- 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(LogicalProject) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
- visit(LogicalSort) - Method in class org.apache.calcite.prepare.CalciteMaterializer.RelNullShuttle
- 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(LogicalUnion) - Method in class org.apache.calcite.prepare.CalciteMaterializer.RelNullShuttle
- 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.prepare.CalciteMaterializer.RelNullShuttle
- 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.MutableRel.MutableRelDumper
- visit(MutableRel) - Method in class org.apache.calcite.rel.mutable.MutableRelVisitor
- visit(RelNode) - Method in class org.apache.calcite.plan.RelOptUtil.CorrelationCollector
- visit(RelNode) - Method in class org.apache.calcite.prepare.CalciteMaterializer.RelNullShuttle
- visit(RelNode) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- 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, int, RelNode) - Method in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
- visit(RelNode, int, RelNode) - Method in class org.apache.calcite.plan.RelOptUtil.VariableSetVisitor
- visit(RelNode, int, RelNode) - Method in class org.apache.calcite.plan.RelTraitPropagationVisitor
- visit(RelNode, int, RelNode) - Method in class org.apache.calcite.plan.TableAccessMap.TableRelVisitor
- visit(RelNode, int, RelNode) - Method in class org.apache.calcite.plan.volcano.RelSubset.CheapestPlanReplacer
- visit(RelNode, int, RelNode) - Method in class org.apache.calcite.rel.RelVisitor
-
Visits a node during a traversal.
- visit(RelNode, int, RelNode) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener.RewriteRelVisitor
- visit(RexNode) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.RexReplacer
- visit(SqlCall) - Method in class org.apache.calcite.sql.fun.SqlBetweenOperator.AndFinder
- visit(SqlCall) - Method in class org.apache.calcite.sql.SqlUtil.Genealogist
- 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.AggChecker
- visit(SqlCall) - Method in class org.apache.calcite.sql.validate.AggVisitor
- visit(SqlCall) - Method in class org.apache.calcite.sql.validate.SqlScopedShuttle
- visit(SqlCall) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.DeriveTypeVisitor
- visit(SqlCall) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.NavigationExpander
- visit(SqlCall) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.NavigationReplacer
- visit(SqlCall) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternValidator
- visit(SqlCall) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternVarVisitor
- visit(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- visit(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggregateFinder
- visit(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- visit(SqlCall) - Method in class org.apache.calcite.util.Util.OverFinder
- visit(SqlDataTypeSpec) - Method in class org.apache.calcite.sql.SqlUtil.Genealogist
- 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.SqlValidatorImpl.DeriveTypeVisitor
- visit(SqlDataTypeSpec) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternValidator
- visit(SqlDataTypeSpec) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternVarVisitor
- visit(SqlDataTypeSpec) - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- visit(SqlDataTypeSpec) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- visit(SqlDataTypeSpec) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- visit(SqlDynamicParam) - Method in class org.apache.calcite.sql.SqlUtil.Genealogist
- 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.SqlValidatorImpl.DeriveTypeVisitor
- visit(SqlDynamicParam) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternValidator
- visit(SqlDynamicParam) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternVarVisitor
- visit(SqlDynamicParam) - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- visit(SqlDynamicParam) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- visit(SqlDynamicParam) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql.SqlUtil.Genealogist
- 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.AggChecker
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.DeriveTypeVisitor
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.Expander
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.ExtendedExpander
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.NavigationExpander
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.NavigationReplacer
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.OrderExpressionExpander
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternValidator
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternVarVisitor
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- visit(SqlIdentifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- visit(SqlIntervalQualifier) - Method in class org.apache.calcite.sql.SqlUtil.Genealogist
- 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.SqlValidatorImpl.DeriveTypeVisitor
- visit(SqlIntervalQualifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternValidator
- visit(SqlIntervalQualifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternVarVisitor
- visit(SqlIntervalQualifier) - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- visit(SqlIntervalQualifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- visit(SqlIntervalQualifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- visit(SqlLiteral) - Method in class org.apache.calcite.sql.SqlUtil.Genealogist
- 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.SqlValidatorImpl.DeriveTypeVisitor
- visit(SqlLiteral) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.ExtendedExpander
- visit(SqlLiteral) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.OrderExpressionExpander
- visit(SqlLiteral) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternValidator
- visit(SqlLiteral) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternVarVisitor
- visit(SqlLiteral) - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- visit(SqlLiteral) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- visit(SqlLiteral) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- visit(SqlNodeList) - Method in class org.apache.calcite.sql.SqlUtil.Genealogist
- 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.SqlValidatorImpl.DeriveTypeVisitor
- visit(SqlNodeList) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.PatternVarVisitor
- visit(SqlNodeList) - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- visit(SqlNodeList) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
- visit(SqlNodeList) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
- VISIT_METHOD_NAME - Static variable in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
- visit0(BinaryExpression, Expression, Expression) - Method in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- 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.elasticsearch.ElasticsearchRules.RexToElasticsearchTranslator
- visitCall(RexCall) - Method in class org.apache.calcite.adapter.elasticsearch.MapProjectionFieldVisitor
- visitCall(RexCall) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.NotLikeConverter
- visitCall(RexCall) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor
- visitCall(RexCall) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRules.RexToGeodeTranslator
- visitCall(RexCall) - Method in class org.apache.calcite.adapter.jdbc.JdbcRules.CheckingUserDefinedFunctionVisitor
- visitCall(RexCall) - Method in class org.apache.calcite.adapter.mongodb.MongoRules.RexToMongoTranslator
- visitCall(RexCall) - Method in class org.apache.calcite.plan.RelOptUtil.InputFinder
- visitCall(RexCall) - Method in class org.apache.calcite.plan.RexImplicationChecker.InputUsageFinder
- visitCall(RexCall) - Method in class org.apache.calcite.rel.core.Match.AggregateFinder
- visitCall(RexCall) - Method in class org.apache.calcite.rel.core.Match.PatternVarFinder
- visitCall(RexCall) - Method in class org.apache.calcite.rel.metadata.RelMdPredicates.JoinConditionBasedPredicateInference.EquivalenceFinder
- visitCall(RexCall) - Method in class org.apache.calcite.rel.metadata.RelMdUtil.CardOfProjExpr
- visitCall(RexCall) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.ImplementTester
- visitCall(RexCall) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractFinder
- visitCall(RexCall) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- visitCall(RexCall) - Method in class org.apache.calcite.rel.rules.FilterRemoveIsNotDistinctFromRule.RemoveIsNotDistinctFromRexShuttle
- visitCall(RexCall) - Method in class org.apache.calcite.rel.rules.PushProjector.InputSpecialOpFinder
- visitCall(RexCall) - Method in class org.apache.calcite.rel.rules.PushProjector.RefAndExprConverter
- visitCall(RexCall) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.DecimalShuttle
-
Rewrites a call in place, from bottom up, as follows: visit operands visit call node rewrite call visit the rewritten call
- 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.RexAnalyzer.VariableCollector
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexChecker
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexCopier
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexInterpreter
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexMultisetUtil.RexCallMultisetOperatorCounter
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexPermuteInputsShuttle
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexProgram.Marshaller
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexProgramBuilder.RegisterShuttle
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexShuttle
- visitCall(RexCall) - Method in enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexUtil.ConstantFinder
- visitCall(RexCall) - Method in class org.apache.calcite.rex.RexUtil.ExpressionNormalizer
- 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) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationRexShuttle
- visitCall(RexCall) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener.RewriteRexShuttle
- visitCall(RexCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.HistogramShuttle
- visitCall(RexCall, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitCall(RexCall, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitChild(int, RelNode) - Method in class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
- visitChild(int, RelNode) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRel.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.RelToSqlConverter
- visitChild(int, RelNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- visitChild(EnumerableRel, int, EnumerableRel, EnumerableRel.Prefer) - Method in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- visitChild(RelNode) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- 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(SqlNode) - Method in class org.apache.calcite.sql.SqlUtil.Genealogist
- 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.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.RexCopier
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rex.RexInterpreter
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rex.RexProgram.ConstantFinder
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rex.RexProgram.Marshaller
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rex.RexProgramBuilder.RegisterShuttle
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rex.RexShuttle
- visitCorrelVariable(RexCorrelVariable) - Method in enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rex.RexUtil.ConstantFinder
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rex.RexUtil.CorrelationFinder
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rex.RexUtil.ExpressionNormalizer
- visitCorrelVariable(RexCorrelVariable) - Method in interface org.apache.calcite.rex.RexVisitor
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.calcite.sql2rel.DeduplicateCorrelateVariables.DeduplicateCorrelateVariablesShuttle
- visitCorrelVariable(RexCorrelVariable, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitCorrelVariable(RexCorrelVariable, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.ImplementTester
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.rex.RexCopier
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.rex.RexInterpreter
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.rex.RexProgram.Marshaller
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.rex.RexProgramBuilder.RegisterShuttle
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.rex.RexShuttle
- visitDynamicParam(RexDynamicParam) - Method in enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.rex.RexUtil.ConstantFinder
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.rex.RexUtil.ExpressionNormalizer
- visitDynamicParam(RexDynamicParam) - Method in interface org.apache.calcite.rex.RexVisitor
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitDynamicParam(RexDynamicParam, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitDynamicParam(RexDynamicParam, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.plan.RelOptUtil.VariableUsedVisitor
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.ImplementTester
- 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.RexAnalyzer.VariableCollector
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rex.RexChecker
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rex.RexCopier
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rex.RexInterpreter
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rex.RexProgram.Marshaller
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rex.RexProgramBuilder.RegisterShuttle
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rex.RexShuttle
- visitFieldAccess(RexFieldAccess) - Method in enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rex.RexUtil.ConstantFinder
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.rex.RexUtil.ExpressionNormalizer
- 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) - Method in class org.apache.calcite.sql2rel.CorrelationReferenceFinder.MyRexVisitor
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.DecorrelateRexShuttle
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationRexShuttle
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener.RewriteRexShuttle
- visitFieldAccess(RexFieldAccess, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitFieldAccess(RexFieldAccess, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- 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(SparkRel, int, SparkRel) - Method in class org.apache.calcite.adapter.spark.SparkRel.Implementor
- visitInput(SparkRel, int, SparkRel) - Method in class org.apache.calcite.adapter.spark.SparkToEnumerableConverter.SparkImplementorImpl
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.adapter.cassandra.CassandraRules.RexToCassandraTranslator
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.RexToElasticsearchTranslator
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRules.RexToGeodeTranslator
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.adapter.mongodb.MongoRules.RexToMongoTranslator
- 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.plan.RexImplicationChecker.InputUsageFinder
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rel.metadata.RelMdExpressionLineage.RexReplacer
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rel.metadata.RelMdUtil.CardOfProjExpr
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.InputToCommonExprConverter
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rel.rules.JoinToMultiJoinRule.InputReferenceCounter
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rel.rules.PushProjector.InputSpecialOpFinder
- 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.rel.rules.ValuesReduceRule.MyRexShuttle
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexAnalyzer.VariableCollector
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexChecker
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexCopier
- 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.RexProgram.Marshaller
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexProgramBuilder.RegisterInputShuttle
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexProgramBuilder.RegisterOutputShuttle
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexShuttle
- visitInputRef(RexInputRef) - Method in enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexUtil.ConstantFinder
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexUtil.ExpressionNormalizer
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexUtil.FixNullabilityShuttle
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexUtil.ForwardRefFinder
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexUtil.RexShiftShuttle
- visitInputRef(RexInputRef) - Method in interface org.apache.calcite.rex.RexVisitor
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.DecorrelateRexShuttle
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationRexShuttle
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener.RewriteRexShuttle
- visitInputRef(RexInputRef) - Method in class org.apache.calcite.tools.RelBuilder.Shifter
- visitInputRef(RexInputRef, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitInputRef(RexInputRef, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitJoin(BiRel) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
- visitLambda(FunctionExpression<T>) - Method in interface org.apache.calcite.linq4j.tree.ExpressionVisitor
-
Visits the children of the delegate expression.
- visitList(List<? extends RexNode>, boolean[]) - Method in class org.apache.calcite.rel.rules.DateRangeRules.ExtractShuttle
- 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.
- visitList(List<? extends RexNode>, List<RexNode>) - Method in class org.apache.calcite.rex.RexShuttle
-
Visits a list and writes the results to another list.
- visitList(List<RexNode>) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.RexToElasticsearchTranslator
- visitList(List<RexNode>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRules.RexToGeodeTranslator
- visitList(List<RexNode>) - Method in class org.apache.calcite.adapter.mongodb.MongoRules.RexToMongoTranslator
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchRules.RexToElasticsearchTranslator
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.Visitor
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.adapter.mongodb.MongoRules.RexToMongoTranslator
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.rel.metadata.RelMdUtil.CardOfProjExpr
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.ImplementTester
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.rex.RexCopier
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.rex.RexInterpreter
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.rex.RexProgram.Marshaller
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.rex.RexProgramBuilder.RegisterShuttle
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.rex.RexShuttle
- visitLiteral(RexLiteral) - Method in enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.rex.RexUtil.ConstantFinder
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.rex.RexUtil.ExpressionNormalizer
- visitLiteral(RexLiteral) - Method in interface org.apache.calcite.rex.RexVisitor
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.RemoveCorrelationRexShuttle
- visitLiteral(RexLiteral, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitLiteral(RexLiteral, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.HighestUsageFinder
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.InputToCommonExprConverter
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rel.rules.CalcRelSplitter.MaxInputFinder
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexChecker
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexCopier
- 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.RexProgram.Checker
-
Overrides
RexChecker
method, becauseRexLocalRef
is is illegal in most rex expressions, but legal in a program. - visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexProgram.ConstantFinder
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexProgram.ExpansionShuttle
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexProgram.Marshaller
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexProgram.ReferenceCounter
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexProgramBuilder.RegisterInputShuttle
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexProgramBuilder.RegisterMidputShuttle
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexProgramBuilder.RegisterOutputShuttle
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexProgramBuilder.UpdateRefShuttle
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexShuttle
- visitLocalRef(RexLocalRef) - Method in enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexUtil.ConstantFinder
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexUtil.ForwardRefFinder
- visitLocalRef(RexLocalRef) - Method in interface org.apache.calcite.rex.RexVisitor
- visitLocalRef(RexLocalRef) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitLocalRef(RexLocalRef, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitLocalRef(RexLocalRef, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitMappingProperties(ObjectNode, BiConsumer<String, String>) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson
-
Visits Elasticsearch mapping properties and calls consumer for each
field / type
pair. - visitMappingProperties(Deque<String>, ObjectNode, BiConsumer<String, String>) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson
- Visitor<R> - Interface in org.apache.calcite.linq4j.tree
-
Node visitor.
- Visitor() - Constructor for class org.apache.calcite.adapter.elasticsearch.PredicateAnalyzer.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 an 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.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- visitOver(RexOver) - Method in class org.apache.calcite.rex.RexCopier
- visitOver(RexOver) - Method in class org.apache.calcite.rex.RexInterpreter
- visitOver(RexOver) - Method in class org.apache.calcite.rex.RexOver.Finder
- visitOver(RexOver) - Method in class org.apache.calcite.rex.RexProgram.ConstantFinder
- visitOver(RexOver) - Method in class org.apache.calcite.rex.RexProgram.Marshaller
- visitOver(RexOver) - Method in class org.apache.calcite.rex.RexProgramBuilder.RegisterShuttle
- visitOver(RexOver) - Method in class org.apache.calcite.rex.RexShuttle
- visitOver(RexOver) - Method in enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- visitOver(RexOver) - Method in class org.apache.calcite.rex.RexUtil.ConstantFinder
- 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
- visitPatternFieldRef(RexPatternFieldRef) - Method in class org.apache.calcite.rel.core.Match.PatternVarFinder
- visitPatternFieldRef(RexPatternFieldRef) - Method in class org.apache.calcite.rex.RexInterpreter
- visitPatternFieldRef(RexPatternFieldRef) - Method in class org.apache.calcite.rex.RexShuttle
- visitPatternFieldRef(RexPatternFieldRef) - Method in enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- visitPatternFieldRef(RexPatternFieldRef) - Method in class org.apache.calcite.rex.RexUtil.ConstantFinder
- visitPatternFieldRef(RexPatternFieldRef) - Method in interface org.apache.calcite.rex.RexVisitor
- visitPatternFieldRef(RexPatternFieldRef) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitPatternFieldRef(RexPatternFieldRef, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitPatternFieldRef(RexPatternFieldRef, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitRangeRef(RexRangeRef) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- visitRangeRef(RexRangeRef) - Method in class org.apache.calcite.rex.RexCopier
- visitRangeRef(RexRangeRef) - Method in class org.apache.calcite.rex.RexInterpreter
- visitRangeRef(RexRangeRef) - Method in class org.apache.calcite.rex.RexProgram.Marshaller
- visitRangeRef(RexRangeRef) - Method in class org.apache.calcite.rex.RexShuttle
- visitRangeRef(RexRangeRef) - Method in enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- visitRangeRef(RexRangeRef) - Method in class org.apache.calcite.rex.RexUtil.ConstantFinder
- visitRangeRef(RexRangeRef) - Method in class org.apache.calcite.rex.RexUtil.ExpressionNormalizer
- visitRangeRef(RexRangeRef) - Method in interface org.apache.calcite.rex.RexVisitor
- visitRangeRef(RexRangeRef) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitRangeRef(RexRangeRef, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitRangeRef(RexRangeRef, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitRoot(RelNode) - Method in class org.apache.calcite.interpreter.Interpreter.CompilerImpl
-
Visits the tree, starting from the root
p
. - 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.SqlValidatorImpl.Expander
- visitScoped(SqlCall) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl.OrderExpressionExpander
- visitScoped(SqlCall) - Method in class org.apache.calcite.sql.validate.SqlValidatorUtil.DeepCopier
-
Deprecated.
- 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.rel.rules.SubQueryRemoveRule.ReplaceSubQueryShuttle
- visitSubQuery(RexSubQuery) - Method in class org.apache.calcite.rex.RexInterpreter
- visitSubQuery(RexSubQuery) - Method in class org.apache.calcite.rex.RexShuttle
- visitSubQuery(RexSubQuery) - Method in enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- visitSubQuery(RexSubQuery) - Method in class org.apache.calcite.rex.RexUtil.ConstantFinder
- 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) - Method in class org.apache.calcite.sql2rel.CorrelationReferenceFinder.MyRexVisitor
- visitSubQuery(RexSubQuery) - Method in class org.apache.calcite.sql2rel.DeduplicateCorrelateVariables.DeduplicateCorrelateVariablesShuttle
- visitSubQuery(RexSubQuery) - Method in class org.apache.calcite.sql2rel.RelStructuredTypeFlattener.RewriteRexShuttle
- visitSubQuery(RexSubQuery, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitSubQuery(RexSubQuery, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitTableInputRef(RexTableInputRef) - Method in class org.apache.calcite.rex.RexInterpreter
- visitTableInputRef(RexTableInputRef) - Method in class org.apache.calcite.rex.RexShuttle
- visitTableInputRef(RexTableInputRef) - Method in enum org.apache.calcite.rex.RexSimplify.SafeRexVisitor
- visitTableInputRef(RexTableInputRef) - Method in class org.apache.calcite.rex.RexUtil.ConstantFinder
- visitTableInputRef(RexTableInputRef) - Method in interface org.apache.calcite.rex.RexVisitor
- visitTableInputRef(RexTableInputRef) - Method in class org.apache.calcite.rex.RexVisitorImpl
- visitTableInputRef(RexTableInputRef, RelOptUtil.Logic) - Method in class org.apache.calcite.rex.LogicVisitor
- visitTableInputRef(RexTableInputRef, P) - Method in interface org.apache.calcite.rex.RexBiVisitor
- visitValueNodes(ElasticsearchJson.Aggregation, List<ElasticsearchJson.Bucket>, BiConsumer<ElasticsearchJson.RowKey, ElasticsearchJson.MultiValue>) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson
- visitValueNodes(ElasticsearchJson.Aggregations, Consumer<Map<String, Object>>) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJson
-
Visits leaves of the aggregation where all values are stored.
- visitWindow(RexWindow) - Method in class org.apache.calcite.rex.RexCopier
- 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.
- VmstatTableFunction() - Constructor for class org.apache.calcite.adapter.os.VmstatTableFunction
- VOID - org.apache.calcite.linq4j.tree.Primitive
- VolcanoCost - Class in org.apache.calcite.plan.volcano
-
VolcanoCost
represents the cost of a plan node. - VolcanoCost(double, double, double) - Constructor for class org.apache.calcite.plan.volcano.VolcanoCost
- VolcanoCost.Factory - Class in org.apache.calcite.plan.volcano
-
Implementation of
RelOptCostFactory
that createsVolcanoCost
s. - 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(Context) - 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.DeferringRuleCall - Class in org.apache.calcite.plan.volcano
-
A rule call which defers its actions.
- VolcanoPlanner.DirectProvenance - Class in org.apache.calcite.plan.volcano
-
A RelNode that came directly from another RelNode via a copy.
- VolcanoPlanner.Provenance - Class in org.apache.calcite.plan.volcano
-
Where a RelNode came from.
- VolcanoPlanner.RuleProvenance - Class in org.apache.calcite.plan.volcano
-
A RelNode that came via the firing of a rule.
- VolcanoPlanner.UnknownProvenance - Class in org.apache.calcite.plan.volcano
-
We do not know where this RelNode came from.
- VolcanoPlannerPhase - Enum in org.apache.calcite.plan.volcano
-
VolcanoPlannerPhase represents the phases of operation that the
VolcanoPlanner
passes through during optimization of a tree ofRelNode
objects. - VolcanoPlannerPhase() - Constructor for enum org.apache.calcite.plan.volcano.VolcanoPlannerPhase
- VolcanoPlannerPhaseRuleMappingInitializer - Interface in org.apache.calcite.plan.volcano
-
VolcanoPlannerPhaseRuleMappingInitializer describes an inteface for initializing the mapping of
VolcanoPlannerPhase
s to sets of rule descriptions. - VolcanoRelMetadataProvider - Class in org.apache.calcite.plan.volcano
-
VolcanoRelMetadataProvider implements the
RelMetadataProvider
interface by combining metadata from the rels making up an equivalence class. - VolcanoRelMetadataProvider() - Constructor for class org.apache.calcite.plan.volcano.VolcanoRelMetadataProvider
- VolcanoRuleCall - Class in org.apache.calcite.plan.volcano
-
VolcanoRuleCall
implements theRelOptRuleCall
interface for VolcanoPlanner. - VolcanoRuleCall(VolcanoPlanner, RelOptRuleOperand) - Constructor for class org.apache.calcite.plan.volcano.VolcanoRuleCall
-
Creates a rule call.
- 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.
- VolcanoRuleMatch - Class in org.apache.calcite.plan.volcano
-
A match of a rule to a particular set of target relational expressions, frozen in time.
- VolcanoRuleMatch(VolcanoPlanner, RelOptRuleOperand, RelNode[], Map<RelNode, List<RelNode>>) - Constructor for class org.apache.calcite.plan.volcano.VolcanoRuleMatch
-
Creates a
VolcanoRuleMatch
. - vuv - Variable in class org.apache.calcite.plan.RelOptUtil.CorrelationCollector
W
- wait(Object) - Static method in class org.apache.calcite.util.Unsafe
-
Calls
Object.wait()
. - warmUpCount - Variable in class org.apache.calcite.profile.ProfilerImpl.SurpriseQueue
- warn(String) - Method in class org.apache.calcite.util.trace.CalciteLogger
- warn(String, Object...) - 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
- webTable - Variable in class org.apache.calcite.adapter.file.FileTableScan
- WEEK - org.apache.calcite.adapter.druid.Granularity.Type
- WEEK - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The SQL
WEEK
operator. - whenList - Variable in class org.apache.calcite.sql.fun.SqlCase
- where - Variable in class org.apache.calcite.sql.SqlSelect
- 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(Enumerator<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- 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<? extends Predicate1<T>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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.linq4j.DefaultQueryable
- where(FunctionExpression<? extends Predicate1<T>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- where(FunctionExpression<? extends Predicate1<TSource>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Filters a sequence of values based on a predicate.
- WHERE - org.apache.calcite.linq4j.OpType
- WHERE - org.apache.calcite.rel.rel2sql.SqlImplementor.Clause
- WHERE - org.apache.calcite.sql.advise.SqlSimpleParser.TokenType
- WHERE - org.apache.calcite.util.BuiltInMethod
- WHERE_LIST - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
WHERE clause.
- WHERE_OPERAND - Static variable in class org.apache.calcite.sql.SqlSelect
- WHERE2 - org.apache.calcite.util.BuiltInMethod
- whereClause - Variable in class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
- whereClause - Variable in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- whereListItemsOnSeparateLines - Variable in class org.apache.calcite.sql.pretty.SqlFormatOptions
- whereListItemsOnSeparateLines - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- 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<? extends Predicate2<T, Integer>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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.linq4j.DefaultQueryable
- whereN(FunctionExpression<? extends Predicate2<T, Integer>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- whereN(FunctionExpression<? extends Predicate2<TSource, Integer>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
Filters a sequence of values based on a predicate.
- whereScopes - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Maps a
SqlSelect
node to the scope used by its WHERE and HAVING clauses. - While - org.apache.calcite.linq4j.tree.ExpressionType
- 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
- width - Variable in class org.apache.calcite.example.maze.Maze
- width - Variable in class org.apache.calcite.example.maze.MazeTable
- width() - Method in class org.apache.calcite.adapter.file.FileRowConverter
- width(TimeUnit) - Static method in class org.apache.calcite.rex.RexLiteral
- 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.
- winAggMap - Variable in class org.apache.calcite.adapter.enumerable.RexImpTable
- 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 - Variable in class org.apache.calcite.rex.RexOver
- window - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
When converting window aggregate, we need to know if the window is guaranteed to be non-empty.
- window - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.HistogramShuttle
- 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, RelNode, List<RexLiteral>, RelDataType, List<Window.Group>) - Constructor for class org.apache.calcite.rel.core.Window
-
Creates a window relational expression.
- WINDOW - org.apache.calcite.rel.mutable.MutableRelType
- WINDOW - org.apache.calcite.sql.SqlKind
-
Window specification
- WINDOW - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Window specification.
- WINDOW_DECL_LIST - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
The WINDOW clause of a SELECT statement.
- 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.
- windowCall - Variable in class org.apache.calcite.sql.SqlWindow
- windowDeclarationStartsLine - Variable in class org.apache.calcite.sql.pretty.SqlFormatOptions
- windowDeclListNewline - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- windowDecls - Variable in class org.apache.calcite.sql.SqlSelect
- windowedAggregateIllegalInClause(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- WindowedAggRelSplitter(Calc, RelBuilder) - Constructor for class org.apache.calcite.rel.rules.ProjectToWindowRule.WindowedAggRelSplitter
- windowHasNegativeSize() - Method in interface org.apache.calcite.runtime.CalciteResource
- WindowKey(ImmutableBitSet, RelCollation, boolean, RexWindowBound, RexWindowBound) - Constructor for class org.apache.calcite.rel.logical.LogicalWindow.WindowKey
- windowListItemsOnSeparateLines - Variable in class org.apache.calcite.sql.pretty.SqlFormatOptions
- windowNameMustBeSimple() - Method in interface org.apache.calcite.runtime.CalciteResource
- windowNames - Variable in class org.apache.calcite.sql.validate.SelectScope
- windowNewline - Variable in class org.apache.calcite.sql.pretty.SqlPrettyWriter
- WindowNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements a
Window
. - WindowNode(Compiler, Window) - Constructor for class org.apache.calcite.interpreter.WindowNode
- windowNotFound(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- windowParent - Variable in class org.apache.calcite.sql.validate.SelectScope
-
Scope to use to resolve windows
- WindowRelInputGetter(Expression, PhysType, int, List<Expression>) - Constructor for class org.apache.calcite.adapter.enumerable.EnumerableWindow.WindowRelInputGetter
- with - Variable in class org.apache.calcite.sql.validate.WithNamespace
- with(StringBuilder) - Method in class org.apache.calcite.materialize.Lattice.SqlWriter
-
Re-binds this writer to a different
StringBuilder
. - with(SqlJsonConstructorNullClause) - Method in class org.apache.calcite.sql.fun.SqlJsonArrayAggAggFunction
- with(SqlJsonConstructorNullClause) - Method in class org.apache.calcite.sql.fun.SqlJsonObjectAggAggFunction
- WITH - org.apache.calcite.sql.SqlKind
-
WITH clause.
- WITH - org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
WITH clause of a SELECT statement.
- WITH_CONDITIONAL_ARRAY - org.apache.calcite.sql.SqlJsonQueryWrapperBehavior
- WITH_ITEM - org.apache.calcite.sql.SqlKind
-
Item in WITH clause.
- WITH_UNCONDITIONAL_ARRAY - org.apache.calcite.sql.SqlJsonQueryWrapperBehavior
- withCaseSensitive(boolean) - Static method in class org.apache.calcite.sql.validate.SqlNameMatchers
-
Returns a name matcher with the given case sensitivity.
- withCollation(RelCollation) - Method in class org.apache.calcite.rel.RelRoot
- withConfig(CalciteConnectionConfig) - Static method in class org.apache.calcite.plan.Contexts
-
Deprecated.
- withConfig(SqlToRelConverter.Config) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
-
Sets configuration identical to a given
SqlToRelConverter.Config
. - withConformance(SqlConformance) - Method in class org.apache.calcite.adapter.enumerable.RexToLixTranslator
- withConvertTableAccess(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- withCreateValuesRel(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- withDatabaseMajorVersion(int) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withDatabaseMajorVersion(int) - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- withDatabaseMinorVersion(int) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withDatabaseMinorVersion(int) - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- withDatabaseProduct(SqlDialect.DatabaseProduct) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withDatabaseProduct(SqlDialect.DatabaseProduct) - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- withDatabaseProductName(String) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withDatabaseProductName(String) - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- withDatabaseVersion(String) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withDatabaseVersion(String) - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- withDataTypeSystem(RelDataTypeSystem) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withDataTypeSystem(RelDataTypeSystem) - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- withDecorrelationEnabled(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- withExpand(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- withExplain(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- withExpression(String) - Method in class org.apache.calcite.adapter.druid.VirtualColumn.Builder
- 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
. - withIdentifierQuoteString(String) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withIdentifierQuoteString(String) - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- withIdPrefix - Variable in class org.apache.calcite.rel.externalize.RelWriterImpl
- withImplementation() - Method in class org.apache.calcite.sql.SqlExplain
- WITHIN_GROUP - 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. - withinGroupClauseIllegalInAggregate(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- withinGroupNotAllowed(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- withInSubqueryThreshold(int) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
-
Deprecated.
- withInSubQueryThreshold(int) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- withItem - Variable in class org.apache.calcite.sql.validate.WithItemNamespace
- withItem - Variable in class org.apache.calcite.sql.validate.WithScope
- WithItemNamespace - Class in org.apache.calcite.sql.validate
-
Very similar to
AliasNamespace
. - WithItemNamespace(SqlValidatorImpl, SqlWithItem, SqlNode) - Constructor for class org.apache.calcite.sql.validate.WithItemNamespace
- withJethroInfo(JethroDataSqlDialect.JethroInfo) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withJethroInfo(JethroDataSqlDialect.JethroInfo) - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- withKind(SqlKind) - Method in class org.apache.calcite.rel.RelRoot
-
Creates a copy, assigning a new kind.
- withList - Variable in class org.apache.calcite.sql.SqlWith
- 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
- withName(String) - Method in class org.apache.calcite.adapter.druid.VirtualColumn.Builder
- WithNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for
WITH
clause. - WithNamespace(SqlValidatorImpl, SqlWith, SqlNode) - Constructor for class org.apache.calcite.sql.validate.WithNamespace
-
Creates a TableConstructorNamespace.
- 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.
- withNullCollation(NullCollation) - Method in interface org.apache.calcite.sql.SqlDialect.Context
- withNullCollation(NullCollation) - Method in class org.apache.calcite.sql.SqlDialect.ContextImpl
- withOrder(SqlCall, SqlNodeList) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Context
-
Wraps a call in a
SqlKind.WITHIN_GROUP
call, iforderList
is non-empty. - 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.runtime.SqlFunctions.ProductComparableListEnumerator
- withOrdinality - Variable in class org.apache.calcite.sql.SqlUnnestOperator
-
Whether
WITH ORDINALITY
was specified. - WITHOUT_ARRAY - org.apache.calcite.sql.SqlJsonQueryWrapperBehavior
- 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.
- withPassSize(int) - Method in class org.apache.calcite.profile.ProfilerImpl.Builder
- 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.
- withPredicateElimination(boolean) - Method in class org.apache.calcite.rex.RexSimplify
-
Returns a RexSimplify the same as this but with a specified
RexSimplify.predicateElimination
value. - withPredicates(RelOptPredicateList) - Method in class org.apache.calcite.rex.RexSimplify
-
Returns a RexSimplify the same as this but with a specified
RexSimplify.predicates
value. - withPrepare(Frameworks.PrepareAction<R>) - Static method in class org.apache.calcite.tools.Frameworks
-
Initializes a container then calls user-specified code with a planner and statement.
- withRel(RelNode) - Method in class org.apache.calcite.rel.RelRoot
-
Creates a copy of this RelRoot, assigning a
RelNode
. - withRelBuilderFactory(RelBuilderFactory) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- withReturned(SqlFunctions.PathMode, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions.PathContext
- 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.
- WithScope - Class in org.apache.calcite.sql.validate
-
Scope providing the objects that are available after evaluating an item in a WITH clause.
- WithScope(SqlValidatorScope, SqlWithItem) - Constructor for class org.apache.calcite.sql.validate.WithScope
-
Creates a WithScope.
- withStrictException(Exception) - Static method in class org.apache.calcite.runtime.SqlFunctions.PathContext
- withTimeZone(TimeZone) - Method in class org.apache.calcite.util.TimestampWithTimeZoneString
- withTimeZone(TimeZone) - Method in class org.apache.calcite.util.TimeWithTimeZoneString
- withTrimUnusedFields(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
- withType() - Method in class org.apache.calcite.sql.SqlExplain
- withType(DruidType) - Method in class org.apache.calcite.adapter.druid.VirtualColumn.Builder
- 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.SqlFunctions.PathContext
- WORD_MASK - Static variable in class org.apache.calcite.util.ImmutableBitSet
- wordIndex(int) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Given a bit index, return word index containing it.
- words - Variable in class org.apache.calcite.util.ImmutableBitSet.Builder
- words - Variable in class org.apache.calcite.util.ImmutableBitSet
- 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(Geometry) - Method in interface org.apache.calcite.runtime.GeoFunctions.Geom
- wrap(Geometry) - Method in class org.apache.calcite.runtime.GeoFunctions.MapGeom
- wrap(Geometry) - Method in class org.apache.calcite.runtime.GeoFunctions.SimpleGeom
- wrap(Properties) - Method in enum org.apache.calcite.config.CalciteConnectionProperty
- wrap(K) - Method in class org.apache.calcite.linq4j.EnumerableDefaults.WrapMap
- wrap(ColumnMetaData.Rep, List, RelDataType) - Static method in class org.apache.calcite.adapter.clone.ColumnLoader
-
Adapt for some types that we represent differently internally than their JDBC types.
- WrapContext(Object) - Constructor for class org.apache.calcite.plan.Contexts.WrapContext
- WrapMap(Function0<Map<EnumerableDefaults.Wrapped<K>, V>>, EqualityComparer<K>) - Constructor for class org.apache.calcite.linq4j.EnumerableDefaults.WrapMap
- Wrapped(EqualityComparer<T>, T) - Constructor for class org.apache.calcite.linq4j.EnumerableDefaults.Wrapped
- wrappedCharset - Variable in class org.apache.calcite.sql.SqlCollation
- wrappedCharset - Variable in class org.apache.calcite.sql.type.BasicSqlType
- Wrapper - Interface in org.apache.calcite.schema
-
Mix-in interface that allows you to find sub-objects.
- wrapperFor(EqualityComparer<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- WrappingSplunkConnection(SplunkConnection) - Constructor for class org.apache.calcite.adapter.splunk.SplunkDriver.WrappingSplunkConnection
- wrapSelect(SqlNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Wraps a node in a SELECT statement that has no clauses: "SELECT ...
- 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.DruidJsonFilter.JsonBound
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonCompositeFilter
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonDimHavingFilter
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonExpressionFilter
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonInFilter
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.DruidJsonFilter.JsonSelector
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.DruidQuery.JsonAggregation
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.DruidQuery.JsonCardinalityAggregation
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.DruidQuery.JsonCollation
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.DruidQuery.JsonExpressionPostAgg
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.DruidQuery.JsonFilteredAggregation
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.DruidQuery.JsonLimit
- 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 enum org.apache.calcite.adapter.druid.Granularities.AllGranularity
- write(JsonGenerator) - Method in class org.apache.calcite.adapter.druid.Granularities.PeriodGranularity
- 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(ExpressionWriter, Object, Type) - Static method in class org.apache.calcite.linq4j.tree.ConstantExpression
- write(Node) - Method in class org.apache.calcite.linq4j.tree.ExpressionWriter
- write(RexNode) - Method in class org.apache.calcite.materialize.Lattice.SqlWriter
-
Writes an expression.
- WRITE_ACCESS - org.apache.calcite.plan.TableAccessMap.Mode
-
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
- writeJson(JsonGenerator) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.BoolQueryBuilder
- writeJson(JsonGenerator) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.ConstantScoreQueryBuilder
- writeJson(JsonGenerator) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.ExistsQueryBuilder
- writeJson(JsonGenerator) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.MatchAllQueryBuilder
- writeJson(JsonGenerator) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.QueryBuilder
-
Convert existing query to JSON format using jackson API.
- writeJson(JsonGenerator) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RangeQueryBuilder
- writeJson(JsonGenerator) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.RegexpQueryBuilder
- writeJson(JsonGenerator) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.TermQueryBuilder
- writeJson(JsonGenerator) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.TermsQueryBuilder
- writeJsonArray(String, List<QueryBuilders.QueryBuilder>, JsonGenerator) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders.BoolQueryBuilder
- writeMap(ExpressionWriter, Map) - Static method in class org.apache.calcite.linq4j.tree.ConstantExpression
- writeObject(JsonGenerator, Object) - Static method in class org.apache.calcite.adapter.druid.DruidQuery
- writeObject(JsonGenerator, Object) - Static method in class org.apache.calcite.adapter.elasticsearch.QueryBuilders
-
Write usually simple (scalar) value (string, number, boolean or null) to json output.
- writeObject(ObjectOutputStream) - Method in class org.apache.calcite.util.SerializableCharset
-
Per
Serializable
. - writeQuote(Character) - Method in class org.apache.calcite.util.StackWriter
- writeReplace() - Method in class org.apache.calcite.rel.type.RelRecordType
-
Per
Serializable
API, provides a replacement object to be written during serialization. - writeReplace() - Method in exception org.apache.calcite.sql.parser.SqlParseException
-
Per
Serializable
API, provides a replacement object to be written during serialization. - wrongNumberOfParam(String, int, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- wrongNumOfArguments() - Method in interface org.apache.calcite.runtime.CalciteResource
X
- XML - org.apache.calcite.sql.SqlExplainFormat
-
Indicates that the plan should be output in XML format.
- XML_ESCAPER - Static variable in class org.apache.calcite.util.XmlOutput.StringEscaper
- XML_NUMERIC_ESCAPER - Static variable in class org.apache.calcite.util.XmlOutput.StringEscaper
- XMLAttrVector() - Constructor for class org.apache.calcite.util.XmlOutput.XMLAttrVector
- xmlOutput - Variable in class org.apache.calcite.rel.externalize.RelXmlWriter
- 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
. - XmlOutput.StringEscaper - Class in org.apache.calcite.util
-
Utility for replacing special characters with escape sequences in strings.
- XmlOutput.XMLAttrVector - Class in org.apache.calcite.util
-
List of attribute names and values.
Y
- YAML_MAPPER - Static variable in class org.apache.calcite.model.ModelHandler
- YEAR - 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
- YES_NO - Static variable in interface org.apache.calcite.sql.type.SqlTypeName.PrecScale
- YES_YES - Static variable in interface org.apache.calcite.sql.type.SqlTypeName.PrecScale
- ymd(int, int, int) - Static method in class org.apache.calcite.util.DateString
-
Validates a year-month-date and converts to a string.
- ymd(StringBuilder, int, int, int) - Static method in class org.apache.calcite.util.DateTimeStringUtils
-
Appends year-month-day to a buffer; assumes they are valid.
- ymdhms(StringBuilder, int, int, int, int, int, int) - Static method in class org.apache.calcite.util.DateTimeStringUtils
-
Appends year-month-day and hour:minute:second to a buffer; assumes they are valid.
Z
- zero(Class<?>) - Static method in class org.apache.calcite.runtime.Resources
- ZERO - org.apache.calcite.sql.type.SqlTypeName.Limit
- ZERO - Static variable in class org.apache.calcite.plan.volcano.VolcanoCost
- ZERO - Static variable in class org.apache.calcite.sql.parser.SqlParserPos
-
SqlParserPos representing line one, character one.
- ZERO - Static variable in class org.apache.calcite.sql.SqlIntervalQualifier
- zeroCost - Variable in class org.apache.calcite.plan.volcano.VolcanoPlanner
-
Zero cost, according to
AbstractRelOptPlanner.costFactory
. - zeroValue(RelDataType) - Static method in class org.apache.calcite.rex.RexBuilder
- 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<K>, List<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<K>, List<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.linq4j.DefaultQueryable
- zip(Enumerable<T1>, FunctionExpression<Function2<T, T1, TResult>>) - Method in class org.apache.calcite.linq4j.EnumerableQueryable
- zip(Enumerable<T1>, FunctionExpression<Function2<TSource, T1, TResult>>) - Method in interface org.apache.calcite.linq4j.ExtendedQueryable
-
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<T>, Enumerable<T1>, FunctionExpression<Function2<T, T1, TResult>>) - Method in class org.apache.calcite.prepare.QueryableRelBuilder
- 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.
- ZipIterator(Iterator<? extends L>, Iterator<? extends R>) - Constructor for class org.apache.calcite.util.Pair.ZipIterator
_
- _createIterable(Meta.StatementHandle, Meta.Signature, List<TypedValue>, Meta.Frame) - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
All Classes All Packages