Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abbrev - Variable in enum org.apache.calcite.sql.fun.SqlLibrary
-
Abbreviation for the library used in SQL reference.
- abs(byte) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ABS
operator applied to byte values. - abs(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ABS
operator applied to double values. - abs(float) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ABS
operator applied to float values. - abs(int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ABS
operator applied to int values. - abs(long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ABS
operator applied to long values. - abs(short) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ABS
operator applied to short values. - abs(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ABS
operator applied to BigDecimal values. - ABS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ABS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
ABS(numeric)
function. - ABSENT_ON_NULL - Enum constant in enum org.apache.calcite.sql.SqlJsonConstructorNullClause
- absentOverClause() - Method in interface org.apache.calcite.runtime.CalciteResource
- ABSTRACT_ENUMERABLE_CTOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ABSTRACT_FACTORY_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Provide an interface for creating families of related or dependent objects without specifying their concrete classes.
- AbstractConverter - Class in org.apache.calcite.plan.volcano
-
Converts a relational expression to any given output convention.
- AbstractConverter(RelOptCluster, RelSubset, RelTraitDef, RelTraitSet) - Constructor for class org.apache.calcite.plan.volcano.AbstractConverter
- AbstractConverter.ExpandConversionRule - Class in org.apache.calcite.plan.volcano
-
Rule that converts an
AbstractConverter
into a chain of converters from the source relation to the target traits. - AbstractConverter.ExpandConversionRule.Config - Interface in org.apache.calcite.plan.volcano
-
Rule configuration.
- AbstractEnumerable<T> - Class in org.apache.calcite.linq4j
-
Abstract implementation of the
Enumerable
interface that implements the extension methods. - AbstractEnumerable() - Constructor for class org.apache.calcite.linq4j.AbstractEnumerable
- AbstractEnumerable2<T> - Class in org.apache.calcite.linq4j
-
Abstract implementation of the
Enumerable
interface that implements the extension methods. - AbstractEnumerable2() - Constructor for class org.apache.calcite.linq4j.AbstractEnumerable2
- AbstractFlatList() - Constructor for class org.apache.calcite.runtime.FlatLists.AbstractFlatList
- AbstractJoinExtractFilterRule - Class in org.apache.calcite.rel.rules
- AbstractJoinExtractFilterRule(AbstractJoinExtractFilterRule.Config) - Constructor for class org.apache.calcite.rel.rules.AbstractJoinExtractFilterRule
-
Creates an AbstractJoinExtractFilterRule.
- AbstractJoinExtractFilterRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AbstractMapping() - Constructor for class org.apache.calcite.util.mapping.Mappings.AbstractMapping
- AbstractModifiableTable - Class in org.apache.calcite.test
-
Abstract base class for implementations of
ModifiableTable
. - AbstractModifiableTable(String) - Constructor for class org.apache.calcite.test.AbstractModifiableTable
- AbstractModifiableView - Class in org.apache.calcite.test
-
Abstract base class for implementations of
ModifiableView
. - AbstractModifiableView() - Constructor for class org.apache.calcite.test.AbstractModifiableView
- AbstractNode - Class in org.apache.calcite.linq4j.tree
-
Abstract implementation of
Node
. - AbstractPreparingTable() - Constructor for class org.apache.calcite.prepare.Prepare.AbstractPreparingTable
- AbstractQueryable<T> - Class in org.apache.calcite.linq4j
-
Abstract implementation of the
Queryable
interface that implements the extension methods. - AbstractQueryable() - Constructor for class org.apache.calcite.linq4j.AbstractQueryable
- AbstractQueryableTable - Class in org.apache.calcite.adapter.java
-
Abstract base class for implementing
Table
. - AbstractQueryableTable(Type) - Constructor for class org.apache.calcite.adapter.java.AbstractQueryableTable
- AbstractRange(long, long) - Constructor for class org.apache.calcite.runtime.SpaceFillingCurve2D.AbstractRange
- AbstractRelNode - Class in org.apache.calcite.rel
-
Base class for every relational expression (
RelNode
). - AbstractRelNode(RelOptCluster, RelTraitSet) - Constructor for class org.apache.calcite.rel.AbstractRelNode
-
Creates an
AbstractRelNode
. - AbstractRelOptPlanner - Class in org.apache.calcite.plan
-
Abstract base for implementations of the
RelOptPlanner
interface. - AbstractRelOptPlanner(RelOptCostFactory, Context) - Constructor for class org.apache.calcite.plan.AbstractRelOptPlanner
-
Creates an AbstractRelOptPlanner.
- AbstractSchema - Class in org.apache.calcite.schema.impl
-
Abstract implementation of
Schema
. - AbstractSchema() - Constructor for class org.apache.calcite.schema.impl.AbstractSchema
- AbstractSchema.Factory - Class in org.apache.calcite.schema.impl
-
Schema factory that creates an
AbstractSchema
. - AbstractSourceMapping - Class in org.apache.calcite.util.mapping
-
Simple implementation of
Mappings.TargetMapping
where the number of sources and targets are specified as constructor parameters, and you just need to implement one method. - AbstractSourceMapping(int, int) - Constructor for class org.apache.calcite.util.mapping.AbstractSourceMapping
- AbstractSqlTester - Class in org.apache.calcite.sql.test
-
Abstract implementation of
SqlTester
that talks to a mock catalog. - AbstractSqlTester() - Constructor for class org.apache.calcite.sql.test.AbstractSqlTester
- AbstractSqlType - Class in org.apache.calcite.sql.type
-
Abstract base class for SQL implementations of
RelDataType
. - AbstractSqlType(SqlTypeName, boolean, List<? extends RelDataTypeField>) - Constructor for class org.apache.calcite.sql.type.AbstractSqlType
-
Creates an AbstractSqlType.
- AbstractSumSplitter() - Constructor for class org.apache.calcite.sql.SqlSplittableAggFunction.AbstractSumSplitter
- AbstractTable - Class in org.apache.calcite.schema.impl
-
Abstract base class for implementing
Table
. - AbstractTable() - Constructor for class org.apache.calcite.schema.impl.AbstractTable
- AbstractTableQueryable<T> - Class in org.apache.calcite.schema.impl
-
Abstract implementation of
Queryable
forQueryableTable
. - AbstractTableQueryable(QueryProvider, SchemaPlus, QueryableTable, String) - Constructor for class org.apache.calcite.schema.impl.AbstractTableQueryable
- AbstractTargetMapping - Class in org.apache.calcite.util.mapping
-
Simple implementation of
Mappings.TargetMapping
where the number of sources and targets are specified as constructor parameters, and you just need to implement one method. - AbstractTargetMapping(int, int) - Constructor for class org.apache.calcite.util.mapping.AbstractTargetMapping
- AbstractTypeCoercion - Class in org.apache.calcite.sql.validate.implicit
-
Base class for all the type coercion rules.
- AbstractUnifyRule(SubstitutionVisitor.Operand, SubstitutionVisitor.Operand, int) - Constructor for class org.apache.calcite.plan.SubstitutionVisitor.AbstractUnifyRule
- accAdvance(AggAddContext, Expression, Expression) - Static method in class org.apache.calcite.adapter.enumerable.StrictAggImplementor
- ACCEL_ONLY_TABLE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
An accel-only table.
- accept(int, K, V) - Method in interface org.apache.calcite.util.Pair.PairWithOrdinalConsumer
-
Performs this operation on the given arguments.
- accept(int, T, U) - Method in interface org.apache.calcite.runtime.PairList.IndexedBiConsumer
-
Performs this operation on the given arguments.
- accept(E) - Method in class org.apache.calcite.util.MonotonicSupplier
- accept(PreparedStatement) - Method in interface org.apache.calcite.test.CalciteAssert.PreparedStatementConsumer
- accept(UnaryOperator<E>) - Method in class org.apache.calcite.util.Holder
-
Applies a transform to the value.
- accept(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.AbstractNode
- accept(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.ClassDeclaration
- accept(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.ConstructorDeclaration
- accept(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.FieldDeclaration
- accept(ExpressionWriter) - Method in class org.apache.calcite.linq4j.tree.MethodDeclaration
- accept(ExpressionWriter) - Method in interface org.apache.calcite.linq4j.tree.Node
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.AbstractNode
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.BinaryExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.BlockStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ClassDeclaration
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ConditionalStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ConstantExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ConstructorDeclaration
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.DeclarationStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.DefaultExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.DynamicExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.Expression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.FieldDeclaration
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ForEachStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ForStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.FunctionExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.GotoStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.IndexExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.InvocationExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.LabelStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.LambdaExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ListInitExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.MemberDeclaration
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.MemberExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.MemberInitExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.MethodCallExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.MethodDeclaration
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.NewArrayExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.NewExpression
- accept(Shuttle) - Method in interface org.apache.calcite.linq4j.tree.Node
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ParameterExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.Statement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.SwitchStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.TernaryExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.ThrowStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.TryStatement
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.TypeBinaryExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.UnaryExpression
- accept(Shuttle) - Method in class org.apache.calcite.linq4j.tree.WhileStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.BinaryExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.BlockStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ClassDeclaration
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ConditionalExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ConditionalStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ConstantExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ConstructorDeclaration
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.DeclarationStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.DefaultExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.DynamicExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.FieldDeclaration
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ForEachStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ForStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.FunctionExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.GotoStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.IndexExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.InvocationExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.LabelStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.LambdaExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ListInitExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.MemberExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.MemberInitExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.MethodCallExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.MethodDeclaration
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.NewArrayExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.NewExpression
- accept(Visitor<R>) - Method in interface org.apache.calcite.linq4j.tree.Node
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ParameterExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.SwitchStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.TernaryExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.ThrowStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.TryStatement
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.TypeBinaryExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.UnaryExpression
- accept(Visitor<R>) - Method in class org.apache.calcite.linq4j.tree.WhileStatement
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonColumn
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonCustomSchema
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonCustomTable
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonFunction
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonJdbcSchema
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonLattice
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonMapSchema
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonMaterialization
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonMeasure
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonSchema
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonTable
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonTile
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonType
- accept(ModelHandler) - Method in class org.apache.calcite.model.JsonView
- accept(RelShuttle) - Method in class org.apache.calcite.rel.AbstractRelNode
- accept(RelShuttle) - Method in class org.apache.calcite.rel.core.TableScan
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalAggregate
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalCalc
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalCorrelate
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalExchange
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalFilter
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalIntersect
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalJoin
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalMatch
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalMinus
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalProject
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalSort
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalTableModify
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalUnion
- accept(RelShuttle) - Method in class org.apache.calcite.rel.logical.LogicalValues
- accept(RelShuttle) - Method in interface org.apache.calcite.rel.RelNode
-
Accepts a visit from a shuttle.
- accept(RelShuttle) - Method in class org.apache.calcite.test.SqlToRelTestBase.CustomCorrelate
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexCall
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexCorrelVariable
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexDynamicParam
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexFieldAccess
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexInputRef
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexLiteral
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexLocalRef
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexNode
-
Accepts a visitor with a payload, dispatching to the right overloaded
RexBiVisitor.visitInputRef(RexInputRef, Object)
visitXxx} method. - accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexOver
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexPatternFieldRef
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexRangeRef
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexSubQuery
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexTableInputRef
- accept(RexBiVisitor<R, P>, P) - Method in class org.apache.calcite.rex.RexWindowBound
-
Transforms the bound via
RexBiVisitor
. - accept(RexShuttle) - Method in class org.apache.calcite.rel.AbstractRelNode
- accept(RexShuttle) - Method in class org.apache.calcite.rel.core.Calc
- accept(RexShuttle) - Method in class org.apache.calcite.rel.core.Filter
- accept(RexShuttle) - Method in class org.apache.calcite.rel.core.Join
- accept(RexShuttle) - Method in class org.apache.calcite.rel.core.Project
- accept(RexShuttle) - Method in class org.apache.calcite.rel.core.Snapshot
- accept(RexShuttle) - Method in class org.apache.calcite.rel.core.Sort
- accept(RexShuttle) - Method in class org.apache.calcite.rel.core.TableFunctionScan
- accept(RexShuttle) - Method in interface org.apache.calcite.rel.RelNode
-
Accepts a visit from a shuttle.
- accept(RexShuttle) - Method in class org.apache.calcite.rel.rules.MultiJoin
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexCall
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexCorrelVariable
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexDynamicParam
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexFieldAccess
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexInputRef
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexLiteral
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexLocalRef
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexNode
-
Accepts a visitor, dispatching to the right overloaded
visitXxx
method. - accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexOver
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexPatternFieldRef
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexRangeRef
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexSubQuery
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexTableInputRef
- accept(RexVisitor<R>) - Method in class org.apache.calcite.rex.RexWindowBound
-
Transforms the bound via
RexVisitor
. - accept(StringAndPos, SqlValidator, SqlNode) - Method in interface org.apache.calcite.sql.test.SqlTester.ValidatedNodeConsumer
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlCall
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlDataTypeSpec
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlDynamicParam
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlIdentifier
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlIntervalQualifier
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlLiteral
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlNode
-
Accepts a generic visitor.
- accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.SqlNodeList
- accept2(ExpressionWriter, boolean) - Method in class org.apache.calcite.linq4j.tree.DeclarationStatement
- acceptCall(SqlVisitor<R>, SqlCall) - Method in class org.apache.calcite.sql.SqlOperator
-
Accepts a
SqlVisitor
, visiting each operand of a call. - acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.fun.SqlConvertFunction
- acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.fun.SqlDotOperator
- acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.SqlAsOperator
- acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.SqlMatchRecognize.SqlMatchRecognizeOperator
- acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.SqlOperator
-
Accepts a
SqlVisitor
, directing anSqlBasicVisitor.ArgHandler
to visit an operand of a call. - acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.SqlOverOperator
-
Accepts a
SqlVisitor
, and tells it to visit each child. - acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.SqlSelectOperator
- acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Method in class org.apache.calcite.sql.SqlSnapshot.SqlSnapshotOperator
- ACCESS - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- accessNotAllowed(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- accessors(Expression, List<Integer>) - Method in interface org.apache.calcite.adapter.enumerable.PhysType
- accessors(Expression, List<Integer>) - Method in class org.apache.calcite.adapter.enumerable.PhysTypeImpl
- AccessSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for the Access database. - AccessSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.AccessSqlDialect
-
Creates an AccessSqlDialect.
- accessValue(RexNode) - Method in class org.apache.calcite.rel.rules.ReduceDecimalsRule.RexExpander
-
Retrieves the primitive value of a numeric node.
- AccumOperation - Class in org.apache.calcite.runtime
-
Used at run time by the ST_Accum function.
- AccumOperation() - Constructor for class org.apache.calcite.runtime.AccumOperation
- accumulate(Iterable<TSource>, TAccumulate) - Method in class org.apache.calcite.adapter.enumerable.BasicLazyAccumulator
- accumulate(Iterable<TSource>, TAccumulate) - Method in class org.apache.calcite.adapter.enumerable.SourceSorter
- accumulate(Iterable<TSource>, TOrigAccumulate) - Method in interface org.apache.calcite.adapter.enumerable.LazyAggregateLambdaFactory.LazyAccumulator
- accumulator() - Method in interface org.apache.calcite.adapter.enumerable.AggResetContext
-
Returns accumulator variables that should be reset.
- accumulator() - Method in class org.apache.calcite.adapter.enumerable.impl.AggResetContextImpl
- accumulatorAdder - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- accumulatorAdder() - Method in interface org.apache.calcite.adapter.enumerable.AggregateLambdaFactory
- accumulatorAdder() - Method in class org.apache.calcite.adapter.enumerable.BasicAggregateLambdaFactory
- accumulatorAdder() - Method in class org.apache.calcite.adapter.enumerable.LazyAggregateLambdaFactory
- accumulatorInitializer() - Method in interface org.apache.calcite.adapter.enumerable.AggregateLambdaFactory
- accumulatorInitializer() - Method in class org.apache.calcite.adapter.enumerable.BasicAggregateLambdaFactory
- accumulatorInitializer() - Method in class org.apache.calcite.adapter.enumerable.LazyAggregateLambdaFactory
- accumulatorType - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- acos(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ACOS
operator applied to double values. - acos(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ACOS
operator applied to BigDecimal values. - ACOS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ACOS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
ACOS(numeric)
function. - acosh(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ACOSH
operator applied to double values. - acosh(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ACOSH
operator applied to BigDecimal values. - ACOSH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ACOSH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
ACOSH(numeric)
function; returns the inverse hyperbolic cosine ofvalue
. - ACTIVE - Enum constant in enum org.apache.calcite.rel.metadata.NullSentinel
-
Placeholder that means that a request for metadata is already active, therefore this request forms a cycle.
- actualFunctionsToReduce() - Method in interface org.apache.calcite.rel.rules.AggregateReduceFunctionsRule.Config
-
Returns the validated set of functions to reduce, or the default set if not specified.
- adapt(List<T1>, Function1<T1, R>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Deprecated.
- adapt(DoubleFunction1<T1>) - Static method in class org.apache.calcite.linq4j.function.Functions
- adapt(FloatFunction1<T1>) - Static method in class org.apache.calcite.linq4j.function.Functions
- adapt(IntegerFunction1<T1>) - Static method in class org.apache.calcite.linq4j.function.Functions
- adapt(LongFunction1<T1>) - Static method in class org.apache.calcite.linq4j.function.Functions
- adapt(T[], Function1<T, R>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Deprecated.Use
Lists.transform(java.util.List<F>, com.google.common.base.Function<? super F, ? extends T>)
andArrays.asList(Object[])
- ADAPTER_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Convert the interface of a class into another interface clients expect.
- adaptTo(RelNode, List<Integer>, int, int, int) - Method in class org.apache.calcite.rel.core.AggregateCall
-
Creates an equivalent AggregateCall that is adapted to a new input types and/or number of columns in GROUP BY.
- add(double, double) - Method in class org.apache.calcite.interpreter.AggregateNode.DoubleSum
- add(int, int) - Method in class org.apache.calcite.interpreter.AggregateNode.IntSum
- add(int, int, int) - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter1
- add(int, E) - Method in class org.apache.calcite.runtime.ConsList
- add(int, E) - Method in class org.apache.calcite.util.CastingList
- add(int, E) - Method in class org.apache.calcite.util.ChunkList
- add(int, String, SqlParserPos) - Method in class org.apache.calcite.sql.SqlIdentifier
-
Returns an identifier that is the same as this except with a component added at a given position.
- add(int, SqlNode) - Method in class org.apache.calcite.sql.SqlNodeList
- add(int, T, U) - Method in interface org.apache.calcite.runtime.PairList
-
Adds a pair to this list at a given position.
- add(long, int) - Static method in class org.apache.calcite.util.Smalls.MyStaticSumFunction
- add(long, int) - Method in class org.apache.calcite.util.Smalls.MySumFunction
- add(long, int, int, int) - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter2
- add(long, int, String) - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter2
- add(long, int, String, String) - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter1
- add(long, long) - Method in class org.apache.calcite.interpreter.AggregateNode.LongSum
- add(short, int) - Method in class org.apache.calcite.util.Smalls.SumFunctionBadIAdd
- add(E) - Method in class org.apache.calcite.linq4j.MemoryFactory
- add(E) - Method in class org.apache.calcite.runtime.ConsList
- add(E) - Method in class org.apache.calcite.util.ChunkList
- add(E) - Method in class org.apache.calcite.util.Closer
-
Registers a resource.
- add(E) - Method in class org.apache.calcite.util.EquivalenceSet
-
Adds an element, and returns the element (which is its own parent).
- add(E) - Method in class org.apache.calcite.util.ImmutableNullableList.Builder
-
Adds
element
to theImmutableNullableList
. - add(E) - Method in class org.apache.calcite.util.ImmutableNullableSet.Builder
-
Adds
element
to theImmutableNullableSet
. - add(E) - Method in class org.apache.calcite.util.PartiallyOrderedSet
-
Adds an element to this lattice.
- add(E...) - Method in class org.apache.calcite.util.ImmutableNullableList.Builder
-
Adds each element of
elements
to theImmutableNullableList
. - add(E...) - Method in class org.apache.calcite.util.ImmutableNullableSet.Builder
-
Adds each element of
elements
to theImmutableNullableSet
. - add(Double, Double) - Static method in class org.apache.calcite.util.NumberUtil
-
Returns the sum of two numbers, or null if either is null.
- add(Boolean, Boolean) - Method in class org.apache.calcite.interpreter.AggregateNode.MaxBoolean
- add(Boolean, Boolean) - Method in class org.apache.calcite.interpreter.AggregateNode.MinBoolean
- add(Class<?>, String) - Method in class org.apache.calcite.schema.impl.ReflectiveFunctionBase.ParameterListBuilder
- add(Class<?>, String, boolean) - Method in class org.apache.calcite.schema.impl.ReflectiveFunctionBase.ParameterListBuilder
- add(Integer, Integer) - Method in class org.apache.calcite.util.Smalls.MySum3
- add(String) - Method in class org.apache.calcite.util.NameSet
- add(String, String) - Method in class org.apache.calcite.adapter.mongodb.MongoRel.Implementor
- add(String, Predicate<MemoryFactory.Memory<E>>) - Method in class org.apache.calcite.runtime.Matcher.Builder
-
Associates a predicate with a symbol.
- add(String, TimeUnit, int, TimeUnit, int) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Adds a field with an interval type.
- add(String, TimeUnit, int, TimeUnit, int) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- add(String, Lattice) - Method in interface org.apache.calcite.schema.SchemaPlus
-
Adds a lattice to this schema.
- add(String, RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Adds a field with given name and type.
- add(String, RelDataType) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- add(String, RelProtoDataType) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Defines a type within this schema.
- add(String, RelProtoDataType) - Method in interface org.apache.calcite.schema.SchemaPlus
-
Adds a type to this schema.
- add(String, Function) - Method in interface org.apache.calcite.schema.SchemaPlus
-
Adds a function to this schema.
- add(String, Schema) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
-
Adds a child schema of this schema.
- add(String, Schema) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds a child schema of this schema.
- add(String, Schema) - Method in interface org.apache.calcite.schema.SchemaPlus
-
Adds a schema as a sub-schema of this schema, and returns the wrapped object.
- add(String, Schema) - Static method in class org.apache.calcite.test.ConnectionFactories
-
Returns a post-processor that adds
Schema
and sets it as default. - add(String, Table) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Defines a table within this schema.
- add(String, Table) - Method in interface org.apache.calcite.schema.SchemaPlus
-
Adds a table to this schema.
- add(String, Table, ImmutableList<String>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Defines a table within this schema.
- add(String, SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Adds a field with a type created using
RelDataTypeFactory.createSqlType(org.apache.calcite.sql.type.SqlTypeName)
. - add(String, SqlTypeName) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- add(String, SqlTypeName, int) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Adds a field with a type created using
RelDataTypeFactory.createSqlType(org.apache.calcite.sql.type.SqlTypeName, int)
. - add(String, SqlTypeName, int) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- add(String, SqlTypeName, int, int) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Adds a field with a type created using
RelDataTypeFactory.createSqlType(org.apache.calcite.sql.type.SqlTypeName, int, int)
. - add(String, SqlTypeName, int, int) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- add(BigDecimal, BigDecimal) - Method in class org.apache.calcite.interpreter.AggregateNode.BigDecimalSum
- add(Map<String, String>, List<String>) - Method in class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
-
Adds newly projected fields and restricted predicates.
- add(Consumer<T>) - Method in enum org.apache.calcite.runtime.Hook
-
Deprecated.this installs a global hook (cross-thread), so it might have greater impact than expected. Use with caution. Prefer thread-local hooks.
- add(Function<T, R>) - Method in enum org.apache.calcite.runtime.Hook
-
Deprecated.Use
Hook.add(Consumer)
. - add(Predicate<Puffin.Line<G, F>>, Consumer<Puffin.Line<G, F>>) - Method in interface org.apache.calcite.util.Puffin.Builder
-
Adds a predicate and action to be invoked on each line of a source.
- add(List<Geometry>, Geometry) - Method in class org.apache.calcite.runtime.AccumOperation
- add(List<Geometry>, Geometry) - Method in class org.apache.calcite.runtime.CollectOperation
- add(List<Geometry>, Geometry) - Method in class org.apache.calcite.runtime.UnionOperation
- add(Expression) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- add(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic addition operation that does not have overflow checking.
- add(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic addition operation that does not have overflow checking.
- add(Statement) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- add(RelDataTypeField) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Adds a field.
- add(RelDataTypeField) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- add(Table) - Method in class org.apache.calcite.schema.impl.StarTable
- add(SqlNode) - Method in class org.apache.calcite.sql.SqlNodeList
- add(SqlAbstractParserImpl) - Method in class org.apache.calcite.sql.parser.Span
-
Adds the position of the last token emitted by a parser to the list, and returns this Span.
- add(SqlParserPos) - Method in class org.apache.calcite.sql.parser.Span
-
Adds a position to the list, and returns this Span.
- add(SqlNode) - Method in class org.apache.calcite.sql.parser.Span
-
Adds a node's position to the list, and returns this Span.
- add(SqlOperator) - Method in class org.apache.calcite.sql.util.ListSqlOperatorTable
-
Deprecated.Use
SqlOperatorTables.of(java.lang.Iterable<? extends org.apache.calcite.sql.SqlOperator>)
, which creates an immutable table. - add(SqlOperatorTable) - Method in class org.apache.calcite.sql.util.ChainedSqlOperatorTable
-
Deprecated.
- add(CalciteAssert.SchemaSpec) - Static method in class org.apache.calcite.test.ConnectionFactories
-
Returns a post-processor that adds a
CalciteAssert.SchemaSpec
(set of schemes) to a connection. - add(T, T) - Method in class org.apache.calcite.interpreter.AggregateNode.NumericComparison
- add(T, U) - Method in interface org.apache.calcite.runtime.PairList
-
Adds a pair to this list.
- add(T, U) - Method in class org.apache.calcite.runtime.PairList.Builder
-
Adds a pair to the list under construction.
- Add - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An addition operation, such as a + b, without overflow checking, for numeric operands.
- ADD_MONTHS - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ADD_MONTHS_INT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- add2(PairList<RexNode, String>, int, List<RelDataTypeField>) - Static method in class org.apache.calcite.rex.RexInputRef
-
Adds to a PairList a reference to a given field in a list of fields.
- addAggCall(AggregateCall, int, boolean, List<AggregateCall>, Map<AggregateCall, RexNode>, List<RelDataType>) - Method in class org.apache.calcite.rex.RexBuilder
-
Deprecated.
- addAggCall(AggregateCall, int, List<AggregateCall>, Map<AggregateCall, RexNode>, List<RelDataType>) - Method in class org.apache.calcite.rex.RexBuilder
-
Deprecated.
- addAggCall(AggregateCall, int, List<AggregateCall>, Map<AggregateCall, RexNode>, IntPredicate) - Method in class org.apache.calcite.rex.RexBuilder
-
Creates a reference to an aggregate call, checking for repeated calls.
- addAggregateFunctions(Map<String, String>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- addAlias(String, String) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Defines an alias for an existing frame.
- addAlias(SqlNode, String) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Converts an expression "expr" into "expr AS alias".
- addAlias(SqlOperator, SqlOperator) - Method in class org.apache.calcite.sql2rel.ReflectiveConvertletTable
-
Registers that one operator is an alias for another.
- addAll(int, Collection<? extends E>) - Method in class org.apache.calcite.runtime.ConsList
- addAll(int, Collection<? extends SqlNode>) - Method in class org.apache.calcite.sql.SqlNodeList
- addAll(int, PairList<T, U>) - Method in interface org.apache.calcite.runtime.PairList
-
Adds to this list, at a given index, the contents of another PairList.
- addAll(Iterable<? extends E>) - Method in class org.apache.calcite.util.ImmutableNullableList.Builder
-
Adds each element of
elements
to theImmutableNullableList
. - addAll(Iterable<? extends E>) - Method in class org.apache.calcite.util.ImmutableNullableSet.Builder
-
Adds each element of
elements
to theImmutableNullableSet
. - addAll(Iterable<? extends Map.Entry<String, RelDataType>>) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Adds all fields in a collection.
- addAll(Iterable<? extends Map.Entry<String, RelDataType>>) - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.FieldInfoBuilder
-
Deprecated.
- addAll(Iterable<? extends SqlNode>) - Method in class org.apache.calcite.sql.parser.Span
-
Adds the positions of a collection of nodes to the list, and returns this Span.
- addAll(Iterable<Integer>) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Sets all bits in a given list of bits.
- addAll(Collection<? extends E>) - Method in class org.apache.calcite.runtime.ConsList
- addAll(Collection<? extends SqlNode>) - Method in class org.apache.calcite.sql.SqlNodeList
- addAll(Iterator<? extends E>) - Method in class org.apache.calcite.util.ImmutableNullableList.Builder
-
Adds each element of
elements
to theImmutableNullableList
. - addAll(Iterator<? extends E>) - Method in class org.apache.calcite.util.ImmutableNullableSet.Builder
-
Adds each element of
elements
to theImmutableNullableSet
. - addAll(TimeFrameSet) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Adds all time frames in
timeFrameSet
to thisBuilder
. - addAll(PairList<T, U>) - Method in interface org.apache.calcite.runtime.PairList
-
Adds to this list the contents of another PairList.
- addAll(ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Sets all bits in a given bit set.
- addAll(ImmutableIntList) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Sets all bits in a given list of
int
s. - addAssign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an addition assignment operation that does not have overflow checking.
- addAssign(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an addition assignment operation that does not have overflow checking.
- addAssign(Expression, Expression, Method, LambdaExpression, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an addition assignment operation that does not have overflow checking.
- AddAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An addition compound assignment operation, such as (a += b), without overflow checking, for numeric operands.
- addAssignChecked(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an addition assignment operation that has overflow checking.
- addAssignChecked(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an addition assignment operation that has overflow checking.
- addAssignChecked(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an addition assignment operation that has overflow checking.
- AddAssignChecked - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An addition compound assignment operation, such as (a += b), with overflow checking, for numeric operands.
- addCarets() - Method in class org.apache.calcite.sql.parser.StringAndPos
- addCarets(String, int, int, int, int) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Converts a string to a string with one or two carets in it.
- addCharsetAndCollation(RelDataType, RelDataTypeFactory) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Adds collation and charset to a character type, returns other types unchanged.
- addChecked(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic addition operation that has overflow checking.
- addChecked(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an arithmetic addition operation that has overflow checking.
- AddChecked - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An addition operation, such as (a + b), with overflow checking, for numeric operands.
- addChild(SqlValidatorNamespace, String, boolean) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- addChild(SqlValidatorNamespace, String, boolean) - Method in class org.apache.calcite.sql.validate.ParameterScope
- addChild(SqlValidatorNamespace, String, boolean) - Method in class org.apache.calcite.sql.validate.JoinScope
- addChild(SqlValidatorNamespace, String, boolean) - Method in class org.apache.calcite.sql.validate.ListScope
- addChild(SqlValidatorNamespace, String, boolean) - Method in interface org.apache.calcite.sql.validate.SqlValidatorScope
-
Registers a relation in this scope.
- addColumn(String, RelDataType) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- addColumn(String, RelDataType, boolean) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- addColumnNames(SqlValidatorNamespace, List<SqlMoniker>) - Method in class org.apache.calcite.sql.validate.DelegatingScope
- addCommonRelSubExprInstruction() - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to attempt to match instances of
CommonRelSubExprRule
, but only in cases where vertices have more than one parent. - addCondition(RexNode) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Sets the condition of the program.
- addConvertedNonCorrSubqs(Map<SqlNode, RexNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Adds to the current map of non-correlated converted sub-queries the elements from another map that contains non-correlated sub-queries that have been converted by another SqlToRelConverter.
- addConverters(boolean) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to attempt to match instances of
ConverterRule
, but only where a conversion is actually required. - addCore(String) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Defines a core time frame.
- addDate(int, int, TimeFrame) - Method in class org.apache.calcite.rel.type.TimeFrameSet
- addDiffMask(String) - Method in class org.apache.calcite.test.DiffTestCase
-
Adds a diff mask.
- addDimension(Lattice.Column) - Method in class org.apache.calcite.materialize.Lattice.TileBuilder
- addDivision(String, Number, String) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Defines a time frame such that each base frame consists of
count
instances of the new frame. - addedDeclarations - Variable in class org.apache.calcite.linq4j.tree.ClassDeclarationFinder
-
The list of new final static fields to be added to the current class.
- addEdge(V, V) - Method in class org.apache.calcite.util.graph.AttributedDirectedGraph
-
Deprecated.
- addEdge(V, V) - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- addEdge(V, V) - Method in interface org.apache.calcite.util.graph.DirectedGraph
-
Adds an edge to this graph.
- addEdge(V, V, Object...) - Method in class org.apache.calcite.util.graph.AttributedDirectedGraph
- addEpsilon(double) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Add an epsilon to the value passed in.
- addEquivalenceClass(RexTableInputRef, RexTableInputRef) - Method in class org.apache.calcite.rel.rules.materialize.MaterializedViewRule.EquivalenceClasses
- addExpr(RexNode) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Adds an expression to the list of common expressions, and returns a reference to the expression.
- addExpressionForReuse(DeclarationStatement) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- addFile(String) - Method in class org.apache.calcite.util.javac.JavaCompilerArgs
- addFunctions(SchemaPlus, String, List<String>, String, String, boolean) - Static method in class org.apache.calcite.model.ModelHandler
-
Creates and validates a
ScalarFunctionImpl
, and adds it to a schema. - addGroupBegin() - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to begin a group of rules.
- addGroupBy(List<String>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- addGroupEnd() - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to end a group of rules, firing the group collectively.
- addIdentity() - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Adds a project item for every input field.
- addIf(SqlNode) - Method in class org.apache.calcite.sql.parser.Span
-
Adds a node's position to the list if the node is not null, and returns this Span.
- addIgnorePattern(String) - Method in class org.apache.calcite.test.DiffTestCase
- addImplicitFuncNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- addImplicitFuncNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit function names to a builder.
- addImplicitFunctionsToBuilder(ImmutableList.Builder<Function>, String, boolean) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- addImplicitFunctionsToBuilder(ImmutableList.Builder<Function>, String, boolean) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit functions to a builder.
- addImplicitSubSchemaToBuilder(ImmutableSortedMap.Builder<String, CalciteSchema>) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- addImplicitSubSchemaToBuilder(ImmutableSortedMap.Builder<String, CalciteSchema>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit sub-schemas to a builder.
- addImplicitTablesBasedOnNullaryFunctionsToBuilder(ImmutableSortedMap.Builder<String, Table>) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- addImplicitTablesBasedOnNullaryFunctionsToBuilder(ImmutableSortedMap.Builder<String, Table>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit table functions to a builder.
- addImplicitTableToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- addImplicitTableToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit tables to a builder.
- addImplicitTypeNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteRootSchema
- addImplicitTypeNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.CalciteSchema
-
Adds implicit type names to a builder.
- addLattice(RelOptLattice) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- addLattice(RelOptLattice) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Defines a lattice.
- addLattice(RelOptLattice) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- addListener(RelOptListener) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- addListener(RelOptListener) - Method in class org.apache.calcite.plan.MulticastRelOptListener
-
Adds a listener which will receive multicast events.
- addListener(RelOptListener) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Adds a listener to this planner.
- addMatch(VolcanoRuleMatch) - Method in class org.apache.calcite.plan.volcano.RuleQueue
-
Add a RuleMatch into the queue.
- addMatchLimit(int) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to limit the number of pattern matches for subsequent instructions.
- addMatchOrder(HepMatchOrder) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to change the order of pattern matching for subsequent instructions.
- addMaterialization(RelOptMaterialization) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- addMaterialization(RelOptMaterialization) - Method in class org.apache.calcite.plan.hep.HepPlanner
- addMaterialization(RelOptMaterialization) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Defines a pair of relational expressions that are equivalent.
- addMaterialization(RelOptMaterialization) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- addMeasure(Lattice.Measure) - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Adds a measure, if it does not already exist.
- addMeasure(Lattice.Measure) - Method in class org.apache.calcite.materialize.Lattice.TileBuilder
- addMethod - Variable in class org.apache.calcite.schema.impl.AggregateFunctionImpl
- addMethodParameters(Method) - Method in class org.apache.calcite.schema.impl.ReflectiveFunctionBase.ParameterListBuilder
- addMonotonic(String) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- addMultiple(String, Number, String) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Defines a time frame that consists of
count
instances of a base frame. - addOrder(List<String>) - Method in class org.apache.calcite.adapter.cassandra.CassandraRel.Implementor
- addOrderByFields(List<String>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
- addOrderItem(List<SqlNode>, RelFieldCollation) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- addPatternVar(String) - Method in class org.apache.calcite.sql.validate.MatchRecognizeScope
- AddPointOperation - Class in org.apache.calcite.runtime
-
Geometry editor operation that adds a point to a geometry.
- AddPointOperation(Geometry, int) - Constructor for class org.apache.calcite.runtime.AddPointOperation
- addPredicates(List<String>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
-
Adds new restricted predicates.
- addProject(int, int, String) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Adds a projection based upon the
index
th expression at a given position. - addProject(int, String) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Adds a projection based upon the
index
th expression. - addProject(int, RexNode, String) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Adds a project expression to the program at a given position.
- addProject(RexNode, String) - Method in class org.apache.calcite.rex.RexProgramBuilder
-
Adds a project expression to the program.
- addQuery(RelNode) - Method in class org.apache.calcite.materialize.LatticeSuggester
-
Adds a query.
- addQuotient(String, String, String) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Defines a time frame that is the number of a minor unit within a major frame.
- addRelBuilderConfigTransform(UnaryOperator<RelBuilder.Config>) - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
-
Adds a transform to
SqlToRelConverter.Config.getRelBuilderConfigTransform()
. - addRelTraitDef(RelTraitDef) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- addRelTraitDef(RelTraitDef) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Registers a rel trait definition.
- addRelTraitDef(RelTraitDef) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- addRemovableOuterJoinFactor(int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Adds a join factor to the set of factors that can be removed because the factor is the null-generating factor in an outer join, its join keys are unique, and the factor is not projected in the query.
- addRemovableSelfJoinPair(int, int) - Method in class org.apache.calcite.rel.rules.LoptMultiJoin
-
Adds to a map that keeps track of removable self-join pairs.
- addRollup(String, String) - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Defines a rollup from one frame to another.
- addRule(RelOptRule) - Method in interface org.apache.calcite.jdbc.CalcitePrepare.SparkHandler.RuleSetBuilder
- addRule(RelOptRule) - Method in class org.apache.calcite.plan.AbstractRelOptPlanner
- addRule(RelOptRule) - Method in interface org.apache.calcite.plan.RelOptPlanner
-
Registers a rule.
- addRule(RelOptRule) - Method in class org.apache.calcite.plan.volcano.VolcanoPlanner
- addRule(RelOptRule) - Method in class org.apache.calcite.test.MockRelOptPlanner
- addRuleByDescription(String) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to attempt to match a specific rule identified by its unique description.
- addRuleClass(Class<R>) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to attempt to match any rules of a given class.
- addRuleCollection(Collection<RelOptRule>) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to attempt to match any rules in a given collection.
- addRuleInstance(RelOptRule) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to attempt to match a specific rule object.
- addSchema(SchemaPlus, CalciteAssert.SchemaSpec...) - Static method in class org.apache.calcite.test.CalciteAssert
-
Adds a schema specification (or specifications) to the root schema, returning the last one created.
- addSelect(List<SqlNode>, SqlNode, RelDataType) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
- addSelect(List<SqlNode>, SqlNode, RelDataType) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- addSelectFields(Map<String, String>) - Method in class org.apache.calcite.adapter.geode.rel.GeodeRel.GeodeImplementContext
-
Adds new projected fields.
- addSelectFields(Map<String, String>) - Method in class org.apache.calcite.adapter.innodb.InnodbRel.Implementor
- addStatement(String) - Method in class org.apache.calcite.adapter.pig.PigRel.Implementor
- addStatement(CalciteConnection, Meta.StatementHandle) - Method in interface org.apache.calcite.server.CalciteServer
- addSubprogram(HepProgram) - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Adds an instruction to execute a subprogram.
- addTable(String) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockSchema
- addThread(Function<T, R>) - Method in enum org.apache.calcite.runtime.Hook
-
Deprecated.
- addThread(Consumer<T>) - Method in enum org.apache.calcite.runtime.Hook
-
Adds a handler for this thread.
- addTile(Lattice.Tile) - Method in class org.apache.calcite.materialize.Lattice.Builder
- addTimestamp(long, long, TimeFrame) - Method in class org.apache.calcite.rel.type.TimeFrameSet
- addToSelectList(List<SqlNode>, Set<String>, List<Map.Entry<String, RelDataType>>, SqlNode, SelectScope, boolean) - Method in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Adds an expression to a select list, ensuring that its alias does not clash with any existing expressions on the list.
- addTrait(T, RelTrait) - Static method in class org.apache.calcite.plan.RelOptUtil
- addType(String, RelProtoDataType) - Static method in class org.apache.calcite.test.ConnectionFactories
-
Returns a post-processor that adds a type.
- addVertex(V) - Method in class org.apache.calcite.util.graph.DefaultDirectedGraph
- addVertex(V) - Method in interface org.apache.calcite.util.graph.DirectedGraph
-
Adds a vertex to this graph.
- addWindowName(String) - Method in class org.apache.calcite.sql.validate.SelectScope
- addWrap(Object) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- AddZTransformer - Class in org.apache.calcite.runtime
-
Operation that adds a z value to a geometry.
- AddZTransformer(double) - Constructor for class org.apache.calcite.runtime.AddZTransformer
- adjacents(Iterable<? extends T>) - Static method in class org.apache.calcite.util.Pair
-
Returns an iterator that iterates over (i, i + 1) pairs in an iterable.
- adjustInputRef(SqlToRelConverter.Blackboard, RexInputRef) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
-
Adjusts the type of a reference to an input field to account for nulls introduced by outer joins; and adjusts the offset to match the physical implementation.
- adjustKeys(List<Integer>, int) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Adjusts key values in a list by some fixed amount.
- adjustType(SqlValidator, SqlCall, RelDataType) - Method in class org.apache.calcite.sql.SqlBinaryOperator
- adjustType(SqlValidator, SqlCall, RelDataType) - Method in class org.apache.calcite.sql.SqlOperator
-
Validates and determines coercibility and resulting collation name of binary operator if needed.
- adjustType(SqlValidator, SqlCall, RelDataType) - Method in class org.apache.calcite.sql.SqlPostfixOperator
- adjustType(SqlValidator, SqlCall, RelDataType) - Method in class org.apache.calcite.sql.SqlPrefixOperator
- adjustTypeForArrayConstructor(RelDataType, SqlOperatorBinding) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
When the array element does not equal the array component type, make explicit casting.
- adjustTypeForMapConstructor(Pair<RelDataType, RelDataType>, SqlOperatorBinding) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
When the map key or value does not equal the map component key type or value type, make explicit casting.
- ADMIN - Enum constant in enum org.apache.calcite.chinook.EnvironmentFairy.User
- adoptConvention(Convention) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns new RelBuilder that adopts the convention provided.
- after - Variable in class org.apache.calcite.rel.core.Match
- after - Variable in class org.apache.calcite.rel.mutable.MutableMatch
- after() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- after(Consumer<Puffin.Context<G, F>>) - Method in interface org.apache.calcite.util.Puffin.Builder
-
Adds an action to be called after all sources.
- afterSource(Consumer<Puffin.Context<G, F>>) - Method in interface org.apache.calcite.util.Puffin.Builder
-
Adds an action to be called after each source.
- afterTableFunction(SqlToRelConverter.Blackboard, SqlCall, LogicalTableFunctionScan) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
- agg - Variable in class org.apache.calcite.materialize.Lattice.Measure
- agg - Variable in class org.apache.calcite.model.JsonMeasure
-
The name of an aggregate function.
- AGG_FIRST - Static variable in interface org.apache.calcite.rel.rules.AggregateUnionAggregateRule.Config
- AGG_INDEX - Enum constant in enum org.apache.calcite.adapter.enumerable.WinAggImplementor.SeekType
-
The index of row that is aggregated.
- AGG_LAMBDA_FACTORY_ACC_ADDER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AGG_LAMBDA_FACTORY_ACC_INITIALIZER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AGG_LAMBDA_FACTORY_ACC_RESULT_SELECTOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AGG_LAMBDA_FACTORY_ACC_SINGLE_GROUP_RESULT_SELECTOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AGG_SECOND - Static variable in interface org.apache.calcite.rel.rules.AggregateUnionAggregateRule.Config
- AGG_SUM - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy for SUM aggregate function inferred from the operand type, and nullable if the call occurs within a "GROUP BY ()" query.
- AGG_SUM_EMPTY_IS_ZERO - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy for $SUM0 aggregate function inferred from the operand type.
- AggAddContext - Interface in org.apache.calcite.adapter.enumerable
-
Information for a call to
AggImplementor.implementAdd(AggContext, AggAddContext)
. - AggAddContextImpl - Class in org.apache.calcite.adapter.enumerable.impl
-
Implementation of
AggAddContext
. - AggAddContextImpl(BlockBuilder, List<Expression>) - Constructor for class org.apache.calcite.adapter.enumerable.impl.AggAddContextImpl
- AggCallBinding(RelDataTypeFactory, SqlAggFunction, List<RelDataType>, int, boolean) - Constructor for class org.apache.calcite.rel.core.Aggregate.AggCallBinding
-
Deprecated.
- AggCallBinding(RelDataTypeFactory, SqlAggFunction, List<RelDataType>, List<RelDataType>, int, boolean) - Constructor for class org.apache.calcite.rel.core.Aggregate.AggCallBinding
-
Creates an AggCallBinding.
- aggCalls - Variable in class org.apache.calcite.rel.core.Aggregate
- aggCalls - Variable in class org.apache.calcite.rel.core.Window.Group
-
List of
Window.RexWinAggCall
objects, each of which is a call to aSqlAggFunction
. - aggCalls - Variable in class org.apache.calcite.rel.mutable.MutableAggregate
- AggContext - Interface in org.apache.calcite.adapter.enumerable
-
Information on the aggregate calculation context.
- aggIdx - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- AggImplementor - Interface in org.apache.calcite.adapter.enumerable
-
Implements an aggregate function by generating expressions to initialize, add to, and get a result from, an accumulator.
- AggImpState - Class in org.apache.calcite.adapter.enumerable
-
Represents internal state when implementing aggregate functions.
- AggImpState(int, AggregateCall, boolean) - Constructor for class org.apache.calcite.adapter.enumerable.AggImpState
- aggList - Variable in class org.apache.calcite.sql.SqlPivot
- aggregate(TAccumulate, Function2<TAccumulate, T, TAccumulate>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- aggregate(TAccumulate, Function2<TAccumulate, TSource, TAccumulate>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Applies an accumulator function over a sequence.
- aggregate(List<Map.Entry<String, Class>>, List<String>) - Method in class org.apache.calcite.adapter.mongodb.MongoTable.MongoQueryable
-
Called via code-generation.
- aggregate(Enumerable<TSource>, Function2<TSource, TSource, TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Applies an accumulator function over a sequence.
- aggregate(Enumerable<TSource>, TAccumulate, Function2<TAccumulate, TSource, TAccumulate>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Applies an accumulator function over a sequence.
- aggregate(Enumerable<TSource>, TAccumulate, Function2<TAccumulate, TSource, TAccumulate>, Function1<TAccumulate, TResult>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Applies an accumulator function over a sequence.
- aggregate(Function2<T, T, T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- aggregate(Function2<TSource, TSource, TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Applies an accumulator function over a sequence.
- aggregate(Queryable<T>, FunctionExpression<Function2<T, T, T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Applies an accumulator function over a sequence.
- aggregate(Queryable<T>, FunctionExpression<Function2<T, T, T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- aggregate(Queryable<T>, FunctionExpression<Function2<T, T, T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Applies an accumulator function over a sequence.
- aggregate(Queryable<T>, TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Applies an accumulator function over a sequence.
- aggregate(Queryable<T>, TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Applies an accumulator function over a sequence.
- aggregate(Queryable<T>, TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- aggregate(Queryable<T>, TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>, FunctionExpression<Function1<TAccumulate, TResult>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Applies an accumulator function over a sequence.
- aggregate(Queryable<T>, TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>, FunctionExpression<Function1<TAccumulate, TResult>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Applies an accumulator function over a sequence.
- aggregate(Queryable<T>, TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>, FunctionExpression<Function1<TAccumulate, TResult>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- aggregate(FunctionExpression<Function2<T, T, T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- aggregate(FunctionExpression<Function2<T, T, T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Applies an accumulator function over a sequence.
- aggregate(RelBuilder.GroupKey, Iterable<? extends RelBuilder.AggCall>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
Aggregate
with multiple calls. - aggregate(RelBuilder.GroupKey, List<AggregateCall>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
Aggregate
with an array ofAggregateCall
s. - aggregate(RelBuilder.GroupKey, RelBuilder.AggCall...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an
Aggregate
with an array of calls. - aggregate(TAccumulate, Function2<TAccumulate, T, TAccumulate>, Function1<TAccumulate, TResult>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- aggregate(TAccumulate, Function2<TAccumulate, TSource, TAccumulate>, Function1<TAccumulate, TResult>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Applies an accumulator function over a sequence.
- aggregate(TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- aggregate(TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>, FunctionExpression<Function1<TAccumulate, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- aggregate(TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Applies an accumulator function over a sequence.
- aggregate(TAccumulate, FunctionExpression<Function2<TAccumulate, T, TAccumulate>>, FunctionExpression<Function1<TAccumulate, TResult>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Applies an accumulator function over a sequence.
- Aggregate - Class in org.apache.calcite.rel.core
-
Relational operator that eliminates duplicates and computes totals.
- Aggregate(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.rel.core.Aggregate
-
Creates an Aggregate.
- Aggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.rel.core.Aggregate
-
Deprecated.
- Aggregate(RelOptCluster, RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.rel.core.Aggregate
-
Deprecated.
- Aggregate(RelInput) - Constructor for class org.apache.calcite.rel.core.Aggregate
-
Creates an Aggregate by parsing serialized output.
- AGGREGATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AGGREGATE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- AGGREGATE - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
Aggregate
nodes. - AGGREGATE - Static variable in class org.apache.calcite.rel.rules.materialize.MaterializedViewRules
-
Rule that matches
Aggregate
. - AGGREGATE - Static variable in interface org.apache.calcite.rel.rules.PruneEmptyRules.RemoveEmptySingleRule.RemoveEmptySingleRuleConfig
- AGGREGATE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "AGGREGATE(m)" aggregate function; aggregates a measure column according to the measure's rollup strategy.
- AGGREGATE - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category consisting of all built-in aggregate functions.
- AGGREGATE_ANY_PULL_UP_CONSTANTS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
More general form of
CoreRules.AGGREGATE_PROJECT_PULL_UP_CONSTANTS
that matches any relational expression. - AGGREGATE_CASE_TO_FILTER - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that converts CASE-style filtered aggregates into true filtered aggregates.
- AGGREGATE_EXPAND_DISTINCT_AGGREGATES - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that expands distinct aggregates (such as
COUNT(DISTINCT x)
) from aAggregate
. - AGGREGATE_EXPAND_DISTINCT_AGGREGATES_TO_JOIN - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.AGGREGATE_EXPAND_DISTINCT_AGGREGATES
but generates a Join. - AGGREGATE_EXPAND_WITHIN_DISTINCT - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that rewrites a
LogicalAggregate
that containsWITHIN DISTINCT
aggregate functions to one that does not. - AGGREGATE_FACTORY - Static variable in class org.apache.calcite.adapter.jdbc.JdbcRules
- AGGREGATE_FILTER_TRANSPOSE - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- AGGREGATE_FILTER_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_FN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
AGGREGATE
aggregate function. - AGGREGATE_INSTANCE - Static variable in class org.apache.calcite.rel.rules.PruneEmptyRules
-
Rule that converts an
Aggregate
to empty if its child is empty. - AGGREGATE_JOIN_JOIN_REMOVE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_JOIN_REMOVE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_JOIN_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_JOIN_TRANSPOSE_EXTENDED - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.AGGREGATE_JOIN_TRANSPOSE
, but extended to push down aggregate functions. - AGGREGATE_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_PROJECT - Static variable in class org.apache.calcite.adapter.druid.DruidRules
- AGGREGATE_PROJECT_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_PROJECT_PULL_UP_CONSTANTS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that removes constant keys from an
Aggregate
. - AGGREGATE_PROJECT_STAR_TABLE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Variant of
CoreRules.AGGREGATE_STAR_TABLE
that accepts aProject
between theAggregate
and itsStarTable.StarTableScan
input. - AGGREGATE_REDUCE_FUNCTIONS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that reduces aggregate functions in an
Aggregate
to simpler forms. - AGGREGATE_REMOVE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that removes an
Aggregate
if it computes no aggregate functions (that is, it is implementingSELECT DISTINCT
), or all the aggregate functions are splittable, and the underlying relational expression is already distinct. - AGGREGATE_STAR_TABLE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that matches an
Aggregate
on aStarTable.StarTableScan
. - AGGREGATE_UNION_AGGREGATE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_UNION_AGGREGATE_FIRST - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.AGGREGATE_UNION_AGGREGATE
, but matches anAggregate
only as the left input of theUnion
. - AGGREGATE_UNION_AGGREGATE_SECOND - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
As
CoreRules.AGGREGATE_UNION_AGGREGATE
, but matches anAggregate
only as the right input of theUnion
. - AGGREGATE_UNION_TRANSPOSE - Static variable in class org.apache.calcite.rel.rules.CoreRules
- AGGREGATE_VALUES - Static variable in class org.apache.calcite.rel.rules.CoreRules
- Aggregate.AggCallBinding - Class in org.apache.calcite.rel.core
-
Implementation of the
SqlOperatorBinding
interface for anaggregate call
applied to a set of operands in the context of aLogicalAggregate
. - Aggregate.Group - Enum in org.apache.calcite.rel.core
-
Describes the kind of roll-up.
- Aggregate.PercentileDiscAggCallBinding - Class in org.apache.calcite.rel.core
-
Used for PERCENTILE_DISC return type inference.
- aggregateCall - Variable in class org.apache.calcite.sql.validate.SqlValidatorUtil.FlatAggregate
- aggregateCall(AggregateCall) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to an aggregate function as a copy of an
AggregateCall
. - aggregateCall(AggregateCall, Mapping) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to an aggregate function as a copy of an
AggregateCall
, applying a mapping. - aggregateCall(SqlAggFunction, boolean, boolean, boolean, RexNode, ImmutableList<RexNode>, ImmutableList<RexNode>, String, ImmutableList<RexNode>, ImmutableList<RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to an aggregate function with all applicable operands.
- aggregateCall(SqlAggFunction, boolean, boolean, RexNode, String, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Deprecated.
- aggregateCall(SqlAggFunction, boolean, boolean, RexNode, String, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Deprecated.
- aggregateCall(SqlAggFunction, boolean, RexNode, String, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Deprecated.
- aggregateCall(SqlAggFunction, boolean, RexNode, String, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Deprecated.
- aggregateCall(SqlAggFunction, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to an aggregate function.
- aggregateCall(SqlAggFunction, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to an aggregate function.
- AggregateCall - Class in org.apache.calcite.rel.core
-
Call to an aggregate function within an
Aggregate
. - AggregateCall(SqlAggFunction, boolean, List<Integer>, RelDataType, String) - Constructor for class org.apache.calcite.rel.core.AggregateCall
-
Deprecated.
- aggregateCalls - Variable in class org.apache.calcite.rel.core.Match
- aggregateCallsPreVar - Variable in class org.apache.calcite.rel.core.Match
- AggregateCaseToFilterRule - Class in org.apache.calcite.rel.rules
-
Rule that converts CASE-style filtered aggregates into true filtered aggregates.
- AggregateCaseToFilterRule(AggregateCaseToFilterRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateCaseToFilterRule
-
Creates an AggregateCaseToFilterRule.
- AggregateCaseToFilterRule(RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.AggregateCaseToFilterRule
-
Deprecated.
- AggregateCaseToFilterRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateExpandDistinctAggregatesRule - Class in org.apache.calcite.rel.rules
-
Planner rule that expands distinct aggregates (such as
COUNT(DISTINCT x)
) from aAggregate
. - AggregateExpandDistinctAggregatesRule(Class<? extends Aggregate>, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
-
Deprecated.
- AggregateExpandDistinctAggregatesRule(Class<? extends LogicalAggregate>, boolean, RelFactories.JoinFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
-
Deprecated.
- AggregateExpandDistinctAggregatesRule(Class<? extends LogicalAggregate>, RelFactories.JoinFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateExpandDistinctAggregatesRule
-
Deprecated.
- AggregateExpandDistinctAggregatesRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateExpandWithinDistinctRule - Class in org.apache.calcite.rel.rules
-
Planner rule that rewrites an
Aggregate
that containsWITHIN DISTINCT
aggregate functions. - AggregateExpandWithinDistinctRule(AggregateExpandWithinDistinctRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateExpandWithinDistinctRule
-
Creates an AggregateExpandWithinDistinctRule.
- AggregateExpandWithinDistinctRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateExtractProjectRule - Class in org.apache.calcite.rel.rules
- AggregateExtractProjectRule(Class<? extends Aggregate>, Class<? extends RelNode>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateExtractProjectRule
-
Deprecated.
- AggregateExtractProjectRule(RelOptRuleOperand, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateExtractProjectRule
-
Deprecated.
- AggregateExtractProjectRule(AggregateExtractProjectRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateExtractProjectRule
-
Creates an AggregateExtractProjectRule.
- AggregateExtractProjectRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- aggregateFactory - Variable in class org.apache.calcite.rel.core.RelFactories.Struct
- AggregateFilterTransposeRule - Class in org.apache.calcite.rel.rules
- AggregateFilterTransposeRule(RelOptRuleOperand, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateFilterTransposeRule
-
Deprecated.
- AggregateFilterTransposeRule(AggregateFilterTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateFilterTransposeRule
-
Creates an AggregateFilterTransposeRule.
- AggregateFilterTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateFunction - Interface in org.apache.calcite.schema
-
Function that combines several values into a scalar result.
- AggregateFunctionImpl - Class in org.apache.calcite.schema.impl
-
Implementation of
AggregateFunction
via user-defined class. - aggregateIllegalInClause(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- aggregateIllegalInOrderBy() - Method in interface org.apache.calcite.runtime.CalciteResource
- aggregateInFilterIllegal() - Method in interface org.apache.calcite.runtime.CalciteResource
- aggregateInWithinDistinctIllegal() - Method in interface org.apache.calcite.runtime.CalciteResource
- aggregateInWithinGroupIllegal() - Method in interface org.apache.calcite.runtime.CalciteResource
- AggregateJoinJoinRemoveRule - Class in org.apache.calcite.rel.rules
- AggregateJoinJoinRemoveRule(Class<? extends Aggregate>, Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinJoinRemoveRule
-
Deprecated.
- AggregateJoinJoinRemoveRule(AggregateJoinJoinRemoveRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinJoinRemoveRule
-
Creates an AggregateJoinJoinRemoveRule.
- AggregateJoinJoinRemoveRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateJoinRemoveRule - Class in org.apache.calcite.rel.rules
- AggregateJoinRemoveRule(Class<? extends Aggregate>, Class<? extends Join>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinRemoveRule
-
Deprecated.
- AggregateJoinRemoveRule(AggregateJoinRemoveRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinRemoveRule
-
Creates an AggregateJoinRemoveRule.
- AggregateJoinRemoveRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateJoinTransposeRule - Class in org.apache.calcite.rel.rules
- AggregateJoinTransposeRule(Class<? extends Aggregate>, Class<? extends Join>, RelBuilderFactory, boolean) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Deprecated.
- AggregateJoinTransposeRule(Class<? extends Aggregate>, RelFactories.AggregateFactory, Class<? extends Join>, RelFactories.JoinFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Deprecated.
- AggregateJoinTransposeRule(Class<? extends Aggregate>, RelFactories.AggregateFactory, Class<? extends Join>, RelFactories.JoinFactory, boolean) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Deprecated.
- AggregateJoinTransposeRule(Class<? extends Aggregate>, RelFactories.AggregateFactory, Class<? extends Join>, RelFactories.JoinFactory, RelFactories.ProjectFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Deprecated.
- AggregateJoinTransposeRule(Class<? extends Aggregate>, RelFactories.AggregateFactory, Class<? extends Join>, RelFactories.JoinFactory, RelFactories.ProjectFactory, boolean) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Deprecated.
- AggregateJoinTransposeRule(AggregateJoinTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateJoinTransposeRule
-
Creates an AggregateJoinTransposeRule.
- AggregateJoinTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateLambdaFactory<TSource,
TOrigAccumulate, TAccumulate, TResult, TKey> - Interface in org.apache.calcite.adapter.enumerable -
Generates lambda functions used in
EnumerableAggregate
. - AggregateMergeRule - Class in org.apache.calcite.rel.rules
- AggregateMergeRule(RelOptRuleOperand, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateMergeRule
-
Deprecated.
- AggregateMergeRule(AggregateMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateMergeRule
-
Creates an AggregateMergeRule.
- AggregateMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- aggregateMissingWithinGroupClause(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- AggregateNode - Class in org.apache.calcite.interpreter
-
Interpreter node that implements an
Aggregate
. - AggregateNode(Compiler, Aggregate) - Constructor for class org.apache.calcite.interpreter.AggregateNode
- AggregateNode.BigDecimalSum - Class in org.apache.calcite.interpreter
-
Implementation of
SUM
over BigDecimal values as a user-defined aggregate. - AggregateNode.DoubleSum - Class in org.apache.calcite.interpreter
-
Implementation of
SUM
over DOUBLE values as a user-defined aggregate. - AggregateNode.IntSum - Class in org.apache.calcite.interpreter
-
Implementation of
SUM
over INTEGER values as a user-defined aggregate. - AggregateNode.LongSum - Class in org.apache.calcite.interpreter
-
Implementation of
SUM
over BIGINT values as a user-defined aggregate. - AggregateNode.MaxBigDecimal - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the maximum ofBigDecimal
values as a user-defined aggregate. - AggregateNode.MaxBoolean - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the maximum ofboolean
values as a user-defined aggregate. - AggregateNode.MaxDouble - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the maximum ofdouble
andreal
values as a user-defined aggregate. - AggregateNode.MaxFloat - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the maximum offloat
values as a user-defined aggregate. - AggregateNode.MaxInt - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the maximum ofinteger
values as a user-defined aggregate. - AggregateNode.MaxLong - Class in org.apache.calcite.interpreter
-
Implementation of
MAX
function to calculate the maximum oflong
values as a user-defined aggregate. - AggregateNode.MinBigDecimal - Class in org.apache.calcite.interpreter
-
Implementation of
MIN
function to calculate the minimum ofBigDecimal
values as a user-defined aggregate. - AggregateNode.MinBoolean - Class in org.apache.calcite.interpreter
-
Implementation of
MIN
function to calculate the minimum ofboolean
values as a user-defined aggregate. - AggregateNode.MinDouble - Class in org.apache.calcite.interpreter
-
Implementation of
MIN
function to calculate the minimum ofdouble
andreal
values as a user-defined aggregate. - AggregateNode.MinFloat - Class in org.apache.calcite.interpreter
-
Implementation of
MIN
function to calculate the minimum offloat
values as a user-defined aggregate. - AggregateNode.MinInt - Class in org.apache.calcite.interpreter
-
Implementation of
MIN
function to calculate the minimum ofinteger
values as a user-defined aggregate. - AggregateNode.MinLong - Class in org.apache.calcite.interpreter
-
Implementation of
MIN
function to calculate the minimum oflong
values as a user-defined aggregate. - AggregateNode.NumericComparison<T> - Class in org.apache.calcite.interpreter
-
Common implementation of comparison aggregate methods over numeric values as a user-defined aggregate.
- AggregateProjectConstantToDummyJoinRule - Class in org.apache.calcite.rel.rules
- AggregateProjectConstantToDummyJoinRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateProjectMergeRule - Class in org.apache.calcite.rel.rules
- AggregateProjectMergeRule(Class<? extends Aggregate>, Class<? extends Project>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateProjectMergeRule
-
Deprecated.
- AggregateProjectMergeRule(AggregateProjectMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateProjectMergeRule
-
Creates an AggregateProjectMergeRule.
- AggregateProjectMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- aggregateProjectPullUpConstantsRule() - Method in interface org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule.Config
-
Instance of rule to pull up constants into aggregate.
- AggregateProjectPullUpConstantsRule - Class in org.apache.calcite.rel.rules
-
Planner rule that removes constant keys from an
Aggregate
. - AggregateProjectPullUpConstantsRule(Class<? extends Aggregate>, Class<? extends RelNode>, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.AggregateProjectPullUpConstantsRule
-
Deprecated.
- AggregateProjectPullUpConstantsRule(AggregateProjectPullUpConstantsRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateProjectPullUpConstantsRule
-
Creates an AggregateProjectPullUpConstantsRule.
- AggregateProjectPullUpConstantsRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateProjectStarTableRule - Class in org.apache.calcite.rel.rules
-
Variant of
AggregateStarTableRule
that accepts aProject
between theAggregate
and itsStarTable.StarTableScan
input. - AggregateProjectStarTableRule(AggregateProjectStarTableRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateProjectStarTableRule
-
Creates an AggregateProjectStarTableRule.
- AggregateProjectStarTableRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateReduceFunctionsRule - Class in org.apache.calcite.rel.rules
-
Planner rule that reduces aggregate functions in
Aggregate
s to simpler forms. - AggregateReduceFunctionsRule(Class<? extends Aggregate>, RelBuilderFactory, EnumSet<SqlKind>) - Constructor for class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Deprecated.
- AggregateReduceFunctionsRule(RelOptRuleOperand, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Deprecated.
- AggregateReduceFunctionsRule(AggregateReduceFunctionsRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Creates an AggregateReduceFunctionsRule.
- AggregateReduceFunctionsRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateRemoveRule - Class in org.apache.calcite.rel.rules
-
Planner rule that removes a
Aggregate
if it computes no aggregate functions (that is, it is implementingSELECT DISTINCT
), or all the aggregate functions are splittable, and the underlying relational expression is already distinct. - AggregateRemoveRule(Class<? extends Aggregate>) - Constructor for class org.apache.calcite.rel.rules.AggregateRemoveRule
-
Deprecated.
- AggregateRemoveRule(Class<? extends Aggregate>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateRemoveRule
-
Deprecated.
- AggregateRemoveRule(AggregateRemoveRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateRemoveRule
-
Creates an AggregateRemoveRule.
- AggregateRemoveRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateStarTableRule - Class in org.apache.calcite.rel.rules
-
Planner rule that matches an
Aggregate
on top of aStarTable.StarTableScan
. - AggregateStarTableRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.AggregateStarTableRule
-
Deprecated.
- AggregateStarTableRule(AggregateStarTableRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateStarTableRule
-
Creates an AggregateStarTableRule.
- AggregateStarTableRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateUnionAggregateRule - Class in org.apache.calcite.rel.rules
- AggregateUnionAggregateRule(Class<? extends Aggregate>, Class<? extends Union>, Class<? extends RelNode>, Class<? extends RelNode>, RelBuilderFactory, String) - Constructor for class org.apache.calcite.rel.rules.AggregateUnionAggregateRule
-
Deprecated.
- AggregateUnionAggregateRule(Class<? extends Aggregate>, RelFactories.AggregateFactory, Class<? extends Union>, RelFactories.SetOpFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateUnionAggregateRule
-
Deprecated.
- AggregateUnionAggregateRule(AggregateUnionAggregateRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateUnionAggregateRule
-
Creates an AggregateUnionAggregateRule.
- AggregateUnionAggregateRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregateUnionTransposeRule - Class in org.apache.calcite.rel.rules
- AggregateUnionTransposeRule(Class<? extends Aggregate>, Class<? extends Union>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateUnionTransposeRule
-
Deprecated.
- AggregateUnionTransposeRule(Class<? extends Aggregate>, RelFactories.AggregateFactory, Class<? extends Union>, RelFactories.SetOpFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateUnionTransposeRule
-
Deprecated.
- AggregateUnionTransposeRule(AggregateUnionTransposeRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateUnionTransposeRule
-
Creates an AggregateUnionTransposeRule.
- AggregateUnionTransposeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- aggregateUnique() - Method in interface org.apache.calcite.tools.RelBuilder.Config
-
Whether to create an Aggregate even if we know that the input is already unique; default false.
- AggregateValuesRule - Class in org.apache.calcite.rel.rules
- AggregateValuesRule(AggregateValuesRule.Config) - Constructor for class org.apache.calcite.rel.rules.AggregateValuesRule
-
Creates an AggregateValuesRule.
- AggregateValuesRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateValuesRule
-
Deprecated.
- AggregateValuesRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- AggregatingScope - Interface in org.apache.calcite.sql.validate
-
An extension to the
SqlValidatorScope
interface which indicates that the scope is aggregating. - AggregatingSelectScope - Class in org.apache.calcite.sql.validate
-
Scope for resolving identifiers within a SELECT statement that has a GROUP BY clause.
- AggregatingSelectScope.Resolved - Class in org.apache.calcite.sql.validate
-
Information about an aggregating scope that can only be determined after validation has occurred.
- aggregation() - Method in interface org.apache.calcite.adapter.enumerable.AggContext
-
Returns the aggregation being implemented.
- aggregation() - Method in class org.apache.calcite.adapter.enumerable.EnumerableAggregateBase.AggContextImpl
- AggResetContext - Interface in org.apache.calcite.adapter.enumerable
-
Information for a call to
AggImplementor.implementReset(AggContext, AggResetContext)
. - AggResetContextImpl - Class in org.apache.calcite.adapter.enumerable.impl
-
Implementation of
AggResetContext
. - AggResetContextImpl(BlockBuilder, List<Expression>) - Constructor for class org.apache.calcite.adapter.enumerable.impl.AggResetContextImpl
-
Creates aggregate reset context.
- AggResultContext - Interface in org.apache.calcite.adapter.enumerable
-
Information for a call to
AggImplementor.implementResult(AggContext, AggResultContext)
- AggResultContextImpl - Class in org.apache.calcite.adapter.enumerable.impl
-
Implementation of
AggResultContext
. - AggResultContextImpl(BlockBuilder, AggregateCall, List<Expression>, ParameterExpression, PhysType) - Constructor for class org.apache.calcite.adapter.enumerable.impl.AggResultContextImpl
-
Creates aggregate result context.
- aid - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Author
- algorithm - Variable in class org.apache.calcite.materialize.Lattice
- algorithm - Variable in class org.apache.calcite.model.JsonLattice
-
Whether to use an optimization algorithm to suggest and populate an initial set of tiles.
- algorithm(boolean) - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Sets the "algorithm" attribute (default false).
- algorithmMaxMillis - Variable in class org.apache.calcite.materialize.Lattice
- algorithmMaxMillis - Variable in class org.apache.calcite.model.JsonLattice
-
Maximum time (in milliseconds) to run the algorithm.
- algorithmMaxMillis(long) - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Sets the "algorithmMaxMillis" attribute (default -1).
- alias - Variable in class org.apache.calcite.materialize.Lattice.Column
-
Alias of the column, unique within the lattice.
- alias - Variable in class org.apache.calcite.materialize.LatticeNode
- alias - Variable in class org.apache.calcite.materialize.LatticeTable
- alias(String) - Method in interface org.apache.calcite.tools.RelBuilder.GroupKey
-
Assigns an alias to this group key.
- alias(RexNode, String) - Method in class org.apache.calcite.tools.RelBuilder
-
Returns an expression wrapped in an alias.
- alias(SqlNode) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
- alias(SqlNode, int) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Derives an alias for a node, and invents a mangled identifier if it cannot.
- ALIAS - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
An alias.
- aliasContext(Map<String, RelDataType>, boolean) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
- AliasContext(SqlDialect, Map<String, RelDataType>, boolean) - Constructor for class org.apache.calcite.rel.rel2sql.SqlImplementor.AliasContext
-
Creates an AliasContext; use
SqlImplementor.aliasContext(Map, boolean)
. - aliasListDegree(int, String, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- aliasListDuplicate(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- aliasMustBeSimpleIdentifier() - Method in interface org.apache.calcite.runtime.CalciteResource
- AliasNamespace - Class in org.apache.calcite.sql.validate
-
Namespace for an
AS t(c1, c2, ...)
clause. - AliasNamespace(SqlValidatorImpl, SqlCall, SqlNode) - Constructor for class org.apache.calcite.sql.validate.AliasNamespace
-
Creates an AliasNamespace.
- aliasSet - Variable in class org.apache.calcite.rel.rel2sql.SqlImplementor
- aliasValue(SqlNodeList) - Static method in class org.apache.calcite.sql.SqlUnpivot
-
Computes an alias.
- all - Variable in class org.apache.calcite.rel.core.RepeatUnion
-
Whether duplicates are considered.
- all - Variable in class org.apache.calcite.rel.core.SetOp
- all - Variable in class org.apache.calcite.rel.mutable.MutableSetOp
- all() - Static method in class org.apache.calcite.adapter.druid.Granularities
-
Returns a Granularity that causes all rows to be rolled up into one.
- all() - Method in class org.apache.calcite.util.PrecedenceClimbingParser
-
Returns a list of all tokens.
- all() - Method in interface org.apache.calcite.util.RangeSets.Consumer
- all() - Method in interface org.apache.calcite.util.RangeSets.Handler
- all(List<? extends E>, Predicate1<E>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns whether
predicate
is true for all elements oflist
. - all(List<? extends E>, Predicate1<E>) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether
predicate
is true for all elements oflist
. - all(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Determines whether all elements of a sequence satisfy a condition.
- all(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- all(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Determines whether all elements of a sequence satisfy a condition.
- all(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Determines whether all the elements of a sequence satisfy a condition.
- all(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Determines whether all the elements of a sequence satisfy a condition.
- all(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- all(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- all(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Determines whether all the elements of a sequence satisfy a condition.
- all(RexNode, SqlOperator, Function<RelBuilder, RelNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an ALL predicate.
- all(SqlKind) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Returns the operator for
ALL comparisonKind
. - ALL - Enum constant in enum org.apache.calcite.adapter.druid.Granularity.Type
- ALL - Enum constant in enum org.apache.calcite.adapter.enumerable.NullPolicy
-
Returns null if and only if all of the arguments are null; If all of the arguments are false return false otherwise true.
- ALL - Enum constant in enum org.apache.calcite.rel.type.RelDataTypeComparability
- ALL - Enum constant in enum org.apache.calcite.sql.ddl.SqlCreateTableLike.LikeOption
- ALL - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
A collection of operators that could be used in all libraries; does not include STANDARD and SPATIAL.
- ALL - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ALL
quantification operator. - ALL - Enum constant in enum org.apache.calcite.sql.SqlSelectKeyword
- ALL - Static variable in class org.apache.calcite.sql.SqlAccessType
- ALL_ATTRIBUTES - Enum constant in enum org.apache.calcite.sql.SqlExplainLevel
-
Display all attributes, including cost.
- ALL_EQ - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ALL_GE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ALL_GT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ALL_LE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ALL_LT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
< ALL
operator. - ALL_NE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- ALL_PIG_OPT_RULES - Static variable in class org.apache.calcite.adapter.pig.PigRules
- ALL_PIG_REL_FACTORIES - Static variable in class org.apache.calcite.adapter.pig.PigRelFactories
- ALL_PREDICATES - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ALL_ROWS - Enum constant in enum org.apache.calcite.sql.SqlMatchRecognize.RowsPerMatchOption
- ALL_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- allAssignable(boolean, Class[], Class[]) - Static method in class org.apache.calcite.linq4j.tree.Types
- allContain(Collection<ImmutableBitSet>, int) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Checks if all bit sets contain a particular bit.
- allCorrelateVariables - Variable in class org.apache.calcite.adapter.enumerable.EnumerableRelImplementor
- allLiterals(List<RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Returns whether every expression in a list is a literal.
- allMatch(BiPredicate<T, U>) - Method in interface org.apache.calcite.runtime.PairList
-
Returns whether the predicate is true for all pairs in this list.
- allMatch(IntPredicate) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns whether a given predicate evaluates to true for all bits in this set.
- allMethodsDeterministic(Class) - Method in class org.apache.calcite.linq4j.tree.DeterministicCodeOptimizer
-
Checks if all the methods in given class are deterministic (i.e.
- allNullable(List<RelDataType>) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether all of array of types are nullable.
- ALLOW_INFINITE_COST_CONVERTERS - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
Whether the optimizer will consider adding converters of infinite cost in order to convert a relational expression from one calling convention to another.
- ALLOW_SPATIAL_FUNCTIONS - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeSchemaFactory
- allowableDifferenceTypes() - Method in enum org.apache.calcite.sql.type.SqlTypeFamily
-
For this type family, returns the allow types of the difference between two values of this family.
- allowAliasUnnestItems() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowAliasUnnestItems() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether directly alias array items in UNNEST.
- allowAliasUnnestItems() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowAliasUnnestItems() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowBangEqual() - Method in interface org.apache.calcite.sql.parser.SqlParser.Config
-
Deprecated.
- allowCharLiteralAlias() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowCharLiteralAlias() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether this dialect allows character literals as column aliases.
- allowCharLiteralAlias() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowCharLiteralAlias() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowedRules - Variable in class org.apache.calcite.sql.type.CompositeOperandTypeChecker
- allowExplicitRowValueConstructor() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowExplicitRowValueConstructor() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow SQL syntax "
ROW(expr1, expr2, expr3)
". - allowExplicitRowValueConstructor() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowExplicitRowValueConstructor() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowExtend() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowExtend() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow mixing table columns with extended columns in
INSERT
(orUPSERT
). - allowExtend() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowExtend() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowExtendedTrim() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowExtendedTrim() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether TRIM should support more than one trim character.
- allowExtendedTrim() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowExtendedTrim() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowGeometry() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowGeometry() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow geo-spatial extensions, including the GEOMETRY type.
- allowGeometry() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowGeometry() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowHyphenInUnquotedTableName() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowHyphenInUnquotedTableName() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow hyphens in an unquoted table name.
- allowHyphenInUnquotedTableName() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowHyphenInUnquotedTableName() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowInfiniteCostConverters() - Method in interface org.apache.calcite.util.SaffronProperties
-
Deprecated.The boolean property "saffron.opt.allowInfiniteCostConverters" determines whether the optimizer will consider adding converters of infinite cost in order to convert a relational expression from one calling convention to another.
- allowLenientCoercion() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowLenientCoercion() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow lenient type coercions.
- allowLenientCoercion() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowLenientCoercion() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowNiladicParentheses() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowNiladicParentheses() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow parentheses to be specified in calls to niladic functions and procedures (that is, functions and procedures with no parameters).
- allowNiladicParentheses() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowNiladicParentheses() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowPartial(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets whether to allow partial width windows; default true.
- allowPluralTimeUnits() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowPluralTimeUnits() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether interval literals should allow plural time units such as "YEARS" and "DAYS" in interval literals.
- allowPluralTimeUnits() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowPluralTimeUnits() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowQualifyingCommonColumn() - Method in class org.apache.calcite.sql.validate.SqlAbstractConformance
- allowQualifyingCommonColumn() - Method in interface org.apache.calcite.sql.validate.SqlConformance
-
Whether to allow a qualified common column in a query that has a NATURAL join or a join with a USING clause.
- allowQualifyingCommonColumn() - Method in enum org.apache.calcite.sql.validate.SqlConformanceEnum
- allowQualifyingCommonColumn() - Method in class org.apache.calcite.sql.validate.SqlDelegatingConformance
- allowsAccess(SqlAccessEnum) - Method in class org.apache.calcite.sql.SqlAccessType
- allowsAs() - Method in class org.apache.calcite.sql.dialect.HiveSqlDialect
- allowsAs() - Method in class org.apache.calcite.sql.dialect.OracleSqlDialect
- allowsAs() - Method in class org.apache.calcite.sql.dialect.SparkSqlDialect
- allowsAs() - Method in class org.apache.calcite.sql.SqlDialect
- allowsFilter() - Method in class org.apache.calcite.sql.fun.SqlAbstractGroupFunction
- allowsFilter() - Method in class org.apache.calcite.sql.fun.SqlSingleValueAggFunction
- allowsFilter() - Method in class org.apache.calcite.sql.SqlAggFunction
-
Whether this aggregate function allows a
FILTER (WHERE ...)
clause. - allowsFraming() - Method in class org.apache.calcite.sql.fun.SqlLeadLagAggFunction
- allowsFraming() - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether this is a window function that allows framing (i.e.
- allowsFraming() - Method in class org.apache.calcite.sql.SqlRankFunction
- allowsIdentifier(String[], int[][]) - Static method in class org.apache.calcite.sql.parser.SqlParserUtil
-
Returns whether the reported ParseException tokenImage allows SQL identifier.
- allowsNoPrecNoScale() - Method in enum org.apache.calcite.sql.type.SqlTypeName
- allowsNullTreatment() - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
- allowsNullTreatment() - Method in class org.apache.calcite.sql.fun.SqlFirstLastValueAggFunction
- allowsNullTreatment() - Method in class org.apache.calcite.sql.fun.SqlLeadLagAggFunction
- allowsNullTreatment() - Method in class org.apache.calcite.sql.fun.SqlNthValueAggFunction
- allowsNullTreatment() - Method in class org.apache.calcite.sql.SqlAggFunction
-
Returns whether this aggregate function allows specifying null treatment (
RESPECT NULLS
orIGNORE NULLS
). - allowsPrec() - Method in enum org.apache.calcite.sql.type.SqlTypeName
- allowsPrecNoScale() - Method in enum org.apache.calcite.sql.type.SqlTypeName
- allowsPrecScale(boolean, boolean) - Method in enum org.apache.calcite.sql.type.SqlTypeName
-
Returns whether this type can be specified with a given combination of precision and scale.
- allowsScale() - Method in enum org.apache.calcite.sql.type.SqlTypeName
- allowsSeparator() - Method in class org.apache.calcite.sql.fun.SqlBasicAggFunction
-
Returns whether this aggregate function allows '
SEPARATOR string
' among its arguments. - AllPrivate() - Constructor for class org.apache.calcite.test.schemata.catchall.CatchallSchema.AllPrivate
- allPrivates - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- allRows - Variable in class org.apache.calcite.rel.core.Match
- allRows - Variable in class org.apache.calcite.rel.mutable.MutableMatch
- allSimple() - Method in class org.apache.calcite.plan.RelTraitSet
-
Returns whether there are any composite traits in this set.
- allStrong(List<RexNode>) - Static method in class org.apache.calcite.plan.Strong
-
Returns whether all expressions in a list are strong.
- allTypeInfo() - Method in class org.apache.calcite.jdbc.CalciteMetaImpl
- ALTER_INDEX - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ALTER INDEX
DDL statement. - ALTER_MATERIALIZED_VIEW - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ALTER MATERIALIZED VIEW
DDL statement. - ALTER_SEQUENCE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ALTER SEQUENCE
DDL statement. - ALTER_SESSION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ALTER SESSION
DDL statement. - ALTER_TABLE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ALTER TABLE
DDL statement. - ALTER_VIEW - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ALTER VIEW
DDL statement. - ALWAYS - Enum constant in enum org.apache.calcite.rex.RexDigestIncludeType
- alwaysUseParentheses() - Method in interface org.apache.calcite.sql.SqlWriterConfig
-
Returns whether expressions should always be included in parentheses.
- ambiguousSortOrderInJsonArrayAggFunc() - Method in interface org.apache.calcite.runtime.CalciteResource
- amend(String, String) - Method in class org.apache.calcite.test.DiffRepository
- analyze(RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil.InputFinder
-
Returns an input finder that has analyzed a given expression.
- analyze(RexNode) - Method in class org.apache.calcite.rel.rules.ReduceExpressionsRule.ReducibleExprLocator
- analyze(SqlValidatorUtil.GroupAnalyzer) - Method in class org.apache.calcite.sql.validate.AggregatingSelectScope
- analyze(SqlValidatorUtil.GroupAnalyzer) - Method in class org.apache.calcite.sql.validate.DelegatingScope
-
Analyzes expressions in this scope and populates a
GroupAnalyzer
. - analyzeCondition() - Method in class org.apache.calcite.rel.core.Join
-
Analyzes the join condition.
- analyzeGroupItem(SqlValidatorScope, SqlValidatorUtil.GroupAnalyzer, ImmutableList.Builder<ImmutableList<ImmutableBitSet>>, SqlNode) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtil
-
Analyzes an expression in a GROUP BY clause.
- analyzeSimpleEquiJoin(LogicalJoin, int[]) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- analyzeView(CalciteConnection, CalciteSchema, List<String>, String, List<String>, boolean) - Static method in class org.apache.calcite.schema.Schemas
-
Analyzes a view.
- analyzeView(CalcitePrepare.Context, String, boolean) - Method in interface org.apache.calcite.jdbc.CalcitePrepare
-
Analyzes a view.
- analyzeView(CalcitePrepare.Context, String, boolean) - Method in class org.apache.calcite.prepare.CalcitePrepareImpl
- AnalyzeViewResult(CalcitePrepareImpl, SqlValidator, String, SqlNode, RelDataType, RelRoot, Table, ImmutableList<String>, RexNode, ImmutableIntList, boolean) - Constructor for class org.apache.calcite.jdbc.CalcitePrepare.AnalyzeViewResult
- ANCHOR_END - Enum constant in enum org.apache.calcite.runtime.Pattern.Op
-
Anchor for end "$".
- ANCHOR_START - Enum constant in enum org.apache.calcite.runtime.Pattern.Op
-
Anchor for start "^".
- and(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an AND.
- and(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise AND operation.
- and(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise AND operation.
- and(HintPredicate...) - Static method in class org.apache.calcite.rel.hint.HintPredicates
-
Returns a composed hint predicate that represents a short-circuiting logical AND of an array of hint predicates
hintPredicates
. - and(RexNode...) - Method in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- and(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an AND.
- and(SqlOperandTypeChecker) - Method in interface org.apache.calcite.sql.type.SqlOperandTypeChecker
-
Composes this with another checker using AND.
- and(SqlOperandTypeChecker...) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a checker that passes if all of the rules pass.
- and(SqlSingleOperandTypeChecker) - Method in interface org.apache.calcite.sql.type.SqlSingleOperandTypeChecker
-
Composes this with another single-operand checker using AND.
- and(SqlSingleOperandTypeChecker...) - Static method in class org.apache.calcite.sql.type.OperandTypes
-
Creates a single-operand checker that passes if all of the rules pass.
- And - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise or logical AND operation, such as
a & b
in Java. - AND - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- AND - Enum constant in enum org.apache.calcite.rel.hint.CompositeHintPredicate.Composition
- AND - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Logical "AND" operator.
- AND - Enum constant in enum org.apache.calcite.sql.type.CompositeOperandTypeChecker.Composition
- AND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Logical
AND
operator. - AND_CHAIN - Enum constant in enum org.apache.calcite.sql.babel.postgresql.AndChain
- AND_NO_CHAIN - Enum constant in enum org.apache.calcite.sql.babel.postgresql.AndChain
- andAlso(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a conditional AND operation that evaluates the second operand only if the first operand evaluates to true.
- andAlso(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a conditional AND operation that evaluates the second operand only if the first operand is resolved to true.
- AndAlso - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A conditional AND operation that evaluates the second operand only if the first operand evaluates to true.
- andAssign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise AND assignment operation.
- andAssign(Expression, Expression, Method) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise AND assignment operation.
- andAssign(Expression, Expression, Method, LambdaExpression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents a bitwise AND assignment operation.
- AndAssign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A bitwise or logical AND compound assignment operation, such as (a &= b) in C#.
- AndChain - Enum in org.apache.calcite.sql.babel.postgresql
-
Defines the keywords that can occur immediately after the "ROLLBACK" or "COMMIT" keywords.
- andExpressions(SqlNode, SqlNode) - Static method in class org.apache.calcite.sql.SqlUtil
-
Returns the AND of two expressions.
- andJoinFilters(RexBuilder, RexNode, RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil
-
Ands two sets of join filters together, either of which can be null.
- andNot(RexBuilder, RexNode, Iterable<? extends RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Creates the expression
e1 AND NOT notTerm1 AND NOT notTerm2 ...
. - andNot(RexBuilder, RexNode, RexNode...) - Static method in class org.apache.calcite.rex.RexUtil
-
Creates the expression
e1 AND NOT notTerm1 AND NOT notTerm2 ...
. - andThen(Consumer<R>) - Method in interface org.apache.calcite.util.RangeSets.Handler
-
Creates a Consumer that sends output to a given sink.
- andThen(UnaryOperator<SqlOperatorBinding>, SqlReturnTypeInference) - Static method in class org.apache.calcite.sql.type.ReturnTypes
-
Returns a return-type inference that first transforms a binding and then applies an inference.
- andThen(UnaryOperator<X>, UnaryOperator<X>) - Static method in class org.apache.calcite.util.Util
-
Returns an operator that applies
op1
and thenop2
. - andThen(SqlTypeTransform) - Method in interface org.apache.calcite.sql.type.SqlReturnTypeInference
-
Returns a return-type inference that applies this rule then a transform.
- ANON_FIELDS - Static variable in class org.apache.calcite.rel.core.Project.Flags
-
Deprecated.
- ANONYMOUS_ROW - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
Similar to
SqlStdOperatorTable.ROW
, but does not print "ROW". - ANONYMOUS_ROW_NO_PARENTHESES - Static variable in class org.apache.calcite.sql.fun.SqlInternalOperators
-
Similar to
SqlInternalOperators.ANONYMOUS_ROW
, but does not print "ROW" or parentheses. - AnotherTableMacroFunctionWithNamedParameters() - Constructor for class org.apache.calcite.util.Smalls.AnotherTableMacroFunctionWithNamedParameters
- AnsiSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for an unknown ANSI compatible database. - AnsiSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.AnsiSqlDialect
-
Creates an AnsiSqlDialect.
- ANTI - Enum constant in enum org.apache.calcite.linq4j.JoinType
-
Anti-join (also known as Anti-semi-join).
- ANTI - Enum constant in enum org.apache.calcite.rel.core.JoinRelType
-
Anti-join (also known as Anti-semi-join).
- ANTI_JOIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- antiJoin(Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an anti-join.
- antiJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns elements of
outer
for which there is NOT a member ofinner
with a matching key. - antiJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, EqualityComparer<TKey>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- antiJoin(Enumerable<TSource>, Enumerable<TInner>, Function1<TSource, TKey>, Function1<TInner, TKey>, EqualityComparer<TKey>, Predicate2<TSource, TInner>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- antiJoin(RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an anti-join.
- any() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- any() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Determines whether a sequence contains any elements.
- any() - Static method in class org.apache.calcite.plan.RelOptRule
-
Deprecated.
- any() - Static method in class org.apache.calcite.sql.type.SqlOperandCountRanges
- any(Class<? extends MutableRel>) - Static method in class org.apache.calcite.plan.SubstitutionVisitor.AbstractUnifyRule
-
Creates an operand that doesn't check inputs.
- any(Enumerable) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Determines whether a sequence contains any elements.
- any(Enumerable<TSource>, Predicate1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Determines whether any element of a sequence satisfies a condition.
- any(Predicate1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- any(Predicate1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Determines whether any element of a sequence satisfies a condition.
- any(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Determines whether a sequence contains any elements.
- any(Queryable<T>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Determines whether a sequence contains any elements.
- any(Queryable<T>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- any(Queryable<T>, FunctionExpression<Predicate1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Determines whether any element of a sequence satisfies a condition.
- any(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Determines whether any element of a sequence satisfies a condition.
- any(Queryable<T>, FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- any(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- any(FunctionExpression<Predicate1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Determines whether any element of a sequence satisfies a condition.
- ANY - Enum constant in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Consumer has no preferred representation.
- ANY - Enum constant in enum org.apache.calcite.adapter.enumerable.NullPolicy
-
If any of the arguments are null, return null.
- ANY - Enum constant in enum org.apache.calcite.plan.RelOptRuleOperandChildPolicy
-
Signifies that operand can have any number of children.
- ANY - Enum constant in enum org.apache.calcite.plan.Strong.Policy
-
This kind of expression is null if and only if at least one of its arguments is null.
- ANY - Enum constant in enum org.apache.calcite.rel.RelDistribution.Type
-
Not a valid distribution, but indicates that a consumer will accept any distribution.
- ANY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- ANY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- ANY - Static variable in class org.apache.calcite.rel.RelDistributions
- ANY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_ANY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_COMPARABLE - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy used by
ARG_MIN(value, comp)
and similar functions, where the first operand can have any type and the second must be comparable. - ANY_IGNORE - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_ITEM - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ANY_NULLABLE - Static variable in class org.apache.calcite.sql.type.InferTypes
-
Operand type-inference strategy where an unknown operand type is assumed to be nullable ANY.
- ANY_NUMERIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_NUMERIC_ANY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_PARAMETER_CHECKER - Static variable in class org.apache.calcite.sql.test.SqlTests
-
Checker that allows any number or type of parameters.
- ANY_RESULT_CHECKER - Static variable in class org.apache.calcite.sql.test.SqlTests
-
Checker that allows any result.
- ANY_STRING_OPTIONAL_STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_STRING_STRING - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ANY_TYPE_CHECKER - Static variable in class org.apache.calcite.sql.test.SqlTests
-
Checker which allows any type.
- ANY_VALUE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ANY_VALUE
aggregate function. - ANY_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
ANY_VALUE
aggregate function. - anyContain(Iterable<? extends RexNode>) - Method in class org.apache.calcite.rex.RexUtil.RexFinder
-
Returns whether any of the given expressions contain what this RexFinder seeks.
- anyInputs() - Method in interface org.apache.calcite.plan.RelRule.OperandDetailBuilder
-
Indicates that this operand takes any number or type of inputs.
- anyMatch(BiPredicate<T, U>) - Method in interface org.apache.calcite.runtime.PairList
-
Returns whether the predicate is true for at least one pair in this list.
- anyMatch(IntPredicate) - Method in class org.apache.calcite.util.ImmutableBitSet
-
Returns whether a given predicate evaluates to true for any bit in this set.
- append(char) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Appends a character, without any quoting.
- append(int) - Method in class org.apache.calcite.util.ImmutableIntList
-
Returns a copy of this list with one element added.
- append(long) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Appends a number, per
StringBuilder.append(long)
. - append(ImmutableList<E>, E) - Static method in class org.apache.calcite.runtime.FlatLists
-
Returns a list that consists of a given list plus an element, guaranteed to be an
ImmutableList
. - append(Integer) - Method in class org.apache.calcite.util.ImmutableIntList
- append(String) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Appends a string, without any quoting.
- append(StringBuilder, int, Object) - Method in class org.apache.calcite.util.JsonBuilder
-
Appends a JSON object to a string builder.
- append(String, BlockStatement) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Appends a block to a list of statements and returns an expression (possibly a variable) that represents the result of the newly added block.
- append(String, BlockStatement, boolean) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Appends an expression to a list of statements, optionally optimizing it to a variable if it is used more than once.
- append(String, Expression) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Appends an expression to a list of statements, and returns an expression (possibly a variable) that represents the result of the newly added block.
- append(String, Expression, boolean) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Appends an expression to a list of statements, optionally optimizing if the expression is used more than once.
- append(List<E>, E) - Static method in class org.apache.calcite.runtime.FlatLists
-
Returns a list that consists of a given list plus an element.
- append(Map<K, V>, K, V) - Static method in class org.apache.calcite.runtime.FlatLists
-
Returns a map that consists of a given map plus an (key, value), guaranteed to be an
ImmutableMap
. - append(Expression) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
- append(SqlString) - Method in class org.apache.calcite.sql.util.SqlBuilder
-
Appends a hygienic SQL string.
- append(Mappings.TargetMapping, Mappings.TargetMapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Creates a mapping by appending two mappings.
- append(Source) - Method in interface org.apache.calcite.util.Source
-
Returns a source whose path concatenates this with a child.
- append(T) - Method in interface org.apache.calcite.linq4j.tree.Expressions.FluentList
- append(T) - Method in class org.apache.calcite.runtime.FlatLists.AbstractFlatList
-
Returns a list that consists of a this list's elements plus a given element.
- append(T) - Method in class org.apache.calcite.runtime.FlatLists.Flat1List
- append(T) - Method in class org.apache.calcite.runtime.FlatLists.Flat2List
- append(T) - Method in class org.apache.calcite.runtime.FlatLists.Flat3List
- append(T) - Method in class org.apache.calcite.runtime.FlatLists.Flat4List
- append(T) - Method in class org.apache.calcite.runtime.FlatLists.Flat5List
- append(T) - Method in class org.apache.calcite.runtime.FlatLists.Flat6List
- appendAll(Iterable<Integer>) - Method in class org.apache.calcite.util.ImmutableIntList
-
Returns a copy of this list with all of the given integers added.
- appendAll(Iterable<T>) - Method in interface org.apache.calcite.linq4j.tree.Expressions.FluentList
- appendAll(T...) - Method in interface org.apache.calcite.linq4j.tree.Expressions.FluentList
- appendIf(boolean, T) - Method in interface org.apache.calcite.linq4j.tree.Expressions.FluentList
- appendIfNotNull(T) - Method in interface org.apache.calcite.linq4j.tree.Expressions.FluentList
- appendIfNotNull(String, Expression) - Method in class org.apache.calcite.linq4j.tree.BlockBuilder
-
Appends an expression to a list of statements if it is not null, and returns the expression.
- appendOperands(StringBuilder) - Method in class org.apache.calcite.rex.RexCall
-
Appends call operands without parenthesis.
- appendSearchString(String, SplunkTableScan, LogicalProject, LogicalProject, RelDataType, RelDataType) - Method in class org.apache.calcite.adapter.splunk.SplunkPushDownRule
-
Appends a search string.
- appendURLEncodedArgs(StringBuilder, CharSequence...) - Static method in class org.apache.calcite.runtime.HttpUtils
- appendURLEncodedArgs(StringBuilder, Map<String, String>) - Static method in class org.apache.calcite.runtime.HttpUtils
- apply() - Method in interface org.apache.calcite.linq4j.function.Function0
- apply(T) - Method in class org.apache.calcite.runtime.PredicateImpl
-
Deprecated.
- apply(String, int, int) - Method in interface org.apache.calcite.sql.validate.SqlValidatorUtil.Suggester
- apply(Class<? extends RelNode>) - Method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
-
Deprecated.
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.plan.volcano.VolcanoRelMetadataProvider
-
Deprecated.
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.rel.metadata.CachingRelMetadataProvider
-
Deprecated.
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.rel.metadata.ChainedRelMetadataProvider
-
Deprecated.
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.rel.metadata.JaninoRelMetadataProvider
-
Deprecated.
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in class org.apache.calcite.rel.metadata.ReflectiveRelMetadataProvider
-
Deprecated.
- apply(Class<? extends RelNode>, Class<? extends M>) - Method in interface org.apache.calcite.rel.metadata.RelMetadataProvider
-
Deprecated.Use
RelMetadataQuery
. - apply(Connection) - Method in interface org.apache.calcite.test.CalciteAssert.ConnectionPostProcessor
- apply(List<T>) - Method in class org.apache.calcite.rex.RexShuttle
-
Applies this shuttle to each expression in a list and returns the resulting list.
- apply(List<?>) - Method in class org.apache.calcite.util.Smalls.SimpleTableMacro
- apply(List<? extends Object>) - Method in class org.apache.calcite.schema.impl.MaterializedViewTable.MaterializedViewTableMacro
- apply(List<? extends Object>) - Method in class org.apache.calcite.schema.impl.TableMacroImpl
-
Applies arguments to yield a table.
- apply(List<? extends Object>) - Method in class org.apache.calcite.schema.impl.ViewTableMacro
- apply(List<? extends Object>) - Method in interface org.apache.calcite.schema.TableMacro
-
Applies arguments to yield a table.
- apply(List<RelHint>, RelNode) - Method in class org.apache.calcite.rel.hint.HintStrategyTable
-
Applies this
HintStrategyTable
hint strategies to the given relational expression and thehints
. - apply(List<T1>, Function1<T1, R>) - Static method in class org.apache.calcite.linq4j.function.Functions
-
Creates a copy of a list, applying a function to each element.
- apply(RelOptCluster, RelOptSchema, SchemaPlus) - Method in interface org.apache.calcite.tools.Frameworks.PlannerAction
- apply(RelOptCluster, RelOptSchema, SchemaPlus, CalciteServerStatement) - Method in interface org.apache.calcite.tools.Frameworks.BasePrepareAction
- apply(RelOptRuleCall, Project, Aggregate, StarTable.StarTableScan) - Method in class org.apache.calcite.rel.rules.AggregateStarTableRule
- apply(RelOptRuleCall, Aggregate, Project) - Static method in class org.apache.calcite.rel.rules.AggregateProjectMergeRule
- apply(RelOptRuleCall, Filter, TableScan) - Method in class org.apache.calcite.rel.rules.FilterTableScanRule
- apply(RelOptRuleCall, Filter, TableScan) - Method in class org.apache.calcite.rel.rules.MaterializedViewFilterScanRule
- apply(RelOptRuleCall, Project, TableScan) - Method in class org.apache.calcite.rel.rules.ProjectTableScanRule
- apply(RelOptRuleCall, LogicalProject, LogicalFilter, LogicalValues) - Method in class org.apache.calcite.rel.rules.ValuesReduceRule
-
Does the work.
- apply(SubstitutionVisitor.UnifyRuleCall) - Method in class org.apache.calcite.plan.SubstitutionVisitor.UnifyRule
-
Applies this rule to a particular node in a query.
- apply(Join, JoinRelType, RexNode) - Method in interface org.apache.calcite.rel.rules.FilterJoinRule.Predicate
- apply(RelHint, RelNode) - Method in class org.apache.calcite.rel.hint.CompositeHintPredicate
- apply(RelHint, RelNode) - Method in interface org.apache.calcite.rel.hint.HintPredicate
-
Decides if the given
hint
can be applied to the relational expressionrel
. - apply(RelHint, RelNode) - Method in class org.apache.calcite.rel.hint.NodeTypeHintPredicate
- apply(RelDataTypeField) - Method in class org.apache.calcite.rel.type.RelDataTypeField.ToFieldIndex
-
Deprecated.
- apply(RelDataTypeField) - Method in class org.apache.calcite.rel.type.RelDataTypeField.ToFieldName
-
Deprecated.
- apply(RexNode) - Method in class org.apache.calcite.rex.RexShuttle
-
Applies this shuttle to an expression, or returns null if the expression is null.
- apply(RexSubQuery, Set<CorrelationId>, RelOptUtil.Logic, RelBuilder, int, int, int) - Method in class org.apache.calcite.rel.rules.SubQueryRemoveRule
- apply(RexVisitor<Void>, List<? extends RexNode>, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a visitor to a list of expressions and, if specified, a single expression.
- apply(RexVisitor<Void>, RexNode[], RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a visitor to an array of expressions and, if specified, a single expression.
- apply(RexVisitor<T>, T[]) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a shuttle to an array of expressions.
- apply(StringAndPos, SqlValidator, SqlNode) - Method in interface org.apache.calcite.sql.test.SqlTester.ValidatedNodeFunction
- apply(Mapping, BitSet) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Applies a mapping to a BitSet.
- apply(Mapping, List<T>) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Applies a mapping to a list.
- apply(Mapping, ImmutableBitSet) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Applies a mapping to an
ImmutableBitSet
. - apply(Mappings.TargetMapping) - Method in interface org.apache.calcite.plan.RelTrait
-
Applies a mapping to this trait.
- apply(Mappings.TargetMapping) - Method in class org.apache.calcite.plan.RelTraitSet
-
Applies a mapping to this traitSet.
- apply(Mappings.TargetMapping) - Method in class org.apache.calcite.rel.RelCollationImpl
-
Applies mapping to a given collation.
- apply(Mappings.TargetMapping) - Method in interface org.apache.calcite.rel.RelDistribution
-
Applies mapping to this distribution trait.
- apply(Mappings.TargetMapping, int) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Applies a mapping to an optional integer, returning an optional result.
- apply(Mappings.TargetMapping, Iterable<? extends RexNode>) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a mapping to an iterable over expressions.
- apply(Mappings.TargetMapping, List<RelCollation>) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a mapping to a collation list.
- apply(Mappings.TargetMapping, RelCollation) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a mapping to a collation.
- apply(Mappings.TargetMapping, RelFieldCollation) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a mapping to a field collation.
- apply(Mappings.TargetMapping, RexNode) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a mapping to an expression.
- apply(PrecedenceClimbingParser, PrecedenceClimbingParser.SpecialOp) - Method in interface org.apache.calcite.util.PrecedenceClimbingParser.Special
-
Given an occurrence of this operator, identifies the range of tokens to be collapsed into a call of this operator, and the arguments to that call.
- apply(T0) - Method in interface org.apache.calcite.linq4j.function.DoubleFunction1
- apply(T0) - Method in interface org.apache.calcite.linq4j.function.FloatFunction1
- apply(T0) - Method in interface org.apache.calcite.linq4j.function.Function1
- apply(T0) - Method in interface org.apache.calcite.linq4j.function.IntegerFunction1
- apply(T0) - Method in interface org.apache.calcite.linq4j.function.LongFunction1
- apply(T0) - Method in interface org.apache.calcite.linq4j.function.Predicate1
- apply(T0, T1) - Method in interface org.apache.calcite.linq4j.function.Function2
- apply(T0, T1) - Method in interface org.apache.calcite.linq4j.function.Predicate2
- apply2(Mapping, Iterable<ImmutableBitSet>) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Applies a mapping to a collection of
ImmutableBitSet
s. - apply2(Mapping, List<Integer>) - Static method in class org.apache.calcite.util.mapping.Mappings
- apply3(Mapping, List<T>) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Creates a view of a list, permuting according to a mapping.
- applyFields(Mappings.TargetMapping, List<RelFieldCollation>) - Static method in class org.apache.calcite.rex.RexUtil
-
Applies a mapping to a list of field collations.
- applyNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- applyResultSelector(Function2<K, Enumerable<V>, TResult>) - Method in interface org.apache.calcite.linq4j.Lookup
-
Applies a transform function to each key and its associated values and returns the results.
- applySettings(Socket) - Method in class org.apache.calcite.runtime.SocketFactoryImpl
-
Applies the current settings to the given socket.
- applyTimeExtract(String, String, TimeZone) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- applyTimestampCeil(String, String, String, TimeZone) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- applyTimestampFloor(String, String, String, TimeZone) - Static method in class org.apache.calcite.adapter.druid.DruidExpressions
- APPROX_COUNT_DISTINCT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
APPROX_COUNT_DISTINCT
aggregate function. - APPROX_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- approximate(boolean) - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
-
Returns a copy of this AggCall that may return approximate results if
approximate
is true. - APPROXIMATE_DECIMAL - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether approximate results from aggregate functions on DECIMAL types are acceptable.
- APPROXIMATE_DISTINCT_COUNT - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether approximate results from
COUNT(DISTINCT ...)
aggregate functions are acceptable. - APPROXIMATE_NUMERIC - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- APPROXIMATE_TOP_N - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether approximate results from "Top N" queries (
ORDER BY aggFun DESC LIMIT n
) are acceptable. - approximateDecimal() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.APPROXIMATE_DECIMAL
. - approximateDecimal() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- approximateDistinctCount() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.APPROXIMATE_DISTINCT_COUNT
. - approximateDistinctCount() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- approximateTopN() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.APPROXIMATE_TOP_N
. - approximateTopN() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- ARBITRARY - Enum constant in enum org.apache.calcite.plan.hep.HepMatchOrder
-
Match in arbitrary order.
- ARCHIVE - Enum constant in enum org.apache.calcite.sql.ddl.SqlDdlNodes.FileType
- areCharacterSetsMismatched(RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Determines whether two types both have different character sets.
- areColumnsDefinitelyUnique(RelMetadataQuery, RelNode, List<RexInputRef>) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
- areColumnsDefinitelyUnique(RelMetadataQuery, RelNode, ImmutableBitSet) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Returns true if the columns represented in a bit mask are definitely known to form a unique column set.
- areColumnsDefinitelyUniqueWhenNullsFiltered(RelMetadataQuery, RelNode, List<RexInputRef>) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
- areColumnsDefinitelyUniqueWhenNullsFiltered(RelMetadataQuery, RelNode, ImmutableBitSet) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
-
Returns true if the columns represented in a bit mask are definitely known to form a unique column set, when nulls have been filtered from the columns.
- areColumnsUnique(RelSubset, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Converter, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Aggregate, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Calc, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Correlate, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Exchange, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Filter, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Intersect, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Join, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Minus, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Project, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(SetOp, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Sort, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(TableModify, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(TableScan, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(Values, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
- areColumnsUnique(RelMetadataQuery, RelNode, List<RexInputRef>) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
- areColumnsUnique(RelNode, RelMetadataQuery, ImmutableBitSet, boolean) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ColumnUniqueness.Handler
- areColumnsUnique(RelNode, RelMetadataQuery, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMdColumnUniqueness
-
Catch-all implementation for
BuiltInMetadata.ColumnUniqueness.areColumnsUnique(ImmutableBitSet, boolean)
, invoked using reflection, for any relational expression not handled by a more specific method. - areColumnsUnique(RelNode, ImmutableBitSet) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.ColumnUniqueness.areColumnsUnique(ImmutableBitSet, boolean)
statistic. - areColumnsUnique(RelNode, ImmutableBitSet, boolean) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns the
BuiltInMetadata.ColumnUniqueness.areColumnsUnique(ImmutableBitSet, boolean)
statistic. - areColumnsUnique(ImmutableBitSet, boolean) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.ColumnUniqueness
-
Determines whether a specified set of columns from a specified relational expression are unique.
- areColumnsUniqueWhenNullsFiltered(RelMetadataQuery, RelNode, List<RexInputRef>) - Static method in class org.apache.calcite.rel.metadata.RelMdUtil
- areEquivalent(E, E) - Method in class org.apache.calcite.util.EquivalenceSet
-
Returns whether two elements are in the same equivalence class.
- areRowsUnique(RelNode) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns whether the rows of a given relational expression are distinct.
- areRowsUnique(RelNode, boolean) - Method in class org.apache.calcite.rel.metadata.RelMetadataQuery
-
Returns whether the rows of a given relational expression are distinct, optionally ignoring NULL values.
- areRowTypesEqual(RelDataType, RelDataType, boolean) - Static method in class org.apache.calcite.plan.RelOptUtil
- areSameFamily(Iterable<RelDataType>) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Returns whether all types in a collection have the same family, as determined by
SqlTypeUtil.isSameFamily(RelDataType, RelDataType)
. - ARG_MAX - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ARG_MAX
aggregate function. - ARG_MAX - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
ARG_MAX
aggregate function. - ARG_MIN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ARG_MIN
aggregate function. - ARG_MIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
ARG_MIN
aggregate function. - ARG0 - Enum constant in enum org.apache.calcite.adapter.enumerable.NullPolicy
-
If the first argument is null, return null.
- ARG0 - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of the operand #0 (0-based).
- ARG0_EXCEPT_DATE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that returns the type of the first operand, unless it is a DATE, in which case the return type is TIMESTAMP.
- ARG0_EXCEPT_DATE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.ARG0_EXCEPT_DATE
but returns with nullability if any of the operands is nullable by usingSqlTypeTransforms.TO_NULLABLE
. - ARG0_EXCEPT_INTEGER - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy that returns the type of the first operand, unless it is an integer type, in which case the return type is DOUBLE.
- ARG0_EXCEPT_INTEGER_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Same as
ReturnTypes.ARG0_EXCEPT_INTEGER
but returns with nullability if any of the operands is nullable by usingSqlTypeTransforms.TO_NULLABLE
. - ARG0_FORCE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of the operand #0 (0-based), with nulls always allowed.
- ARG0_INTERVAL - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- ARG0_INTERVAL_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- ARG0_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of the operand #0 (0-based).
- ARG0_NULLABLE - Static variable in class org.apache.calcite.sql.type.SqlTypeTransforms
-
Parameter type-inference transform strategy where a derived type is transformed into the same type, but nullable if and only if the type of a call's operand #0 (0-based) is nullable.
- ARG0_NULLABLE_IF_ARG0_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of the operand #0 (0-based).
- ARG0_NULLABLE_IF_EMPTY - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of the operand #0 (0-based), and nullable if the call occurs within a "GROUP BY ()" query.
- ARG0_NULLABLE_VARYING - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is VARYING the type of the first argument.
- ARG0_OR_EXACT_NO_SCALE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is
ReturnTypes.DECIMAL_SCALE0
with a fallback toReturnTypes.ARG0
This rule is used for floor, ceiling. - ARG0_TABLE_FUNCTION_WINDOWING - Static variable in class org.apache.calcite.sql.SqlWindowTableFunction
-
Type-inference strategy whereby the row type of a table function call is a ROW, which is combined from the row type of operand #0 (which is a TABLE) and two additional fields.
- ARG1 - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of the operand #1 (0-based).
- ARG1_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of the operand #1 (0-based).
- ARG2 - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of operand #2 (0-based).
- ARG2_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is the type of operand #2 (0-based).
- argBitSet() - Method in class org.apache.calcite.materialize.Lattice.Measure
-
Returns the set of distinct argument ordinals.
- ArgHandlerImpl() - Constructor for class org.apache.calcite.sql.util.SqlBasicVisitor.ArgHandlerImpl
- argOrdinals() - Method in class org.apache.calcite.materialize.Lattice.Measure
-
Returns a list of argument ordinals.
- args - Variable in class org.apache.calcite.materialize.Lattice.Measure
- args - Variable in class org.apache.calcite.model.JsonMeasure
-
Arguments to the measure.
- args - Variable in class org.apache.calcite.util.javac.JaninoCompiler
- args - Variable in class org.apache.calcite.util.PrecedenceClimbingParser.Call
- argTypes - Variable in class org.apache.calcite.sql.fun.SqlMinMaxAggFunction
-
Deprecated.
- ARGUMENT_ASSIGNMENT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Argument assignment operator,
=>
. - ARGUMENT_ASSIGNMENT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
ARGUMENT_ASSIGNMENT
operator (=<
) assigns an argument to a function call to a particular named parameter. - argumentMustBeBooleanLiteral(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- argumentMustBeLiteral(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- argumentMustBeMeasure(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- argumentMustBeNumericLiteralInRange(String, int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- argumentMustBePositiveInteger(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.fun.SqlCursorConstructor
- argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.fun.SqlInOperator
- argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.fun.SqlMultisetQueryConstructor
- argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.SqlOperator
-
Returns whether the
ordinal
th argument to this operator must be scalar (as opposed to a query). - argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.SqlSelectOperator
- argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.SqlSetSemanticsTableOperator
- argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.SqlUnnestOperator
- argumentMustBeScalar(int) - Method in class org.apache.calcite.sql.SqlWindowTableFunction
-
Returns whether the
ordinal
th argument to this operator must be scalar (as opposed to a query). - argumentMustBeScalar(int) - Method in class org.apache.calcite.test.MockSqlOperatorTable.InvalidTableFunction
- argumentMustBeScalar(int) - Method in class org.apache.calcite.test.MockSqlOperatorTable.ScoreTableFunction
- argumentMustBeScalar(int) - Method in class org.apache.calcite.test.MockSqlOperatorTable.SimilarlityTableFunction
- argumentMustBeScalar(int) - Method in class org.apache.calcite.test.MockSqlOperatorTable.TopNTableFunction
- argumentMustBeValidPrecision(String, int, int) - Method in interface org.apache.calcite.runtime.CalciteResource
- argumentMustHaveScaleZero(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- argumentMustNotBeNull(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- arguments - Variable in class org.apache.calcite.linq4j.tree.NewExpression
- arguments() - Method in interface org.apache.calcite.adapter.enumerable.AggAddContext
-
Returns Linq4j form of arguments.
- arguments() - Method in class org.apache.calcite.adapter.enumerable.impl.AggAddContextImpl
- arguments() - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggAddContextImpl
- arguments(Expression) - Method in class org.apache.calcite.adapter.enumerable.impl.WinAggResultContextImpl
- arguments(Expression) - Method in interface org.apache.calcite.adapter.enumerable.WinAggResultContext
-
Returns Linq4j form of arguments.
- array - Variable in class org.apache.calcite.linq4j.tree.IndexExpression
- array(Object...) - Static method in class org.apache.calcite.runtime.SqlFunctions
- array(RelNode) - Static method in class org.apache.calcite.rex.RexSubQuery
-
Creates an ARRAY sub-query.
- Array - Annotation Type in org.apache.calcite.adapter.java
-
Annotation that indicates that a field is an array type.
- ARRAY - Enum constant in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Records must be represented as arrays.
- ARRAY - Enum constant in enum org.apache.calcite.adapter.enumerable.JavaRowFormat
- ARRAY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- ARRAY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- ARRAY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY(exp, ...)" function (Spark); compare with the standard array value constructor, "ARRAY [exp, ...]".
- ARRAY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_AGG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ARRAY_AGG
aggregate function. - ARRAY_AGG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_AGG(value [ ORDER BY ...])" aggregate function, in BigQuery and PostgreSQL, gathers values into arrays.
- ARRAY_APPEND - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_APPEND
function (Spark semantics). - ARRAY_APPEND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_APPEND - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_APPEND(array, element)" function.
- ARRAY_ARRAY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_BOOLEAN_LITERAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where the first operand must be array and the second operand must be a boolean non-NULL literal.
- ARRAY_COMPACT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_COMPACT
function (Spark semantics). - ARRAY_COMPACT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_COMPACT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_COMPACT(array)" function.
- ARRAY_COMPARER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_CONCAT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_CONCAT
function (BigQuery semantics). - ARRAY_CONCAT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_CONCAT(array [, array]*)" function.
- ARRAY_CONCAT_AGG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
ARRAY_CONCAT_AGG
aggregate function. - ARRAY_CONCAT_AGG - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_CONCAT_AGG(value [ ORDER BY ...])" aggregate function, in BigQuery and PostgreSQL, concatenates array values into arrays.
- ARRAY_CONTAINS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_CONTAINS
function (Spark semantics). - ARRAY_CONTAINS - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_CONTAINS(array, element)" function.
- ARRAY_DISTINCT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_DISTINCT
function (Spark semantics). - ARRAY_DISTINCT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_DISTINCT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_DISTINCT(array)" function.
- ARRAY_ELEMENT - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_EXCEPT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_EXCEPT
function (Spark semantics). - ARRAY_EXCEPT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_EXCEPT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_EXCEPT(array1, array2)" function.
- ARRAY_INSERT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_INSERT
function (Spark semantics). - ARRAY_INSERT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_INSERT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_INSERT(array, pos, val)" function (Spark).
- ARRAY_INSERT - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_INTERSECT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_INTERSECT
function (Spark semantics). - ARRAY_INTERSECT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_INTERSECT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_INTERSECT(array1, array2)" function.
- ARRAY_ITEM - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_JOIN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_JOIN
function (Spark semantics). - ARRAY_JOIN - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_JOIN(array, delimiter [, nullText ])" function.
- ARRAY_LENGTH - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_LENGTH
function (Spark semantics). - ARRAY_LENGTH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_LENGTH(array)" function.
- ARRAY_MAX - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_MAX
function (Spark semantics). - ARRAY_MAX - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_MAX - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_MAX(array)" function.
- ARRAY_MIN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_MIN
function (Spark semantics). - ARRAY_MIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_MIN - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_MAX(array)" function.
- ARRAY_NICE - Enum constant in enum org.apache.calcite.adapter.enumerable.EnumerableRel.Prefer
-
Consumer would prefer that records are represented as arrays, but can accommodate records represented as objects.
- ARRAY_OF_INTEGER - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_OR_MAP - Static variable in class org.apache.calcite.sql.type.OperandTypes
- ARRAY_POSITION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_POSITION
function (Spark semantics). - ARRAY_POSITION - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_POSITION - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_POSITION(array, element)" function.
- ARRAY_PREPEND - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_PREPEND
function (Spark semantics). - ARRAY_PREPEND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_PREPEND - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_PREPEND(array, element)" function.
- ARRAY_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The ARRAY Query Constructor.
- ARRAY_QUERY_CONSTRUCTOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Array Query Constructor, e.g.
- ARRAY_REMOVE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_REMOVE
function (Spark semantics). - ARRAY_REMOVE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_REMOVE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_REMOVE(array, element)" function.
- ARRAY_REPEAT - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_REPEAT
function (Spark semantics). - ARRAY_REPEAT - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_REPEAT - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_REPEAT(element, count)" function.
- ARRAY_REVERSE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_REVERSE
function (BigQuery semantics). - ARRAY_REVERSE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_REVERSE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_REVERSE(array)" function.
- ARRAY_SIZE - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_SIZE
function (Spark semantics). - ARRAY_SIZE - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_SIZE(array)" function.
- ARRAY_TO_RDD - Enum constant in enum org.apache.calcite.adapter.spark.SparkMethod
- ARRAY_TO_STRING - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_TO_STRING
function (BigQuery semantics). - ARRAY_TO_STRING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_TO_STRING - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_TO_STRING(array, delimiter [, nullText ])" function.
- ARRAY_UNION - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAY_UNION
function (Spark semantics). - ARRAY_UNION - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAY_UNION - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAY_UNION(array1, array2)" function.
- ARRAY_VALUE_CONSTRUCTOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Array Value Constructor, e.g.
- ARRAY_VALUE_CONSTRUCTOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The ARRAY Value Constructor.
- arrayAppend(List, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_APPEND function.
- arrayAppendFun(List, Integer) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- ArrayBindable - Interface in org.apache.calcite.runtime
-
Extension to
Bindable
that returns rows that are arrays of objects. - ArrayComparator - Class in org.apache.calcite.runtime
-
Compares arrays.
- ArrayComparator(boolean...) - Constructor for class org.apache.calcite.runtime.ArrayComparator
- ArrayComparator(Comparator...) - Constructor for class org.apache.calcite.runtime.ArrayComparator
- arrayComparer() - Static method in class org.apache.calcite.linq4j.function.Functions
-
Returns an
EqualityComparer
that works on arrays of objects. - arrayConverter(List<RelDataType>, List<Integer>, boolean) - Static method in class org.apache.calcite.adapter.file.CsvEnumerator
- ArrayElementOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Parameter type-checking strategy where types must be Array and Array element type.
- ArrayElementOperandTypeChecker() - Constructor for class org.apache.calcite.sql.type.ArrayElementOperandTypeChecker
- ArrayEnumeratorCursor - Class in org.apache.calcite.runtime
- ArrayEnumeratorCursor(Enumerator<Object[]>) - Constructor for class org.apache.calcite.runtime.ArrayEnumeratorCursor
-
Creates an ArrayEnumeratorCursor.
- arrayExcept(List, List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_EXCEPT function.
- arrayIndex(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates an expression that represents applying an array index operator to an array of rank one.
- ArrayIndex - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An indexing operation in a one-dimensional array, such as
array[index]
in Java. - arrayIndexOutOfBounds(int) - Method in interface org.apache.calcite.runtime.CalciteResource
- arrayInsert(List, Object, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_INSERT function.
- ArrayInsertOperandTypeChecker - Class in org.apache.calcite.sql.type
-
Parameter type checking strategy, where the operand size is 3, and the first type is array, the second type is integer, and the third type is the component type of the first array ( strictly matched without leastRestrictive conversion).
- ArrayInsertOperandTypeChecker() - Constructor for class org.apache.calcite.sql.type.ArrayInsertOperandTypeChecker
- arrayIntersect(List, List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_INTERSECT function.
- arrayItem(Object, int) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Gets an item from an array.
- arrayItem(Object, int, Primitive.Sink) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Sends to a sink an from an array.
- arrayItem(List, int, int, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Helper for "array element reference".
- arrayItem(Primitive.Source, Object, int) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Reads value from a source into an array.
- arrayItemOptional(List, int, int, boolean) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
As
SqlFunctions.arrayItem(java.util.List, int, int, boolean)
method, but allows array to be nullable. - arrayLength(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a UnaryExpression that represents an expression for obtaining the length of a one-dimensional array.
- ArrayLength - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An operation that obtains the length of a one-dimensional array, such as array.Length.
- ArrayLengthRecordField - Class in org.apache.calcite.linq4j.tree
-
Length field of a RecordType.
- ArrayLengthRecordField(String, Class) - Constructor for class org.apache.calcite.linq4j.tree.ArrayLengthRecordField
- arrayMax(List<? extends T>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_MAX function.
- arrayMin(List<? extends T>) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_MIN function.
- arrayOrObjectValueRequiredInStrictModeOfJsonQueryFunc(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- arrayPosition(List, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_POSITION function.
- arrayPrepend(List, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_PREPEND function.
- arrayQuery(Function<RelBuilder, RelNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates an ARRAY sub-query.
- arrayRemove(List, Object) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_REMOVE function.
- arrays(Comparator<V>) - Method in class org.apache.calcite.runtime.SortedMultiMap
- ARRAYS_AS_LIST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAYS_OVERLAP - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAYS_OVERLAP
function (Spark semantics). - ARRAYS_OVERLAP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAYS_OVERLAP - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAYS_OVERLAP(array1, array2)" function (Spark).
- ARRAYS_ZIP - Enum constant in enum org.apache.calcite.sql.SqlKind
-
ARRAYS_ZIP
function (Spark semantics). - ARRAYS_ZIP - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ARRAYS_ZIP - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "ARRAYS_ZIP(array, ...)" function (Spark).
- arraysOverlap(List, List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAYS_OVERLAP function.
- ArraySqlType - Class in org.apache.calcite.sql.type
-
SQL array type.
- ArraySqlType(RelDataType, boolean) - Constructor for class org.apache.calcite.sql.type.ArraySqlType
-
Creates an ArraySqlType.
- arraysZip(List...) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAYS_ZIP function.
- arrayToList(Array) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Converts a JDBC array to a list.
- arrayToString(Object) - Method in enum org.apache.calcite.linq4j.tree.Primitive
-
Converts an array to a string.
- arrayToString(List, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ARRAY_TO_STRING(array, delimiter)
function. - arrayToString(List, String, String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ARRAY_TO_STRING(array, delimiter, nullText)
function. - ArrayType(Type) - Constructor for class org.apache.calcite.linq4j.tree.Types.ArrayType
- ArrayType(Type, boolean, long) - Constructor for class org.apache.calcite.linq4j.tree.Types.ArrayType
- arrayUnion(List, List) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Support the ARRAY_UNION function.
- ARTIFICIAL_SELECTIVITY_FUNC - Static variable in class org.apache.calcite.rel.metadata.RelMdUtil
- as(String) - Method in interface org.apache.calcite.tools.RelBuilder.AggCall
-
Returns a copy of this AggCall with a given alias.
- as(Class<T>) - Method in interface org.apache.calcite.plan.RelRule.Config
-
Casts this configuration to another type, usually a sub-class.
- as(String) - Method in class org.apache.calcite.tools.PigRelBuilder
-
As super-class method, but also retains alias for naming of aggregates.
- as(String) - Method in class org.apache.calcite.tools.RelBuilder
-
Assigns a table alias to the top entry on the stack.
- as(String) - Method in interface org.apache.calcite.tools.RelBuilder.OverCall
-
Sets the alias of this expression, and converts it to a
RexNode
; default is the alias that was set viaRelBuilder.AggCall.as(String)
. - as(SqlNode, String, String...) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor
-
Convenience method for creating column and table aliases.
- AS - Enum constant in enum org.apache.calcite.sql.SqlKind
-
AS
operator. - AS - Enum constant in enum org.apache.calcite.sql.SqlWriter.FrameTypeEnum
-
Alias ("AS").
- AS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
AS
operator associates an expression in the SELECT clause with an alias. - AS_ENUMERABLE - Enum constant in enum org.apache.calcite.adapter.spark.SparkMethod
- AS_ENUMERABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AS_ENUMERABLE2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AS_IS - Enum constant in enum org.apache.calcite.plan.Strong.Policy
-
This kind of expression may be null.
- AS_LIST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AS_QUERYABLE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- asBufferParameters() - Method in class org.apache.calcite.runtime.BufferStyle
-
Returns buffer parameters.
- ASC - Enum constant in enum org.apache.calcite.piglet.Ast.Direction
- ASC - Static variable in class org.apache.calcite.adapter.geode.rel.GeodeSort
- ASCENDING - Enum constant in enum org.apache.calcite.rel.RelFieldCollation.Direction
-
Ascending direction: A value is always followed by a greater or equal value.
- ascii(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL ASCII(string) function.
- ASCII - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ASCII - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- asCopy(Object...) - Static method in class org.apache.calcite.interpreter.Row
-
Creates a Row.
- asEnumerable() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- asEnumerable() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- asEnumerable() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Returns the input typed as
Enumerable<TSource>
. - asEnumerable(Iterable<T>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Adapter that converts an
Iterable
into anEnumerable
. - asEnumerable(Collection<T>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Adapter that converts an
Collection
into anEnumerable
. - asEnumerable(List<T>) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Adapter that converts an
List
into anEnumerable
. - asEnumerable(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Returns the input typed as
Enumerable<TSource>
. - asEnumerable(JavaRDD<T>) - Static method in class org.apache.calcite.adapter.spark.SparkRuntime
-
Converts an RDD into an enumerable.
- asEnumerable(T[]) - Static method in class org.apache.calcite.linq4j.Linq4j
-
Adapter that converts an array into an enumerable.
- asEwkt(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Returns the Extended Well-Known text (EWKT) representation of the geometry.
- asFrom() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Returns a node that can be included in the FROM clause or a JOIN.
- asGeoJson(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Returns the GeoJson representation of the geometry.
- asGml(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Returns the GML representation of the geometry.
- asIdentifier(SqlNode) - Static method in class org.apache.calcite.sql.SqlIntervalQualifier
-
Converts a
SqlIntervalQualifier
to aSqlIdentifier
if it is a time frame reference. - asImmutable() - Method in class org.apache.calcite.util.IntList
-
Deprecated.
- asin(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ASIN
operator applied to double values. - asin(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ASIN
operator applied to BigDecimal values. - ASIN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ASIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
ASIN(numeric)
function. - asIndexMap(Collection<V>, Function<V, K>) - Static method in class org.apache.calcite.util.Util
-
Deprecated.
- asIndexMapJ(Collection<V>, Function<V, K>) - Static method in class org.apache.calcite.util.Util
-
Returns a map that is a view onto a collection of values, using the provided function to convert a value to a key.
- asinh(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ASINH
operator applied to double values. - asinh(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ASINH
operator applied to BigDecimal values. - ASINH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ASINH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
ASINH(numeric)
function; returns the inverse hyperbolic sine ofvalue
. - asList() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Creates a view onto this bit set as a list of integers.
- asList(boolean[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(byte[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(char[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(double[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(float[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(int[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(int[]) - Static method in class org.apache.calcite.util.IntList
-
Deprecated.
- asList(long[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(short[]) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
- asList(Object) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Adapts a primitive array into a
List
. - asList(Mappings.TargetMapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Returns a mapping as a list such that
list.get(source)
ismapping.getTarget(source)
andlist.size()
ismapping.getSourceCount()
. - asListNonNull(Mappings.TargetMapping) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Returns a mapping as a list such that
list.get(source)
ismapping.getTarget(source)
andlist.size()
ismapping.getSourceCount()
. - asOrderedQueryable() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- asOrderedQueryable(Enumerable<T>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
- asQueryable() - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- asQueryable() - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- asQueryable() - Method in interface org.apache.calcite.linq4j.Enumerable
-
Converts this Enumerable to a Queryable.
- asQueryable() - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Converts an Enumerable to a
Queryable
. - asQueryable(DefaultEnumerable<T>) - Static method in class org.apache.calcite.linq4j.Extensions
- asQueryable(Enumerable<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Converts an Enumerable to an IQueryable.
- asQueryable(Queryable<T>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Converts a generic
Enumerable<T>
to a genericIQueryable<T>
. - asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.csv.CsvTranslatableTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.file.CsvTranslatableTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.geode.rel.GeodeTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.innodb.InnodbTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.jdbc.JdbcTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.mongodb.MongoTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.schema.impl.ListTransientTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.schema.impl.ViewTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in interface org.apache.calcite.schema.QueryableTable
-
Converts this table into a
Queryable
. - asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockDynamicTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.util.Smalls.SimpleTable
- asQueryOrValues() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Converts a non-query node into a SELECT node.
- asSelect() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Converts a non-query node into a SELECT node.
- assertArrayEqual(String, Object[], Object[]) - Static method in class org.apache.calcite.test.CalciteAssert
-
Asserts that two objects are equal.
- assertBindType(Matcher<String>) - Method in class org.apache.calcite.test.SqlValidatorFixture
- assertCharset(Matcher<Charset>) - Method in class org.apache.calcite.test.SqlValidatorFixture
- assertCollation(Matcher<String>, Matcher<SqlCollation.Coercibility>) - Method in class org.apache.calcite.test.SqlValidatorFixture
- assertColumnOriginDouble(String, String, String, String, boolean) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks that
RelMetadataQuery.getColumnOrigins(RelNode, int)
for column 0 returns two origins. - assertColumnOriginIsEmpty() - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks that
RelMetadataQuery.getColumnOrigins(RelNode, int)
for column 0 returns no origins. - assertColumnOriginSingle(String, String, boolean) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks that
RelMetadataQuery.getColumnOrigins(RelNode, int)
for column 0 returns one origin. - assertConvertsTo(SqlTestFactory, DiffRepository, String, String, boolean, boolean, boolean) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- assertConvertsTo(SqlTestFactory, DiffRepository, String, String, boolean, boolean, boolean) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Checks that a SQL statement converts to a given plan, optionally trimming columns that are not needed.
- assertCpuCost(Matcher<Double>, String) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks the CPU component of
RelNode.computeSelfCost(RelOptPlanner, RelMetadataQuery)
. - assertEquals(String, String, String) - Method in class org.apache.calcite.test.DiffRepository
- assertEqualsVerbose(String, String) - Static method in class org.apache.calcite.util.TestUtil
- assertExceptionIsThrown(SqlTestFactory, StringAndPos, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- assertExceptionIsThrown(SqlTestFactory, StringAndPos, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Checks that a query is valid, or, if invalid, throws the right message at the right location.
- assertExceptionIsThrown(SqlTestFactory, StringAndPos, String) - Method in class org.apache.calcite.test.SqlOperatorTest.TesterImpl
- assertExceptionIsThrown(SqlTestFactory, StringAndPos, String, boolean) - Method in class org.apache.calcite.test.SqlOperatorTest.TesterImpl
- assertFieldOrigin(Matcher<String>) - Method in class org.apache.calcite.test.SqlValidatorFixture
-
Tests that the list of the origins of each result field of the current query match expected.
- assertInterval(Matcher<Long>) - Method in class org.apache.calcite.test.SqlValidatorFixture
-
Checks if the interval value conversion to milliseconds is valid.
- assertMonotonicity(Matcher<SqlMonotonicity>) - Method in class org.apache.calcite.test.SqlValidatorFixture
-
Tests that the first column of the query has a given monotonicity.
- assertParse(String) - Method in interface org.apache.calcite.test.IntervalTest.Fixture2
-
Checks that the expression parses successfully and produces the given SQL when unparsed.
- assertPercentageOriginalRows(Matcher<Double>) - Method in class org.apache.calcite.test.RelMetadataFixture
- assertRowsUnique(boolean, Matcher<Boolean>, String) - Method in class org.apache.calcite.test.RelMetadataFixture
- assertRowsUnique(Matcher<Boolean>, String) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks
RelMetadataQuery.areRowsUnique(RelNode)
for all values ofignoreNulls
. - assertThatAreColumnsUnique(Function<RelNode, ImmutableBitSet>, UnaryOperator<RelNode>, Matcher<Boolean>) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks
RelMetadataQuery.areColumnsUnique(RelNode, ImmutableBitSet)
, deriving parameters via functions. - assertThatAreColumnsUnique(ImmutableBitSet, Matcher<Boolean>) - Method in class org.apache.calcite.test.RelMetadataFixture
- assertThatAreRowsUnique(Matcher<Boolean>) - Method in class org.apache.calcite.test.RelMetadataFixture
- assertThatDistinctRowCount(Function<RelNode, ImmutableBitSet>, Matcher<Double>) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks
RelMetadataQuery.getDistinctRowCount(RelNode, ImmutableBitSet, RexNode)
with a null predicate, deriving the group key from theRelNode
. - assertThatDistinctRowCount(ImmutableBitSet, Matcher<Double>) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks
RelMetadataQuery.getDistinctRowCount(RelNode, ImmutableBitSet, RexNode)
with a null predicate. - assertThatNodeTypeCount(Matcher<Map<Class<? extends RelNode>, Integer>>) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks the number of each sub-class of
RelNode
, callingRelMetadataQuery.getNodeTypes(RelNode)
. - assertThatNodeTypeCountIs(Class<? extends RelNode>, Integer, Object...) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Shorthand for a call to
RelMetadataFixture.assertThatNodeTypeCount(Matcher)
with a constant map. - assertThatRel(Matcher<RelNode>) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks the
RelNode
produced byRelMetadataFixture.toRel()
. - assertThatRowCount(Matcher<Number>, Matcher<Number>, Matcher<Number>) - Method in class org.apache.calcite.test.RelMetadataFixture
- assertThatSelectivity(Matcher<Double>) - Method in class org.apache.calcite.test.RelMetadataFixture
- assertThatUniqueKeys(Matcher<Iterable<ImmutableBitSet>>) - Method in class org.apache.calcite.test.RelMetadataFixture
- assertThatUniqueKeysAre(ImmutableBitSet...) - Method in class org.apache.calcite.test.RelMetadataFixture
-
Checks result of getting unique keys for SQL.
- asSet() - Method in class org.apache.calcite.util.ImmutableBitSet
-
Creates a view onto this bit set as a set of integers.
- asSidedDistance(double) - Method in class org.apache.calcite.runtime.BufferStyle
-
Returns a sided distance.
- assign(Expression, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BinaryExpression that represents an assignment operation.
- Assign - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
An assignment operation, such as (a = b).
- assignableFrom(Primitive) - Method in enum org.apache.calcite.linq4j.tree.Primitive
- AssignableOperandTypeChecker - Class in org.apache.calcite.sql.type
-
AssignableOperandTypeChecker implements
SqlOperandTypeChecker
by verifying that the type of each argument is assignable to a predefined set of parameter types (under the SQL definition of "assignable"). - AssignableOperandTypeChecker(List<RelDataType>, List<String>) - Constructor for class org.apache.calcite.sql.type.AssignableOperandTypeChecker
-
Instantiates this strategy with a specific set of parameter types.
- Assignment(SqlParserPos, Ast.Op, Ast.Identifier) - Constructor for class org.apache.calcite.piglet.Ast.Assignment
- Assignment1(SqlParserPos, Ast.Op, Ast.Identifier, Ast.Identifier) - Constructor for class org.apache.calcite.piglet.Ast.Assignment1
- assignments() - Method in class org.apache.calcite.rex.RexAnalyzer
-
Generates a map of variables and lists of values that could be assigned to them.
- assignNamesFrom(SqlIdentifier) - Method in class org.apache.calcite.sql.SqlIdentifier
-
Copies names and components from another identifier.
- asSql(boolean, boolean) - Method in class org.apache.calcite.util.NlsString
-
As
NlsString.asSql(boolean, boolean, SqlDialect)
but with SQL standard dialect. - asSql(boolean, boolean, SqlDialect) - Method in class org.apache.calcite.util.NlsString
-
Returns the string quoted for SQL, for example
_ISO-8859-1'is it a plane? no it''s superman!'
. - asStatement() - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Converts a non-query node into a SELECT node.
- asString() - Method in class org.apache.calcite.rel.externalize.RelJsonWriter
-
Returns a JSON string describing the relational expressions that were just explained.
- asStringBuilder(Appendable, Consumer<StringBuilder>) - Static method in class org.apache.calcite.util.Util
-
Given an
Appendable
, performs an action that requires aStringBuilder
. - Ast - Class in org.apache.calcite.piglet
-
Abstract syntax tree.
- Ast.Assignment - Class in org.apache.calcite.piglet
-
Abstract base class for statements that assign to a named relation.
- Ast.Assignment1 - Class in org.apache.calcite.piglet
-
Abstract base class for an assignment with one source relation.
- Ast.BagType - Class in org.apache.calcite.piglet
-
Parse tree for a bag type.
- Ast.Call - Class in org.apache.calcite.piglet
-
Parse tree node for a call to a function or operator.
- Ast.DescribeStmt - Class in org.apache.calcite.piglet
-
Parse tree node for DESCRIBE statement.
- Ast.Direction - Enum in org.apache.calcite.piglet
-
Sort direction.
- Ast.DistinctStmt - Class in org.apache.calcite.piglet
-
Parse tree node for DISTINCT statement.
- Ast.DumpStmt - Class in org.apache.calcite.piglet
-
Parse tree node for DUMP statement.
- Ast.FieldSchema - Class in org.apache.calcite.piglet
-
Parse tree for field schema.
- Ast.FilterStmt - Class in org.apache.calcite.piglet
-
Parse tree node for FILTER statement.
- Ast.ForeachNestedStmt - Class in org.apache.calcite.piglet
-
Parse tree node for FOREACH statement (nested).
- Ast.ForeachStmt - Class in org.apache.calcite.piglet
-
Parse tree node for FOREACH statement (non-nested).
- Ast.GroupStmt - Class in org.apache.calcite.piglet
-
Parse tree node for GROUP statement.
- Ast.Identifier - Class in org.apache.calcite.piglet
-
Parse tree node for Identifier.
- Ast.LimitStmt - Class in org.apache.calcite.piglet
-
Parse tree node for LIMIT statement.
- Ast.Literal - Class in org.apache.calcite.piglet
-
Parse tree node for Literal.
- Ast.LoadStmt - Class in org.apache.calcite.piglet
-
Parse tree node for LOAD statement.
- Ast.MapType - Class in org.apache.calcite.piglet
-
Parse tree for a map type.
- Ast.Node - Class in org.apache.calcite.piglet
-
Abstract base class for parse tree node.
- Ast.NumericLiteral - Class in org.apache.calcite.piglet
-
Parse tree node for NumericLiteral.
- Ast.Op - Enum in org.apache.calcite.piglet
-
Parse tree node type.
- Ast.OrderStmt - Class in org.apache.calcite.piglet
-
Parse tree node for ORDER statement.
- Ast.Program - Class in org.apache.calcite.piglet
-
Parse tree node for a program.
- Ast.ScalarType - Class in org.apache.calcite.piglet
-
Parse tree for scalar type such as
int
. - Ast.Schema - Class in org.apache.calcite.piglet
-
Parse tree for schema.
- Ast.SpecialIdentifier - Class in org.apache.calcite.piglet
-
Parse tree node for "*", a special kind of identifier.
- Ast.Stmt - Class in org.apache.calcite.piglet
-
Abstract base class for parse tree node representing a statement.
- Ast.TupleType - Class in org.apache.calcite.piglet
-
Parse tree for a tuple type.
- Ast.Type - Class in org.apache.calcite.piglet
-
Parse tree for type.
- Ast.ValuesStmt - Class in org.apache.calcite.piglet
-
Parse tree node for VALUES statement.
- asWkb(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Returns the Extended Well-Known binary (WKB) representation of the geometry.
- asWkt(Geometry) - Static method in class org.apache.calcite.runtime.SpatialTypeUtils
-
Returns the Well-Known text (WKT) representation of the geometry.
- ASYMMETRIC - Enum constant in enum org.apache.calcite.sql.fun.SqlBetweenOperator.Flag
- AT_LEAST_ONE_SAME_VARIADIC - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy where any positive number of operands must all be in the same type family.
- atan(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATAN
operator applied to double values. - atan(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATAN
operator applied to BigDecimal values. - ATAN - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ATAN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
ATAN(numeric)
function. - atan2(double, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATAN2
operator applied to double values. - atan2(double, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATAN2
operator applied to double/BigDecimal values. - atan2(BigDecimal, double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATAN2
operator applied to BigDecimal/double values. - atan2(BigDecimal, BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATAN2
operator applied to BigDecimal values. - ATAN2 - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ATAN2 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
The
ATAN2(numeric, numeric)
function. - atanh(double) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATANH
operator applied to double values. - atanh(BigDecimal) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL
ATANH
operator applied to BigDecimal values. - ATANH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- ATANH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The
ATANH(numeric)
function; returns the inverse hyperbolic tangent ofvalue
. - atLeast(V) - Method in interface org.apache.calcite.util.RangeSets.Consumer
- atLeast(V) - Method in interface org.apache.calcite.util.RangeSets.Handler
- atMost(V) - Method in interface org.apache.calcite.util.RangeSets.Consumer
- atMost(V) - Method in interface org.apache.calcite.util.RangeSets.Handler
- atom(Object) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- atom(Object) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- ATOM - Enum constant in enum org.apache.calcite.util.PrecedenceClimbingParser.Type
- atomicBoolean - Variable in class org.apache.calcite.util.CancelFlag
-
The flag that holds the cancel state.
- attachHints(List<RelHint>) - Method in interface org.apache.calcite.rel.hint.Hintable
-
Attaches list of hints to this relational expression.
- attachRelHint(HintStrategyTable, List<RelHint>, Hintable) - Static method in class org.apache.calcite.sql.SqlUtil
-
Attach the
hints
torel
with specified hint strategies. - attachTo(RelOptPlanner) - Method in class org.apache.calcite.plan.visualizer.RuleMatchVisualizer
-
Attaches the visualizer to the planner.
- ATTEMPT_SUGGESTER - Static variable in class org.apache.calcite.sql.validate.SqlValidatorUtil
- attribute(String, String) - Method in class org.apache.calcite.util.XmlOutput
-
Writes an attribute.
- attribute(SqlParserPos, SqlIdentifier, SqlDataTypeSpec, SqlNode, SqlCollation) - Static method in class org.apache.calcite.sql.ddl.SqlDdlNodes
-
Creates an attribute definition.
- ATTRIBUTE_DEF - Enum constant in enum org.apache.calcite.sql.SqlKind
-
Attribute definition.
- AttributedDirectedGraph<V,
E extends DefaultEdge> - Class in org.apache.calcite.util.graph -
Directed graph where edges have attributes and allows multiple edges between any two vertices provided that their attributes are different.
- AttributedDirectedGraph(AttributedDirectedGraph.AttributedEdgeFactory<V, E>) - Constructor for class org.apache.calcite.util.graph.AttributedDirectedGraph
-
Creates an attributed graph.
- AttributedDirectedGraph.AttributedEdgeFactory<V,
E> - Interface in org.apache.calcite.util.graph -
Factory for edges that have attributes.
- attributeDefs - Variable in class org.apache.calcite.sql.ddl.SqlCreateType
- attributes - Variable in class org.apache.calcite.model.JsonType
-
Definition of the attributes of this type.
- Author(int, String, BookstoreSchema.Place, List<BookstoreSchema.Book>) - Constructor for class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Author
- authors - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema
- auto - Variable in class org.apache.calcite.materialize.Lattice
- auto - Variable in class org.apache.calcite.model.JsonLattice
-
Whether to materialize tiles on demand as queries are executed.
- auto(boolean) - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Sets the "auto" attribute (default true).
- AUTO_TEMP - Enum constant in enum org.apache.calcite.config.CalciteConnectionProperty
-
Whether to store query results in temporary tables.
- autodetectRelTypeFromRegion(Region<?, ?>) - Static method in class org.apache.calcite.adapter.geode.util.GeodeUtils
-
Extract the first entity of each Regions and use it to build a table types.
- autoLattice - Variable in class org.apache.calcite.model.JsonSchema
-
Whether to create lattices in this schema based on queries occurring in other schemas.
- automaton() - Method in class org.apache.calcite.runtime.Pattern.PatternBuilder
-
Returns the resulting automaton.
- Automaton - Class in org.apache.calcite.runtime
-
A nondeterministic finite-state automaton (NFA).
- AutomatonBuilder - Class in org.apache.calcite.runtime
-
Builds a state-transition graph for deterministic finite automaton.
- AutomatonBuilder() - Constructor for class org.apache.calcite.runtime.AutomatonBuilder
- autoPruneOld() - Method in class org.apache.calcite.rel.rules.ProjectRemoveRule
- autoPruneOld() - Method in class org.apache.calcite.rel.rules.PruneEmptyRules.PruneEmptyRule
- autoPruneOld() - Method in interface org.apache.calcite.rel.rules.SubstitutionRule
-
Whether the planner should automatically prune old node when there is at least 1 equivalent rel generated by the rule.
- autoPruneOld() - Method in class org.apache.calcite.rel.rules.UnionEliminatorRule
- autoTemp() - Method in interface org.apache.calcite.config.CalciteConnectionConfig
-
Returns the value of
CalciteConnectionProperty.AUTO_TEMP
. - autoTemp() - Method in class org.apache.calcite.config.CalciteConnectionConfigImpl
- AUX - Enum constant in enum org.apache.calcite.test.CalciteAssert.Config
-
Configuration that loads AUX schema for tests involving view expansions and lateral joins tests.
- AUX - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- auxiliary(String, SqlKind) - Method in class org.apache.calcite.sql.SqlGroupedWindowFunction
-
Creates an auxiliary function from this grouped window function.
- auxiliary(SqlKind) - Method in class org.apache.calcite.sql.SqlGroupedWindowFunction
-
Creates an auxiliary function from this grouped window function.
- AUXILIARY_TABLE - Enum constant in enum org.apache.calcite.schema.Schema.TableType
-
An auxiliary table.
- AuxiliaryConverter - Interface in org.apache.calcite.sql2rel
-
Converts an expression for a group window function (e.g.
- AuxiliaryConverter.Impl - Class in org.apache.calcite.sql2rel
-
Simple implementation of
AuxiliaryConverter
. - auxiliaryToGroup(SqlKind) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Returns the group function for which a given kind is an auxiliary function, or null if it is not an auxiliary function.
- auxiliaryWithoutMatchingGroupCall(String, String) - Method in interface org.apache.calcite.runtime.CalciteResource
- AVATICA_VERSION - Static variable in class org.apache.calcite.util.TestUtil
- average(Enumerable<TSource>, BigDecimalFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of Decimal values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, DoubleFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of Double values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, FloatFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of Float values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, IntegerFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of int values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, LongFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of long values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, NullableBigDecimalFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of nullable Decimal values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, NullableDoubleFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of nullable Double values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, NullableFloatFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of nullable Float values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, NullableIntegerFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of nullable int values that are obtained by invoking a transform function on each element of the input sequence.
- average(Enumerable<TSource>, NullableLongFunction1<TSource>) - Static method in class org.apache.calcite.linq4j.EnumerableDefaults
-
Computes the average of a sequence of nullable long values that are obtained by invoking a transform function on each element of the input sequence.
- average(BigDecimalFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(BigDecimalFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of Decimal values that are obtained by invoking a transform function on each element of the input sequence.
- average(DoubleFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(DoubleFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of Double values that are obtained by invoking a transform function on each element of the input sequence.
- average(FloatFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(FloatFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of Float values that are obtained by invoking a transform function on each element of the input sequence.
- average(IntegerFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(IntegerFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of int values that are obtained by invoking a transform function on each element of the input sequence.
- average(LongFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(LongFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of long values that are obtained by invoking a transform function on each element of the input sequence.
- average(NullableBigDecimalFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(NullableBigDecimalFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of nullable Decimal values that are obtained by invoking a transform function on each element of the input sequence.
- average(NullableDoubleFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(NullableDoubleFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of nullable Double values that are obtained by invoking a transform function on each element of the input sequence.
- average(NullableFloatFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(NullableFloatFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of nullable Float values that are obtained by invoking a transform function on each element of the input sequence.
- average(NullableIntegerFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(NullableIntegerFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of nullable int values that are obtained by invoking a transform function on each element of the input sequence.
- average(NullableLongFunction1<T>) - Method in class org.apache.calcite.linq4j.DefaultEnumerable
- average(NullableLongFunction1<TSource>) - Method in interface org.apache.calcite.linq4j.ExtendedEnumerable
-
Computes the average of a sequence of nullable long values that are obtained by invoking a transform function on each element of the input sequence.
- AVERAGE_COLUMN_SIZES - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- AVERAGE_ROW_SIZE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- averageBigDecimal(Queryable<T>, FunctionExpression<BigDecimalFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- averageBigDecimal(Queryable<T>, FunctionExpression<BigDecimalFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- averageBigDecimal(Queryable<T>, FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageBigDecimal(FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageBigDecimal(FunctionExpression<BigDecimalFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- averageColumnSizes() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Size
-
Determines the average size (in bytes) of a value of a column in this relational expression.
- averageColumnSizes(Aggregate, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Calc, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Exchange, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Filter, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Intersect, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Join, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Minus, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Project, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Sort, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(TableModify, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(TableScan, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Union, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(Values, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageColumnSizes(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Size.Handler
- averageColumnSizes(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
-
Catch-all implementation for
BuiltInMetadata.Size.averageColumnSizes()
, invoked using reflection. - averageDouble(Queryable<T>, FunctionExpression<DoubleFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of Double values that is obtained by invoking a projection function on each element of the input sequence.
- averageDouble(Queryable<T>, FunctionExpression<DoubleFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of Double values that is obtained by invoking a projection function on each element of the input sequence.
- averageDouble(Queryable<T>, FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageDouble(FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageDouble(FunctionExpression<DoubleFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of Double values that is obtained by invoking a projection function on each element of the input sequence.
- averageFieldValueSize(RelDataTypeField) - Method in class org.apache.calcite.rel.metadata.RelMdSize
-
Estimates the average size (in bytes) of a value of a field, knowing nothing more than its type.
- averageFloat(Queryable<T>, FunctionExpression<FloatFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of Float values that is obtained by invoking a projection function on each element of the input sequence.
- averageFloat(Queryable<T>, FunctionExpression<FloatFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of Float values that is obtained by invoking a projection function on each element of the input sequence.
- averageFloat(Queryable<T>, FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageFloat(FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageFloat(FunctionExpression<FloatFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of Float values that is obtained by invoking a projection function on each element of the input sequence.
- averageInteger(Queryable<T>, FunctionExpression<IntegerFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of int values that is obtained by invoking a projection function on each element of the input sequence.
- averageInteger(Queryable<T>, FunctionExpression<IntegerFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of int values that is obtained by invoking a projection function on each element of the input sequence.
- averageInteger(Queryable<T>, FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageInteger(FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageInteger(FunctionExpression<IntegerFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of int values that is obtained by invoking a projection function on each element of the input sequence.
- averageLong(Queryable<T>, FunctionExpression<LongFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of long values that is obtained by invoking a projection function on each element of the input sequence.
- averageLong(Queryable<T>, FunctionExpression<LongFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of long values that is obtained by invoking a projection function on each element of the input sequence.
- averageLong(Queryable<T>, FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageLong(FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageLong(FunctionExpression<LongFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of long values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableBigDecimal(Queryable<T>, FunctionExpression<NullableBigDecimalFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of nullable Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableBigDecimal(Queryable<T>, FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of nullable Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableBigDecimal(Queryable<T>, FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageNullableBigDecimal(FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageNullableBigDecimal(FunctionExpression<NullableBigDecimalFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of nullable Decimal values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableDouble(Queryable<T>, FunctionExpression<NullableDoubleFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of nullable Double values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableDouble(Queryable<T>, FunctionExpression<NullableDoubleFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of nullable Double values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableDouble(Queryable<T>, FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageNullableDouble(FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageNullableDouble(FunctionExpression<NullableDoubleFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of nullable Double values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableFloat(Queryable<T>, FunctionExpression<NullableFloatFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of nullable Float values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableFloat(Queryable<T>, FunctionExpression<NullableFloatFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of nullable Float values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableFloat(Queryable<T>, FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageNullableFloat(FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageNullableFloat(FunctionExpression<NullableFloatFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of nullable Float values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableInteger(Queryable<T>, FunctionExpression<NullableIntegerFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of nullable int values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableInteger(Queryable<T>, FunctionExpression<NullableIntegerFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of nullable int values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableInteger(Queryable<T>, FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageNullableInteger(FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageNullableInteger(FunctionExpression<NullableIntegerFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of nullable int values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableLong(Queryable<T>, FunctionExpression<NullableLongFunction1<T>>) - Static method in class org.apache.calcite.linq4j.QueryableDefaults
-
Computes the average of a sequence of nullable long values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableLong(Queryable<T>, FunctionExpression<NullableLongFunction1<T>>) - Method in interface org.apache.calcite.linq4j.QueryableFactory
-
Computes the average of a sequence of nullable long values that is obtained by invoking a projection function on each element of the input sequence.
- averageNullableLong(Queryable<T>, FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.linq4j.QueryableRecorder
- averageNullableLong(FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
- averageNullableLong(FunctionExpression<NullableLongFunction1<T>>) - Method in class org.apache.calcite.adapter.cassandra.CassandraTable.CassandraQueryable
-
Computes the average of a sequence of nullable long values that is obtained by invoking a projection function on each element of the input sequence.
- averageRexSize(RexNode, List<? extends Double>) - Method in class org.apache.calcite.rel.metadata.RelMdSize
- averageRowSize() - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Size
-
Determines the average size (in bytes) of a row from this relational expression.
- averageRowSize(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.BuiltInMetadata.Size.Handler
- averageRowSize(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.metadata.RelMdSize
-
Catch-all implementation for
BuiltInMetadata.Size.averageRowSize()
, invoked using reflection. - averageTypeValueSize(RelDataType) - Method in class org.apache.calcite.rel.metadata.RelMdSize
-
Estimates the average size (in bytes) of a value of a type.
- avg(boolean, String, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
AVG
aggregate function, optionally distinct and with an alias. - avg(RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to the
AVG
aggregate function. - AVG - Enum constant in enum org.apache.calcite.sql.fun.SqlAvgAggFunction.Subtype
-
Deprecated.
- AVG - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
AVG
aggregate function. - AVG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
AVG
aggregate function. - AVG_AGG_FUNCTION - Static variable in class org.apache.calcite.sql.type.ReturnTypes
- AVG_AGG_FUNCTIONS - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of SqlAvgAggFunction.
- axisList - Variable in class org.apache.calcite.sql.SqlPivot
- axisList - Variable in class org.apache.calcite.sql.SqlUnpivot
B
- BABEL - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that allows anything supported by any dialect.
- backedBy(List<Object>) - Static method in interface org.apache.calcite.runtime.PairList
-
Creates a PairList backed by a given list.
- BAD_DATETIME_MESSAGE - Static variable in interface org.apache.calcite.sql.test.SqlOperatorFixture
- badFormat(String) - Method in interface org.apache.calcite.runtime.CalciteResource
- badLowerBoundary() - Method in interface org.apache.calcite.runtime.CalciteResource
- BadTableFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.BadTableFunction
- BadType() - Constructor for class org.apache.calcite.test.schemata.catchall.CatchallSchema.BadType
- badTypes - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- badUpperBoundary() - Method in interface org.apache.calcite.runtime.CalciteResource
- BAG - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- BAG_TYPE - Enum constant in enum org.apache.calcite.piglet.Ast.Op
- BagType(SqlParserPos, Ast.Type) - Constructor for class org.apache.calcite.piglet.Ast.BagType
- bangEqualNotAllowed() - Method in interface org.apache.calcite.runtime.CalciteResource
- BarfingInvocationHandler - Class in org.apache.calcite.util
-
A class derived from
BarfingInvocationHandler
handles a method call by looking for a method in itself with identical parameters. - BarfingInvocationHandler() - Constructor for class org.apache.calcite.util.BarfingInvocationHandler
- BASE_DIRECTORY - Enum constant in enum org.apache.calcite.model.ModelHandler.ExtraOperand
-
Base directory from which to read files.
- BaseOrderStreamTable - Class in org.apache.calcite.test.schemata.orderstream
-
Base table for the Orders table.
- BaseOrderStreamTable() - Constructor for class org.apache.calcite.test.schemata.orderstream.BaseOrderStreamTable
- BaseQueryable<TSource> - Class in org.apache.calcite.linq4j
-
Skeleton implementation of
Queryable
. - BaseQueryable(QueryProvider, Type, Expression) - Constructor for class org.apache.calcite.linq4j.BaseQueryable
- baseUnit(SqlTypeName) - Static method in class org.apache.calcite.rex.RexBuilder
-
Returns the lowest granularity unit for the given unit.
- BASIC_AGGREGATE_LAMBDA_FACTORY - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BASIC_LAZY_ACCUMULATOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BasicAggregateLambdaFactory<TSource,
TAccumulate, TResult, TKey> - Class in org.apache.calcite.adapter.enumerable -
Implementation of
AggregateLambdaFactory
that applies a sequence of accumulator adders to input source. - BasicAggregateLambdaFactory(Function0<TAccumulate>, List<Function2<TAccumulate, TSource, TAccumulate>>) - Constructor for class org.apache.calcite.adapter.enumerable.BasicAggregateLambdaFactory
- BasicLazyAccumulator<TAccumulate,
TSource> - Class in org.apache.calcite.adapter.enumerable -
Performs accumulation against a pre-collected list of input sources, used with
LazyAggregateLambdaFactory
. - BasicLazyAccumulator(Function2<TAccumulate, TSource, TAccumulate>) - Constructor for class org.apache.calcite.adapter.enumerable.BasicLazyAccumulator
- BasicSqlType - Class in org.apache.calcite.sql.type
-
BasicSqlType represents a standard atomic SQL type (excluding interval types).
- BasicSqlType(RelDataTypeSystem, SqlTypeName) - Constructor for class org.apache.calcite.sql.type.BasicSqlType
-
Constructs a type with no parameters.
- BasicSqlType(RelDataTypeSystem, SqlTypeName, boolean) - Constructor for class org.apache.calcite.sql.type.BasicSqlType
- BasicSqlType(RelDataTypeSystem, SqlTypeName, int) - Constructor for class org.apache.calcite.sql.type.BasicSqlType
-
Constructs a type with precision/length but no scale.
- BasicSqlType(RelDataTypeSystem, SqlTypeName, int, int) - Constructor for class org.apache.calcite.sql.type.BasicSqlType
-
Constructs a type with precision/length and scale.
- batchSize() - Method in interface org.apache.calcite.adapter.enumerable.EnumerableBatchNestedLoopJoinRule.Config
-
Batch size.
- before() - Method in class org.apache.calcite.sql.pretty.SqlPrettyWriter.FrameImpl
- before(Consumer<Puffin.Context<G, F>>) - Method in interface org.apache.calcite.util.Puffin.Builder
-
Adds an action to be called before all sources.
- beforeSource(Consumer<Puffin.Context<G, F>>) - Method in interface org.apache.calcite.util.Puffin.Builder
-
Adds an action to be called before each source.
- beginBeginTag(String) - Method in class org.apache.calcite.util.XmlOutput
- beginNode() - Method in class org.apache.calcite.util.XmlOutput
-
If we are currently inside the start tag, finishes it off.
- beginTag(String, XmlOutput.XMLAttrVector) - Method in class org.apache.calcite.util.XmlOutput
-
Starts writing a new tag to the stream.
- belongsTo(Collection<SqlKind>) - Method in enum org.apache.calcite.sql.SqlKind
-
Returns whether this
SqlKind
belongs to a given category. - Benchmark - Class in org.apache.calcite.util
-
Helps to run benchmarks by running the same task repeatedly and averaging the running times.
- Benchmark(String, Function1<Benchmark.Statistician, Void>, int) - Constructor for class org.apache.calcite.util.Benchmark
- Benchmark.Statistician - Class in org.apache.calcite.util
-
Collects statistics for a test that is run multiple times.
- bestString() - Method in interface org.apache.calcite.sql.validate.SqlNameMatcher
-
Returns the most recent match.
- between(int, int) - Static method in class org.apache.calcite.sql.type.SqlOperandCountRanges
- between(RexNode, RexNode, RexNode) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a
BETWEEN
. - between(T, T) - Static method in class org.apache.calcite.test.Matchers
-
Creates a matcher that matches if the examined value is between bounds:
min ≤ value ≤ max
. - BETWEEN - Enum constant in enum org.apache.calcite.sql.SqlKind
-
BETWEEN
operator. - BETWEEN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
- betweenWithoutAnd() - Method in interface org.apache.calcite.runtime.CalciteResource
- BI_PREDICATE_TEST - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIG_DECIMAL - Static variable in interface org.apache.calcite.util.JdbcType
- BIG_DECIMAL_ADD - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIG_DECIMAL_NEGATE - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIG_DECIMAL_NULLABLE - Static variable in interface org.apache.calcite.util.JdbcType
- BIG_QUERY - Enum constant in enum org.apache.calcite.config.Lex
-
Lexical policy similar to BigQuery.
- BIG_QUERY - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
A collection of operators that are in Google BigQuery but not in standard SQL.
- BIG_QUERY - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- BIG_QUERY - Enum constant in enum org.apache.calcite.sql.validate.SqlConformanceEnum
-
Conformance value that instructs Calcite to use SQL semantics consistent with BigQuery.
- BIG_QUERY - Static variable in class org.apache.calcite.sql.parser.SqlParserTest
- BIG_QUERY - Static variable in class org.apache.calcite.util.format.FormatModels
-
Format model for BigQuery.
- bigDecimal - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.EveryType
- BigDecimalFunction1<T0> - Interface in org.apache.calcite.linq4j.function
-
Function that takes one parameter and returns a
BigDecimal
value. - bigdecimalmax(Tuple) - Static method in class org.apache.calcite.piglet.PigUdfs
- bigdecimalsum(Tuple) - Static method in class org.apache.calcite.piglet.PigUdfs
- BigDecimalSum() - Constructor for class org.apache.calcite.interpreter.AggregateNode.BigDecimalSum
- bigDecimalValue() - Method in class org.apache.calcite.sql.SqlLiteral
-
Returns a numeric literal's value as a
BigDecimal
. - BIGINT - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- BIGINT - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is a BIGINT.
- BIGINT_FORCE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is a nullable BIGINT.
- BIGINT_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is a BIGINT with nulls allowed if any of the operands allow nulls.
- BigQuerySqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation for Google BigQuery's "Standard SQL" dialect. - BigQuerySqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.BigQuerySqlDialect
-
Creates a BigQuerySqlDialect.
- bijection(List<Integer>) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Creates a bijection.
- bijection(Map<Integer, Integer>) - Static method in class org.apache.calcite.util.mapping.Mappings
-
Creates a bijection.
- BIJECTION - Enum constant in enum org.apache.calcite.util.mapping.MappingType
- BINARY - Enum constant in enum org.apache.calcite.sql.SqlSyntax
-
Binary operator syntax, as in "x + y".
- BINARY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- BINARY - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- BINARY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- BINARY_ARITHMETIC - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of binary arithmetic.
- BINARY_BINARY - Static variable in class org.apache.calcite.sql.type.OperandTypes
- BINARY_COMPARISON - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of binary comparison.
- BINARY_EQUALITY - Static variable in enum org.apache.calcite.sql.SqlKind
-
Category of binary equality.
- BINARY_SEARCH5_LOWER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BINARY_SEARCH5_UPPER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BINARY_SEARCH6_LOWER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BINARY_SEARCH6_UPPER - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BINARY_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- binaryArithmeticCoercion(SqlCallBinding) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Coerces operand of binary arithmetic expressions to Numeric type.
- binaryArithmeticCoercion(SqlCallBinding) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
-
Coerces operands in binary arithmetic expressions to NUMERIC types.
- binaryArithmeticWithStrings(SqlCallBinding, RelDataType, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
-
For NUMERIC and STRING operands, cast STRING to data type of the other operand.
- binaryComparisonCoercion(SqlCallBinding) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Coerces operands in binary comparison expressions.
- binaryComparisonCoercion(SqlCallBinding) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
-
Coerces operands in binary comparison expressions.
- BinaryExpression - Class in org.apache.calcite.linq4j.tree
-
Represents an expression that has a binary operator.
- binaryLiteralInvalid() - Method in interface org.apache.calcite.runtime.CalciteResource
- binaryLiteralOdd() - Method in interface org.apache.calcite.runtime.CalciteResource
- BinaryOperatorConversion - Class in org.apache.calcite.adapter.druid
-
Binary operator conversion utility class; used to convert expressions like
exp1 Operator exp2
. - BinaryOperatorConversion(SqlOperator, String) - Constructor for class org.apache.calcite.adapter.druid.BinaryOperatorConversion
- BinarySearch - Class in org.apache.calcite.runtime
-
Binary search for the implementation of RANGE BETWEEN XXX PRECEDING/FOLLOWING clause.
- BinarySearch() - Constructor for class org.apache.calcite.runtime.BinarySearch
- BinaryTree(LoptJoinTree) - Constructor for class org.apache.calcite.rel.rules.LoptJoinTree.BinaryTree
- bind(Member, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberAssignment that represents the initialization of a field or property.
- bind(Method, Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MemberAssignment that represents the initialization of a member by using a property accessor method.
- bind(DataContext) - Method in class org.apache.calcite.adapter.druid.DruidQuery
- bind(DataContext) - Method in class org.apache.calcite.adapter.enumerable.EnumerableBindable
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableAggregate
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableFilter
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableIntersect
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableJoin
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableMatch
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableMinus
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableProject
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableSort
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableTableScan
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableUnion
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableValues
- bind(DataContext) - Method in class org.apache.calcite.interpreter.Bindables.BindableWindow
- bind(DataContext) - Method in class org.apache.calcite.interpreter.InterpretableConverter
- bind(DataContext) - Method in interface org.apache.calcite.runtime.Bindable
-
Executes this statement and returns an enumerable which will yield rows.
- bind(RelNode, RelMetadataQuery) - Method in interface org.apache.calcite.rel.metadata.UnboundMetadata
- bindable(RelNode) - Static method in class org.apache.calcite.interpreter.Interpreters
-
Creates a
Bindable
that interprets a given relational expression. - Bindable<T> - Interface in org.apache.calcite.runtime
-
Statement that can be bound to a
DataContext
and then executed. - BINDABLE_AGGREGATE_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_BIND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BINDABLE_CACHE_CONCURRENCY_LEVEL - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
The concurrency level of the cache used for storing Bindable objects, instantiated via dynamically generated Java classes.
- BINDABLE_CACHE_MAX_SIZE - Static variable in class org.apache.calcite.config.CalciteSystemProperty
-
The maximum size of the cache used for storing Bindable objects, instantiated via dynamically generated Java classes.
- BINDABLE_FILTER_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_JOIN_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_MATCH_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_PROJECT_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_SET_OP_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_SETOP_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
-
Deprecated.
- BINDABLE_SORT_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_TABLE_SCAN_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_VALUES_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BINDABLE_WINDOW_RULE - Static variable in class org.apache.calcite.interpreter.Bindables
- BindableAggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableAggregate
-
Deprecated.
- BindableAggregate(RelOptCluster, RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableAggregate
- BindableAggregateRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableAggregateRule
-
Called from the Config.
- BindableConvention - Enum in org.apache.calcite.interpreter
-
Calling convention that returns results as an
Enumerable
of object arrays. - BindableFilter(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableFilter
- BindableFilterRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableFilterRule
-
Called from the Config.
- BindableIntersect(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableIntersect
- BindableJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableJoin
-
Creates a BindableJoin.
- BindableJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, Set<String>) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableJoin
-
Deprecated.
- BindableJoinRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableJoinRule
-
Called from the Config.
- BindableMatchRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableMatchRule
-
Called from the Config.
- BindableMinus(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableMinus
- BindableProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableProject
- BindableProjectRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableProjectRule
-
Called from the Config.
- BindableRel - Interface in org.apache.calcite.interpreter
-
Relational expression that can implement itself in Bindable convention.
- Bindables - Class in org.apache.calcite.interpreter
-
Utilities pertaining to
BindableRel
andBindableConvention
. - Bindables.BindableAggregate - Class in org.apache.calcite.interpreter
-
Implementation of
Aggregate
in bindable calling convention. - Bindables.BindableAggregateRule - Class in org.apache.calcite.interpreter
-
Rule that converts an
Aggregate
to bindable convention. - Bindables.BindableFilter - Class in org.apache.calcite.interpreter
-
Implementation of
Filter
in bindable convention. - Bindables.BindableFilterRule - Class in org.apache.calcite.interpreter
-
Rule that converts a
Filter
to bindable convention. - Bindables.BindableIntersect - Class in org.apache.calcite.interpreter
-
Implementation of
Intersect
in bindable calling convention. - Bindables.BindableJoin - Class in org.apache.calcite.interpreter
-
Implementation of
Join
in bindable calling convention. - Bindables.BindableJoinRule - Class in org.apache.calcite.interpreter
-
Rule to convert a
LogicalJoin
to aBindables.BindableJoin
. - Bindables.BindableMatch - Class in org.apache.calcite.interpreter
-
Implementation of
Match
in bindable convention. - Bindables.BindableMatchRule - Class in org.apache.calcite.interpreter
-
Rule to convert a
LogicalMatch
to aBindables.BindableMatch
. - Bindables.BindableMinus - Class in org.apache.calcite.interpreter
-
Implementation of
Minus
in bindable calling convention. - Bindables.BindableProject - Class in org.apache.calcite.interpreter
-
Implementation of
Project
in bindable calling convention. - Bindables.BindableProjectRule - Class in org.apache.calcite.interpreter
-
Rule to convert a
LogicalProject
to aBindables.BindableProject
. - Bindables.BindableSetOpRule - Class in org.apache.calcite.interpreter
-
Rule to convert an
SetOp
to aBindables.BindableUnion
orBindables.BindableIntersect
orBindables.BindableMinus
. - Bindables.BindableSort - Class in org.apache.calcite.interpreter
-
Implementation of
Sort
bindable calling convention. - Bindables.BindableSortRule - Class in org.apache.calcite.interpreter
-
Rule to convert an
Sort
to aBindables.BindableSort
. - Bindables.BindableTableScan - Class in org.apache.calcite.interpreter
-
Scan of a table that implements
ScannableTable
and therefore can be converted into anEnumerable
. - Bindables.BindableTableScanRule - Class in org.apache.calcite.interpreter
-
Rule that converts a
TableScan
to bindable convention. - Bindables.BindableTableScanRule.Config - Interface in org.apache.calcite.interpreter
-
Rule configuration.
- Bindables.BindableUnion - Class in org.apache.calcite.interpreter
-
Implementation of
Union
in bindable calling convention. - Bindables.BindableValues - Class in org.apache.calcite.interpreter
-
Implementation of
Values
in bindable calling convention. - Bindables.BindableValuesRule - Class in org.apache.calcite.interpreter
-
Rule that converts a
Values
to bindable convention. - Bindables.BindableWindow - Class in org.apache.calcite.interpreter
-
Implementation of
Window
in bindable convention. - Bindables.BindableWindowRule - Class in org.apache.calcite.interpreter
-
Rule to convert a
LogicalWindow
to aBindables.BindableWindow
. - BindableSetOpRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableSetOpRule
-
Called from the Config.
- BindableSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableSort
- BindableSortRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableSortRule
-
Called from the Config.
- BindableTableScanRule(Bindables.BindableTableScanRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableTableScanRule
-
Called from Config.
- BindableTableScanRule(RelBuilderFactory) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableTableScanRule
-
Deprecated.
- BindableUnion(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableUnion
- BindableValuesRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableValuesRule
-
Called from the Config.
- BindableWindowRule(ConverterRule.Config) - Constructor for class org.apache.calcite.interpreter.Bindables.BindableWindowRule
-
Called from the Config.
- BiRel - Class in org.apache.calcite.rel
-
Abstract base class for relational expressions with a two inputs.
- BiRel(RelOptCluster, RelTraitSet, RelNode, RelNode) - Constructor for class org.apache.calcite.rel.BiRel
- birthPlace - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Author
- BIT_AND - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
BIT_AND
aggregate function. - BIT_AND - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIT_AND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
BIT_AND
aggregate function. - BIT_GET - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIT_GET - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "BIT_GET(value, position)" function.
- BIT_LENGTH - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIT_LENGTH - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "BIT_LENGTH(string or binary)" function.
- BIT_OR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
BIT_OR
aggregate function. - BIT_OR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIT_OR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
BIT_OR
aggregate function. - BIT_SET_INCLUSION_ORDERING - Static variable in class org.apache.calcite.util.PartiallyOrderedSet
-
Ordering that orders bit sets by inclusion.
- BIT_XOR - Enum constant in enum org.apache.calcite.sql.SqlKind
-
The
BIT_XOR
aggregate function. - BIT_XOR - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BIT_XOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
BIT_XOR
aggregate function. - bitAnd(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BIT_AND
applied to integer values. - bitAnd(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BIT_AND
applied to binary values. - bitGet(byte, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL BIT_GET(value, position) function.
- bitGet(int, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL BIT_GET(value, position) function.
- bitGet(long, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL BIT_GET(value, position) function.
- bitGet(short, int) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL BIT_GET(value, position) function.
- bitLength(String) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL BIT_LENGTH(string) function.
- bitLength(ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
SQL BIT_LENGTH(binary) function.
- bitOr(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BIT_OR
applied to integer values. - bitOr(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BIT_OR
applied to binary values. - bits(List<RexNode>, RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil.InputFinder
-
Returns a bit set describing the inputs used by a collection of project expressions and an optional condition.
- bits(RexNode) - Static method in class org.apache.calcite.plan.RelOptUtil.InputFinder
-
Returns a bit set describing the inputs used by an expression.
- bitSet - Variable in class org.apache.calcite.materialize.Lattice.Tile
- bitSet - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema.BadType
- bitSet - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- bitSet() - Method in class org.apache.calcite.materialize.Lattice.Tile
- BitSets - Class in org.apache.calcite.util
-
Utility functions for
BitSet
. - BitString - Class in org.apache.calcite.util
-
String of bits.
- BitString(String, int) - Constructor for class org.apache.calcite.util.BitString
- bitXor(long, long) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BIT_XOR
applied to integer values. - bitXor(ByteString, ByteString) - Static method in class org.apache.calcite.runtime.SqlFunctions
-
Bitwise function
BIT_XOR
applied to binary values. - bl - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- BLACK - Enum constant in enum org.apache.calcite.sql.SqlWriter.SubQueryStyle
-
Damian's style of sub-query nesting.
- Blackboard(SqlValidatorScope, Map<String, RexNode>, boolean) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
-
Creates a Blackboard.
- blackholeMap() - Static method in class org.apache.calcite.util.Util
-
Returns a map which ignores any write operation.
- BLANK - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- bloat() - Method in interface org.apache.calcite.rel.rules.ProjectMergeRule.Config
-
Limit how much complexity can increase during merging.
- bloat() - Method in interface org.apache.calcite.tools.RelBuilder.Config
-
Controls whether to merge two
Project
operators when inlining expressions causes complexity to increase. - block - Variable in class org.apache.calcite.adapter.enumerable.EnumerableRel.Result
- block - Variable in class org.apache.calcite.adapter.spark.SparkRel.Result
- block(Iterable<? extends Statement>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BlockExpression that contains the given statements.
- block(Type, Iterable<? extends Statement>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BlockExpression that contains the given expressions, has no variables and has specific result type.
- block(Type, Statement...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BlockExpression that contains the given statements and has a specific result type, using varargs.
- block(Statement...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a BlockExpression that contains the given statements, using varargs.
- Block - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A block of expressions.
- BlockBuilder - Class in org.apache.calcite.linq4j.tree
-
Builder for
BlockStatement
. - BlockBuilder() - Constructor for class org.apache.calcite.linq4j.tree.BlockBuilder
-
Creates a non-optimizing BlockBuilder.
- BlockBuilder(boolean) - Constructor for class org.apache.calcite.linq4j.tree.BlockBuilder
-
Creates a BlockBuilder.
- BlockBuilder(boolean, BlockBuilder) - Constructor for class org.apache.calcite.linq4j.tree.BlockBuilder
-
Creates a BlockBuilder.
- Blocks - Class in org.apache.calcite.linq4j.tree
-
Helper methods concerning
BlockStatement
s. - BlockStatement - Class in org.apache.calcite.linq4j.tree
-
Represents a block that contains a sequence of expressions where variables can be defined.
- body - Variable in class org.apache.calcite.linq4j.tree.CatchBlock
- body - Variable in class org.apache.calcite.linq4j.tree.ConstructorDeclaration
- body - Variable in class org.apache.calcite.linq4j.tree.ForEachStatement
- body - Variable in class org.apache.calcite.linq4j.tree.ForStatement
- body - Variable in class org.apache.calcite.linq4j.tree.FunctionExpression
- body - Variable in class org.apache.calcite.linq4j.tree.MethodDeclaration
- body - Variable in class org.apache.calcite.linq4j.tree.TryStatement
- body - Variable in class org.apache.calcite.linq4j.tree.WhileStatement
- body - Variable in class org.apache.calcite.sql.SqlWith
- Book(String, int, List<BookstoreSchema.Page>) - Constructor for class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Book
- books - Variable in class org.apache.calcite.test.schemata.bookstore.BookstoreSchema.Author
- BOOKSTORE - Enum constant in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- BookstoreSchema - Class in org.apache.calcite.test.schemata.bookstore
-
A Schema representing a bookstore.
- BookstoreSchema() - Constructor for class org.apache.calcite.test.schemata.bookstore.BookstoreSchema
- BookstoreSchema.Author - Class in org.apache.calcite.test.schemata.bookstore
-
Author.
- BookstoreSchema.Book - Class in org.apache.calcite.test.schemata.bookstore
-
Book.
- BookstoreSchema.Coordinate - Class in org.apache.calcite.test.schemata.bookstore
-
Coordinate.
- BookstoreSchema.Page - Class in org.apache.calcite.test.schemata.bookstore
-
Page.
- BookstoreSchema.Place - Class in org.apache.calcite.test.schemata.bookstore
-
Place.
- BOOL_AND - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "BOOL_AND(condition)" aggregate function, PostgreSQL and Redshift's equivalent to
SqlStdOperatorTable.EVERY
. - BOOL_OR - Static variable in class org.apache.calcite.sql.fun.SqlLibraryOperators
-
The "BOOL_OR(condition)" aggregate function, PostgreSQL and Redshift's equivalent to
SqlStdOperatorTable.SOME
. - BOOLEAN - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive
- BOOLEAN - Enum constant in enum org.apache.calcite.sql.type.SqlTypeFamily
- BOOLEAN - Enum constant in enum org.apache.calcite.sql.type.SqlTypeName
- BOOLEAN - Static variable in class org.apache.calcite.sql.type.InferTypes
-
Operand type-inference strategy where an unknown operand type is assumed to be boolean.
- BOOLEAN - Static variable in class org.apache.calcite.sql.type.OperandTypes
- BOOLEAN - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is Boolean.
- BOOLEAN - Static variable in interface org.apache.calcite.util.JdbcType
- BOOLEAN_BOOLEAN - Static variable in class org.apache.calcite.sql.type.OperandTypes
- BOOLEAN_FORCE_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is a nullable Boolean.
- BOOLEAN_LITERAL - Static variable in class org.apache.calcite.sql.type.OperandTypes
-
Operand type-checking strategy type must be a boolean non-NULL literal.
- BOOLEAN_NOT_NULL - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is BOOLEAN NOT NULL.
- BOOLEAN_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is Boolean, with nulls allowed if any of the operands allow nulls.
- BOOLEAN_NULLABLE - Static variable in interface org.apache.calcite.util.JdbcType
- BOOLEAN_NULLABLE_IF_ARG0_NULLABLE - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy whereby the result type of a call is Boolean, with nulls allowed if the type of the operand #0 (0-based) is nullable.
- BOOLEAN_NULLABLE_OPTIMIZED - Static variable in class org.apache.calcite.sql.type.ReturnTypes
-
Type-inference strategy with similar effect to
ReturnTypes.BOOLEAN_NULLABLE
, which is more efficient, but can only be used if all arguments are BOOLEAN. - BOOLEAN_TO_STRING - Enum constant in enum org.apache.calcite.util.BuiltInMethod
- BOOLEAN_TYPE_CHECKER - Static variable in class org.apache.calcite.sql.test.SqlTests
- BOOLEAN_TYPES - Static variable in enum org.apache.calcite.sql.type.SqlTypeName
- booleanEquality(SqlCallBinding, RelDataType, RelDataType) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
-
Casts "BOOLEAN = NUMERIC" to "NUMERIC = NUMERIC".
- booleanValue() - Method in class org.apache.calcite.sql.SqlLiteral
-
Returns the value as a boolean.
- booleanValue(RexNode) - Static method in class org.apache.calcite.rex.RexLiteral
- boolRelDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- bools - Variable in class org.apache.calcite.test.schemata.catchall.CatchallSchema
- BOTH - Enum constant in enum org.apache.calcite.plan.DeriveMode
-
Iterates over each child, uses current child's traits to decide what traits to require from the other children.
- BOTH - Enum constant in enum org.apache.calcite.sql.fun.SqlTrimFunction.Flag
- BOTH_PROJECT - Static variable in interface org.apache.calcite.rel.rules.MultiJoinProjectTransposeRule.Config
- BOTTOM_UP - Enum constant in enum org.apache.calcite.plan.hep.HepMatchOrder
-
Match from leaves up.
- bound - Variable in class org.apache.calcite.linq4j.tree.NewArrayExpression
- box(Class) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Converts a primitive class to a boxed class; returns other classes unchanged.
- box(Type) - Static method in enum org.apache.calcite.linq4j.tree.Primitive
-
Converts a primitive type to a boxed type; returns other types unchanged.
- box(Type) - Static method in class org.apache.calcite.linq4j.tree.Types
- box(Expression) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Converts e.g.
- box(Expression, Primitive) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Returns an expression to box the value of a primitive expression.
- BOX - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive.Flavor
-
A type that boxes a primitive, e.g.
- boxClass - Variable in enum org.apache.calcite.linq4j.tree.Primitive
- BOXED - Static variable in class org.apache.calcite.rel.core.Project.Flags
-
Deprecated.
- BOXED_FALSE_EXPR - Static variable in class org.apache.calcite.adapter.enumerable.RexImpTable
- BOXED_FALSE_EXPR - Static variable in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- BOXED_TRUE_EXPR - Static variable in class org.apache.calcite.adapter.enumerable.RexImpTable
- BOXED_TRUE_EXPR - Static variable in class org.apache.calcite.linq4j.tree.OptimizeShuttle
- boxName - Variable in enum org.apache.calcite.linq4j.tree.Primitive
- BQ_DOUBLE - Enum constant in enum org.apache.calcite.config.CharLiteralStyle
-
Double-quoted character literal with backslash escapes, as in BigQuery.
- BQ_SINGLE - Enum constant in enum org.apache.calcite.config.CharLiteralStyle
-
Single-quoted character literal with backslash escapes, as in BigQuery.
- BreadthFirstIterator<V,
E extends DefaultEdge> - Class in org.apache.calcite.util.graph -
Iterates over the vertices in a directed graph in breadth-first order.
- BreadthFirstIterator(DirectedGraph<V, E>, V) - Constructor for class org.apache.calcite.util.graph.BreadthFirstIterator
- Break - Enum constant in enum org.apache.calcite.linq4j.tree.GotoExpressionKind
-
A GotoExpression that represents a break statement.
- break_(LabelTarget) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a GotoExpression representing a break statement.
- break_(LabelTarget, 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_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Decouple an abstraction from its implementation so that the two can very independently.
- BROADCAST_DISTRIBUTED - Enum constant in enum org.apache.calcite.rel.RelDistribution.Type
-
There are multiple instances of the stream, and all records appear in each instance.
- BROADCAST_DISTRIBUTED - Static variable in class org.apache.calcite.rel.RelDistributions
-
The singleton broadcast distribution.
- brokenTestsEnabled() - Method in interface org.apache.calcite.sql.test.SqlOperatorFixture
-
Returns whether to run tests that are considered 'broken'.
- buf - Variable in class org.apache.calcite.materialize.Lattice.SqlWriter
- BufferStyle - Class in org.apache.calcite.runtime
-
A parser for buffer styles as defined by PostGIS.
- BufferStyle(String) - Constructor for class org.apache.calcite.runtime.BufferStyle
- Bug - Class in org.apache.calcite.util
-
Holder for a list of constants describing which bugs which have not been fixed.
- Bug() - Constructor for class org.apache.calcite.util.Bug
- build() - Method in class org.apache.calcite.adapter.druid.VirtualColumn.Builder
- build() - Method in class org.apache.calcite.interpreter.Row.RowBuilder
-
Returns a Row.
- build() - Method in class org.apache.calcite.materialize.Lattice.Builder
-
Builds a lattice.
- build() - Method in class org.apache.calcite.materialize.Lattice.TileBuilder
- build() - Method in class org.apache.calcite.plan.hep.HepProgramBuilder
-
Returns the constructed program, clearing the state of this program builder as a side-effect.
- build() - Method in class org.apache.calcite.plan.RelOptUtil.InputFinder
-
Returns the bit set.
- build() - Method in class org.apache.calcite.profile.ProfilerImpl.Builder
- build() - Method in class org.apache.calcite.rel.hint.HintStrategy.Builder
- build() - Method in class org.apache.calcite.rel.hint.HintStrategyTable.Builder
- build() - Method in class org.apache.calcite.rel.hint.RelHint.Builder
- build() - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Creates a struct type with the current contents of this builder.
- build() - Method in interface org.apache.calcite.rel.type.TimeFrameSet.Builder
-
Creates a
TimeFrameSet
. - build() - Method in class org.apache.calcite.runtime.AutomatonBuilder
-
Builds the automaton.
- build() - Method in class org.apache.calcite.runtime.Matcher.Builder
- build() - Method in class org.apache.calcite.runtime.PairList.Builder
-
Builds the PairList.
- build() - Method in class org.apache.calcite.runtime.Pattern.PatternBuilder
-
Returns the resulting pattern.
- build() - Method in class org.apache.calcite.schema.impl.ReflectiveFunctionBase.ParameterListBuilder
- build() - Method in class org.apache.calcite.sql.parser.SqlParser.ConfigBuilder
-
Deprecated.Builds a
SqlParser.Config
. - build() - Method in class org.apache.calcite.sql.TableCharacteristic.Builder
- build() - Method in class org.apache.calcite.tools.Frameworks.ConfigBuilder
- build() - Method in class org.apache.calcite.tools.RelBuilder
-
Returns the final relational expression.
- build() - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Builds an ImmutableBitSet from the contents of this Builder.
- build() - Method in class org.apache.calcite.util.ImmutableNullableList.Builder
-
Returns a newly-created
ImmutableNullableList
based on the contents of theBuilder
. - build() - Method in class org.apache.calcite.util.ImmutableNullableSet.Builder
-
Returns a newly-created
ImmutableNullableSet
based on the contents of theBuilder
. - build() - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- build() - Method in interface org.apache.calcite.util.Puffin.Builder
-
Builds the program.
- build(ImmutableList.Builder<SqlValidatorScope.Step>) - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.Path
- build(ImmutableList.Builder<SqlValidatorScope.Step>) - Method in class org.apache.calcite.sql.validate.SqlValidatorScope.Step
- build(RelNode...) - Method in class org.apache.calcite.sql2rel.RelDecorrelator.CorelMapBuilder
-
Creates a CorelMap by iterating over a
RelNode
tree. - build(ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Builds an ImmutableBitSet from the contents of this Builder, using an existing ImmutableBitSet if it happens to have the same contents.
- buildAggGroupList(Aggregate, SqlImplementor.Builder, List<SqlNode>, List<SqlNode>) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Builds the group list for an Aggregate node.
- buildAggregate(Aggregate, SqlImplementor.Builder, List<SqlNode>, List<SqlNode>) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverter
-
Builds an aggregate query.
- buildAndReset() - Method in class org.apache.calcite.util.ImmutableBitSet.Builder
-
Builds an ImmutableBitSet from the contents of this Builder.
- buildBag(Object...) - Static method in class org.apache.calcite.piglet.PigRelSqlUdfs
-
Implementation for PIG_BAG functions.
- buildDynamic() - Method in class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Creates a dynamic struct type with the current contents of this builder.
- builder() - Static method in class org.apache.calcite.adapter.druid.VirtualColumn
- builder() - Static method in class org.apache.calcite.materialize.Lattice.Tile
- builder() - Static method in class org.apache.calcite.plan.hep.HepProgram
- builder() - Method in class org.apache.calcite.plan.RelOptRuleCall
-
Creates a
RelBuilder
to be used by code within the call. - builder() - Static method in class org.apache.calcite.profile.ProfilerImpl
- builder() - Static method in class org.apache.calcite.rel.hint.HintStrategyTable
-
Returns a
HintStrategyTable
builder. - builder() - Method in interface org.apache.calcite.rel.type.RelDataTypeFactory
-
Creates a
RelDataTypeFactory.FieldInfoBuilder
. - builder() - Method in class org.apache.calcite.rel.type.RelDataTypeFactoryImpl
- builder() - Static method in class org.apache.calcite.rel.type.TimeFrameSet
-
Creates a Builder.
- builder() - Static method in interface org.apache.calcite.runtime.PairList
-
Creates a Builder.
- builder() - Static method in interface org.apache.calcite.runtime.Pattern
-
Creates a builder.
- builder() - Static method in class org.apache.calcite.schema.impl.ReflectiveFunctionBase
-
Creates a ParameterListBuilder.
- builder() - Static method in class org.apache.calcite.sql.type.SqlTypeMappingRules
-
Returns a
SqlTypeMappingRules.Builder
to build the type mappings. - builder() - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Creates an empty Builder.
- builder() - Static method in class org.apache.calcite.util.ImmutableNullableList
-
Returns a new builder.
- builder() - Static method in class org.apache.calcite.util.ImmutableNullableSet
-
Returns a new builder.
- builder() - Static method in class org.apache.calcite.util.Puffin
-
Creates a Builder with no state.
- builder(String) - Static method in class org.apache.calcite.rel.hint.RelHint
-
Creates a hint builder with specified hint name.
- builder(Supplier<G>, Function<G, F>) - Static method in class org.apache.calcite.util.Puffin
-
Creates a Builder.
- builder(CalciteSchema, String) - Static method in class org.apache.calcite.materialize.Lattice
- builder(HintPredicate) - Static method in class org.apache.calcite.rel.hint.HintStrategy
-
Returns a
HintStrategy
builder with given hint predicate. - builder(RelNode) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Creates a builder for the SQL of the given relational expression, using the clauses that you declared when you called
SqlImplementor.visitInput(RelNode, int, Set)
. - builder(RelNode, SqlImplementor.Clause, SqlImplementor.Clause...) - Method in class org.apache.calcite.rel.rel2sql.SqlImplementor.Result
-
Deprecated.Provide the expected clauses up-front, when you call
SqlImplementor.visitInput(RelNode, int, Set)
, then create a builder usingSqlImplementor.Result.builder(RelNode)
. - builder(Automaton) - Static method in class org.apache.calcite.runtime.Matcher
- builder(TableCharacteristic.Semantics) - Static method in class org.apache.calcite.sql.TableCharacteristic
-
Creates a builder.
- builder(ImmutableBitSet) - Static method in class org.apache.calcite.util.ImmutableBitSet
-
Deprecated.
- Builder() - Constructor for class org.apache.calcite.adapter.druid.VirtualColumn.Builder
- Builder() - Constructor for class org.apache.calcite.profile.ProfilerImpl.Builder
- Builder() - Constructor for class org.apache.calcite.rel.hint.HintStrategyTable.Builder
- Builder() - Constructor for class org.apache.calcite.runtime.PairList.Builder
- Builder() - Constructor for class org.apache.calcite.util.ImmutableNullableList.Builder
-
Creates a new builder.
- Builder() - Constructor for class org.apache.calcite.util.ImmutableNullableSet.Builder
-
Creates a new builder.
- Builder() - Constructor for class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- Builder(LatticeSpace, CalciteSchema, String) - Constructor for class org.apache.calcite.materialize.Lattice.Builder
- Builder(RelNode, List<SqlImplementor.Clause>, SqlSelect, SqlImplementor.Context, boolean, Map<String, RelDataType>) - Constructor for class org.apache.calcite.rel.rel2sql.SqlImplementor.Builder
- Builder(RelDataTypeFactory) - Constructor for class org.apache.calcite.rel.type.RelDataTypeFactory.Builder
-
Creates a Builder with the given type factory.
- BUILDER_PATTERN - Static variable in interface org.apache.calcite.util.Glossary
-
Separate the construction of a complex object from its representation so that the same construction process can create different representations.
- buildImmutable() - Method in class org.apache.calcite.runtime.PairList.Builder
-
Builds an ImmutablePairList.
- buildIndex(Iterable<? extends SqlOperator>) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
-
Derives a value to be assigned to
SqlOperatorTables.IndexedSqlOperatorTable.operators
from a given list of operators. - buildQuery(String) - Static method in class org.apache.calcite.sql.test.AbstractSqlTester
- buildQuery2(SqlTestFactory, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
-
Builds a query that extracts all literals as columns in an underlying select.
- buildQueryAgg(String) - Static method in class org.apache.calcite.sql.test.AbstractSqlTester
- buildTuple(Object...) - Static method in class org.apache.calcite.piglet.PigRelSqlUdfs
-
Implementation for PIG_TUPLE functions.
- BUILT_IN_OPERATORS_LIST - Static variable in class org.apache.calcite.sql.SqlDialect
-
Built-in scalar functions and operators common for every dialect.
- builtinFunctionCoercion(SqlCallBinding, List<RelDataType>, List<SqlTypeFamily>) - Method in interface org.apache.calcite.sql.validate.implicit.TypeCoercion
-
Type coercion with inferred type from passed in arguments and the
SqlTypeFamily
defined in the checkers, e.g. - builtinFunctionCoercion(SqlCallBinding, List<RelDataType>, List<SqlTypeFamily>) - Method in class org.apache.calcite.sql.validate.implicit.TypeCoercionImpl
- BuiltInMetadata - Class in org.apache.calcite.rel.metadata
-
Contains the interfaces for several common forms of metadata.
- BuiltInMetadata() - Constructor for class org.apache.calcite.rel.metadata.BuiltInMetadata
- BuiltInMetadata.AllPredicates - Interface in org.apache.calcite.rel.metadata
-
Metadata about the predicates that hold in the rows emitted from a relational expression.
- BuiltInMetadata.AllPredicates.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Collation - Interface in org.apache.calcite.rel.metadata
-
Metadata about which columns are sorted.
- BuiltInMetadata.Collation.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.ColumnOrigin - Interface in org.apache.calcite.rel.metadata
-
Metadata about the origins of columns.
- BuiltInMetadata.ColumnOrigin.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.ColumnUniqueness - Interface in org.apache.calcite.rel.metadata
-
Metadata about whether a set of columns uniquely identifies a row.
- BuiltInMetadata.ColumnUniqueness.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.CumulativeCost - Interface in org.apache.calcite.rel.metadata
-
Metadata about the cost of evaluating a relational expression, including all of its inputs.
- BuiltInMetadata.CumulativeCost.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.DistinctRowCount - Interface in org.apache.calcite.rel.metadata
-
Metadata about the number of distinct rows returned by a set of columns in a relational expression.
- BuiltInMetadata.DistinctRowCount.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Distribution - Interface in org.apache.calcite.rel.metadata
-
Metadata about how a relational expression is distributed.
- BuiltInMetadata.Distribution.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.ExplainVisibility - Interface in org.apache.calcite.rel.metadata
-
Metadata about whether a relational expression should appear in a plan.
- BuiltInMetadata.ExplainVisibility.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.ExpressionLineage - Interface in org.apache.calcite.rel.metadata
-
Metadata about the origins of expressions.
- BuiltInMetadata.ExpressionLineage.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.LowerBoundCost - Interface in org.apache.calcite.rel.metadata
-
Metadata to get the lower bound cost of a RelNode.
- BuiltInMetadata.LowerBoundCost.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.MaxRowCount - Interface in org.apache.calcite.rel.metadata
-
Metadata about the maximum number of rows returned by a relational expression.
- BuiltInMetadata.MaxRowCount.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Memory - Interface in org.apache.calcite.rel.metadata
-
Metadata about the memory use of an operator.
- BuiltInMetadata.Memory.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.MinRowCount - Interface in org.apache.calcite.rel.metadata
-
Metadata about the minimum number of rows returned by a relational expression.
- BuiltInMetadata.MinRowCount.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.NodeTypes - Interface in org.apache.calcite.rel.metadata
-
Metadata about the node types in a relational expression.
- BuiltInMetadata.NodeTypes.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.NonCumulativeCost - Interface in org.apache.calcite.rel.metadata
-
Metadata about the cost of evaluating a relational expression, not including its inputs.
- BuiltInMetadata.NonCumulativeCost.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Parallelism - Interface in org.apache.calcite.rel.metadata
-
Metadata about the degree of parallelism of a relational expression, and how its operators are assigned to processes with independent resource pools.
- BuiltInMetadata.Parallelism.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.PercentageOriginalRows - Interface in org.apache.calcite.rel.metadata
-
Metadata about the proportion of original rows that remain in a relational expression.
- BuiltInMetadata.PercentageOriginalRows.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.PopulationSize - Interface in org.apache.calcite.rel.metadata
-
Metadata about the number of distinct values in the original source of a column or set of columns.
- BuiltInMetadata.PopulationSize.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Predicates - Interface in org.apache.calcite.rel.metadata
-
Metadata about the predicates that hold in the rows emitted from a relational expression.
- BuiltInMetadata.Predicates.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.RowCount - Interface in org.apache.calcite.rel.metadata
-
Metadata about the number of rows returned by a relational expression.
- BuiltInMetadata.RowCount.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Selectivity - Interface in org.apache.calcite.rel.metadata
-
Metadata about the selectivity of a predicate.
- BuiltInMetadata.Selectivity.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.Size - Interface in org.apache.calcite.rel.metadata
-
Metadata about the size of rows and columns.
- BuiltInMetadata.Size.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.TableReferences - Interface in org.apache.calcite.rel.metadata
-
Metadata to obtain references to tables used by a given expression.
- BuiltInMetadata.TableReferences.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMetadata.UniqueKeys - Interface in org.apache.calcite.rel.metadata
-
Metadata about which combinations of columns are unique identifiers.
- BuiltInMetadata.UniqueKeys.Handler - Interface in org.apache.calcite.rel.metadata
-
Handler API.
- BuiltInMethod - Enum in org.apache.calcite.util
-
Built-in methods.
- by - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- BYTE - Enum constant in enum org.apache.calcite.linq4j.tree.Primitive
- byteDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerFixtures.Fixture
- BYTES_PER_CHARACTER - Static variable in class org.apache.calcite.rel.metadata.RelMdSize
-
Bytes per character (2).
C
- c(int) - Static method in class org.apache.calcite.test.schemata.tpch.TpchSchema
- cache - Variable in class org.apache.calcite.model.JsonSchema
-
Whether to cache metadata (tables, functions and sub-schemas) generated by this schema.
- CACHED_SQL - Static variable in class org.apache.calcite.materialize.Lattices
-
Statistics provider that uses SQL then stores the results in a cache.
- CacheUtil - Class in org.apache.calcite.rel.metadata.janino
-
Functions used by generated code.
- CachingRelMetadataProvider - Class in org.apache.calcite.rel.metadata
-
Deprecated.
- CachingRelMetadataProvider(RelMetadataProvider, RelOptPlanner) - Constructor for class org.apache.calcite.rel.metadata.CachingRelMetadataProvider
-
Deprecated.
- CachingSqlStatisticProvider - Class in org.apache.calcite.statistic
-
Implementation of
SqlStatisticProvider
that reads and writes a cache. - CachingSqlStatisticProvider(SqlStatisticProvider, Cache<List, Object>) - Constructor for class org.apache.calcite.statistic.CachingSqlStatisticProvider
- calc(RelMetadataProvider) - Static method in class org.apache.calcite.tools.Programs
- calc(RelMetadataQuery, RelNode, RexProgram) - Static method in class org.apache.calcite.rel.metadata.RelMdCollation
-
Helper method to determine a
Calc
's collation. - calc(RelMetadataQuery, RelNode, RexProgram) - Static method in class org.apache.calcite.rel.metadata.RelMdDistribution
-
Helper method to determine a
Calc
's distribution. - Calc - Class in org.apache.calcite.rel.core
-
Calc
is an abstract base class for implementations ofLogicalCalc
. - Calc(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RexProgram) - Constructor for class org.apache.calcite.rel.core.Calc
-
Creates a Calc.
- Calc(RelOptCluster, RelTraitSet, RelNode, RexProgram) - Constructor for class org.apache.calcite.rel.core.Calc
-
Deprecated.
- Calc(RelOptCluster, RelTraitSet, RelNode, RexProgram, List<RelCollation>) - Constructor for class org.apache.calcite.rel.core.Calc
-
Deprecated.
- CALC - Static variable in class org.apache.calcite.rel.hint.HintPredicates
-
A hint predicate that indicates a hint can only be used to
Calc
nodes. - CALC_MERGE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that merges a
Calc
onto aCalc
. - CALC_PREDICATE - Static variable in class org.apache.calcite.plan.RelOptUtil
-
Deprecated.
- CALC_PROGRAM - Static variable in class org.apache.calcite.tools.Programs
-
Program that converts filters and projects to
Calc
s. - CALC_REDUCE_DECIMALS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that reduces operations on the DECIMAL type, such as casts or arithmetic, into operations involving more primitive types such as BIGINT and DOUBLE.
- CALC_REDUCE_EXPRESSIONS - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that reduces constants inside a
LogicalCalc
. - CALC_REMOVE - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that removes a trivial
LogicalCalc
. - CALC_RULES - Static variable in class org.apache.calcite.plan.RelOptRules
-
Calc rule set; public so that
Programs
can use it. - CALC_RULES - Static variable in class org.apache.calcite.tools.Programs
-
Deprecated.
- CALC_SPLIT - Static variable in class org.apache.calcite.rel.rules.CoreRules
- CALC_TO_WINDOW - Static variable in class org.apache.calcite.rel.rules.CoreRules
-
Rule that transforms a
Calc
that contains windowed aggregates to a mixture ofLogicalWindow
andCalc
. - CALCITE - Enum constant in enum org.apache.calcite.sql.fun.SqlLibrary
-
Calcite-specific extensions.
- CALCITE - Enum constant in enum org.apache.calcite.sql.SqlDialect.DatabaseProduct
- CALCITE_1045_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-1045] Decorrelate sub-queries in Project and Join is fixed.
- CALCITE_1048_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-1048] Make metadata more robust is fixed.
- CALCITE_194_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-194] Array items in MongoDB adapter is fixed.
- CALCITE_2400_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_2401_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-2401] Improve RelMdPredicates performance is fixed.
- CALCITE_2539_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_2869_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-2869] JSON data type support is fixed.
- CALCITE_3243_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-3243] Incomplete validation of operands in JSON functions is fixed.
- CALCITE_4204_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_4205_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_4213_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_4645_FIXED - Static variable in class org.apache.calcite.util.Bug
- CALCITE_5422_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-5422] MILLISECOND and MICROSECOND units in INTERVAL literal is fixed.
- CALCITE_673_FIXED - Static variable in class org.apache.calcite.util.Bug
-
Whether [CALCITE-673] Timeout executing joins against MySQL is fixed.
- CALCITE_AS_ADMIN - Enum constant in enum org.apache.calcite.chinook.ConnectionFactory.DatabaseWrapper
- CALCITE_AS_SPECIFIC_USER - Enum constant in enum org.apache.calcite.chinook.ConnectionFactory.DatabaseWrapper
- CalciteAssert - Class in org.apache.calcite.test
-
Fluid DSL for testing Calcite connections and queries.
- CalciteAssert.AssertMetaData - Class in org.apache.calcite.test
-
Fluent interface for building a metadata query to be tested.
- CalciteAssert.AssertQuery - Class in org.apache.calcite.test
-
Fluent interface for building a query to be tested.
- CalciteAssert.AssertThat - Class in org.apache.calcite.test
-
Result of calling
CalciteAssert.that()
. - CalciteAssert.Config - Enum in org.apache.calcite.test
-
Connection configuration.
- CalciteAssert.ConnectionPostProcessor - Interface in org.apache.calcite.test
-
Connection post-processor.
- CalciteAssert.DatabaseInstance - Enum in org.apache.calcite.test
-
Information necessary to create a JDBC connection.
- CalciteAssert.PreparedStatementConsumer - Interface in org.apache.calcite.test
-
We want a consumer that can throw SqlException.
- CalciteAssert.SchemaSpec - Enum in org.apache.calcite.test
-
Specification for common test schemas.
- CalciteCatalogReader - Class in org.apache.calcite.prepare
-
Implementation of
Prepare.CatalogReader
and alsoSqlOperatorTable
based on tables and functions defined schemas. - CalciteCatalogReader(CalciteSchema, List<String>, RelDataTypeFactory, CalciteConnectionConfig) - Constructor for class org.apache.calcite.prepare.CalciteCatalogReader
- CalciteCatalogReader(CalciteSchema, SqlNameMatcher, List<List<String>>, RelDataTypeFactory, CalciteConnectionConfig) - Constructor for class org.apache.calcite.prepare.CalciteCatalogReader
- CalciteChinookMetaFactory() - Constructor for class org.apache.calcite.chinook.ChinookAvaticaServer.CalciteChinookMetaFactory
- CalciteConnection - Interface in org.apache.calcite.jdbc
-
Extension to Calcite's implementation of
JDBC connection
allows schemas to be defined dynamically. - CalciteConnectionConfig - Interface in org.apache.calcite.config
-
Interface for reading connection properties within Calcite code.
- CalciteConnectionConfigImpl - Class in org.apache.calcite.config
-
Implementation of
CalciteConnectionConfig
. - CalciteConnectionConfigImpl(Properties) - Constructor for class org.apache.calcite.config.CalciteConnectionConfigImpl
- CalciteConnectionProperty - Enum in org.apache.calcite.config
-
Properties that may be specified on the JDBC connect string.
- CalciteConnectionProvider - Class in org.apache.calcite.chinook
-
Provider of calcite connections for end-to-end tests.
- CalciteConnectionProvider() - Constructor for class org.apache.calcite.chinook.CalciteConnectionProvider
- CalciteContextException - Exception Class in org.apache.calcite.runtime
-
Exception which contains information about the textual context of the causing exception.
- CalciteContextException(String, Throwable) - Constructor for exception class org.apache.calcite.runtime.CalciteContextException
-
Creates a new CalciteContextException object.
- CalciteContextException(String, Throwable, int, int, int, int) - Constructor for exception class org.apache.calcite.runtime.CalciteContextException
-
Creates a new CalciteContextException object.
- CalciteContextException(String, Throwable, String) - Constructor for exception class org.apache.calcite.runtime.CalciteContextException
-
Creates a new CalciteContextException object.
- CalciteException - Exception Class in org.apache.calcite.runtime
-
Base class for all exceptions originating from Farrago.
- CalciteException(String, Throwable) - Constructor for exception class org.apache.calcite.runtime.CalciteException
-
Creates a new CalciteException object.
- CalciteFactory - Class in org.apache.calcite.jdbc
-
Extension of
AvaticaFactory
for Calcite. - CalciteFactory(int, int) - Constructor for class org.apache.calcite.jdbc.CalciteFactory
-
Creates a JDBC factory with given major/minor version number.
- CalciteFlatMapFunction() - Constructor for class org.apache.calcite.adapter.spark.SparkRuntime.CalciteFlatMapFunction
- CalciteImmutable - Annotation Type in org.apache.calcite
-
Annotation to be used to convert interfaces/abstract classes into Immutable POJO using Immutables package.
- CalciteJdbc41Factory - Class in org.apache.calcite.jdbc
-
Implementation of
AvaticaFactory
for Calcite and JDBC 4.1 (corresponds to JDK 1.7). - CalciteJdbc41Factory() - Constructor for class org.apache.calcite.jdbc.CalciteJdbc41Factory
-
Creates a factory for JDBC version 4.1.
- CalciteJdbc41Factory(int, int) - Constructor for class org.apache.calcite.jdbc.CalciteJdbc41Factory
-
Creates a JDBC factory with given major/minor version number.
- CalciteLogger - Class in org.apache.calcite.util.trace
-
Small extension to
Logger
with some performance improvements. - CalciteLogger(Logger) - Constructor for class org.apache.calcite.util.trace.CalciteLogger
- CalciteMetaColumnFactory - Interface in org.apache.calcite.jdbc
-
Factory for creating instances of
MetaImpl.MetaColumn
. - CalciteMetaColumnFactoryImpl - Class in org.apache.calcite.jdbc
-
Default implementation of CalciteMetaColumnFactoryImpl.
- CalciteMetaColumnFactoryImpl() - Constructor for class org.apache.calcite.jdbc.CalciteMetaColumnFactoryImpl
-
Internal constructor; protected to allow subclassing.
- CalciteMetaImpl - Class in org.apache.calcite.jdbc
-
Helper for implementing the
getXxx
methods such asAvaticaDatabaseMetaData.getTables(java.lang.String, java.lang.String, java.lang.String, java.lang.String[])
. - CalciteMetaImpl(CalciteConnectionImpl) - Constructor for class org.apache.calcite.jdbc.CalciteMetaImpl
-
Deprecated.Use
CalciteMetaImpl.create(CalciteConnection)
instead. - CalciteMetaImpl(CalciteConnectionImpl, CalciteMetaTableFactory, CalciteMetaColumnFactory) - Constructor for class org.apache.calcite.jdbc.CalciteMetaImpl
-
Internal constructor.
- CalciteMetaImpl.CalciteMetaTable - Class in org.apache.calcite.jdbc
-
Metadata describing a Calcite table.
- CalciteMetaTable(Table, String, String, String) - Constructor for class org.apache.calcite.jdbc.CalciteMetaImpl.CalciteMetaTable
-
Creates a CalciteMetaTable.
- CalciteMetaTableFactory - Interface in org.apache.calcite.jdbc
-
Factory for creating instances of
MetaImpl.MetaTable
. - CalciteMetaTableFactoryImpl - Class in org.apache.calcite.jdbc
-
Default implementation of CalciteMetaTableFactory.
- CalciteMetaTableFactoryImpl() - Constructor for class org.apache.calcite.jdbc.CalciteMetaTableFactoryImpl
-
Internal constructor; protected to allow subclassing.
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.BinaryOperatorConversion
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.CeilOperatorConversion
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.DirectOperatorConversion
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.DruidSqlCastConverter
- calciteOperator() - Method in interface org.apache.calcite.adapter.druid.DruidSqlOperatorConverter
-
Returns the calcite SQL operator corresponding to Druid operator.
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.ExtractOperatorConversion
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.FloorOperatorConversion
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.NaryOperatorConverter
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.SubstringOperatorConversion
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.UnaryPrefixOperatorConversion
- calciteOperator() - Method in class org.apache.calcite.adapter.druid.UnarySuffixOperatorConversion
- CalciteParserException - Interface in org.apache.calcite.util
-
Tagging interface to allow a
SqlParseException
to be identified without adding a dependency on it from client-side code. - CalcitePrepare - Interface in org.apache.calcite.jdbc
-
API for a service that prepares statements for execution.
- CalcitePrepare.AnalyzeViewResult - Class in org.apache.calcite.jdbc
-
The result of analyzing a view.
- CalcitePrepare.CalciteSignature<T> - Class in org.apache.calcite.jdbc
-
The result of preparing a query.
- CalcitePrepare.Context - Interface in org.apache.calcite.jdbc
-
Context for preparing a statement.
- CalcitePrepare.ConvertResult - Class in org.apache.calcite.jdbc
-
The result of parsing and validating a SQL query and converting it to relational algebra.
- CalcitePrepare.Dummy - Class in org.apache.calcite.jdbc
-
Namespace that allows us to define non-abstract methods inside an interface.
- CalcitePrepare.ParseResult - Class in org.apache.calcite.jdbc
-
The result of parsing and validating a SQL query.
- CalcitePrepare.Query<T> - Class in org.apache.calcite.jdbc
- CalcitePrepare.SparkHandler - Interface in org.apache.calcite.jdbc
-
Callback to register Spark as the main engine.
- CalcitePrepare.SparkHandler.RuleSetBuilder - Interface in org.apache.calcite.jdbc
-
Allows Spark to declare the rules it needs.
- CalcitePrepareImpl - Class in org.apache.calcite.prepare
-
Shit just got real.
- CalcitePrepareImpl() - Constructor for class org.apache.calcite.prepare.CalcitePrepareImpl
- CalcitePrepareImpl.CalcitePreparingStmt - Class in org.apache.calcite.prepare
-
Holds state for the process of preparing a SQL statement.
- CalcitePreparingStmt(CalcitePrepareImpl, CalcitePrepare.Context, Prepare.CatalogReader, RelDataTypeFactory, CalciteSchema, EnumerableRel.Prefer, RelOptCluster, Convention, SqlRexConvertletTable) - Constructor for class org.apache.calcite.prepare.CalcitePrepareImpl.CalcitePreparingStmt
-
Constructor.
- CalciteResource - Interface in org.apache.calcite.runtime
-
Compiler-checked resources for the Calcite project.
- CalciteResultSet - Class in org.apache.calcite.jdbc
-
Implementation of
ResultSet
for the Calcite engine. - CalciteRootSchema - Class in org.apache.calcite.jdbc
-
Deprecated.
- CalciteSchema - Class in org.apache.calcite.jdbc
-
Schema.
- CalciteSchema(CalciteSchema, Schema, String, NameMap<CalciteSchema>, NameMap<CalciteSchema.TableEntry>, NameMap<CalciteSchema.LatticeEntry>, NameMap<CalciteSchema.TypeEntry>, NameMultimap<CalciteSchema.FunctionEntry>, NameSet, NameMap<CalciteSchema.FunctionEntry>, List<? extends List<String>>) - Constructor for class org.apache.calcite.jdbc.CalciteSchema
- CalciteSchema.Entry - Class in org.apache.calcite.jdbc
-
Entry in a schema, such as a table or sub-schema.
- CalciteSchema.FunctionEntry - Class in org.apache.calcite.jdbc
-
Membership of a function in a schema.
- CalciteSchema.FunctionEntryImpl - Class in org.apache.calcite.jdbc
-
Implementation of
CalciteSchema.FunctionEntry
where all properties are held in fields. - CalciteSchema.LatticeEntry - Class in org.apache.calcite.jdbc
-
Membership of a lattice in a schema.
- CalciteSchema.LatticeEntryImpl - Class in org.apache.calcite.jdbc
-
Implementation of
CalciteSchema.LatticeEntry
where all properties are held in fields. - CalciteSchema.TableEntry - Class in org.apache.calcite.jdbc
-
Membership of a table in a schema.
- CalciteSchema.TableEntryImpl - Class in org.apache.calcite.jdbc
-
Implementation of
CalciteSchema.TableEntry
where all properties are held in fields. - CalciteSchema.TypeEntry - Class in org.apache.calcite.jdbc
-
Membership of a type in a schema.
- CalciteSchema.TypeEntryImpl - Class in org.apache.calcite.jdbc
-
Implementation of
CalciteSchema.TypeEntry
where all properties are held in fields. - CalciteServer - Interface in org.apache.calcite.server
-
Server.
- CalciteServerStatement - Interface in org.apache.calcite.server
-
Statement within a Calcite server.
- CalciteSignature(String, List<AvaticaParameter>, Map<String, Object>, RelDataType, List<ColumnMetaData>, Meta.CursorFactory, CalciteSchema, List<RelCollation>, long, Bindable<T>, Meta.StatementType) - Constructor for class org.apache.calcite.jdbc.CalcitePrepare.CalciteSignature
- CalciteSignature(String, List<AvaticaParameter>, Map<String, Object>, RelDataType, List<ColumnMetaData>, Meta.CursorFactory, CalciteSchema, List<RelCollation>, long, Bindable<T>) - Constructor for class org.apache.calcite.jdbc.CalcitePrepare.CalciteSignature
-
Deprecated.
- CalciteSqlDialect - Class in org.apache.calcite.sql.dialect
-
A
SqlDialect
implementation that produces SQL that can be parsed by Apache Calcite. - CalciteSqlDialect(SqlDialect.Context) - Constructor for class org.apache.calcite.sql.dialect.CalciteSqlDialect
-
Creates a CalciteSqlDialect.
- CalciteSqlValidator - Class in org.apache.calcite.prepare
-
Validator.
- CalciteSqlValidator(SqlOperatorTable, CalciteCatalogReader, JavaTypeFactory, SqlValidator.Config) - Constructor for class org.apache.calcite.prepare.CalciteSqlValidator
- CalciteStatement - Class in org.apache.calcite.jdbc
-
Implementation of
Statement
for the Calcite engine. - CalciteSystemProperty<T> - Class in org.apache.calcite.config
-
A Calcite specific system property that is used to configure various aspects of the framework.
- CalciteTimingTracer - Class in org.apache.calcite.util.trace
-
CalciteTimingTracer provides a mechanism for tracing the timing of a call sequence at nanosecond resolution.
- CalciteTimingTracer(Logger, String) - Constructor for class org.apache.calcite.util.trace.CalciteTimingTracer
-
Creates a new timing tracer, publishing an initial event (at elapsed time 0).
- CalciteTrace - Class in org.apache.calcite.util.trace
-
Contains all of the
tracers
used within org.apache.calcite class libraries. - CalciteTrace() - Constructor for class org.apache.calcite.util.trace.CalciteTrace
- CalciteValidatorException - Interface in org.apache.calcite.util
-
Tagging interface to allow a
SqlValidatorException
to be identified without adding a dependency on it from client-side code. - CalcMergeRule - Class in org.apache.calcite.rel.rules
- CalcMergeRule(CalcMergeRule.Config) - Constructor for class org.apache.calcite.rel.rules.CalcMergeRule
-
Creates a CalcMergeRule.
- CalcMergeRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.CalcMergeRule
-
Deprecated.
- CalcMergeRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- CalcReduceExpressionsRule(Class<? extends Calc>, boolean, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.CalcReduceExpressionsRule
-
Deprecated.
- CalcReduceExpressionsRule(Class<? extends Calc>, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.CalcReduceExpressionsRule
-
Deprecated.
- CalcReduceExpressionsRule(ReduceExpressionsRule.CalcReduceExpressionsRule.CalcReduceExpressionsRuleConfig) - Constructor for class org.apache.calcite.rel.rules.ReduceExpressionsRule.CalcReduceExpressionsRule
-
Creates a CalcReduceExpressionsRule.
- CalcRelSplitter - Class in org.apache.calcite.rel.rules
- CalcRelSplitter.RelType - Class in org.apache.calcite.rel.rules
-
Type of relational expression.
- CalcRemoveRule - Class in org.apache.calcite.rel.rules
-
Planner rule that removes a trivial
LogicalCalc
. - CalcRemoveRule(CalcRemoveRule.Config) - Constructor for class org.apache.calcite.rel.rules.CalcRemoveRule
-
Creates a CalcRemoveRule.
- CalcRemoveRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.CalcRemoveRule
-
Deprecated.
- CalcRemoveRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- CalcSplitRule - Class in org.apache.calcite.rel.rules
- CalcSplitRule(CalcSplitRule.Config) - Constructor for class org.apache.calcite.rel.rules.CalcSplitRule
-
Creates a CalcSplitRule.
- CalcSplitRule(RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.CalcSplitRule
-
Deprecated.
- CalcSplitRule.Config - Interface in org.apache.calcite.rel.rules
-
Rule configuration.
- CalcToWindowRule(ProjectToWindowRule.CalcToWindowRule.CalcToWindowRuleConfig) - Constructor for class org.apache.calcite.rel.rules.ProjectToWindowRule.CalcToWindowRule
-
Creates a CalcToWindowRule.
- calendar() - Static method in class org.apache.calcite.util.Util
-
Creates a
Calendar
in the UTC time zone and root locale. - calendar(long) - Static method in class org.apache.calcite.util.Util
-
Creates a
Calendar
in the UTC time zone and root locale with a given time. - call - Variable in class org.apache.calcite.adapter.enumerable.AggImpState
- call - Variable in class org.apache.calcite.sql.validate.AliasNamespace
- call() - Method in interface org.apache.calcite.adapter.enumerable.AggResultContext
-
Returns the aggregate call.
- call() - Method in class org.apache.calcite.adapter.enumerable.impl.AggResetContextImpl
- call() - Method in class org.apache.calcite.adapter.enumerable.impl.AggResultContextImpl
- call(Method, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a static method that has arguments.
- call(Method, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a static method that has arguments, using varargs.
- call(Type, String, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a static method by calling the appropriate factory method.
- call(Type, String, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a static method by calling the appropriate factory method, using varargs.
- call(Type, Expression, Method, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a method that takes arguments, with an explicit return type.
- call(Type, Expression, Method, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a method that takes arguments, with an explicit return type, with varargs.
- call(Expression, Class, String, List<? extends Expression>) - Static method in class org.apache.calcite.adapter.enumerable.EnumUtils
-
A more powerful version of
Expressions.call(Type, String, Iterable)
. - call(Expression, Method, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a method that takes arguments.
- call(Expression, Method, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to a method that takes arguments, using varargs.
- call(Expression, String, Iterable<? extends Expression>) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to an instance method by calling the appropriate factory method.
- call(Expression, String, Expression...) - Static method in class org.apache.calcite.linq4j.tree.Expressions
-
Creates a MethodCallExpression that represents a call to an instance method by calling the appropriate factory method, using varargs.
- call(SqlOperator, Iterable<? extends RexNode>) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to a scalar operator.
- call(SqlOperator, RexNode...) - Method in class org.apache.calcite.tools.RelBuilder
-
Creates a call to a scalar operator.
- call(PrecedenceClimbingParser.Op, ImmutableList<PrecedenceClimbingParser.Token>) - Method in class org.apache.calcite.util.PrecedenceClimbingParser
- call(PrecedenceClimbingParser.Op, PrecedenceClimbingParser.Token, PrecedenceClimbingParser.Token) - Method in class org.apache.calcite.util.PrecedenceClimbingParser.Builder
- Call - Enum constant in enum org.apache.calcite.linq4j.tree.ExpressionType
-
A method call, such as in the
obj.sampleMethod()
expression. - Call(SqlParserPos, Ast.Op, Iterable<? extends Ast.Node>) - Constructor for class org.apache.calcite.piglet.Ast.Call
- Call(SqlParserPos, Ast.Op, Ast.Node...) - Constructor for class org.apache.calcite.piglet.Ast.Call
- CALL - Enum constant in enum org.apache.calcite.util.PrecedenceClimbingParser.Type
- CallCopyingArgHandler(SqlCall, boolean) - Constructor for class org.apache.calcite.sql.util.SqlShuttle.CallCopyingArgHandler
- CallImplementor - Interface in org.apache.calcite.adapter.enumerable
-
Implements a call via given translator.
- callRewrite() - Method in interface org.apache.calcite.sql.validate.SqlValidator.Config
-
Returns whether to enable rewrite of "macro-like" calls such as COALESCE.
- CallSiteBinder - Interface in org.apache.calcite.linq4j.tree
-
Creates a
DynamicExpression
that represents a dynamic operation bound by the providedCallSiteBinder
. - callToOperandTypesMap - Variable in class org.apache.calcite.sql.validate.SqlValidatorImpl
-
Provides the data for
SqlValidatorImpl.getValidatedOperandTypes(SqlCall)
. - camelName - Variable in enum org.apache.calcite.DataContext.Variable
- camelName - Variable in enum org.apache.calcite.model.ModelHandler.ExtraOperand
- camelName() - Method in enum org.apache.calcite.config.CalciteConnectionProperty
- canApplyFrom(SqlTypeName, SqlTypeName) - Method in interface org.apache.calcite.sql.type.SqlTypeMappingRule
-
Returns whether it is valid to apply the defined rules from type
from
to typeto
. - canAssignFrom(RelDataType, RelDataType) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Tests whether a value can be assigned to a site.
- canBeUsed(AggregateCall) - Method in class org.apache.calcite.adapter.druid.ComplexMetric
-
Returns true if and only if this
ComplexMetric
can be used in the givenAggregateCall
. - canCastFrom(RelDataType, RelDataType, boolean) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Compares two types and returns whether
fromType
can be cast totoType
, using either coercion or assignment. - canCastFrom(RelDataType, RelDataType, SqlTypeMappingRule) - Static method in class org.apache.calcite.sql.type.SqlTypeUtil
-
Compares two types and returns whether
fromType
can be cast totoType
. - CANCEL_FLAG - Enum constant in enum org.apache.calcite.DataContext.Variable
-
A mutable flag that indicates whether user has requested that the current statement be canceled.
- cancelFlag - Variable in class org.apache.calcite.plan.AbstractRelOptPlanner
- CancelFlag - Class in org.apache.calcite.util
-
CancelFlag is used to post and check cancellation requests.
- CancelFlag(AtomicBoolean) - Constructor for class org.apache.calcite.util.CancelFlag
- cancelNullsOnLeft() - Method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns a join type similar to this but that does not generate nulls on the left.
- cancelNullsOnRight() - Method in enum org.apache.calcite.rel.core.JoinRelType
-
Returns a join type similar to this but that does not generate nulls on the right.
- canConvert(RelOptPlanner, Convention, Convention) - Method in class org.apache.calcite.plan.ConventionTraitDef
- canConvert(RelOptPlanner, RelCollation, RelCollation) - Method in class org.apache.calcite.rel.RelCollationTraitDef
- canConvert(RelOptPlanner, RelDistribution, RelDistribution) - Method in class org.apache.calcite.rel.RelDistributionTraitDef
- canConvert(RelOptPlanner, T, T) - Method in class org.apache.calcite.plan.RelTraitDef
-
Tests whether the given RelTrait can be converted to another RelTrait.
- canConvertConvention(Convention) - Method in enum org.apache.calcite.adapter.enumerable.EnumerableConvention
- canConvertConvention(Convention) - Method in enum org.apache.calcite.interpreter.BindableConvention
- canConvertConvention(Convention) - Method in enum org.apache.calcite.interpreter.InterpretableConvention
- canConvertConvention(Convention) - Method in interface org.apache.calcite.plan.Convention
-
Returns whether we should convert from this convention to
toConvention
. - canConvertConvention(Convention) - Method in class org.apache.calcite.plan.
Lists.transform(java.util.List<F>, com.google.common.base.Function<? super F, ? extends T>)