| Name | Description | Type | Package | Framework | 
| AbstractConverter | Converts a relational expression to any given output convention. | Class | org.apache.calcite.plan.volcano | Calcite | 
|
| AbstractCursor | Base class for implementing a cursor. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| AbstractEnumerable | Abstract implementation of the Enumerable interface that implements the extension methods. | Class | org.apache.calcite.linq4j | Calcite | 
|
| AbstractEnumerable2 | Abstract implementation of the Enumerable interface that implements the extension methods. | Class | org.apache.calcite.linq4j | Calcite | 
|
| AbstractHandler | Abstract base class for Handlers to extend to inherit functionality common across serialization strategies. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| AbstractNode | Abstract implementation of Node. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| AbstractQueryable | Abstract implementation of the Queryable interface that implements the extension methods. | Class | org.apache.calcite.linq4j | Calcite | 
|
| AbstractQueryableTable | Abstract base class for implementing Table. | Class | org.apache.calcite.adapter.java | Calcite | 
|
| AbstractRelNode | Base class for every relational expression (RelNode). | Class | org.apache.calcite.rel | Calcite | 
|
| AbstractRelOptPlanner | Abstract base for implementations of the RelOptPlanner interface. | Class | org.apache.calcite.plan | Calcite | 
|
| AbstractSchema | Abstract implementation of Schema. | Class | org.apache.calcite.schema.impl | Calcite | 
|
| AbstractService | A common base class for Service implementations that implement modifications made to response objects. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| AbstractSourceMapping | Simple implementation of Mappings. | Class | org.apache.calcite.util.mapping | Calcite | 
|
| AbstractSqlType | Abstract base class for SQL implementations of RelDataType. | Class | org.apache.calcite.sql.type | Calcite | 
|
| AbstractTable | Abstract base class for implementing Table. | Class | org.apache.calcite.schema.impl | Calcite | 
|
| AbstractTableQueryable | Abstract implementation of Queryable for Not to be confused with | Class | org.apache.calcite.schema.impl | Calcite | 
|
| AbstractTargetMapping | Simple implementation of Mappings. | Class | org.apache.calcite.util.mapping | Calcite | 
|
| AggAddContext | Information for a call to AggImplementor. | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| AggAddContextImpl |  | Class | org.apache.calcite.adapter.enumerable.impl | Calcite | 
|
| AggContext | Information on the aggregate calculation context. | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| AggImplementor | initialize, add to, and get a result from, an accumulator. | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| AggImpState | Represents internal state when implementing aggregate functions. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| Aggregate | Relational operator that eliminates duplicates and computes totals. | Class | org.apache.calcite.rel.core | Calcite | 
|
| AggregateCall |  | Class | org.apache.calcite.rel.core | Calcite | 
|
| AggregateExpandDistinctAggregatesRule | Planner rule that expands distinct aggregates (such as COUNT(DISTINCT x)) from a | Class | org.apache.calcite.rel.rules | Calcite | 
|
| AggregateFilterTransposeRule | Planner rule that matches an Aggregate on a Filter and transposes them, | Class | org.apache.calcite.rel.rules | Calcite | 
|
| AggregateFunction | Function that combines several values into a scalar result. | Interface | org.apache.calcite.schema | Calcite | 
|
| AggregateFunctionImpl | The class should implement A init(), A add(A, V), and R result(A) methods. | Class | org.apache.calcite.schema.impl | Calcite | 
|
| AggregateJoinTransposeRule |  | Class | org.apache.calcite.rel.rules | Calcite | 
|
| AggregateNode |  | Class | org.apache.calcite.interpreter | Calcite | 
|
| AggregateProjectMergeRule | Planner rule that recognizes a Aggregate on top of a Project and if possible | Class | org.apache.calcite.rel.rules | Calcite | 
|
| AggregateProjectPullUpConstantsRule | Planner rule that removes constant keys from an Constant fields are deduced using | Class | org.apache.calcite.rel.rules | Calcite | 
|
| AggregateReduceFunctionsRule | Planner rule that reduces aggregate functions in Aggregates to simpler forms. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| AggregateRemoveRule | Planner rule that removes if it computes no aggregate functions | Class | org.apache.calcite.rel.rules | Calcite | 
|
| AggregateStarTableRule | Planner rule that matches an Aggregate on top of a StarTable. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| AggregateUnionAggregateRule | Planner rule that matches Aggregates beneath a | Class | org.apache.calcite.rel.rules | Calcite | 
|
| AggregateUnionTransposeRule | Planner rule that pushes an past a non-distinct Union. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| AggregatingScope | An extension to the SqlValidatorScope interface which indicates that the scope is aggregating. | Interface | org.apache.calcite.sql.validate | Calcite | 
|
| AggregatingSelectScope | Scope for resolving identifiers within a SELECT statement that has a The same set of identifiers are in scope, but it won't allow access to | Class | org.apache.calcite.sql.validate | Calcite | 
|
| AggResetContext | Information for a call to AggImplementor. | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| AggResetContextImpl |  | Class | org.apache.calcite.adapter.enumerable.impl | Calcite | 
|
| AggResultContext | Information for a call to AggImplementor. | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| AggResultContextImpl |  | Class | org.apache.calcite.adapter.enumerable.impl | Calcite | 
|
| AliasNamespace | Namespace for an AS t(c1, c2, . | Class | org.apache.calcite.sql.validate | Calcite | 
|
| Array | Annotation that indicates that a field is an array type. | Class | org.apache.calcite.adapter.java | Calcite | 
|
| ArrayBindable | Extension to Bindable that returns rows that are arrays of objects. | Interface | org.apache.calcite.runtime | Calcite | 
|
| ArrayComparator |  | Class | org.apache.calcite.runtime | Calcite | 
|
| ArrayEnumeratorCursor | returns an array of Object for each row. | Class | org.apache.calcite.runtime | Calcite | 
|
| ArrayImpl |  | Class | org.apache.calcite.avatica.util | Calcite | 
|
| ArrayIteratorCursor | returns an array of Object for each row. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| ArrayLengthRecordField |  | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ArraySqlType |  | Class | org.apache.calcite.sql.type | Calcite | 
|
| AssignableOperandTypeChecker | AssignableOperandTypeChecker implements SqlOperandTypeChecker by verifying that the type of each argument is assignable to a predefined set of | Class | org.apache.calcite.sql.type | Calcite | 
|
| Ast | Abstract syntax tree. | Class | org.apache.calcite.piglet | Calcite | 
|
| AvaticaClientRuntimeException | The client-side representation of AvaticaRuntimeException. | Class | org.apache.calcite.avatica | Calcite | 
|
| AvaticaConnection | for the Avatica framework. | Class | org.apache.calcite.avatica | Calcite | 
|
| AvaticaDatabaseMetaData | for the Avatica engine. | Class | org.apache.calcite.avatica | Calcite | 
|
| AvaticaFactory | Factory for JDBC objects. | Interface | org.apache.calcite.avatica | Calcite | 
|
| AvaticaHandler | A custom interface that extends the Jetty interface to enable extra control within Avatica. | Interface | org.apache.calcite.avatica.server | Calcite | 
|
| AvaticaHttpClient | An interface which defines how requests are sent to the Avatica server. | Interface | org.apache.calcite.avatica.remote | Calcite | 
|
| AvaticaHttpClientImpl | A common class to invoke HTTP requests against the Avatica server agnostic of the data being sent and received across the wire. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| AvaticaJsonHandler | Jetty handler that executes Avatica JSON request-responses. | Class | org.apache.calcite.avatica.server | Calcite | 
|
| AvaticaParameter | Metadata for a parameter. | Class | org.apache.calcite.avatica | Calcite | 
|
| AvaticaPreparedStatement | for the Avatica engine. | Class | org.apache.calcite.avatica | Calcite | 
|
| AvaticaProtobufHandler | Jetty handler that executes Avatica JSON request-responses. | Class | org.apache.calcite.avatica.server | Calcite | 
|
| AvaticaRemoteConnectionConfigImpl | with extra properties specific to Remote Driver. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| AvaticaRemoteConnectionProperty | enum AvaticaRemoteConnectionPropertyEnumeration of Avatica remote driver's built-in connection properties. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| AvaticaResultSet | for the Avatica engine. | Class | org.apache.calcite.avatica | Calcite | 
|
| AvaticaResultSetMetaData | for the Avatica framework. | Class | org.apache.calcite.avatica | Calcite | 
|
| AvaticaRuntimeException | A RuntimeException thrown by Avatica with additional contextual information about what happened to cause the Exception. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| AvaticaSeverity | enum AvaticaSeverityAn enumeration that denotes the severity of a given unexpected state. | Class | org.apache.calcite.avatica | Calcite | 
|
| AvaticaSite | A location that a value can be written to or read from. | Class | org.apache.calcite.avatica | Calcite | 
|
| AvaticaSqlException | A client-facing SQLException which encapsulates errors from the remote Avatica server. | Class | org.apache.calcite.avatica | Calcite | 
|
| AvaticaStatement | for the Avatica engine. | Class | org.apache.calcite.avatica | Calcite | 
|
| AvaticaUtils | Returns the boxed class. | Class | org.apache.calcite.avatica | Calcite | 
|
| BarfingInvocationHandler | A class derived from BarfingInvocationHandler handles a method call by looking for a method in itself with identical parameters. | Class | org.apache.calcite.util | Calcite | 
|
| Base64 | Encodes and decodes to and from Base64 notation. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| BaseQueryable | Skeleton implementation of Queryable. | Class | org.apache.calcite.linq4j | Calcite | 
|
| BasicDatetime | BasicDatetime is an interface for dates, times, or timestamps that can be assigned from a long value. | Interface | org.apache.calcite.util | Calcite | 
|
| BasicSqlType | BasicSqlType represents a standard atomic SQL type (excluding intervalSee Also:Serialized Form | Class | org.apache.calcite.sql.type | Calcite | 
|
| Benchmark |  | Class | org.apache.calcite.util | Calcite | 
|
| BigDecimalFunction1 | Function that takes one parameter and returns a BigDecimal value. | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| BinaryExpression | Represents an expression that has a binary operator. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| BinarySearch | Binary search for the implementation of RANGE BETWEEN XXX PRECEDING/FOLLOWING clause. | Class | org.apache.calcite.runtime | Calcite | 
|
| Bindable | Statement that can be bound to a DataContext and then executed. | Interface | org.apache.calcite.runtime | Calcite | 
|
| BindableConvention | enum BindableConventionCalling convention that returns results as an | Class | org.apache.calcite.interpreter | Calcite | 
|
| BindableRel | Relational expression that can implement itself in BindableSee Also:BindableConvention | Interface | org.apache.calcite.interpreter | Calcite | 
|
| Bindables | Utilities pertaining to BindableRel and BindableConvention. | Class | org.apache.calcite.interpreter | Calcite | 
|
| BiRel | Abstract base class for relational expressions with a two inputs. | Class | org.apache.calcite.rel | Calcite | 
|
| BitSets | Utility functions for BitSet. | Class | org.apache.calcite.util | Calcite | 
|
| BitString | A bit string logically consists of a set of '0' and '1' values, of a specified length. | Class | org.apache.calcite.util | Calcite | 
|
| BlockBuilder | Builder for BlockStatement. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| Blocks | Helper methods concerning BlockStatements. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| BlockStatement |  | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| BreadthFirstIterator | Iterates over the vertices in a directed graph in breadth-first order. | Class | org.apache.calcite.util.graph | Calcite | 
|
| Bug | Holder for a list of constants describing which bugs which have not been You can use these constants to control the flow of your code. | Class | org.apache.calcite.util | Calcite | 
|
| BuiltInConnectionProperty | enum BuiltInConnectionPropertyEnumeration of Avatica's built-in connection properties. | Class | org.apache.calcite.avatica | Calcite | 
|
| BuiltInMetadata | Contains the interfaces for several common forms of metadata. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| BuiltInMethod |  | Class | org.apache.calcite.util | Calcite | 
|
| ByteString | Collection of bytes. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| CachingRelMetadataProvider | interface that caches results from an underlying provider. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| Calc |  | Class | org.apache.calcite.rel.core | Calcite | 
|
| CalciteCatalogReader | and also SqlOperatorTable based on tables and functions defined schemas. | Class | org.apache.calcite.prepare | Calcite | 
|
| CalciteConnection | Extension to Calcite's implementation of JDBC connection allows schemas to be defined | Interface | org.apache.calcite.jdbc | Calcite | 
|
| CalciteConnectionConfig | Interface for reading connection properties within Calcite code. | Interface | org.apache.calcite.config | Calcite | 
|
| CalciteConnectionConfigImpl |  | Class | org.apache.calcite.config | Calcite | 
|
| CalciteConnectionProperty | enum CalciteConnectionPropertyProperties that may be specified on the JDBC connect string. | Class | org.apache.calcite.config | Calcite | 
|
| CalciteContextException | Exception which contains information about the textual context of the causingSee Also:Serialized Form | Class | org.apache.calcite.runtime | Calcite | 
|
| CalciteException | Base class for all exceptions originating from Farrago. | Class | org.apache.calcite.runtime | Calcite | 
|
| CalciteFactory |  | Class | org.apache.calcite.jdbc | Calcite | 
|
| CalciteJdbc41Factory | for Calcite and JDBC 4. | Class | org.apache.calcite.jdbc | Calcite | 
|
| CalciteLogger | Small extension to Logger with some performance improvements. | Class | org.apache.calcite.util.trace | Calcite | 
|
| CalciteMetaImpl | Helper for implementing the getXxx methods such as AvaticaDatabaseMetaData. | Class | org.apache.calcite.jdbc | Calcite | 
|
| CalcitePrepare | API for a service that prepares statements for execution. | Interface | org.apache.calcite.jdbc | Calcite | 
|
| CalcitePrepareImpl | This class is public so that projects that create their own JDBC driver and server can fine-tune preferences. | Class | org.apache.calcite.prepare | Calcite | 
|
| CalciteResource | Compiler-checked resources for the Calcite project. | Interface | org.apache.calcite.runtime | Calcite | 
|
| CalciteResultSet | for the Calcite engine. | Class | org.apache.calcite.jdbc | Calcite | 
|
| CalciteRootSchema |  | Class | org.apache.calcite.jdbc | Calcite | 
|
| CalciteSchema | Wrapper around user-defined schema used internally. | Class | org.apache.calcite.jdbc | Calcite | 
|
| CalciteServer | Represents shared state among connections, and will have monitoring and management facilities. | Interface | org.apache.calcite.server | Calcite | 
|
| CalciteServerStatement | Statement within a Calcite server. | Interface | org.apache.calcite.server | Calcite | 
|
| CalciteStatement | for the Calcite engine. | Class | org.apache.calcite.jdbc | Calcite | 
|
| CalciteTimingTracer | CalciteTimingTracer provides a mechanism for tracing the timing of a call sequence at nanosecond resolution. | Class | org.apache.calcite.util.trace | Calcite | 
|
| CalciteTrace | Contains all of the tracers used within org. | Class | org.apache.calcite.util.trace | Calcite | 
|
| CalcMergeRule | Planner rule that merges a The resulting LogicalCalc has the | Class | org.apache.calcite.rel.rules | Calcite | 
|
| CalcRelSplitter | CalcRelSplitter operates on a Calc with multiple RexCall | Class | org.apache.calcite.rel.rules | Calcite | 
|
| CalcRemoveRule | Planner rule that removes a trivial is trivial if it projects its input fields in their | Class | org.apache.calcite.rel.rules | Calcite | 
|
| CalcSplitRule | Planner rule that converts a Calc Not enabled by default, as it works against the usual flow, which is to | Class | org.apache.calcite.rel.rules | Calcite | 
|
| CallImplementor |  | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| CancelFlag | CancelFlag is used to post and check cancellation requests. | Class | org.apache.calcite.util | Calcite | 
|
| Casing | Policy for converting case of identifiers before storing them. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| CastingList | Converts a list whose members are automatically down-cast to a given type. | Class | org.apache.calcite.util | Calcite | 
|
| CatchBlock | Represents a catch statement in a try block. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ChainedPhaseRuleMappingInitializer | ChainedPhaseRuleMappingInitializer is an abstract implementation of VolcanoPlannerPhaseRuleMappingInitializer that allows additional | Class | org.apache.calcite.plan.volcano | Calcite | 
|
| ChainedRelMetadataProvider | Glossary. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| ChainedSqlOperatorTable | ChainedSqlOperatorTable implements the SqlOperatorTable interface by chaining together any number of underlying operator table instances. | Class | org.apache.calcite.sql.util | Calcite | 
|
| Chi | Relational operator that converts a stream to a relation. | Class | org.apache.calcite.rel.stream | Calcite | 
|
| ChunkList | in chunks of 32 elements. | Class | org.apache.calcite.util | Calcite | 
|
| ClassDeclaration | Declaration of a class. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ClassDeclarationFinder | Entry point for optimizers that factor ou deterministic expressions to final static fields. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| CloneSchema | Schema that contains in-memory copies of tables from a JDBC schema. | Class | org.apache.calcite.adapter.clone | Calcite | 
|
| ClosableAllocation | ClosableAllocation represents an object which requires a call in order to release resources early rather than waiting for finalization. | Interface | org.apache.calcite.util | Calcite | 
|
| ClosableAllocationOwner | ClosableAllocationOwner represents an object which can take ownership of ClosableAllocations and guarantee that they will be cleaned up correctly when | Interface | org.apache.calcite.util | Calcite | 
|
| CoerceInputsRule | CoerceInputsRule precasts inputs to a particular type. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| Collect | A relational expression that collapses multiple rows into one. | Class | org.apache.calcite.rel.core | Calcite | 
|
| CollectNamespace | Namespace for COLLECT and TABLE constructs. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| ColumnMetaData | Metadata for a column. | Class | org.apache.calcite.avatica | Calcite | 
|
| Common |  | Class | org.apache.calcite.avatica.proto | Calcite | 
|
| CommonRelSubExprRule | A CommonRelSubExprRule is an abstract base class for rules that are fired only on relational expressions that appear more than once | Class | org.apache.calcite.plan | Calcite | 
|
| ComparableOperandTypeChecker | Type checking strategy which verifies that types have the required attributes to be used as arguments to comparison operators. | Class | org.apache.calcite.sql.type | Calcite | 
|
| Compatible | Compatibility layer. | Interface | org.apache.calcite.util | Calcite | 
|
| CompositeList | Read-only list that is the concatenation of sub-lists. | Class | org.apache.calcite.util | Calcite | 
|
| CompositeMap | Unmodifiable view onto multiple backing maps. | Class | org.apache.calcite.util | Calcite | 
|
| CompositeOperandTypeChecker | This class allows multiple existing SqlOperandTypeChecker rules to be combined into one rule. | Class | org.apache.calcite.sql.type | Calcite | 
|
| CompositeSingleOperandTypeChecker | SqlSingleOperandTypeChecker rules to be combined into one rule. | Class | org.apache.calcite.sql.type | Calcite | 
|
| CompoundClosableAllocation | CompoundClosableAllocation represents a collection of ClosableAllocations which share a common lifecycle. | Class | org.apache.calcite.util | Calcite | 
|
| ConditionalExpression | Represents an expression that has a conditional operator. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ConditionalStatement | Represents an expression that has a conditional operator. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ConnectionConfig | Connection configuration. | Interface | org.apache.calcite.avatica | Calcite | 
|
| ConnectionConfigImpl |  | Class | org.apache.calcite.avatica | Calcite | 
|
| ConnectionPropertiesImpl | Concrete implementation of Meta. | Class | org.apache.calcite.avatica | Calcite | 
|
| ConnectionProperty | Definition of a property that may be specified on the JDBC connect string. | Interface | org.apache.calcite.avatica | Calcite | 
|
| ConnectStringParser | ConnectStringParser is a utility class that parses or creates a JDBC connect string according to the OLE DB connect string syntax described at | Class | org.apache.calcite.avatica | Calcite | 
|
| ConstantExpression | Represents an expression that has a constant value. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ConstantUntypedNull | Represents a constant null of unknown type Java allows type inference for such nulls, thus null cannot always be | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ConstructorDeclaration | Declaration of a constructor. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| Context | Context for executing a scalar expression in an interpreter. | Class | org.apache.calcite.interpreter | Calcite | 
|
| Context | Provides library users a way to store data within the planner session and access it within rules. | Interface | org.apache.calcite.plan | Calcite | 
|
| Contexts | Utilities for Context. | Class | org.apache.calcite.plan | Calcite | 
|
| ControlFlowException | Exception intended to be used for control flow, as opposed to the usual use of exceptions which is to signal an error condition. | Class | org.apache.calcite.util | Calcite | 
|
| Convention | Calling convention trait. | Interface | org.apache.calcite.plan | Calcite | 
|
| ConventionTraitDef | Definition of the the convention trait. | Class | org.apache.calcite.plan | Calcite | 
|
| ConversionUtil |  | Class | org.apache.calcite.util | Calcite | 
|
| Converter | A relational expression implements the interface Converter to indicate that it converts a physical attribute, or | Interface | org.apache.calcite.rel.convert | Calcite | 
|
| ConverterImpl | Abstract implementation of Converter. | Class | org.apache.calcite.rel.convert | Calcite | 
|
| ConverterRule | Abstract base class for a rule which converts from one calling convention to another without changing semantics. | Class | org.apache.calcite.rel.convert | Calcite | 
|
| Correlate | A relational operator that performs nested-loop joins. | Class | org.apache.calcite.rel.core | Calcite | 
|
| CorrelateJoinType | enum CorrelateJoinTypeSpecifies the type of correlation operation: inner, left, semi, or anti. | Class | org.apache.calcite.linq4j | Calcite | 
|
| CorrelationId | Describes the necessary parameters for an implementation in order to identify and set dynamic variables | Class | org.apache.calcite.rel.core | Calcite | 
|
| CorrelationReferenceFinder |  | Class | org.apache.calcite.sql2rel | Calcite | 
|
| CsvFilterableTable | Table based on a CSV file that can implement simple filtering. | Class | org.apache.calcite.adapter.csv | Calcite | 
|
| CsvProjectTableScanRule | Planner rule that projects from a CsvTableScan scan just the columns needed to satisfy a projection. | Class | org.apache.calcite.adapter.csv | Calcite | 
|
| CsvScannableTable | Table based on a CSV file. | Class | org.apache.calcite.adapter.csv | Calcite | 
|
| CsvSchema | Schema mapped onto a directory of CSV files. | Class | org.apache.calcite.adapter.csv | Calcite | 
|
| CsvSchemaFactory | Factory that creates a CsvSchema. | Class | org.apache.calcite.adapter.csv | Calcite | 
|
| CsvTable | Base class for table that reads CSV files. | Class | org.apache.calcite.adapter.csv | Calcite | 
|
| CsvTableFactory | Factory that creates a CsvTranslatableTable. | Class | org.apache.calcite.adapter.csv | Calcite | 
|
| CsvTableScan | Relational expression representing a scan of a CSV file. | Class | org.apache.calcite.adapter.csv | Calcite | 
|
| CsvTranslatableTable | Table based on a CSV file. | Class | org.apache.calcite.adapter.csv | Calcite | 
|
| Cursor | Interface to an iteration that is similar to, and can easily support, a JDBC ResultSet, but is simpler to implement. | Interface | org.apache.calcite.avatica.util | Calcite | 
|
| CursorReturnTypeInference | Returns the rowtype of a cursor of the operand at a particular 0-basedSee Also:OrdinalReturnTypeInference | Class | org.apache.calcite.sql.type | Calcite | 
|
| CycleDetector | Detects cycles in directed graphs. | Class | org.apache.calcite.util.graph | Calcite | 
|
| CyclicMetadataException | Exception that indicates that a cycle has been detected while computing metadata. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| DataContext | Runtime context allowing access to the tables in a database. | Interface | org.apache.calcite | Calcite | 
|
| DateTimeUtils | Utility functions for datetime types: date, time, timestamp. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| DeclarationStatement | Expression that declares and optionally initializes a variable. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| DeduplicateCorrelateVariables | Rewrites relations to ensure the same correlation is referenced by the same correlation variable. | Class | org.apache.calcite.sql2rel | Calcite | 
|
| DefaultDirectedGraph | Default implementation of DirectedGraph. | Class | org.apache.calcite.util.graph | Calcite | 
|
| DefaultEdge | Default implementation of Edge. | Class | org.apache.calcite.util.graph | Calcite | 
|
| DefaultEnumerable | that implements the extension methods by calling into the Extensions The are two abstract methods: | Class | org.apache.calcite.linq4j | Calcite | 
|
| DefaultExpression | Represents the default value of a type or an empty expression. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| DefaultRelMetadataProvider | DefaultRelMetadataProvider supplies a default implementation of the RelMetadataProvider interface. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| DefaultValueFactory | DefaultValueFactory supplies default values for INSERT, UPDATE, and NEW. | Interface | org.apache.calcite.sql2rel | Calcite | 
|
| DelegatingAvaticaHandler | An AvaticaHandler implementation that delegates to a provided Jetty Handler instance. | Class | org.apache.calcite.avatica.server | Calcite | 
|
| DelegatingEnumerator | Simple enumerator that just delegates all calls to the passed enumerator. | Class | org.apache.calcite.linq4j | Calcite | 
|
| DelegatingInvocationHandler | A class derived from DelegatingInvocationHandler handles a method call by looking for a method in itself with identical parameters. | Class | org.apache.calcite.util | Calcite | 
|
| DelegatingLatticeStatisticProvider | to an underlying provider. | Class | org.apache.calcite.materialize | Calcite | 
|
| DelegatingNamespace | An implementation of SqlValidatorNamespace that delegates all methods to an underlying object. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| DelegatingSchema | an underlying schema. | Class | org.apache.calcite.schema.impl | Calcite | 
|
| DelegatingScope | A scope which delegates all requests to its parent scope. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| DelegatingSqlValidatorCatalogReader | SqlValidatorCatalogReader that passes all calls to a parent catalog reader. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| DelegatingSqlValidatorTable | delegating to a parent table. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| Delta | Relational operator that converts a relation to a stream. | Class | org.apache.calcite.rel.stream | Calcite | 
|
| Demo |  | Class | org.apache.calcite | Calcite | 
|
| DepthFirstIterator | Iterates over the vertices in a directed graph in depth-first order. | Class | org.apache.calcite.util.graph | Calcite | 
|
| DeterministicCodeOptimizer | Factors out deterministic expressions to final static fields. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| DirectedGraph |  | Interface | org.apache.calcite.util.graph | Calcite | 
|
| DoubleFunction1 | Function that takes one parameter and returns a native double value. | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| Driver | Avatica Remote JDBC driver. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| Driver | Calcite JDBC driver. | Class | org.apache.calcite.jdbc | Calcite | 
|
| DriverVersion | Driver version information. | Class | org.apache.calcite.avatica | Calcite | 
|
| DynamicExpression | Represents a dynamic operation. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ElementInit | Represents an initializer for a single element of an Enumerable collection. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| Enumerable | Exposes the enumerator, which supports a simple iteration over a collection. | Interface | org.apache.calcite.linq4j | Calcite | 
|
| EnumerableAggregate | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableBindable | Relational expression that converts an enumerable input to interpretable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableCalc | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableCollect | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableConvention | enum EnumerableConventionFamily of calling conventions that return results as an | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableCorrelate | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableCorrelateRule |  | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableDefaults | Default implementations of methods in the Enumerable interface. | Class | org.apache.calcite.linq4j | Calcite | 
|
| EnumerableFilter | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableFilterToCalcRule | Variant of FilterToCalcRule for enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableInterpretable | Relational expression that converts an enumerable input to interpretable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableInterpreter | Relational expression that executes its children using an interpreter. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableInterpreterRule | Planner rule that converts BindableRel to EnumerableRel by creating | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableIntersect | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableJoin | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableLimit | Relational expression that applies a limit and/or offset to its input. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableMergeJoin |  | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableMinus | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableProject | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableProjectToCalcRule | Variant of ProjectToCalcRule for enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableRel | A relational expression of one of the EnumerableConvention calling | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableRelImplementor | Subclass of RelImplementor for relational operators of EnumerableConvention calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableRules | Rules and relational operators for the enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| Enumerables | Utilities for processing Enumerable This class is a place to put things not yet added to linq4j. | Class | org.apache.calcite.runtime | Calcite | 
|
| EnumerableSemiJoin | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableSort | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableTableFunctionScan | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableTableFunctionScanRule | Planner rule that converts a LogicalTableFunctionScan | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableTableModify | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableTableModifyRule | Planner rule that converts a relational expression | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableTableScan | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableTableScanRule | Planner rule that converts a LogicalTableFunctionScan | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableThetaJoin | enumerable calling convention that allows conditions that are not just = (equals). | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableToSparkConverter | Relational expression that converts input of EnumerableConvention into Spark convention. | Class | org.apache.calcite.adapter.spark | Calcite | 
|
| EnumerableToSparkConverterRule |  | Class | org.apache.calcite.adapter.spark | Calcite | 
|
| EnumerableUncollect | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableUnion | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableValues | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableValuesRule | Planner rule that converts a relational expression | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EnumerableWindow | enumerable calling convention. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| Enumerator | Supports a simple iteration over a collection. | Interface | org.apache.calcite.linq4j | Calcite | 
|
| EnumeratorCursor | returns a record for each row. | Class | org.apache.calcite.runtime | Calcite | 
|
| EnumUtils |  | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| EqualityComparer | Compares values for equality. | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| EquiJoin | Base class for any join whose condition is based on column equality. | Class | org.apache.calcite.rel.core | Calcite | 
|
| EquiJoin | Base class for any join whose condition is based on column equality. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| Exchange | Relational expression that imposes a particular distribution on its input without otherwise changing its content. | Class | org.apache.calcite.rel.core | Calcite | 
|
| ExplicitOperandTypeInference | ExplicitOperandTypeInferences implements SqlOperandTypeInference by explicitly supplying a type for each parameter. | Class | org.apache.calcite.sql.type | Calcite | 
|
| ExplicitOperatorBinding | ExplicitOperatorBinding implements SqlOperatorBinding via an underlying array of known operand types. | Class | org.apache.calcite.sql | Calcite | 
|
| ExplicitReturnTypeInference | A SqlReturnTypeInference which always returns the same SQL type. | Class | org.apache.calcite.sql.type | Calcite | 
|
| Expression | Analogous to LINQ's System. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| Expressions | Utility methods for expressions, including a lot of factory methods. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ExpressionType | Analogous to LINQ's System. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ExpressionVisitor | Represents a visitor or rewriter for expression trees. | Interface | org.apache.calcite.linq4j.tree | Calcite | 
|
| ExtendedEnumerable | Extension methods in Enumerable. | Interface | org.apache.calcite.linq4j | Calcite | 
|
| ExtendedOrderedEnumerable | Extension methods for OrderedEnumerable. | Interface | org.apache.calcite.linq4j | Calcite | 
|
| ExtendedOrderedQueryable | Extension methods for OrderedQueryable. | Interface | org.apache.calcite.linq4j | Calcite | 
|
| ExtensibleTable | Table whose row type can be extended to include extra fields. | Interface | org.apache.calcite.schema | Calcite | 
|
| Extensions | Contains what, in LINQ. | Class | org.apache.calcite.linq4j | Calcite | 
|
| ExtraSqlTypes | Holds constants associated with SQL types introduced after the earliest version of Java supported by Farrago (this currently means anything | Interface | org.apache.calcite.sql.type | Calcite | 
|
| FamilyOperandTypeChecker |  | Class | org.apache.calcite.sql.type | Calcite | 
|
| Feature | SQL language feature. | Class | org.apache.calcite.runtime | Calcite | 
|
| FieldDeclaration | Declaration of a field. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| Filter | Relational expression that iterates over its input and returns elements for which condition evaluates to | Class | org.apache.calcite.rel.core | Calcite | 
|
| FilterableTable | Table that can be scanned, optionally applying supplied filter expressions, without creating an intermediate relational expression. | Interface | org.apache.calcite.schema | Calcite | 
|
| FilterAggregateTransposeRule | Planner rule that pushes a FilterSee Also:AggregateFilterTransposeRule | Class | org.apache.calcite.rel.rules | Calcite | 
|
| Filterator | Filtered iterator class: an iterator that includes only elements that are instanceof a specified class. | Class | org.apache.calcite.util | Calcite | 
|
| FilterCalcMergeRule | Planner rule that merges a LogicalFilter and a | Class | org.apache.calcite.rel.rules | Calcite | 
|
| FilterCorrelateRule | Planner rule that pushes a Filter above a Correlate into the inputs of the Correlate. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| FilterJoinRule | Planner rule that pushes filters above and within a join node into the join node and/or its children nodes. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| FilterMergeRule |  | Class | org.apache.calcite.rel.rules | Calcite | 
|
| FilterMultiJoinMergeRule | Planner rule that merges a creating a richer MultiJoin. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| FilterNode |  | Class | org.apache.calcite.interpreter | Calcite | 
|
| FilterProjectTransposeRule | Planner rule that pushes past a LogicalProject. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| FilterRemoveIsNotDistinctFromRule | Planner rule that replaces IS NOT DISTINCT FROM with logically equivalent operations. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| FilterSetOpTransposeRule |  | Class | org.apache.calcite.rel.rules | Calcite | 
|
| FilterTableFunctionTransposeRule | Planner rule that pushes past a LogicalTableFunctionScan. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| FilterTableScanRule | Planner rule that converts of a FilterableTable | Class | org.apache.calcite.rel.rules | Calcite | 
|
| FilterToCalcRule | Planner rule that converts a The rule does NOT fire if the child is a | Class | org.apache.calcite.rel.rules | Calcite | 
|
| FlatLists | Space-efficient, comparable, immutable lists. | Class | org.apache.calcite.runtime | Calcite | 
|
| FlightRecorderProfiler | Captures Flight Recorder log. | Class | org.apache.calcite.benchmarks | Calcite | 
|
| FloatFunction1 | Function that takes one parameter and returns a native float value. | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| ForStatement | Represents an infinite loop. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| FrameworkConfig | Interface that describes how to configure planning sessions generated using the Frameworks tools. | Interface | org.apache.calcite.tools | Calcite | 
|
| Frameworks |  | Class | org.apache.calcite.tools | Calcite | 
|
| Function | Named expression that accepts parameters and returns a result. | Interface | org.apache.calcite.schema | Calcite | 
|
| Function0 | Function with no parameters. | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| Function1 | Function with one parameter. | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| Function2 | Function with two parameters. | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| FunctionExpression | Represents a strongly typed lambda expression as a data structure in the form of an expression tree. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| FunctionParameter | Parameter to a Function. | Interface | org.apache.calcite.schema | Calcite | 
|
| Functions | Utilities relating to functions. | Class | org.apache.calcite.linq4j.function | Calcite | 
|
| Glossary | A collection of terms. | Interface | org.apache.calcite.util | Calcite | 
|
| GotoExpressionKind | enum GotoExpressionKindSpecifies what kind of jump a GotoStatement represents. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| GotoStatement | Represents an unconditional jump. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| Graphs | Miscellaneous graph utilities. | Class | org.apache.calcite.util.graph | Calcite | 
|
| Grouping | Represents a collection of objects that have a common key. | Interface | org.apache.calcite.linq4j | Calcite | 
|
| Handler | Called at various points in the JDBC lifecycle. | Interface | org.apache.calcite.avatica | Calcite | 
|
| Handler | API for text request-response calls to an Avatica server. | Interface | org.apache.calcite.avatica.remote | Calcite | 
|
| Handler |  | Class | org.apache.calcite.piglet | Calcite | 
|
| HandlerFactory | Factory that instantiates the desired implementation, typically differing on the method used to serialize messages, for use in the Avatica server. | Class | org.apache.calcite.avatica.server | Calcite | 
|
| HandlerImpl | It is recommended implementations of Handler use this as a base class, to ensure forward compatibility. | Class | org.apache.calcite.avatica | Calcite | 
|
| Helper | Utility methods, mainly concerning error-handling. | Class | org.apache.calcite.avatica | Calcite | 
|
| HepMatchOrder | HepMatchOrder specifies the order of graph traversal when looking for ruleEnum Constant Summary | Class | org.apache.calcite.plan.hep | Calcite | 
|
| HepPlanner |  | Class | org.apache.calcite.plan.hep | Calcite | 
|
| HepProgram | HepProgram specifies the order in which rules should be attempted by HepPlanner. | Class | org.apache.calcite.plan.hep | Calcite | 
|
| HepProgramBuilder | HepProgramBuilder creates instances of HepProgram. | Class | org.apache.calcite.plan.hep | Calcite | 
|
| HepRelVertex | HepRelVertex wraps a real RelNode as a vertex in a DAG representing the entire query expression. | Class | org.apache.calcite.plan.hep | Calcite | 
|
| HepRuleCall | HepRuleCall implements RelOptRuleCall for a HepPlanner. | Class | org.apache.calcite.plan.hep | Calcite | 
|
| Holder | A mutable slot that can contain one object. | Class | org.apache.calcite.util | Calcite | 
|
| Hook | Collection of hooks that can be set by observers and are executed at various parts of the query preparation process. | Class | org.apache.calcite.runtime | Calcite | 
|
| HttpServer | Avatica HTTP server. | Class | org.apache.calcite.avatica.server | Calcite | 
|
| HttpUtils | Utilities for connecting to Splunk via HTTP. | Class | org.apache.calcite.adapter.splunk.util | Calcite | 
|
| IdentifierNamespace |  | Class | org.apache.calcite.sql.validate | Calcite | 
|
| ImmutableBitSet | An immutable list of bits. | Class | org.apache.calcite.util | Calcite | 
|
| ImmutableIntList | An immutable list of Integer values backed by an array ofReturns a copy of this list with one element added. | Class | org.apache.calcite.util | Calcite | 
|
| ImmutableNullableList | An immutable list that may contain null values. | Class | org.apache.calcite.util | Calcite | 
|
| ImplementableAggFunction | Function that can be translated to java code. | Interface | org.apache.calcite.schema | Calcite | 
|
| ImplementableFunction | Function that can be translated to java code. | Interface | org.apache.calcite.schema | Calcite | 
|
| IndexExpression | Represents indexing a property or array. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| InferTypes | Strategies for inferring operand types. | Class | org.apache.calcite.sql.type | Calcite | 
|
| IntegerFunction1 | Function that takes one parameter and returns a native int value. | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| IntegerIntervalSet | A set of non-negative integers defined by a sequence of points, intervals,Parses a range of integers expressed as a string. | Class | org.apache.calcite.util | Calcite | 
|
| InternalProperty | enum InternalPropertyDefinitions of properties that drive the behavior of | Class | org.apache.calcite.avatica | Calcite | 
|
| InterpretableConvention | enum InterpretableConventionCalling convention that returns results as an | Class | org.apache.calcite.interpreter | Calcite | 
|
| InterpretableConverter | Relational expression that converts any relational expression input to InterpretableConvention, by wrapping | Class | org.apache.calcite.interpreter | Calcite | 
|
| InterpretableRel | Relational expression that can implement itself using an interpreter. | Interface | org.apache.calcite.interpreter | Calcite | 
|
| Interpreter | Contains the context for interpreting relational expressions. | Class | org.apache.calcite.interpreter | Calcite | 
|
| Interpreters | Utilities relating to Interpreter and InterpretableConvention. | Class | org.apache.calcite.interpreter | Calcite | 
|
| Intersect | Relational expression that returns the intersection of the rows of its If all is true, performs then multiset intersection; otherwise, | Class | org.apache.calcite.rel.core | Calcite | 
|
| IntervalSqlType | IntervalSqlType represents a standard SQL datetime interval type. | Class | org.apache.calcite.sql.type | Calcite | 
|
| IntList | Extension to ArrayList to help build an array of intSee Also:Serialized Form | Class | org.apache.calcite.util | Calcite | 
|
| IntPair | An immutable pair of integers. | Class | org.apache.calcite.util.mapping | Calcite | 
|
| InvalidRelException | Exception that indicates that a relational expression would be invalid with given parameters. | Class | org.apache.calcite.rel | Calcite | 
|
| InvocationExpression | Represents an expression that applies a delegate or lambda expression to a list of argument expressions. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| IteratorCursor | on top of an Iterator that returns a record for each row. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| JaninoCompiler |  | Class | org.apache.calcite.util.javac | Calcite | 
|
| JaninoRexCompiler | Compiles a scalar expression (RexNode) to an expression that can be evaluated (Scalar) by generating a Java AST and compiling it | Class | org.apache.calcite.interpreter | Calcite | 
|
| JavaCompiler | The interface JavaCompiler represents an interface to invoke a regular Java compiler. | Interface | org.apache.calcite.util.javac | Calcite | 
|
| JavaCompilerArgs | A JavaCompilerArgs holds the arguments for a Specific implementations of JavaCompiler may override | Class | org.apache.calcite.util.javac | Calcite | 
|
| JavaRecordType | Record type based on a Java class. | Class | org.apache.calcite.jdbc | Calcite | 
|
| JavaRelImplementor | Abstract base class for implementations of RelImplementor that generate java code. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| JavaRowFormat | How a row is represented as a Java value. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| JavaToSqlTypeConversionRules | JavaToSqlTypeConversionRules defines mappings from common Java types to corresponding SQL types. | Class | org.apache.calcite.sql.type | Calcite | 
|
| JavaTypeFactory | Type factory that can register Java classes as record types. | Interface | org.apache.calcite.adapter.java | Calcite | 
|
| JavaTypeFactoryImpl | NOTE: This class is experimental and subject to change/removal without notice. | Class | org.apache.calcite.jdbc | Calcite | 
|
| JdbcConvention | Calling convention for relational operations that occur in a JDBC The convention is a slight misnomer. | Class | org.apache.calcite.adapter.jdbc | Calcite | 
|
| JdbcImplementor | State for generating a SQL statement. | Class | org.apache.calcite.adapter.jdbc | Calcite | 
|
| JdbcMeta |  | Class | org.apache.calcite.avatica.jdbc | Calcite | 
|
| JdbcQueryProvider |  | Class | org.apache.calcite.adapter.jdbc | Calcite | 
|
| JdbcRel | Relational expression that uses JDBC calling convention. | Interface | org.apache.calcite.adapter.jdbc | Calcite | 
|
| JdbcRules | Rules and relational operators for calling convention. | Class | org.apache.calcite.adapter.jdbc | Calcite | 
|
| JdbcSchema | The tables in the JDBC data source appear to be tables in this schema; queries against this schema are executed against those tables, pushing down | Class | org.apache.calcite.adapter.jdbc | Calcite | 
|
| JdbcTableScan | Relational expression representing a scan of a table in a JDBC data source. | Class | org.apache.calcite.adapter.jdbc | Calcite | 
|
| JdbcToEnumerableConverter | Relational expression representing a scan of a table in a JDBC data source. | Class | org.apache.calcite.adapter.jdbc | Calcite | 
|
| JdbcToEnumerableConverterRule | Rule to convert a relational expression from EnumerableConvention. | Class | org.apache.calcite.adapter.jdbc | Calcite | 
|
| JdbcToSparkConverter | Relational expression representing a scan of a table in a JDBC data source that returns its results as a Spark RDD. | Class | org.apache.calcite.adapter.spark | Calcite | 
|
| JdbcToSparkConverterRule |  | Class | org.apache.calcite.adapter.spark | Calcite | 
|
| Join | Relational expression that combines two relational expressions according to Each output row has columns from the left and right inputs. | Class | org.apache.calcite.rel.core | Calcite | 
|
| JoinAddRedundantSemiJoinRule | Rule to add a semi-join into a join. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| JoinAssociateRule | Planner rule that changes a join based on the associativity rule. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| JoinCommuteRule | Planner rule that permutes the inputs to a Permutation of outer joins can be turned on/off by specifying the | Class | org.apache.calcite.rel.rules | Calcite | 
|
| JoinConditionType | enum JoinConditionTypeEnumerates the types of condition in a join expression. | Class | org.apache.calcite.sql | Calcite | 
|
| JoinExtractFilterRule | cartesian inner join. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| JoinInfo | An analyzed join condition. | Class | org.apache.calcite.rel.core | Calcite | 
|
| JoinNode |  | Class | org.apache.calcite.interpreter | Calcite | 
|
| JoinProjectTransposeRule | Planner rule that matches a Join one of whose inputs is a | Class | org.apache.calcite.rel.rules | Calcite | 
|
| JoinPushExpressionsRule | Planner rule that pushes down expressions in equal join condition. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| JoinPushThroughJoinRule | Rule that pushes the right input of a join into through the left input of the join, provided that the left input is also a join. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| JoinPushTransitivePredicatesRule | Planner rule that infers predicates from on a Filters if those predicates can be pushed | Class | org.apache.calcite.rel.rules | Calcite | 
|
| JoinRelType | Enumeration of join types. | Class | org.apache.calcite.rel.core | Calcite | 
|
| JoinScope | The name-resolution context for expression inside a JOIN clause. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| JoinToCorrelateRule | Rule that converts a LogicalJoin into a LogicalCorrelate, which can | Class | org.apache.calcite.rel.rules | Calcite | 
|
| JoinToMultiJoinRule | Planner rule to flatten a tree of into a single MultiJoin with N inputs. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| JoinType | Enumerates the types of join. | Class | org.apache.calcite.sql | Calcite | 
|
| JoinUnionTransposeRule | Planner rule that pushes a past a non-distinct LogicalUnion. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| JsonBuilder | Builder for JSON documents (represented as List, Map, String, Boolean, Long). | Class | org.apache.calcite.util | Calcite | 
|
| JsonColumn | JSON object representing a column. | Class | org.apache.calcite.model | Calcite | 
|
| JsonCustomSchema | JSON schema element that represents a custom schema. | Class | org.apache.calcite.model | Calcite | 
|
| JsonCustomTable | Custom table schema element. | Class | org.apache.calcite.model | Calcite | 
|
| JsonFunction | Function schema element. | Class | org.apache.calcite.model | Calcite | 
|
| JsonHandler | that decodes JSON requests, sends them to a Service, and encodes the responses into JSON. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| JsonJdbcSchema | JSON object representing a schema that maps to a JDBC database. | Class | org.apache.calcite.model | Calcite | 
|
| JsonLattice | Element that describes a star schema and provides a framework for defining, recognizing, and recommending materialized views at various levels of | Class | org.apache.calcite.model | Calcite | 
|
| JsonMapSchema | JSON object representing a schema whose tables are explicitly specified. | Class | org.apache.calcite.model | Calcite | 
|
| JsonMaterialization | Element that describes how a table is a materialization of a query. | Class | org.apache.calcite.model | Calcite | 
|
| JsonMeasure | An aggregate function applied to a column (or columns) of a lattice. | Class | org.apache.calcite.model | Calcite | 
|
| JsonRoot | Root schema element. | Class | org.apache.calcite.model | Calcite | 
|
| JsonSchema | Schema schema element. | Class | org.apache.calcite.model | Calcite | 
|
| JsonService | that encodes requests and responses as JSON. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| JsonStream | Information about whether a table allows streaming. | Class | org.apache.calcite.model | Calcite | 
|
| JsonTable | Table based on a JSON file. | Class | org.apache.calcite.adapter.csv | Calcite | 
|
| JsonTable | Table schema element. | Class | org.apache.calcite.model | Calcite | 
|
| JsonTile | Materialized view within a JsonLattice. | Class | org.apache.calcite.model | Calcite | 
|
| JsonView | View schema element. | Class | org.apache.calcite.model | Calcite | 
|
| LabelStatement | Represents a label, which can be put in any Expression context. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| LabelTarget | Used to represent the target of a GotoStatement. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| LambdaExpression | Describes a lambda expression. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| Lattice | Structure that allows materialized views based upon a star schema to be recognized and recommended. | Class | org.apache.calcite.materialize | Calcite | 
|
| Lattices | Utilities for Lattice, LatticeStatisticProvider. | Class | org.apache.calcite.materialize | Calcite | 
|
| LatticeStatisticProvider | Estimates row counts for a lattice and its attributes. | Interface | org.apache.calcite.materialize | Calcite | 
|
| Lex | Named, built-in lexical policy. | Class | org.apache.calcite.config | Calcite | 
|
| Like | Utilities for converting SQL LIKE and SIMILAR operators to regular expressions. | Class | org.apache.calcite.runtime | Calcite | 
|
| Linq4j | Utility and factory methods for Linq4j. | Class | org.apache.calcite.linq4j | Calcite | 
|
| ListInitExpression | Represents a constructor call that has a collection initializer. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ListIteratorCursor | returns a List for each row. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| ListScope | Abstract base for a scope which is defined by a list of child namespaces and which inherits from a parent scope. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| ListSqlOperatorTable |  | Class | org.apache.calcite.sql.util | Calcite | 
|
| LiteralOperandTypeChecker | Parameter type-checking strategy type must be a literal (whether null is allowed is determined by the constructor). | Class | org.apache.calcite.sql.type | Calcite | 
|
| Litmus | Callback to be called when a test for validity succeeds or fails. | Interface | org.apache.calcite.util | Calcite | 
|
| LocalJsonService | that goes to an in-process instance of Service. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| LocalProtobufService | A Service implementation that performs protocol buffer serialization on request and responses on either side of computing a response from a request to mimic some transport to a server which | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| LocalService |  | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| LogicalAggregate | LogicalAggregate is a relational operator which eliminates duplicates and computes totals. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalCalc | A relational expression which computes project expressions and also filters. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalChi | not targeted at any particular engine or calling convention. | Class | org.apache.calcite.rel.stream | Calcite | 
|
| LogicalCorrelate | A relational operator that performs nested-loop joins. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalDelta | not targeted at any particular engine or calling convention. | Class | org.apache.calcite.rel.stream | Calcite | 
|
| LogicalExchange | Sub-class of Exchange not targeted at any particular engine or calling convention. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalFilter | not targeted at any particular engine or calling convention. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalIntersect | Sub-class of Intersect not targeted at any particular engine or calling convention. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalJoin | not targeted at any particular engine or calling convention. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalMinus | not targeted at any particular engine or calling convention. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalProject | Sub-class of Project not targeted at any particular engine or calling convention. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalSort | Sub-class of Sort not targeted at any particular engine or calling convention. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalTableFunctionScan | Sub-class of TableFunctionScan not targeted at any particular engine or calling convention. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalTableModify | Sub-class of TableModify not targeted at any particular engine or calling convention. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalTableScan | A LogicalTableScan reads all the rows from a If the table is a net. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalUnion | not targeted at any particular engine or calling convention. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalValues | not targeted at any particular engine or calling convention. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicalWindow | not targeted at any particular engine or calling convention. | Class | org.apache.calcite.rel.logical | Calcite | 
|
| LogicVisitor | Visitor pattern for traversing a tree of RexNode objects. | Class | org.apache.calcite.rex | Calcite | 
|
| LongFunction1 | Function that takes one parameter and returns a native long value. | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| Lookup | Represents a collection of keys each mapped to one or more values. | Interface | org.apache.calcite.linq4j | Calcite | 
|
| LoptJoinTree | Utility class used to store a Join tree and the factors that make up the tree. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| LoptMultiJoin | Utility class that keeps track of the join factors that make up a MultiJoin. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| LoptOptimizeJoinRule | Planner rule that implements the heuristic planner for determining optimal It is triggered by the pattern | Class | org.apache.calcite.rel.rules | Calcite | 
|
| LoptSemiJoinOptimizer | semi-joins to be used in processing joins in a query. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| Main | Jetty handler that executes Avatica JSON request-responses. | Class | org.apache.calcite.avatica.server | Calcite | 
|
| Map | Annotation that indicates that a field is a map type. | Class | org.apache.calcite.adapter.java | Calcite | 
|
| MapIteratorCursor | returns a Map for each row. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| Mapping | A Mapping is a relationship between a source domain to target domain of integers. | Interface | org.apache.calcite.util.mapping | Calcite | 
|
| Mappings | Utility functions related to mappings. | Class | org.apache.calcite.util.mapping | Calcite | 
|
| MappingType | Describes the type of a mapping, from the most general MULTI_FUNCTION (every element in the source and target domain can | Class | org.apache.calcite.util.mapping | Calcite | 
|
| MapSqlType |  | Class | org.apache.calcite.sql.type | Calcite | 
|
| MatchReturnTypeInference | Returns the first type that matches a set of given SqlTypeNames. | Class | org.apache.calcite.sql.type | Calcite | 
|
| MaterializationKey | Unique identifier for a materialization. | Class | org.apache.calcite.materialize | Calcite | 
|
| MaterializationService | Manages the collection of materialized tables known to the system, and the process by which they become valid and invalid. | Class | org.apache.calcite.materialize | Calcite | 
|
| MaterializedViewSubstitutionVisitor | Extension to SubstitutionVisitor. | Class | org.apache.calcite.plan | Calcite | 
|
| MaterializedViewTable | Table that is a materialized view. | Class | org.apache.calcite.schema.impl | Calcite | 
|
| MazeTable | User-defined table function that generates a Maze and prints it in textTable function that generates a maze. | Class | org.apache.calcite.example.maze | Calcite | 
|
| Member | A named expression in a schema. | Interface | org.apache.calcite.schema | Calcite | 
|
| MemberAssignment | Represents assignment operation for a field or property of an object. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| MemberBinding | Provides the base class from which the classes that represent bindings that are used to initialize members of a newly created object derive. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| MemberDeclaration | Declaration of a member of a class. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| MemberExpression | Represents accessing a field or property. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| MemberInitExpression |  | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| MemberListBinding |  | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| MemberMemberBinding | Represents initializing members of a member of a newly created object. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| Meta | Command handler for getting various metadata. | Interface | org.apache.calcite.avatica | Calcite | 
|
| Metadata | Metadata about a relational expression. | Interface | org.apache.calcite.rel.metadata | Calcite | 
|
| MetadataFactory | Source of metadata about relational expressions. | Interface | org.apache.calcite.rel.metadata | Calcite | 
|
| MetadataFactoryImpl | RelMetadataProvider and stores them in a cache. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| MetaDataOperation | enum MetaDataOperationIdentifies an operation from DatabaseMetaData which returns a ResultSet. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| MetaImpl | Basic implementation of Meta. | Class | org.apache.calcite.avatica | Calcite | 
|
| MethodCallExpression | Represents a call to either a static or an instance method. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| MethodDeclaration | Declaration of a method. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| Minus | Relational expression that returns the rows of its first input minus any matching rows from its other inputs. | Class | org.apache.calcite.rel.core | Calcite | 
|
| MissingResultsException | An Exception which denotes that a cached Statement is present but has no ResultSet. | Class | org.apache.calcite.avatica | Calcite | 
|
| MockJsonService | Mock implementation of Service that encodes its requests and responses as JSON | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| MockProtobufService | A mock implementation of ProtobufService for testing. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| ModelHandler | Reads a model and creates schema objects accordingly. | Class | org.apache.calcite.model | Calcite | 
|
| ModifiableTable | A table that can be modified. | Interface | org.apache.calcite.schema | Calcite | 
|
| ModifiableView | A modifiable view onto ModifiableTable. | Interface | org.apache.calcite.schema | Calcite | 
|
| MongoAggregate |  | Class | org.apache.calcite.adapter.mongodb | Calcite | 
|
| MongoFilter | relational expression in MongoDB. | Class | org.apache.calcite.adapter.mongodb | Calcite | 
|
| MongoMethod | Builtin methods in the MongoDB adapter. | Class | org.apache.calcite.adapter.mongodb | Calcite | 
|
| MongoProject | relational expression in MongoDB. | Class | org.apache.calcite.adapter.mongodb | Calcite | 
|
| MongoRel | Relational expression that uses Mongo calling convention. | Interface | org.apache.calcite.adapter.mongodb | Calcite | 
|
| MongoRules | Rules and relational operators for calling convention. | Class | org.apache.calcite.adapter.mongodb | Calcite | 
|
| MongoSchema | Schema mapped onto a directory of MONGO files. | Class | org.apache.calcite.adapter.mongodb | Calcite | 
|
| MongoSchemaFactory | Factory that creates a MongoSchema. | Class | org.apache.calcite.adapter.mongodb | Calcite | 
|
| MongoSort | relational expression in MongoDB. | Class | org.apache.calcite.adapter.mongodb | Calcite | 
|
| MongoTable | Table based on a MongoDB collection. | Class | org.apache.calcite.adapter.mongodb | Calcite | 
|
| MongoTableScan | Relational expression representing a scan of a MongoDB collection. | Class | org.apache.calcite.adapter.mongodb | Calcite | 
|
| MongoToEnumerableConverter | Relational expression representing a scan of a table in a Mongo data source. | Class | org.apache.calcite.adapter.mongodb | Calcite | 
|
| MongoToEnumerableConverterRule | Rule to convert a relational expression from MongoRel. | Class | org.apache.calcite.adapter.mongodb | Calcite | 
|
| MulticastRelOptListener | MulticastRelOptListener implements the RelOptListener interface by forwarding events on to a collection of other listeners. | Class | org.apache.calcite.plan | Calcite | 
|
| MultiJoin | A MultiJoin represents a join of N inputs, whereas regular Joins represent strictly binary joins. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| MultiJoinOptimizeBushyRule | Planner rule that finds an approximately optimal ordering for join operators using a heuristic algorithm. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| MultiJoinProjectTransposeRule | MultiJoinProjectTransposeRule implements the rule for pulling LogicalProjects that are on top of a | Class | org.apache.calcite.rel.rules | Calcite | 
|
| MultisetOperandTypeChecker | Parameter type-checking strategy types must be [nullable] Multiset, [nullable] Multiset and the two types must have the same element type | Class | org.apache.calcite.sql.type | Calcite | 
|
| MultisetSqlType | MultisetSqlType represents a standard SQL2003 multiset type. | Class | org.apache.calcite.sql.type | Calcite | 
|
| NestedBlockBuilder | Allows to build nested code blocks with tracking of current context and the nullability of particular RexNode expressions. | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| NestedBlockBuilderImpl | Allows to build nested code blocks with tracking of current context and the nullability of particular RexNode expressions. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| NewArrayExpression |  | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| NewExpression | Represents a constructor call. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| NlsString | A string, optionally with character set and SqlCollation. | Class | org.apache.calcite.util | Calcite | 
|
| Node | Relational expression that can be executed using an interpreter. | Interface | org.apache.calcite.interpreter | Calcite | 
|
| Node |  | Interface | org.apache.calcite.linq4j.tree | Calcite | 
|
| Nodes |  | Class | org.apache.calcite.interpreter | Calcite | 
|
| NonDeterministic | Specifies that function is NOT deterministic (i. | Class | org.apache.calcite.linq4j.function | Calcite | 
|
| NoneConverter |  | Class | org.apache.calcite.rel.convert | Calcite | 
|
| NoneToBindableConverterRule | Rule to convert a relational expression from to BindableConvention. | Class | org.apache.calcite.interpreter | Calcite | 
|
| NoSuchConnectionException | An Exception that denotes that the given Connection is not cached. | Class | org.apache.calcite.avatica | Calcite | 
|
| NoSuchStatementException | An Exception that denotes that the given Statement is not cached. | Class | org.apache.calcite.avatica | Calcite | 
|
| NotNullImplementor | Simplified version of that does not know about null semantics. | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| NullableBigDecimalFunction1 |  | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| NullableDoubleFunction1 |  | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| NullableFloatFunction1 |  | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| NullableIntegerFunction1 |  | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| NullableLongFunction1 |  | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| NullCollation | Strategy for how NULL values are to be sorted if NULLS FIRST or NULLS LAST are not specified in an item in the ORDER BY clause. | Class | org.apache.calcite.config | Calcite | 
|
| NullPolicy | Describes when a function/operator will return null. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| NumberUtil | Utility functions for working with numbers This class is JDK 1. | Class | org.apache.calcite.util | Calcite | 
|
| ObjectEnumeratorCursor | returns an Object for each row. | Class | org.apache.calcite.runtime | Calcite | 
|
| ObjectSqlType | ObjectSqlType represents an SQL structured user-defined type. | Class | org.apache.calcite.sql.type | Calcite | 
|
| OperandsTypeChecking | Strategies to check for allowed operand types of an operator call. | Class | org.apache.calcite.sql.type | Calcite | 
|
| OperandTypes | Strategies for checking operand types. | Class | org.apache.calcite.sql.type | Calcite | 
|
| OptimizeVisitor | Visitor that optimizes expressions. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| OpType |  | Class | org.apache.calcite.linq4j | Calcite | 
|
| Ord | Pair of an element and an ordinal. | Class | org.apache.calcite.linq4j | Calcite | 
|
| OrderByScope | Represents the name-resolution context for expressions in an ORDER BY clause. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| OrderedEnumerable |  | Interface | org.apache.calcite.linq4j | Calcite | 
|
| OrderedQueryable | Represents the result of applying a sorting operation to a Queryable. | Interface | org.apache.calcite.linq4j | Calcite | 
|
| OrdinalReturnTypeInference | Returns the type of the operand at a particular 0-based ordinal position. | Class | org.apache.calcite.sql.type | Calcite | 
|
| OverScope | The name-resolution scope of a OVER clause. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| PackageMarker | This is a dummy annotation that forces javac to produce output for otherwise empty package-info. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| PackageMarker | This is a dummy annotation that forces javac to produce output for otherwise empty package-info. | Class | org.apache.calcite.linq4j | Calcite | 
|
| Pair | Because a pair implements equals(Object), hashCode() and compareTo(Pair), it can be used in any kind of | Class | org.apache.calcite.util | Calcite | 
|
| Parameter | Annotation that supplies metadata about a function parameter. | Class | org.apache.calcite.linq4j.function | Calcite | 
|
| ParameterExpression | Represents a named parameter expression. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ParameterScope | A scope which contains nothing besides a few parameters. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| ParserBenchmark |  | Class | org.apache.calcite.benchmarks | Calcite | 
|
| ParserBenchmark_jmhType |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| ParserBenchmark_jmhType_B1 |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| ParserBenchmark_jmhType_B2 |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| ParserBenchmark_jmhType_B3 |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| ParserBenchmark_parseCached_jmhTest |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| ParserBenchmark_parseNonCached_jmhTest |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| PartiallyOrderedSet | Partially-ordered set. | Class | org.apache.calcite.util | Calcite | 
|
| Path | Path from a root schema to a particular object (schema, table, function). | Interface | org.apache.calcite.schema | Calcite | 
|
| Permutation | Represents a mapping which reorders elements in an array. | Class | org.apache.calcite.util | Calcite | 
|
| PhysType | Physical type of a row. | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| PhysTypeImpl |  | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| PigRelBuilder | Extension to RelBuilder for Pig relational operators. | Class | org.apache.calcite.tools | Calcite | 
|
| Planner |  | Interface | org.apache.calcite.tools | Calcite | 
|
| PlannerImpl |  | Class | org.apache.calcite.prepare | Calcite | 
|
| PositionedCursor | Abstract implementation of Cursor that caches its current row. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| PreconditionTest |  | Class | org.apache.calcite.benchmarks | Calcite | 
|
| Predicate1 | Function with one parameter returning a native boolean value. | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| Predicate2 | Function with two parameters returning a native boolean value. | Interface | org.apache.calcite.linq4j.function | Calcite | 
|
| Prepare | Abstract base for classes that implement the process of preparing and executing SQL expressions. | Class | org.apache.calcite.prepare | Calcite | 
|
| Primitive | Enumeration of Java's primitive types. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ProcedureNamespace | Namespace whose contents are defined by the result of a call to a user-defined procedure. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| Program | Program that transforms a relational expression into another relational A planner is a sequence of programs, each of which is sometimes called | Interface | org.apache.calcite.tools | Calcite | 
|
| Programs | Utilities for creating Programs. | Class | org.apache.calcite.tools | Calcite | 
|
| Project | Relational expression that computes a set of 'select expressions' from its input relational expression. | Class | org.apache.calcite.rel.core | Calcite | 
|
| ProjectableFilterableTable | Table that can be scanned, optionally applying supplied filter expressions, and projecting a given list of columns, | Interface | org.apache.calcite.schema | Calcite | 
|
| ProjectCalcMergeRule | Planner rule which merges a LogicalProject and a | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ProjectFilterTransposeRule |  | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ProjectJoinTransposeRule | Planner rule that pushes a Project by splitting the projection into a projection on top of each child of | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ProjectMergeRule | ProjectMergeRule merges a Project into provided the projects aren't projecting identical sets of input references. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ProjectMultiJoinMergeRule | Planner rule that pushes creating a richer MultiJoin. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ProjectNode |  | Class | org.apache.calcite.interpreter | Calcite | 
|
| ProjectRemoveRule | given a Project node that merely returns its input, converts the node into its child. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ProjectSetOpTransposeRule | Planner rule that pushes The children of the SetOp will project | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ProjectSortTransposeRule | Planner rule that pushesSee Also:SortProjectTransposeRule | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ProjectTableScanRule | Planner rule that converts a Project of a ProjectableFilterableTable | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ProjectToCalcRule | LogicalProject to a The rule does not fire if the child is a | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ProjectToWindowRule | Planner rule that slices a into sections which contain windowed | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ProjectWindowTransposeRule | Planner rule that pushes past a LogicalWindow. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ProtobufHandler | Dispatches serialized protocol buffer messages to the provided Service by converting them to the POJO Request. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| ProtobufService | Service implementation that encodes requests and responses as protocol buffers. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| ProtobufTranslation | Generic interface to support parsing of serialized protocol buffers between client and server. | Interface | org.apache.calcite.avatica.remote | Calcite | 
|
| ProtobufTranslationImpl | protobuf requests to POJO requests. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| PruneEmptyRules | Collection of rules which remove sections of a query plan known never to Conventionally, the way to represent an empty relational expression is | Class | org.apache.calcite.rel.rules | Calcite | 
|
| PseudoField | Contains the parts of the Field class needed for code generation, but might be implemented differently. | Interface | org.apache.calcite.linq4j.tree | Calcite | 
|
| PushProjector | PushProjector is a utility class used to perform operations used in push Pushing is particularly interesting in the case of join, because there | Class | org.apache.calcite.rel.rules | Calcite | 
|
| Queryable | Provides functionality to evaluate queries against a specific data source wherein the type of the data is known. | Interface | org.apache.calcite.linq4j | Calcite | 
|
| QueryableDefaults | Default implementations for methods in the Queryable interface. | Class | org.apache.calcite.linq4j | Calcite | 
|
| QueryableFactory | Factory for building Queryable objects. | Interface | org.apache.calcite.linq4j | Calcite | 
|
| QueryableRecorder | and returns an object that can replay the event when you call its QueryableDefaults. | Class | org.apache.calcite.linq4j | Calcite | 
|
| QueryableTable | Extension to Table that can translate itself to a Queryable. | Interface | org.apache.calcite.schema | Calcite | 
|
| QueryProvider | Defines methods to create and execute queries that are described by a Analogous to LINQ's System. | Interface | org.apache.calcite.linq4j | Calcite | 
|
| QueryProviderImpl | Partial implementation of QueryProvider. | Class | org.apache.calcite.linq4j | Calcite | 
|
| QueryState |  | Class | org.apache.calcite.avatica | Calcite | 
|
| Quoting | Syntax for quoting identifiers in SQL statements. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| RawEnumerable | Exposes the enumerator, which supports a simple iteration over a collection, without the extension methods. | Interface | org.apache.calcite.linq4j | Calcite | 
|
| RawQueryable | Core methods that define a Queryable. | Interface | org.apache.calcite.linq4j | Calcite | 
|
| RecordEnumeratorCursor | returns a record for each row. | Class | org.apache.calcite.runtime | Calcite | 
|
| RecordIteratorCursor | returns a record for each row. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| ReduceDecimalsRule | ReduceDecimalsRule is a rule which reduces decimal operations (such as casts or arithmetic) into operations involving more primitive types (such as longs | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ReduceExpressionsRule | Collection of planner rules that apply various simplifying transformations on RexNode trees. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ReflectedPseudoField |  | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ReflectiveCallNotNullImplementor | that calls a given Method. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| ReflectiveConvertletTable | any method of the form public RexNode convertXxx(ConvertletContext, SqlNode) or public RexNode convertXxx(ConvertletContext, | Class | org.apache.calcite.sql2rel | Calcite | 
|
| ReflectiveFunctionBase | This class mainly solves conversion of method parameter types to List form. | Class | org.apache.calcite.schema.impl | Calcite | 
|
| ReflectiveRelMetadataProvider | metadata methods to methods on a given object via reflection. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| ReflectiveSchema | public fields and methods in a Java object. | Class | org.apache.calcite.adapter.java | Calcite | 
|
| ReflectiveSqlOperatorTable | ReflectiveSqlOperatorTable implements the SqlOperatorTable interface by reflecting the public fields of a subclass. | Class | org.apache.calcite.sql.util | Calcite | 
|
| ReflectiveVisitDispatcher | Interface for looking up methods relating to reflective visitation. | Interface | org.apache.calcite.util | Calcite | 
|
| ReflectiveVisitor | Object which can be a target for a reflective visitation (see ReflectUtil. | Interface | org.apache.calcite.util | Calcite | 
|
| ReflectUtil | Static utilities for Java reflection. | Class | org.apache.calcite.util | Calcite | 
|
| RelBuilder | Builder for relational expressions. | Class | org.apache.calcite.tools | Calcite | 
|
| RelBuilderFactory | A partially-created RelBuilder. | Interface | org.apache.calcite.tools | Calcite | 
|
| RelCollation | Description of the physical ordering of a relational expression. | Interface | org.apache.calcite.rel | Calcite | 
|
| RelCollationImpl | Simple implementation of RelCollation. | Class | org.apache.calcite.rel | Calcite | 
|
| RelCollations | Utilities concerning RelCollation and RelFieldCollation. | Class | org.apache.calcite.rel | Calcite | 
|
| RelCollationTraitDef | Definition of the ordering trait. | Class | org.apache.calcite.rel | Calcite | 
|
| RelColumnMapping | Mapping from an input column of a RelNode to one of its output columns. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelColumnOrigin | RelColumnOrigin is a data structure describing one of the origins of an output column produced by a relational expression. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelConversionException | An Exception thrown when attempting conversion to a set ofSee Also:Serialized Form | Class | org.apache.calcite.tools | Calcite | 
|
| RelCrossType | Type of the cartesian product of two or more sets of records. | Class | org.apache.calcite.rel.type | Calcite | 
|
| RelDataType | RelDataType represents the type of a scalar expression or entire row returned from a relational expression. | Interface | org.apache.calcite.rel.type | Calcite | 
|
| RelDataTypeComparability | enum RelDataTypeComparabilityRelDataTypeComparability is an enumeration of the categories of comparison | Class | org.apache.calcite.rel.type | Calcite | 
|
| RelDataTypeFactory | RelDataTypeFactory is a factory for datatype descriptors. | Interface | org.apache.calcite.rel.type | Calcite | 
|
| RelDataTypeFactoryImpl | Abstract base for implementations of RelDataTypeFactory. | Class | org.apache.calcite.rel.type | Calcite | 
|
| RelDataTypeField | RelDataTypeField represents the definition of a field in a structured Extends the Map. | Interface | org.apache.calcite.rel.type | Calcite | 
|
| RelDataTypeFieldImpl | Default implementation of RelDataTypeField. | Class | org.apache.calcite.rel.type | Calcite | 
|
| RelDataTypeImpl | RelDataTypeImpl is an abstract base for implementations of Identity is based upon the digest field, which each derived class | Class | org.apache.calcite.rel.type | Calcite | 
|
| RelDataTypePrecedenceList | RelDataTypePrecedenceList defines a type precedence list for a particularSQL 99 spec:Part 2 Section 9. | Interface | org.apache.calcite.rel.type | Calcite | 
|
| RelDataTypeSystem | Provides behaviors concerning type limits and behaviors. | Interface | org.apache.calcite.rel.type | Calcite | 
|
| RelDataTypeSystemImpl | Default implementation of providing parameters from the SQL standard. | Class | org.apache.calcite.rel.type | Calcite | 
|
| RelDecorrelator | RelDecorrelator replaces all correlated expressions (corExp) in a relational expression (RelNode) tree with non-correlated expressions that are produced | Class | org.apache.calcite.sql2rel | Calcite | 
|
| RelDistribution | Description of the physical distribution of a relational expression. | Interface | org.apache.calcite.rel | Calcite | 
|
| RelDistributions | Utilities concerning RelDistribution. | Class | org.apache.calcite.rel | Calcite | 
|
| RelDistributionTraitDef | Definition of the distribution trait. | Class | org.apache.calcite.rel | Calcite | 
|
| RelFactories |  | Class | org.apache.calcite.rel.core | Calcite | 
|
| RelFieldCollation | Definition of the ordering of one field of a RelNode whose output is to be sorted. | Class | org.apache.calcite.rel | Calcite | 
|
| RelFieldTrimmer | Transformer that walks over a tree of relational expressions, replacing each RelNode with a 'slimmed down' relational expression that projects | Class | org.apache.calcite.sql2rel | Calcite | 
|
| RelHomogeneousShuttle |  | Class | org.apache.calcite.rel | Calcite | 
|
| RelImplementor | This is a marker interface for a callback used to convert a tree of relational expressions into a plan. | Interface | org.apache.calcite.plan | Calcite | 
|
| RelInput | Context from which a relational expression can initialize itself, reading from a serialized form of the relational expression. | Interface | org.apache.calcite.rel | Calcite | 
|
| RelJson |  | Class | org.apache.calcite.rel.externalize | Calcite | 
|
| RelJsonReader | Reads a JSON plan and converts it back to a tree of relational expressions. | Class | org.apache.calcite.rel.externalize | Calcite | 
|
| RelJsonWriter | Callback for a relational expression to dump itself as JSON. | Class | org.apache.calcite.rel.externalize | Calcite | 
|
| RelMdCollation | RelMdCollation supplies a default implementation of RelMetadataQuery. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdColumnOrigins | RelMdColumnOrigins supplies a default implementation of RelMetadataQuery. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdColumnUniqueness | RelMdColumnUniqueness supplies a default implementation of RelMetadataQuery. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdDistinctRowCount | RelMdDistinctRowCount supplies a default implementation of RelMetadataQuery. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdDistribution | RelMdCollation supplies a default implementation of RelMetadataQuery. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdExplainVisibility | RelMdExplainVisibility supplies a default implementation of RelMetadataQuery. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdMaxRowCount | RelMdMaxRowCount supplies a default implementation of RelMetadataQuery. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdMemory | Default implementations of the BuiltInMetadata. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdParallelism | Default implementations of the BuiltInMetadata. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdPercentageOriginalRows | RelMdPercentageOriginalRows supplies a default implementation of RelMetadataQuery. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdPopulationSize | RelMdPopulationSize supplies a default implementation of RelMetadataQuery. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdPredicates | Utility to infer Predicates that are applicable above a RelNode. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdRowCount | RelMdRowCount supplies a default implementation of RelMetadataQuery. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdSelectivity | RelMdSelectivity supplies a default implementation of RelMetadataQuery. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdSize | Default implementations of the BuiltInMetadata. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdUniqueKeys | RelMdUniqueKeys supplies a default implementation of RelMetadataQuery. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMdUtil | RelMdUtil provides utility methods used by the metadata provider methods. | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMetadataProvider | RelMetadataProvider defines an interface for obtaining metadata about relational expressions. | Interface | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMetadataQuery | RelMetadataQuery provides a strongly-typed facade on top of RelMetadataProvider for the set of relational expression metadata | Class | org.apache.calcite.rel.metadata | Calcite | 
|
| RelMultipleTrait | Trait for which a given relational expression can have multiple values. | Interface | org.apache.calcite.plan | Calcite | 
|
| RelNode | A RelNode is a relational expression. | Interface | org.apache.calcite.rel | Calcite | 
|
| RelNodes | Utilities concerning relational expressions. | Class | org.apache.calcite.rel | Calcite | 
|
| RelOptAbstractTable | Partial implementation of RelOptTable. | Class | org.apache.calcite.plan | Calcite | 
|
| RelOptCluster | An environment for related relational expressions during the optimization of a query. | Class | org.apache.calcite.plan | Calcite | 
|
| RelOptConnection | The planner's view of a connection to a database. | Interface | org.apache.calcite.plan | Calcite | 
|
| RelOptCost | RelOptCost defines an interface for optimizer cost in terms of number of rows processed, CPU cost, and I/O cost. | Interface | org.apache.calcite.plan | Calcite | 
|
| RelOptCostFactory | Cost model for query planning. | Interface | org.apache.calcite.plan | Calcite | 
|
| RelOptCostImpl | RelOptCostImpl provides a default implementation for the RelOptCost interface. | Class | org.apache.calcite.plan | Calcite | 
|
| RelOptLattice | Use of a lattice by the query optimizer. | Class | org.apache.calcite.plan | Calcite | 
|
| RelOptListener | RelOptListener defines an interface for listening to events which occur during the optimization process. | Interface | org.apache.calcite.plan | Calcite | 
|
| RelOptMaterialization | Records that a particular query is materialized by a particular table. | Class | org.apache.calcite.plan | Calcite | 
|
| RelOptNode | Returns the cluster this relational expression belongs to. | Interface | org.apache.calcite.plan | Calcite | 
|
| RelOptPlanner | A RelOptPlanner is a query optimizer: it transforms a relational expression into a semantically equivalent relational expression, according to | Interface | org.apache.calcite.plan | Calcite | 
|
| RelOptPredicateList | Predicates that are known to hold in the output of a particular relational Pulled up predicates (field pulledUpPredicates are | Class | org.apache.calcite.plan | Calcite | 
|
| RelOptQuery | A RelOptQuery represents a set of relational expressions which derive from the same | Class | org.apache.calcite.plan | Calcite | 
|
| RelOptRule | A RelOptRule transforms an expression into another. | Class | org.apache.calcite.plan | Calcite | 
|
| RelOptRuleCall | A RelOptRuleCall is an invocation of a RelOptRule with a set of relational expressions as arguments. | Class | org.apache.calcite.plan | Calcite | 
|
| RelOptRuleOperand | Operand that determines whether a RelOptRule can be applied to a particular expression. | Class | org.apache.calcite.plan | Calcite | 
|
| RelOptRuleOperandChildPolicy | enum RelOptRuleOperandChildPolicyPolicy by which operands will be matched by relational expressions with | Class | org.apache.calcite.plan | Calcite | 
|
| RelOptRuleOperandChildren | Children of a RelOptRuleOperand and the policy for matching them. | Class | org.apache.calcite.plan | Calcite | 
|
| RelOptSamplingParameters | RelOptSamplingParameters represents the parameters necessary to produce a sample of a relation. | Class | org.apache.calcite.plan | Calcite | 
|
| RelOptSchema | A RelOptSchema is a set of RelOptTable objects. | Interface | org.apache.calcite.plan | Calcite | 
|
| RelOptSchemaWithSampling | Extension to RelOptSchema with support for sample data-sets. | Interface | org.apache.calcite.plan | Calcite | 
|
| RelOptTable | Represents a relational dataset in a RelOptSchema. | Interface | org.apache.calcite.plan | Calcite | 
|
| RelOptTableImpl |  | Class | org.apache.calcite.prepare | Calcite | 
|
| RelOptUtil |  | Class | org.apache.calcite.plan | Calcite | 
|
| RelProtoDataType | Can be converted into a RelDataType given a RelDataTypeFactory. | Interface | org.apache.calcite.rel.type | Calcite | 
|
| RelRecordType | RelRecordType represents a structured type having named fields. | Class | org.apache.calcite.rel.type | Calcite | 
|
| RelRoot | Root of a tree of RelNode. | Class | org.apache.calcite.rel | Calcite | 
|
| RelRunner | Runs a relational expression. | Interface | org.apache.calcite.tools | Calcite | 
|
| RelRunners | Runs a relational expression by creating a JDBC connection. | Class | org.apache.calcite.tools | Calcite | 
|
| RelShuttle | Visitor that has methods for the common logical relational expressions. | Interface | org.apache.calcite.rel | Calcite | 
|
| RelShuttleImpl | Basic implementation of RelShuttle that calls RelNode. | Class | org.apache.calcite.rel | Calcite | 
|
| RelStructuredTypeFlattener | RelStructuredTypeFlattener removes all structured types from a tree of relational expressions. | Class | org.apache.calcite.sql2rel | Calcite | 
|
| RelSubset | Subset of an equivalence class where all relational expressions have the same physical properties. | Class | org.apache.calcite.plan.volcano | Calcite | 
|
| RelToSqlConverter | Utility to convert relational expressions to SQL abstract syntax tree. | Class | org.apache.calcite.rel.rel2sql | Calcite | 
|
| RelTrait | RelTrait represents the manifestation of a relational expression trait within a trait definition. | Interface | org.apache.calcite.plan | Calcite | 
|
| RelTraitDef | RelTraitDef represents a class of RelTraits. | Class | org.apache.calcite.plan | Calcite | 
|
| RelTraitPropagationVisitor | RelTraitPropagationVisitor traverses a RelNode and its unregistered children, making sure that each has a full complement of traits. | Class | org.apache.calcite.plan | Calcite | 
|
| RelTraitSet | RelTraitSet represents an ordered set of RelTraits. | Class | org.apache.calcite.plan | Calcite | 
|
| RelVisitor | A RelVisitor is a Visitor role in the visitor pattern and | Class | org.apache.calcite.rel | Calcite | 
|
| RelWriter | Callback for an expression to dump itself to. | Interface | org.apache.calcite.rel | Calcite | 
|
| RelWriterImpl |  | Class | org.apache.calcite.rel.externalize | Calcite | 
|
| RelXmlWriter | Callback for a relational expression to dump in XML format. | Class | org.apache.calcite.rel.externalize | Calcite | 
|
| RemoteProtobufService | ProtobufService implementation that queries against a remote implementation, using protocol buffers as the serialized form. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| RemoteService | that translates requests into JSON and sends them to a remote server, usually an HTTP server. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| Requests |  | Class | org.apache.calcite.avatica.proto | Calcite | 
|
| RequestTranslator | Encapsulate the logic of transforming a protobuf Request message into the Avatica POJO request. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| Resources | Defining wrapper classes around resources that allow the compiler to check whether the resources exist and have the argument types that your code | Class | org.apache.calcite.runtime | Calcite | 
|
| Responses |  | Class | org.apache.calcite.avatica.proto | Calcite | 
|
| ResponseTranslator | Encapsulate the logic of transforming a protobuf Response message into the Avatica POJO Response. | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| ResultSetEnumerable | Executes a SQL statement and returns the result as an Enumerable. | Class | org.apache.calcite.runtime | Calcite | 
|
| ReturnTypes | A collection of return-type inference strategies. | Class | org.apache.calcite.sql.type | Calcite | 
|
| RexAction | A RexAction is called when a RexPattern finds a match. | Interface | org.apache.calcite.rex | Calcite | 
|
| RexBiVisitor | Visitor pattern for traversing a tree of RexNode objects and passing a payload to each. | Interface | org.apache.calcite.rex | Calcite | 
|
| RexBuilder | Factory for row expressions. | Class | org.apache.calcite.rex | Calcite | 
|
| RexCall | An expression formed by a call to an operator with zero or more expressions Operators may be binary, unary, functions, special syntactic constructs | Class | org.apache.calcite.rex | Calcite | 
|
| RexCallBinding | RexCallBinding implements SqlOperatorBinding by referring to an underlying collection of RexNode operands. | Class | org.apache.calcite.rex | Calcite | 
|
| RexChecker | Visitor which checks the validity of a RexNode expression. | Class | org.apache.calcite.rex | Calcite | 
|
| RexCorrelVariable | Reference to the current row of a correlating relational expression. | Class | org.apache.calcite.rex | Calcite | 
|
| RexDynamicParam | Dynamic parameter reference in a row-expression. | Class | org.apache.calcite.rex | Calcite | 
|
| RexExecutable | Result of compiling code generated from a RexNode expression. | Class | org.apache.calcite.rex | Calcite | 
|
| RexExecutorImpl | Evaluates a RexNode expression. | Class | org.apache.calcite.rex | Calcite | 
|
| RexFieldAccess | Access to a field of a row-expression. | Class | org.apache.calcite.rex | Calcite | 
|
| RexFieldCollation | Expression combined with sort flags (DESCENDING, NULLS LAST). | Class | org.apache.calcite.rex | Calcite | 
|
| RexImplicationChecker | Checks whether one condition logically implies another. | Class | org.apache.calcite.plan | Calcite | 
|
| RexImpTable | Contains implementations of Rex operators as Java code. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| RexInputRef | Variable which references a field of an input relational expression. | Class | org.apache.calcite.rex | Calcite | 
|
| RexLiteral | Constant value in a row-expression. | Class | org.apache.calcite.rex | Calcite | 
|
| RexLocalRef | Identity is based upon type and index. | Class | org.apache.calcite.rex | Calcite | 
|
| RexMultisetUtil | Utility class for various methods related to multisets. | Class | org.apache.calcite.rex | Calcite | 
|
| RexNode | Every row-expression has a type. | Class | org.apache.calcite.rex | Calcite | 
|
| RexOver | Call to an aggregate function over a window. | Class | org.apache.calcite.rex | Calcite | 
|
| RexPattern | A RexPattern represents an expression with holes in it. | Interface | org.apache.calcite.rex | Calcite | 
|
| RexPermutationShuttle | Visitor which replaces RexLocalRef objects after the expressions in a RexProgram have been reordered. | Class | org.apache.calcite.rex | Calcite | 
|
| RexPermuteInputsShuttle | Shuttle which applies a permutation to its input fields. | Class | org.apache.calcite.rex | Calcite | 
|
| RexProgram | A collection of expressions which read inputs, compute output expressions, and optionally use a condition to filter rows. | Class | org.apache.calcite.rex | Calcite | 
|
| RexProgramBuilder | Workspace for constructing a RexProgram. | Class | org.apache.calcite.rex | Calcite | 
|
| RexRangeRef | Reference to a range of columns. | Class | org.apache.calcite.rex | Calcite | 
|
| RexShuttle | Passes over a row-expression, calling a handler method for each node, appropriate to the type of the node. | Class | org.apache.calcite.rex | Calcite | 
|
| RexSlot | Abstract base class for RexInputRef and RexLocalRef. | Class | org.apache.calcite.rex | Calcite | 
|
| RexSqlConvertlet | Converts a RexNode expression into a SqlNode expression. | Interface | org.apache.calcite.rex | Calcite | 
|
| RexSqlConvertletTable | Collection of RexSqlConvertlets. | Interface | org.apache.calcite.rex | Calcite | 
|
| RexSqlReflectiveConvertletTable |  | Class | org.apache.calcite.rex | Calcite | 
|
| RexSqlStandardConvertletTable | Standard implementation of RexSqlConvertletTable. | Class | org.apache.calcite.rex | Calcite | 
|
| RexSubQuery | Scalar expression that represents an IN, EXISTS or scalar sub-query. | Class | org.apache.calcite.rex | Calcite | 
|
| RexToLixTranslator | Translates REX expressions to linq4j expressions. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| RexToSqlNodeConverter | Converts expressions from RexNode to SqlNode. | Interface | org.apache.calcite.rex | Calcite | 
|
| RexToSqlNodeConverterImpl | Standard implementation of RexToSqlNodeConverter. | Class | org.apache.calcite.rex | Calcite | 
|
| RexTransformer | Takes a tree of RexNode objects and transforms it into another in one sense equivalent tree. | Class | org.apache.calcite.rex | Calcite | 
|
| RexUtil | Utility methods concerning row-expressions. | Class | org.apache.calcite.rex | Calcite | 
|
| RexVariable | A row-expression which references a field. | Class | org.apache.calcite.rex | Calcite | 
|
| RexVisitor | Visitor pattern for traversing a tree of RexNode objects. | Interface | org.apache.calcite.rex | Calcite | 
|
| RexVisitorImpl | Default implementation of RexVisitor, which visits each node but does nothing while it's there. | Class | org.apache.calcite.rex | Calcite | 
|
| RexWindow | Specification of the window of rows over which a RexOver windowed aggregate is evaluated. | Class | org.apache.calcite.rex | Calcite | 
|
| RexWindowBound |  | Class | org.apache.calcite.rex | Calcite | 
|
| Row |  | Class | org.apache.calcite.interpreter | Calcite | 
|
| RuleSet | A set rules associated with a particular type of invocation of the Planner. | Interface | org.apache.calcite.tools | Calcite | 
|
| RuleSets | Utilities for creating and composing rule sets. | Class | org.apache.calcite.tools | Calcite | 
|
| SaffronProperties | Provides an environment for debugging information, et cetera, used by getIntProperty(java. | Class | org.apache.calcite.util | Calcite | 
|
| SameOperandTypeChecker | Parameter type-checking strategy where all operand types must be the same. | Class | org.apache.calcite.sql.type | Calcite | 
|
| Sample | Relational expression that returns a sample of the rows from its input. | Class | org.apache.calcite.rel.core | Calcite | 
|
| Scalar | Compiled scalar expression. | Interface | org.apache.calcite.interpreter | Calcite | 
|
| ScalarFunction | Function that returns a scalar result. | Interface | org.apache.calcite.schema | Calcite | 
|
| ScalarFunctionImpl |  | Class | org.apache.calcite.schema.impl | Calcite | 
|
| ScannableTable | Table that can be scanned without creating an intermediate relationalReturns an enumerator over the rows in this Table. | Interface | org.apache.calcite.schema | Calcite | 
|
| Schema | A namespace for tables and functions. | Interface | org.apache.calcite.schema | Calcite | 
|
| SchemaFactory | Factory for Schema objects. | Interface | org.apache.calcite.schema | Calcite | 
|
| SchemaPlus | Extension to the Schema interface. | Interface | org.apache.calcite.schema | Calcite | 
|
| Schemas | Utility functions for schemas. | Class | org.apache.calcite.schema | Calcite | 
|
| SearchResultListener | Called each time a search returns a record. | Interface | org.apache.calcite.adapter.splunk.search | Calcite | 
|
| SelectNamespace | Namespace offered by a subquery. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SelectScope | The name-resolution scope of a SELECT clause. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SemiJoin | Relational expression that joins two relational expressions according to some condition, but outputs only columns from the left input, and eliminates | Class | org.apache.calcite.rel.core | Calcite | 
|
| SemiJoinFilterTransposeRule | Planner rule that pushes SemiJoins down in a tree past | Class | org.apache.calcite.rel.rules | Calcite | 
|
| SemiJoinJoinTransposeRule | Planner rule that pushes a SemiJoin down in a tree past a Join | Class | org.apache.calcite.rel.rules | Calcite | 
|
| SemiJoinProjectTransposeRule | Planner rule that pushes a SemiJoin down in a tree past | Class | org.apache.calcite.rel.rules | Calcite | 
|
| SemiJoinRemoveRule | Planner rule that removes a SemiJoins It is invoked after attempts have been made to convert a SemiJoin to an | Class | org.apache.calcite.rel.rules | Calcite | 
|
| SemiJoinRule |  | Class | org.apache.calcite.rel.rules | Calcite | 
|
| SemiJoinType | Enumeration representing different join types used in correlationEnum Constant Summary | Class | org.apache.calcite.sql | Calcite | 
|
| SemiMutableSchema | Schema to which materializations can be added. | Interface | org.apache.calcite.schema | Calcite | 
|
| SerializableCharset | Serializable wrapper around a Charset. | Class | org.apache.calcite.util | Calcite | 
|
| Service | API for request-response calls to an Avatica server. | Interface | org.apache.calcite.avatica.remote | Calcite | 
|
| SetOp | SetOp is an abstract base for relational set operators such as UNION, MINUS (aka EXCEPT), and INTERSECT. | Class | org.apache.calcite.rel.core | Calcite | 
|
| SetopNamespace | Namespace based upon a set operation (UNION, INTERSECT, EXCEPT). | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SetopOperandTypeChecker | Parameter type-checking strategy for a set operator (UNION, INTERSECT, Both arguments must be records with the same number of fields, and the | Class | org.apache.calcite.sql.type | Calcite | 
|
| SingleRel | Abstract base class for relational expressions with a single input. | Class | org.apache.calcite.rel | Calcite | 
|
| Sink | Sink to which to send rows. | Interface | org.apache.calcite.interpreter | Calcite | 
|
| SocketFactoryImpl | created sockets inherit a set of options whose values are set in the 1. | Class | org.apache.calcite.adapter.splunk.util | Calcite | 
|
| Sort | Relational expression that imposes a particular sort order on its input without otherwise changing its content. | Class | org.apache.calcite.rel.core | Calcite | 
|
| SortedMultiMap | Map that allows you to partition values into lists according to a common key, and then convert those lists into an iterator of sorted arrays. | Class | org.apache.calcite.runtime | Calcite | 
|
| SortExchange | Relational expression that performs Exchange and Sort Whereas a Sort produces output with a particular | Class | org.apache.calcite.rel.core | Calcite | 
|
| SortJoinTransposeRule | Planner rule that pushes a Sort past a At the moment, we only consider left/right outer joins. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| SortNode |  | Class | org.apache.calcite.interpreter | Calcite | 
|
| SortProjectTransposeRule | Planner rule that pushesSee Also:ProjectSortTransposeRule | Class | org.apache.calcite.rel.rules | Calcite | 
|
| SortRemoveRule | Planner rule that removes a Sort if its input is already sorted. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| SortUnionTransposeRule |  | Class | org.apache.calcite.rel.rules | Calcite | 
|
| Source | Corresponds to an input of a relational expression. | Interface | org.apache.calcite.interpreter | Calcite | 
|
| Spacer | Efficiently writes strings of spaces. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| Spaces | Utilities for creating strings of spaces. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| SparkHandlerImpl | CalcitePrepare. | Class | org.apache.calcite.adapter.spark | Calcite | 
|
| SparkMethod | Built-in methods in the Spark adapter. | Class | org.apache.calcite.adapter.spark | Calcite | 
|
| SparkRel | Relational expression that uses Spark calling convention. | Interface | org.apache.calcite.adapter.spark | Calcite | 
|
| SparkRules | Rules for the Spark calling convention. | Class | org.apache.calcite.adapter.spark | Calcite | 
|
| SparkRuntime | Runtime utilities for Calcite's Spark adapter. | Class | org.apache.calcite.adapter.spark | Calcite | 
|
| SparkToEnumerableConverter | Relational expression that converts input of into EnumerableConvention. | Class | org.apache.calcite.adapter.spark | Calcite | 
|
| SplunkConnection | Connection to Splunk. | Interface | org.apache.calcite.adapter.splunk.search | Calcite | 
|
| SplunkConnectionImpl |  | Class | org.apache.calcite.adapter.splunk.search | Calcite | 
|
| SplunkDriver | JDBC driver for Splunk. | Class | org.apache.calcite.adapter.splunk | Calcite | 
|
| SplunkPushDownRule | Planner rule to push filters and projections to Splunk. | Class | org.apache.calcite.adapter.splunk | Calcite | 
|
| SplunkQuery | Query against Splunk. | Class | org.apache.calcite.adapter.splunk | Calcite | 
|
| SplunkSchema |  | Class | org.apache.calcite.adapter.splunk | Calcite | 
|
| SplunkTableScan | Relational expression representing a scan of Splunk. | Class | org.apache.calcite.adapter.splunk | Calcite | 
|
| SqlAbstractGroupFunction |  | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlAbstractParserImpl | Abstract base for parsers generated from CommonParser. | Class | org.apache.calcite.sql.parser | Calcite | 
|
| SqlAbstractTimeFunction | Base class for time functions such as LOCALTIME, LOCALTIME(n). | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlAccessEnum | Enumeration representing different access typesEnum Constant Summary | Class | org.apache.calcite.sql | Calcite | 
|
| SqlAccessType |  | Class | org.apache.calcite.sql | Calcite | 
|
| SqlAdvisor | An assistant which offers hints and corrections to a partially-formed SQL statement. | Class | org.apache.calcite.sql.advise | Calcite | 
|
| SqlAdvisorGetHintsFunction | Table function that returns completion hints for a given SQL statement. | Class | org.apache.calcite.sql.advise | Calcite | 
|
| SqlAdvisorHint | This class is used to return values for (String, int, String[]). | Class | org.apache.calcite.sql.advise | Calcite | 
|
| SqlAdvisorValidator | SqlAdvisorValidator is used by SqlAdvisor to traverse the parse tree of a SQL statement, not for validation purpose but for setting | Class | org.apache.calcite.sql.advise | Calcite | 
|
| SqlAggFunction | Abstract base class for the definition of an aggregate function: an operator which aggregates sets of values into a result. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlArrayQueryConstructor |  | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlArrayValueConstructor |  | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlAsOperator | The AS operator associates an expression with an alias. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlAvgAggFunction | Avg is an aggregator which returns the average of the values which go into it. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlBasicCall |  | Class | org.apache.calcite.sql | Calcite | 
|
| SqlBasicVisitor | Basic implementation of SqlVisitor which does nothing at each node. | Class | org.apache.calcite.sql.util | Calcite | 
|
| SqlBetweenOperator | Defines the BETWEEN operator. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlBinaryOperator | SqlBinaryOperator is a binary operator. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlBinaryStringLiteral | A binary (or hexadecimal) string literal. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlBuilder | Extension to StringBuilder for the purposes of creating SQL queries Using this class helps to prevent SQL injection attacks, incorrectly | Class | org.apache.calcite.sql.util | Calcite | 
|
| SqlCall | A SqlCall is a call to an operator. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlCallBinding | SqlCallBinding implements SqlOperatorBinding by analyzing to the operands of a SqlCall with a SqlValidator. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlCase | A SqlCase is a node of a parse tree which represents a case statement. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlCaseOperator | An operator describing a CASE, NULLIF or  COALESCE expression. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlCastFunction | SqlCastFunction. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlCharStringLiteral | A character string literal. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlCoalesceFunction | The COALESCE function. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlCollation | A SqlCollation is an object representing a Collate statement. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlCollectionTableOperator | SqlCollectionTableOperator is the table function derived table operator. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlColumnListConstructor | SqlColumnListConstructor defines the non-standard constructor used to pass a COLUMN_LIST parameter to a UDX. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlConformance | Enumeration of valid SQL compatiblity modes. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlConvertFunction |  | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlCountAggFunction | Definition of the SQL COUNT aggregation function. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlCovarAggFunction | Covar is an aggregator which returns the Covariance of the values which go into it. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlCurrentDateFunction | The CURRENT_DATE function. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlCursorConstructor |  | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlDataTypeSpec | Represents a SQL data type specification in a parse tree. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlDateLiteral | A SQL literal representing a DATE value, such as DATE Create values using SqlLiteral. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlDatetimeSubtractionOperator | A special operator for the subtraction of two DATETIMEs. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlDelete |  | Class | org.apache.calcite.sql | Calcite | 
|
| SqlDialect | SqlDialect encapsulates the differences between dialects of SQL. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlDynamicParam | A SqlDynamicParam represents a dynamic parameter marker in an SQL statement. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlExplain | A SqlExplain is a node of a parse tree which represents an EXPLAIN PLAN statement. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlExplainLevel | enum SqlExplainLevelSqlExplainLevel defines detail levels for EXPLAIN PLAN. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlExtractFunction | The SQL EXTRACT operator. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlFilterOperator | An operator that applies a filter before rows are included in an aggregate Operands are as follows: | Class | org.apache.calcite.sql | Calcite | 
|
| SqlFirstLastValueAggFunction | FIRST_VALUE and LAST_VALUE aggregate functions return the first or the last value in a list of values that are input to the | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlFloorFunction | Definition of the FLOOR and CEIL built-in SQL functions. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlFormatOptions | Data structure to hold options for SqlPrettyWriter. | Class | org.apache.calcite.sql.pretty | Calcite | 
|
| SqlFunction | A SqlFunction is a type of operator which has conventional function-call syntax. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlFunctionalOperator |  | Class | org.apache.calcite.sql | Calcite | 
|
| SqlFunctionCategory | enum SqlFunctionCategoryEnumeration of the categories of | Class | org.apache.calcite.sql | Calcite | 
|
| SqlFunctions | Helper methods to implement SQL functions in generated code. | Class | org.apache.calcite.runtime | Calcite | 
|
| SqlHistogramAggFunction | HISTOGRAM is the base operator that supports the Histogram MIN/MAX aggregate functions. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlIdentifier | A SqlIdentifier is an identifier, possibly compound. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlIdentifierMoniker | An implementation of SqlMoniker that encapsulates the normalized name information of a SqlIdentifier. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlImplementor | State for generating a SQL statement. | Class | org.apache.calcite.rel.rel2sql | Calcite | 
|
| SqlInfixOperator | A generalization of a binary operator to involve several (two or more) arguments, and keywords between each pair of arguments. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlInOperator | Definition of the SQL IN operator, which tests for a value's membership in a subquery or a list of values. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlInsert |  | Class | org.apache.calcite.sql | Calcite | 
|
| SqlInsertKeyword | enum SqlInsertKeywordDefines the keywords that can occur immediately after the INSERT keyword. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlInternalOperator | Generic operator for nodes with internal syntax. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlIntervalLiteral | A SQL literal representing a time interval. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlIntervalQualifier | Represents an INTERVAL qualifier. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlJdbcFunctionCall | A SqlJdbcFunctionCall is a node of a parse tree which represents a JDBC function call. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlJoin | Parse tree node representing a JOIN clause. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlKind | Enumerates the possible types of SqlNode. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlLeadLagAggFunction | LEAD and LAG aggregate functions return the value of given expression evaluated at given offset. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlLikeOperator | An operator describing the LIKE and SIMILAR Syntax of the two operators: | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlLiteral | A SqlLiteral is a constant. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlLiteralChainOperator | Internal operator, by which the parser represents a continued string literal. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlMapQueryConstructor | Definition of the MAP query constructor,  Like the MAP type, not standard SQL. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlMapValueConstructor | Definition of the MAP constructor, MAP [, , . | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlMerge |  | Class | org.apache.calcite.sql | Calcite | 
|
| SqlMinMaxAggFunction | Definition of the MIN and MAX aggregate functions, returning the returns the smallest/largest of the values which go into it. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlModality | Relational or streaming. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlMoniker |  | Interface | org.apache.calcite.sql.validate | Calcite | 
|
| SqlMonikerImpl | A generic implementation of SqlMoniker. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlMonikerType | An enumeration of moniker types. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlMonotonicBinaryOperator | Base class for binary operators such as addition, subtraction, and multiplication which are monotonic for the patterns m op c and | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlMonotonicity | enum SqlMonotonicityEnumeration of types of monotonicity. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlMonotonicUnaryFunction |  | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlMultisetMemberOfOperator | Multiset MEMBER OF. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlMultisetQueryConstructor | Definition of the SQL:2003 standard MULTISET query constructor,  MULTISET (). | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlMultisetSetOperator | An operator which performs set operations on multisets, such as MULTISET Not to be confused with SqlMultisetValueConstructor or | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlMultisetValueConstructor | Definition of the SQL:2003 standard MULTISET constructor, MULTISET Derived classes construct other kinds of collections. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlNewOperator | SqlNewOperator represents an SQL new specification such as NEW UDT(1, 2). | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlNode | A SqlNode is a SQL parse tree. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlNodeList | A SqlNodeList is a list of SqlNodes. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlNodeToRexConverter | Converts expressions from SqlNode to RexNode. | Interface | org.apache.calcite.sql2rel | Calcite | 
|
| SqlNodeToRexConverterImpl | Standard implementation of SqlNodeToRexConverter. | Class | org.apache.calcite.sql2rel | Calcite | 
|
| SqlNtileAggFunction | NTILE aggregate function return the value of given expression evaluated at given offset. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlNullifFunction | The NULLIF function. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlNullSemantics | enum SqlNullSemanticsSqlNullSemantics defines the possible comparison rules for values which might | Class | org.apache.calcite.sql | Calcite | 
|
| SqlNumericLiteral | A numeric SQL literal. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlOperandCountRange | A class that describes how many operands an operator can take. | Interface | org.apache.calcite.sql | Calcite | 
|
| SqlOperandCountRanges | Helpers for SqlOperandCountRange. | Class | org.apache.calcite.sql.type | Calcite | 
|
| SqlOperandTypeChecker | Strategy interface to check for allowed operand types of an operator call. | Interface | org.apache.calcite.sql.type | Calcite | 
|
| SqlOperandTypeInference | Strategy to infer unknown types of the operands of an operator call. | Interface | org.apache.calcite.sql.type | Calcite | 
|
| SqlOperator | A SqlOperator is a type of node in a SQL parse tree (it is NOT a node in a SQL parse tree). | Class | org.apache.calcite.sql | Calcite | 
|
| SqlOperatorBinding | SqlOperatorBinding represents the binding of an SqlOperator to actual operands, along with any additional information | Class | org.apache.calcite.sql | Calcite | 
|
| SqlOperatorTable | SqlOperatorTable defines a directory interface for enumerating and looking up SQL operators and functions. | Interface | org.apache.calcite.sql | Calcite | 
|
| SqlOrderBy | Parse tree node that represents an ORDER BY on a query other than a SELECT (e. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlOverlapsOperator | SqlOverlapsOperator represents the SQL:1999 standard OVERLAPS function. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlOverlayFunction | The OVERLAY function. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlOverOperator | An operator describing a window function specification. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlParseException | SqlParseException defines a checked exception corresponding toSee Also:Serialized Form | Class | org.apache.calcite.sql.parser | Calcite | 
|
| SqlParser | A SqlParser parses a SQL statement. | Class | org.apache.calcite.sql.parser | Calcite | 
|
| SqlParserImplFactory | SqlAbstractParserImpl objects. | Interface | org.apache.calcite.sql.parser | Calcite | 
|
| SqlParserPos | SqlParserPos represents the position of a parsed token within SQL statementSee Also:Serialized Form | Class | org.apache.calcite.sql.parser | Calcite | 
|
| SqlParserUtil | Utility methods relating to parsing SQL. | Class | org.apache.calcite.sql.parser | Calcite | 
|
| SqlPositionFunction | The POSITION function. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlPostfixOperator | A postfix unary operator. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlPrefixOperator |  | Class | org.apache.calcite.sql | Calcite | 
|
| SqlPrettyWriter | Pretty printer for SQL statements. | Class | org.apache.calcite.sql.pretty | Calcite | 
|
| SqlProcedureCallOperator | SqlProcedureCallOperator represents the CALL statement. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlQualified | Fully-qualified identifier. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlQuarterFunction | SqlQuarterFunction represents the SQL:1999 standard QUARTER function. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlRankFunction | Operator which aggregates sets of values into a result. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlReturnTypeInference | Strategy interface to infer the type of an operator call from the type of the This interface is an example of the | Interface | org.apache.calcite.sql.type | Calcite | 
|
| SqlReturnTypeInferenceChain | Strategy to infer the type of an operator call from the type of the operands by using a series of SqlReturnTypeInference rules in a given order. | Class | org.apache.calcite.sql.type | Calcite | 
|
| SqlRexContext | Contains the context necessary for a SqlRexConvertlet to convert a SqlNode expression into a RexNode. | Interface | org.apache.calcite.sql2rel | Calcite | 
|
| SqlRexConvertlet |  | Interface | org.apache.calcite.sql2rel | Calcite | 
|
| SqlRexConvertletTable | Collection of SqlRexConvertlets. | Interface | org.apache.calcite.sql2rel | Calcite | 
|
| SqlRowOperator | SqlRowOperator represents the special ROW constructor. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlSampleSpec | Specification of a SQL sample. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlScopedShuttle | Refinement to SqlShuttle which maintains a stack of scopes. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlSelect | A SqlSelect is a node of a parse tree which represents a select statement. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlSelectKeyword | enum SqlSelectKeywordDefines the keywords which can occur immediately after the SELECT keyword. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlSelectOperator | An operator describing a query. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlSequenceValueOperator | Operator that returns the current or next value of a sequence. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlSetOperator | SqlSetOperator represents a relational set theory operator (UNION, INTERSECT, MINUS). | Class | org.apache.calcite.sql | Calcite | 
|
| SqlSetOption | SQL parse tree node to represent SET and RESET statements, optionally preceded by ALTER SYSTEM or ALTER SESSION. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlShuttle | Basic implementation of SqlVisitor which returns each leaf node This class is useful as a base class for classes which implement the | Class | org.apache.calcite.sql.util | Calcite | 
|
| SqlSimpleParser | A simple parser that takes an incomplete and turn it into a syntactically correct statement. | Class | org.apache.calcite.sql.advise | Calcite | 
|
| SqlSingleOperandTypeChecker | SqlSingleOperandTypeChecker is an extension of SqlOperandTypeChecker for implementations which are capable of checking the type of a single | Interface | org.apache.calcite.sql.type | Calcite | 
|
| SqlSingleValueAggFunction | SINGLE_VALUE aggregate function returns the input value if there is only one value in the input; Otherwise it triggers a run-time error. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlSpecialOperator | Generic operator for nodes with special syntax. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlSplittableAggFunction | Aggregate function that can be split into partial aggregates. | Interface | org.apache.calcite.sql | Calcite | 
|
| SqlStateCodes | Contains Glossary. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlStdOperatorTable | the standard operators and functions. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlString | String that represents a kocher SQL statement, expression, or fragment. | Class | org.apache.calcite.sql.util | Calcite | 
|
| SqlStringContextVariable | Base class for functions such as USER, CURRENT_ROLE, and CURRENT_PATH. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlSubstringFunction | Definition of the SUBSTRING builtin SQL function. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlSumAggFunction | Sum is an aggregator which returns the sum of the values which go into it. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlSumEmptyIsZeroAggFunction | Sum0 is an aggregator which returns the sum of the values which go into it like Sum. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlSyntax | Enumeration of possible syntactic types of operators. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlThrowOperator | An internal operator that throws an exception. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlTimeLiteral | A SQL literal representing a TIME value, for example TIME Create values using SqlLiteral. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlTimeoutException | Indicates that an operation timed out. | Class | org.apache.calcite.jdbc | Calcite | 
|
| SqlTimestampLiteral | A SQL literal representing a TIMESTAMP value, for example TIMESTAMP '1969-07-21 03:15 GMT'. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlToRelConverter | Converts a SQL parse tree (consisting of SqlNode objects) into a relational algebra | Class | org.apache.calcite.sql2rel | Calcite | 
|
| SqlTrimFunction | Definition of the TRIM builtin SQL function. | Class | org.apache.calcite.sql.fun | Calcite | 
|
| SqlType | The information in the following conversions tables (from the JDBC 4. | Class | org.apache.calcite.avatica | Calcite | 
|
| SqlTypeAssignmentRules | Class to hold rules to determine if a type is assignable from another type. | Class | org.apache.calcite.sql.type | Calcite | 
|
| SqlTypeExplicitPrecedenceList | SqlTypeExplicitPrecedenceList implements the RelDataTypePrecedenceList interface via an explicit list of | Class | org.apache.calcite.sql.type | Calcite | 
|
| SqlTypeFactoryImpl | SqlTypeFactoryImpl provides a default implementation of RelDataTypeFactory which supports SQL types. | Class | org.apache.calcite.sql.type | Calcite | 
|
| SqlTypeFamily | SqlTypeFamily provides SQL type categorization. | Class | org.apache.calcite.sql.type | Calcite | 
|
| SqlTypeName | Enumeration of the type names which can be used to construct a SQL type. | Class | org.apache.calcite.sql.type | Calcite | 
|
| SqlTypeTransform | Strategy to transform one type to another. | Interface | org.apache.calcite.sql.type | Calcite | 
|
| SqlTypeTransformCascade | Strategy to infer the type of an operator call from the type of the operands by using one SqlReturnTypeInference rule and a combination of | Class | org.apache.calcite.sql.type | Calcite | 
|
| SqlTypeTransforms | SqlTypeTransforms defines a number of reusable instances of NOTE: avoid anonymous inner classes here except for unique, | Class | org.apache.calcite.sql.type | Calcite | 
|
| SqlTypeUtil | Contains utility methods used during SQL validation or type derivation. | Class | org.apache.calcite.sql.type | Calcite | 
|
| SqlUnnestOperator | The UNNEST operator. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlUnresolvedFunction | Placeholder for an unresolved function. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlUpdate |  | Class | org.apache.calcite.sql | Calcite | 
|
| SqlUserDefinedAggFunction | User-defined aggregate function. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlUserDefinedFunction | User-defined scalar function. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlUserDefinedTableFunction | User-defined table function. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlUserDefinedTableMacro | User-defined table macro. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlUtil | Contains utility functions related to SQL parsing, all static. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlValidator | Validates the parse tree of a SQL statement, and provides semantic information about the parse tree. | Interface | org.apache.calcite.sql.validate | Calcite | 
|
| SqlValidatorCatalogReader | Supplies catalog information for SqlValidator. | Interface | org.apache.calcite.sql.validate | Calcite | 
|
| SqlValidatorException | Exception thrown while validating a SQL statement. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlValidatorImpl | Default implementation of SqlValidator. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlValidatorNamespace | A namespace describes the relation returned by a section of a SQL query. | Interface | org.apache.calcite.sql.validate | Calcite | 
|
| SqlValidatorScope | Name-resolution scope. | Interface | org.apache.calcite.sql.validate | Calcite | 
|
| SqlValidatorTable | Supplies a SqlValidator with the metadata for a table. | Interface | org.apache.calcite.sql.validate | Calcite | 
|
| SqlValidatorUtil | Utility methods related to validation. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| SqlValidatorWithHints | qualified names of sql objects, alternative valid sql objects that can be used in the SQL statement (dubbed as hints) | Interface | org.apache.calcite.sql.validate | Calcite | 
|
| SqlValuesOperator | The VALUES operator. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlVisitor | Visitor class, follows the The type parameter R is the return type of each | Interface | org.apache.calcite.sql.util | Calcite | 
|
| SqlWindow | SQL window specification. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlWith | The WITH clause of a query. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlWithItem | An item in a WITH clause of a query. | Class | org.apache.calcite.sql | Calcite | 
|
| SqlWriter | A SqlWriter is the target to construct a SQL statement from a parse tree. | Interface | org.apache.calcite.sql | Calcite | 
|
| Stacks | Utilities to make vanilla lists look like stacks. | Class | org.apache.calcite.util | Calcite | 
|
| StackWriter | A helper class for generating formatted text. | Class | org.apache.calcite.util | Calcite | 
|
| StandardConvertletTable | Standard implementation of SqlRexConvertletTable. | Class | org.apache.calcite.sql2rel | Calcite | 
|
| StarTable | Virtual table that is composed of two or more tables joined together. | Class | org.apache.calcite.schema.impl | Calcite | 
|
| Statement |  | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| StatementInfo | All we know about a statement. | Class | org.apache.calcite.avatica.jdbc | Calcite | 
|
| StatementTest | Compares Statement vs PreparedStatement. | Class | org.apache.calcite.benchmarks | Calcite | 
|
| StatementTest_bindExecute_jmhTest |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_executeQuery_jmhTest |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_forEach_jmhTest |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_HrConnection_jmhType |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_HrConnection_jmhType_B1 |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_HrConnection_jmhType_B2 |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_HrConnection_jmhType_B3 |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_HrPreparedStatement_jmhType |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_HrPreparedStatement_jmhType_B1 |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_HrPreparedStatement_jmhType_B2 |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_HrPreparedStatement_jmhType_B3 |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_jmhType |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_jmhType_B1 |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_jmhType_B2 |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_jmhType_B3 |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| StatementTest_prepareBindExecute_jmhTest |  | Class | org.apache.calcite.benchmarks.generated | Calcite | 
|
| Static | Definitions of objects to be statically imported. | Class | org.apache.calcite.util | Calcite | 
|
| Statistic | Statistics about a Table. | Interface | org.apache.calcite.schema | Calcite | 
|
| Statistics | Utility functions regarding Statistic. | Class | org.apache.calcite.schema | Calcite | 
|
| StreamableTable | Table that can be converted to a stream. | Interface | org.apache.calcite.schema | Calcite | 
|
| StreamRules | Rules and relational operators for streaming relational expressions. | Class | org.apache.calcite.rel.stream | Calcite | 
|
| StrictAggImplementor | The base implementation of strict aggregate function. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| StrictWinAggImplementor | The base implementation of strict window aggregate function. | Class | org.apache.calcite.adapter.enumerable | Calcite | 
|
| StringUtils | Utility methods for encoding and decoding strings for Splunk REST calls. | Class | org.apache.calcite.adapter.splunk.util | Calcite | 
|
| Strong | Utilities for strong predicates. | Class | org.apache.calcite.plan | Calcite | 
|
| StructImpl |  | Class | org.apache.calcite.avatica.util | Calcite | 
|
| SubqueryConverter | SubqueryConverter provides the interface for classes that convert subqueries into equivalent expressions. | Interface | org.apache.calcite.sql2rel | Calcite | 
|
| SubQueryRemoveRule | Transform that converts IN, EXISTS and scalar sub-queries into joins. | Class | org.apache.calcite.rel.rules | Calcite | 
|
| SubstitutionVisitor | Substitutes part of a tree of relational expressions with another tree. | Class | org.apache.calcite.plan | Calcite | 
|
| SwitchCase | Represents one case of a SwitchStatement. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| SwitchStatement | Represents a control expression that handles multiple selections by passing control to SwitchCase. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| Table | The typical way for a table to be created is when Calcite interrogates a user-defined schema in order to validate names appearing in a SQL query. | Interface | org.apache.calcite.schema | Calcite | 
|
| TableAccessMap | TableAccessMap represents the tables accessed by a query plan, with READ/WRITE information. | Class | org.apache.calcite.plan | Calcite | 
|
| TableConstructorNamespace | Namespace for a table constructor VALUES (expr, expr, . | Class | org.apache.calcite.sql.validate | Calcite | 
|
| TableFactory | Factory for Table objects. | Interface | org.apache.calcite.schema | Calcite | 
|
| TableFunction | Function that returns a table during execution time. | Interface | org.apache.calcite.schema | Calcite | 
|
| TableFunctionImpl |  | Class | org.apache.calcite.schema.impl | Calcite | 
|
| TableFunctionReturnTypeInference | TableFunctionReturnTypeInference implements rules for deriving table function output row types by expanding references to cursor parameters. | Class | org.apache.calcite.sql.type | Calcite | 
|
| TableFunctionScan | Relational expression that calls a table-valued function. | Class | org.apache.calcite.rel.core | Calcite | 
|
| TableMacro | Function that returns a Table. | Interface | org.apache.calcite.schema | Calcite | 
|
| TableMacroImpl |  | Class | org.apache.calcite.schema.impl | Calcite | 
|
| TableModify | Relational expression that modifies a table. | Class | org.apache.calcite.rel.core | Calcite | 
|
| TableScan | Relational operator that returns the contents of a table. | Class | org.apache.calcite.rel.core | Calcite | 
|
| TableScanNode |  | Class | org.apache.calcite.interpreter | Calcite | 
|
| TableScanRule | Planner rule that converts a LogicalTableScan to the result | Class | org.apache.calcite.rel.rules | Calcite | 
|
| Template | It is extended from MessageFormat to allow parameters to be substituted by name as well as by position. | Class | org.apache.calcite.util | Calcite | 
|
| TernaryExpression | Represents an expression that has a ternary operator. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| ThrowStatement | Represents a throw statement. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| TileKey | Definition of a particular combination of dimensions and measures of a lattice that is the basis of a materialization. | Class | org.apache.calcite.materialize | Calcite | 
|
| TileSuggester | Algorithm that suggests a set of initial tiles (materialized aggregate views) for a given lattice. | Class | org.apache.calcite.materialize | Calcite | 
|
| TimeUnit | Enumeration of time units used to construct an interval. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| TimeUnitRange | A range of time units. | Class | org.apache.calcite.avatica.util | Calcite | 
|
| TopologicalOrderIterator | Iterates over the edges of a graph in topological order. | Class | org.apache.calcite.util.graph | Calcite | 
|
| TpcdsSchema | Schema that provides TPC-DS tables, populated according to a particular scale factor. | Class | org.apache.calcite.adapter.tpcds | Calcite | 
|
| TpcdsSchemaFactory | Factory that creates a TpcdsSchema. | Class | org.apache.calcite.adapter.tpcds | Calcite | 
|
| TpchSchema | Schema that provides TPC-H tables, populated according to a particular scale factor. | Class | org.apache.calcite.adapter.tpch | Calcite | 
|
| TpchSchemaFactory | Factory that creates a TpchSchema. | Class | org.apache.calcite.adapter.tpch | Calcite | 
|
| TraitMatchingRule | TraitMatchingRule adapts a converter rule, restricting it to fire only when its input already matches the expected output trait. | Class | org.apache.calcite.rel.convert | Calcite | 
|
| TransformedEnumerator |  | Class | org.apache.calcite.linq4j | Calcite | 
|
| TranslatableTable | Extension to Table that specifies how it is to be translated to It is optional for a Table to implement this interface. | Interface | org.apache.calcite.schema | Calcite | 
|
| TrustAllSslSocketFactory | Socket factory that trusts all SSL connections. | Class | org.apache.calcite.adapter.splunk.util | Calcite | 
|
| TryStatement | Represents a try . | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| TryThreadLocal | Thread-local variable that returns a handle that can be closed. | Class | org.apache.calcite.util | Calcite | 
|
| TypeBinaryExpression | Represents an operation between an expression and a type. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| Typed | Adds type information to a Enumerable. | Interface | org.apache.calcite.runtime | Calcite | 
|
| TypedValue | There are 3 representations: JDBC - the representation used by JDBC get and set methods | Class | org.apache.calcite.avatica.remote | Calcite | 
|
| Types |  | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| UnaryExpression | Represents an expression that has a unary operator. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| UnboundMetadata | Metadata that needs to be bound to a RelNode and RelMetadataQuery before it can be used. | Interface | org.apache.calcite.rel.metadata | Calcite | 
|
| Uncollect | Relational expression that unnests its input's columns into a relation. | Class | org.apache.calcite.rel.core | Calcite | 
|
| Union | Relational expression that returns the union of the rows of its inputs, optionally eliminating duplicates. | Class | org.apache.calcite.rel.core | Calcite | 
|
| UnionEliminatorRule | UnionEliminatorRule checks to see if its possible to optimize a Union call by eliminating the Union operator altogether in the case the call | Class | org.apache.calcite.rel.rules | Calcite | 
|
| UnionMergeRule | UnionMergeRule implements the rule for combining two non-distinct Unions | Class | org.apache.calcite.rel.rules | Calcite | 
|
| UnionNode |  | Class | org.apache.calcite.interpreter | Calcite | 
|
| UnionToDistinctRule | Planner rule that translates a distinct on top of a non-distinct Union | Class | org.apache.calcite.rel.rules | Calcite | 
|
| Unit | Synthetic record with zero fields. | Class | org.apache.calcite.runtime | Calcite | 
|
| UnmodifiableArrayList | A view onto an array that cannot be modified by the client. | Class | org.apache.calcite.util | Calcite | 
|
| UnregisteredDriver | You can easily create a vanity driver that recognizes its own URL prefix as a sub-class of this class. | Class | org.apache.calcite.avatica | Calcite | 
|
| Util | Miscellaneous utility functions. | Class | org.apache.calcite.util | Calcite | 
|
| Utilities | Utility methods called by generated code. | Class | org.apache.calcite.runtime | Calcite | 
|
| ValidationException | An Exception thrown when attempting to validate a SQL parse tree. | Class | org.apache.calcite.tools | Calcite | 
|
| Values |  | Class | org.apache.calcite.rel.core | Calcite | 
|
| ValuesNode |  | Class | org.apache.calcite.interpreter | Calcite | 
|
| ValuesReduceRule | Planner rule that folds projections and filters into an underlying Returns a simplified Values, perhaps containing zero tuples | Class | org.apache.calcite.rel.rules | Calcite | 
|
| ViewTable | Table whose contents are defined using an SQL statement. | Class | org.apache.calcite.schema.impl | Calcite | 
|
| Visitor |  | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| VisitorDataContext |  | Class | org.apache.calcite.plan | Calcite | 
|
| VolcanoPlanner | VolcanoPlanner optimizes queries by transforming expressions selectively according to a dynamic programming algorithm. | Class | org.apache.calcite.plan.volcano | Calcite | 
|
| VolcanoPlannerPhase | enum VolcanoPlannerPhaseVolcanoPlannerPhase represents the phases of operation that the | Class | org.apache.calcite.plan.volcano | Calcite | 
|
| VolcanoPlannerPhaseRuleMappingInitializer | VolcanoPlannerPhaseRuleMappingInitializer describes an inteface for initializing the mapping of VolcanoPlannerPhases to sets of rule | Interface | org.apache.calcite.plan.volcano | Calcite | 
|
| VolcanoRelMetadataProvider | VolcanoRelMetadataProvider implements the RelMetadataProvider interface by combining metadata from the rels making up an equivalence class. | Class | org.apache.calcite.plan.volcano | Calcite | 
|
| VolcanoRuleCall | VolcanoRuleCall implements the RelOptRuleCall interface for VolcanoPlanner. | Class | org.apache.calcite.plan.volcano | Calcite | 
|
| WhileStatement | Represents a while statement. | Class | org.apache.calcite.linq4j.tree | Calcite | 
|
| WinAggAddContext | Information for a call to AggImplementor. | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| WinAggAddContextImpl |  | Class | org.apache.calcite.adapter.enumerable.impl | Calcite | 
|
| WinAggContext | Marker interface to allow to tell if it is used in regular or windowed context. | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| WinAggFrameContext | Provides information on the current window. | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| WinAggFrameResultContext |  | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| WinAggImplementor | initialize, add to, and get a result from, an accumulator. | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| WinAggResetContext | Information for a call to AggImplementor. | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| WinAggResetContextImpl | WinAggResetContext. | Class | org.apache.calcite.adapter.enumerable.impl | Calcite | 
|
| WinAggResultContext | Information for a call to AggImplementor. | Interface | org.apache.calcite.adapter.enumerable | Calcite | 
|
| WinAggResultContextImpl | WinAggResultContext. | Class | org.apache.calcite.adapter.enumerable.impl | Calcite | 
|
| Window | A relational expression representing a set of window aggregates. | Class | org.apache.calcite.rel.core | Calcite | 
|
| WindowNode |  | Class | org.apache.calcite.interpreter | Calcite | 
|
| WithNamespace | Namespace for WITH clause. | Class | org.apache.calcite.sql.validate | Calcite | 
|
| XmlOutput | Streaming XML output. | Class | org.apache.calcite.util | Calcite | 
|
| ZonelessDate | ZonelessDate is a date value without a time zone. | Class | org.apache.calcite.util | Calcite | 
|
| ZonelessDatetime | ZonelessDatetime is an abstract class for dates, times, or timestamps that contain a zoneless time value. | Class | org.apache.calcite.util | Calcite | 
|
| ZonelessTime | ZonelessTime is a time value without a time zone. | Class | org.apache.calcite.util | Calcite | 
|
| ZonelessTimestamp | ZonelessTimestamp is a timestamp value without a time zone. | Class | org.apache.calcite.util | Calcite | 
|