Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



# Classes and Interfaces in #Calcite - 1138 results found.
NameDescriptionTypePackageFramework
AbstractConverterConverts a relational expression to any given output convention.Classorg.apache.calcite.plan.volcanoCalcite
AbstractCursorBase class for implementing a cursor.Classorg.apache.calcite.avatica.utilCalcite
AbstractEnumerableAbstract implementation of the Enumerable interface that implements the extension methods.Classorg.apache.calcite.linq4jCalcite
AbstractEnumerable2Abstract implementation of the Enumerable interface that implements the extension methods.Classorg.apache.calcite.linq4jCalcite
AbstractHandlerAbstract base class for Handlers to extend to inherit functionality common across serialization strategies.Classorg.apache.calcite.avatica.remoteCalcite
AbstractNodeAbstract implementation of Node.Classorg.apache.calcite.linq4j.treeCalcite
AbstractQueryableAbstract implementation of the Queryable interface that implements the extension methods.Classorg.apache.calcite.linq4jCalcite
AbstractQueryableTableAbstract base class for implementing Table.Classorg.apache.calcite.adapter.javaCalcite
AbstractRelNodeBase class for every relational expression (RelNode).Classorg.apache.calcite.relCalcite
AbstractRelOptPlannerAbstract base for implementations of the RelOptPlanner interface.Classorg.apache.calcite.planCalcite
AbstractSchemaAbstract implementation of Schema.Classorg.apache.calcite.schema.implCalcite
AbstractServiceA common base class for Service implementations that implement modifications made to response objects.Classorg.apache.calcite.avatica.remoteCalcite
AbstractSourceMappingSimple implementation of Mappings.Classorg.apache.calcite.util.mappingCalcite
AbstractSqlTypeAbstract base class for SQL implementations of RelDataType.Classorg.apache.calcite.sql.typeCalcite
AbstractTableAbstract base class for implementing Table.Classorg.apache.calcite.schema.implCalcite
AbstractTableQueryableAbstract implementation of Queryable for Not to be confused withClassorg.apache.calcite.schema.implCalcite
AbstractTargetMappingSimple implementation of Mappings.Classorg.apache.calcite.util.mappingCalcite
AggAddContextInformation for a call to AggImplementor.Interfaceorg.apache.calcite.adapter.enumerableCalcite
AggAddContextImplClassorg.apache.calcite.adapter.enumerable.implCalcite
AggContextInformation on the aggregate calculation context.Interfaceorg.apache.calcite.adapter.enumerableCalcite
AggImplementor initialize, add to, and get a result from, an accumulator.Interfaceorg.apache.calcite.adapter.enumerableCalcite
AggImpStateRepresents internal state when implementing aggregate functions.Classorg.apache.calcite.adapter.enumerableCalcite
AggregateRelational operator that eliminates duplicates and computes totals.Classorg.apache.calcite.rel.coreCalcite
AggregateCallClassorg.apache.calcite.rel.coreCalcite
AggregateExpandDistinctAggregatesRulePlanner rule that expands distinct aggregates (such as COUNT(DISTINCT x)) from aClassorg.apache.calcite.rel.rulesCalcite
AggregateFilterTransposeRulePlanner rule that matches an Aggregate on a Filter and transposes them,Classorg.apache.calcite.rel.rulesCalcite
AggregateFunctionFunction that combines several values into a scalar result.Interfaceorg.apache.calcite.schemaCalcite
AggregateFunctionImpl The class should implement A init(), A add(A, V), and R result(A) methods.Classorg.apache.calcite.schema.implCalcite
AggregateJoinTransposeRuleClassorg.apache.calcite.rel.rulesCalcite
AggregateNodeClassorg.apache.calcite.interpreterCalcite
AggregateProjectMergeRulePlanner rule that recognizes a Aggregate on top of a Project and if possibleClassorg.apache.calcite.rel.rulesCalcite
AggregateProjectPullUpConstantsRulePlanner rule that removes constant keys from an Constant fields are deduced usingClassorg.apache.calcite.rel.rulesCalcite
AggregateReduceFunctionsRulePlanner rule that reduces aggregate functions in Aggregates to simpler forms.Classorg.apache.calcite.rel.rulesCalcite
AggregateRemoveRulePlanner rule that removes if it computes no aggregate functionsClassorg.apache.calcite.rel.rulesCalcite
AggregateStarTableRulePlanner rule that matches an Aggregate on top of a StarTable.Classorg.apache.calcite.rel.rulesCalcite
AggregateUnionAggregateRulePlanner rule that matches Aggregates beneath aClassorg.apache.calcite.rel.rulesCalcite
AggregateUnionTransposeRulePlanner rule that pushes an past a non-distinct Union.Classorg.apache.calcite.rel.rulesCalcite
AggregatingScopeAn extension to the SqlValidatorScope interface which indicates that the scope is aggregating.Interfaceorg.apache.calcite.sql.validateCalcite
AggregatingSelectScopeScope for resolving identifiers within a SELECT statement that has a The same set of identifiers are in scope, but it won't allow access toClassorg.apache.calcite.sql.validateCalcite
AggResetContextInformation for a call to AggImplementor.Interfaceorg.apache.calcite.adapter.enumerableCalcite
AggResetContextImplClassorg.apache.calcite.adapter.enumerable.implCalcite
AggResultContextInformation for a call to AggImplementor.Interfaceorg.apache.calcite.adapter.enumerableCalcite
AggResultContextImplClassorg.apache.calcite.adapter.enumerable.implCalcite
AliasNamespaceNamespace for an AS t(c1, c2, .Classorg.apache.calcite.sql.validateCalcite
ArrayAnnotation that indicates that a field is an array type.Classorg.apache.calcite.adapter.javaCalcite
ArrayBindableExtension to Bindable that returns rows that are arrays of objects.Interfaceorg.apache.calcite.runtimeCalcite
ArrayComparatorClassorg.apache.calcite.runtimeCalcite
ArrayEnumeratorCursor returns an array of Object for each row.Classorg.apache.calcite.runtimeCalcite
ArrayImplClassorg.apache.calcite.avatica.utilCalcite
ArrayIteratorCursor returns an array of Object for each row.Classorg.apache.calcite.avatica.utilCalcite
ArrayLengthRecordFieldClassorg.apache.calcite.linq4j.treeCalcite
ArraySqlTypeClassorg.apache.calcite.sql.typeCalcite
AssignableOperandTypeCheckerAssignableOperandTypeChecker implements SqlOperandTypeChecker by verifying that the type of each argument is assignable to a predefined set ofClassorg.apache.calcite.sql.typeCalcite
AstAbstract syntax tree.Classorg.apache.calcite.pigletCalcite
AvaticaClientRuntimeExceptionThe client-side representation of AvaticaRuntimeException.Classorg.apache.calcite.avaticaCalcite
AvaticaConnection for the Avatica framework.Classorg.apache.calcite.avaticaCalcite
AvaticaDatabaseMetaData for the Avatica engine.Classorg.apache.calcite.avaticaCalcite
AvaticaFactoryFactory for JDBC objects.Interfaceorg.apache.calcite.avaticaCalcite
AvaticaHandlerA custom interface that extends the Jetty interface to enable extra control within Avatica.Interfaceorg.apache.calcite.avatica.serverCalcite
AvaticaHttpClientAn interface which defines how requests are sent to the Avatica server.Interfaceorg.apache.calcite.avatica.remoteCalcite
AvaticaHttpClientImplA common class to invoke HTTP requests against the Avatica server agnostic of the data being sent and received across the wire.Classorg.apache.calcite.avatica.remoteCalcite
AvaticaJsonHandlerJetty handler that executes Avatica JSON request-responses.Classorg.apache.calcite.avatica.serverCalcite
AvaticaParameterMetadata for a parameter.Classorg.apache.calcite.avaticaCalcite
AvaticaPreparedStatement for the Avatica engine.Classorg.apache.calcite.avaticaCalcite
AvaticaProtobufHandlerJetty handler that executes Avatica JSON request-responses.Classorg.apache.calcite.avatica.serverCalcite
AvaticaRemoteConnectionConfigImpl with extra properties specific to Remote Driver.Classorg.apache.calcite.avatica.remoteCalcite
AvaticaRemoteConnectionPropertyenum AvaticaRemoteConnectionPropertyEnumeration of Avatica remote driver's built-in connection properties.Classorg.apache.calcite.avatica.remoteCalcite
AvaticaResultSet for the Avatica engine.Classorg.apache.calcite.avaticaCalcite
AvaticaResultSetMetaData for the Avatica framework.Classorg.apache.calcite.avaticaCalcite
AvaticaRuntimeExceptionA RuntimeException thrown by Avatica with additional contextual information about what happened to cause the Exception.Classorg.apache.calcite.avatica.remoteCalcite
AvaticaSeverityenum AvaticaSeverityAn enumeration that denotes the severity of a given unexpected state.Classorg.apache.calcite.avaticaCalcite
AvaticaSiteA location that a value can be written to or read from.Classorg.apache.calcite.avaticaCalcite
AvaticaSqlExceptionA client-facing SQLException which encapsulates errors from the remote Avatica server.Classorg.apache.calcite.avaticaCalcite
AvaticaStatement for the Avatica engine.Classorg.apache.calcite.avaticaCalcite
AvaticaUtilsReturns the boxed class.Classorg.apache.calcite.avaticaCalcite
BarfingInvocationHandlerA class derived from BarfingInvocationHandler handles a method call by looking for a method in itself with identical parameters.Classorg.apache.calcite.utilCalcite
Base64Encodes and decodes to and from Base64 notation.Classorg.apache.calcite.avatica.utilCalcite
BaseQueryableSkeleton implementation of Queryable.Classorg.apache.calcite.linq4jCalcite
BasicDatetimeBasicDatetime is an interface for dates, times, or timestamps that can be assigned from a long value.Interfaceorg.apache.calcite.utilCalcite
BasicSqlTypeBasicSqlType represents a standard atomic SQL type (excluding intervalSee Also:Serialized FormClassorg.apache.calcite.sql.typeCalcite
BenchmarkClassorg.apache.calcite.utilCalcite
BigDecimalFunction1Function that takes one parameter and returns a BigDecimal value.Interfaceorg.apache.calcite.linq4j.functionCalcite
BinaryExpressionRepresents an expression that has a binary operator.Classorg.apache.calcite.linq4j.treeCalcite
BinarySearchBinary search for the implementation of RANGE BETWEEN XXX PRECEDING/FOLLOWING clause.Classorg.apache.calcite.runtimeCalcite
BindableStatement that can be bound to a DataContext and then executed.Interfaceorg.apache.calcite.runtimeCalcite
BindableConventionenum BindableConventionCalling convention that returns results as anClassorg.apache.calcite.interpreterCalcite
BindableRelRelational expression that can implement itself in BindableSee Also:BindableConventionInterfaceorg.apache.calcite.interpreterCalcite
BindablesUtilities pertaining to BindableRel and BindableConvention.Classorg.apache.calcite.interpreterCalcite
BiRelAbstract base class for relational expressions with a two inputs.Classorg.apache.calcite.relCalcite
BitSetsUtility functions for BitSet.Classorg.apache.calcite.utilCalcite
BitString A bit string logically consists of a set of '0' and '1' values, of a specified length.Classorg.apache.calcite.utilCalcite
BlockBuilderBuilder for BlockStatement.Classorg.apache.calcite.linq4j.treeCalcite
BlocksHelper methods concerning BlockStatements.Classorg.apache.calcite.linq4j.treeCalcite
BlockStatementClassorg.apache.calcite.linq4j.treeCalcite
BreadthFirstIteratorIterates over the vertices in a directed graph in breadth-first order.Classorg.apache.calcite.util.graphCalcite
BugHolder for a list of constants describing which bugs which have not been You can use these constants to control the flow of your code.Classorg.apache.calcite.utilCalcite
BuiltInConnectionPropertyenum BuiltInConnectionPropertyEnumeration of Avatica's built-in connection properties.Classorg.apache.calcite.avaticaCalcite
BuiltInMetadataContains the interfaces for several common forms of metadata.Classorg.apache.calcite.rel.metadataCalcite
BuiltInMethodClassorg.apache.calcite.utilCalcite
ByteStringCollection of bytes.Classorg.apache.calcite.avatica.utilCalcite
CachingRelMetadataProvider interface that caches results from an underlying provider.Classorg.apache.calcite.rel.metadataCalcite
CalcClassorg.apache.calcite.rel.coreCalcite
CalciteCatalogReader and also SqlOperatorTable based on tables and functions defined schemas.Classorg.apache.calcite.prepareCalcite
CalciteConnectionExtension to Calcite's implementation of JDBC connection allows schemas to be definedInterfaceorg.apache.calcite.jdbcCalcite
CalciteConnectionConfigInterface for reading connection properties within Calcite code.Interfaceorg.apache.calcite.configCalcite
CalciteConnectionConfigImplClassorg.apache.calcite.configCalcite
CalciteConnectionPropertyenum CalciteConnectionPropertyProperties that may be specified on the JDBC connect string.Classorg.apache.calcite.configCalcite
CalciteContextExceptionException which contains information about the textual context of the causingSee Also:Serialized FormClassorg.apache.calcite.runtimeCalcite
CalciteExceptionBase class for all exceptions originating from Farrago.Classorg.apache.calcite.runtimeCalcite
CalciteFactoryClassorg.apache.calcite.jdbcCalcite
CalciteJdbc41Factory for Calcite and JDBC 4.Classorg.apache.calcite.jdbcCalcite
CalciteLoggerSmall extension to Logger with some performance improvements.Classorg.apache.calcite.util.traceCalcite
CalciteMetaImplHelper for implementing the getXxx methods such as AvaticaDatabaseMetaData.Classorg.apache.calcite.jdbcCalcite
CalcitePrepareAPI for a service that prepares statements for execution.Interfaceorg.apache.calcite.jdbcCalcite
CalcitePrepareImpl This class is public so that projects that create their own JDBC driver and server can fine-tune preferences.Classorg.apache.calcite.prepareCalcite
CalciteResourceCompiler-checked resources for the Calcite project.Interfaceorg.apache.calcite.runtimeCalcite
CalciteResultSet for the Calcite engine.Classorg.apache.calcite.jdbcCalcite
CalciteRootSchemaClassorg.apache.calcite.jdbcCalcite
CalciteSchema Wrapper around user-defined schema used internally.Classorg.apache.calcite.jdbcCalcite
CalciteServer Represents shared state among connections, and will have monitoring and management facilities.Interfaceorg.apache.calcite.serverCalcite
CalciteServerStatementStatement within a Calcite server.Interfaceorg.apache.calcite.serverCalcite
CalciteStatement for the Calcite engine.Classorg.apache.calcite.jdbcCalcite
CalciteTimingTracerCalciteTimingTracer provides a mechanism for tracing the timing of a call sequence at nanosecond resolution.Classorg.apache.calcite.util.traceCalcite
CalciteTraceContains all of the tracers used within org.Classorg.apache.calcite.util.traceCalcite
CalcMergeRulePlanner rule that merges a The resulting LogicalCalc has theClassorg.apache.calcite.rel.rulesCalcite
CalcRelSplitterCalcRelSplitter operates on a Calc with multiple RexCallClassorg.apache.calcite.rel.rulesCalcite
CalcRemoveRulePlanner rule that removes a trivial is trivial if it projects its input fields in theirClassorg.apache.calcite.rel.rulesCalcite
CalcSplitRulePlanner rule that converts a Calc Not enabled by default, as it works against the usual flow, which is toClassorg.apache.calcite.rel.rulesCalcite
CallImplementorInterfaceorg.apache.calcite.adapter.enumerableCalcite
CancelFlagCancelFlag is used to post and check cancellation requests.Classorg.apache.calcite.utilCalcite
CasingPolicy for converting case of identifiers before storing them.Classorg.apache.calcite.avatica.utilCalcite
CastingListConverts a list whose members are automatically down-cast to a given type.Classorg.apache.calcite.utilCalcite
CatchBlockRepresents a catch statement in a try block.Classorg.apache.calcite.linq4j.treeCalcite
ChainedPhaseRuleMappingInitializerChainedPhaseRuleMappingInitializer is an abstract implementation of VolcanoPlannerPhaseRuleMappingInitializer that allows additionalClassorg.apache.calcite.plan.volcanoCalcite
ChainedRelMetadataProvider Glossary.Classorg.apache.calcite.rel.metadataCalcite
ChainedSqlOperatorTableChainedSqlOperatorTable implements the SqlOperatorTable interface by chaining together any number of underlying operator table instances.Classorg.apache.calcite.sql.utilCalcite
ChiRelational operator that converts a stream to a relation.Classorg.apache.calcite.rel.streamCalcite
ChunkList in chunks of 32 elements.Classorg.apache.calcite.utilCalcite
ClassDeclarationDeclaration of a class.Classorg.apache.calcite.linq4j.treeCalcite
ClassDeclarationFinderEntry point for optimizers that factor ou deterministic expressions to final static fields.Classorg.apache.calcite.linq4j.treeCalcite
CloneSchemaSchema that contains in-memory copies of tables from a JDBC schema.Classorg.apache.calcite.adapter.cloneCalcite
ClosableAllocationClosableAllocation represents an object which requires a call in order to release resources early rather than waiting for finalization.Interfaceorg.apache.calcite.utilCalcite
ClosableAllocationOwnerClosableAllocationOwner represents an object which can take ownership of ClosableAllocations and guarantee that they will be cleaned up correctly whenInterfaceorg.apache.calcite.utilCalcite
CoerceInputsRuleCoerceInputsRule precasts inputs to a particular type.Classorg.apache.calcite.rel.rulesCalcite
CollectA relational expression that collapses multiple rows into one.Classorg.apache.calcite.rel.coreCalcite
CollectNamespaceNamespace for COLLECT and TABLE constructs.Classorg.apache.calcite.sql.validateCalcite
ColumnMetaDataMetadata for a column.Classorg.apache.calcite.avaticaCalcite
CommonClassorg.apache.calcite.avatica.protoCalcite
CommonRelSubExprRuleA CommonRelSubExprRule is an abstract base class for rules that are fired only on relational expressions that appear more than onceClassorg.apache.calcite.planCalcite
ComparableOperandTypeCheckerType checking strategy which verifies that types have the required attributes to be used as arguments to comparison operators.Classorg.apache.calcite.sql.typeCalcite
CompatibleCompatibility layer.Interfaceorg.apache.calcite.utilCalcite
CompositeListRead-only list that is the concatenation of sub-lists.Classorg.apache.calcite.utilCalcite
CompositeMapUnmodifiable view onto multiple backing maps.Classorg.apache.calcite.utilCalcite
CompositeOperandTypeCheckerThis class allows multiple existing SqlOperandTypeChecker rules to be combined into one rule.Classorg.apache.calcite.sql.typeCalcite
CompositeSingleOperandTypeChecker SqlSingleOperandTypeChecker rules to be combined into one rule.Classorg.apache.calcite.sql.typeCalcite
CompoundClosableAllocationCompoundClosableAllocation represents a collection of ClosableAllocations which share a common lifecycle.Classorg.apache.calcite.utilCalcite
ConditionalExpressionRepresents an expression that has a conditional operator.Classorg.apache.calcite.linq4j.treeCalcite
ConditionalStatementRepresents an expression that has a conditional operator.Classorg.apache.calcite.linq4j.treeCalcite
ConnectionConfigConnection configuration.Interfaceorg.apache.calcite.avaticaCalcite
ConnectionConfigImplClassorg.apache.calcite.avaticaCalcite
ConnectionPropertiesImplConcrete implementation of Meta.Classorg.apache.calcite.avaticaCalcite
ConnectionPropertyDefinition of a property that may be specified on the JDBC connect string.Interfaceorg.apache.calcite.avaticaCalcite
ConnectStringParserConnectStringParser is a utility class that parses or creates a JDBC connect string according to the OLE DB connect string syntax described at Classorg.apache.calcite.avaticaCalcite
ConstantExpressionRepresents an expression that has a constant value.Classorg.apache.calcite.linq4j.treeCalcite
ConstantUntypedNullRepresents a constant null of unknown type Java allows type inference for such nulls, thus null cannot always beClassorg.apache.calcite.linq4j.treeCalcite
ConstructorDeclarationDeclaration of a constructor.Classorg.apache.calcite.linq4j.treeCalcite
ContextContext for executing a scalar expression in an interpreter.Classorg.apache.calcite.interpreterCalcite
ContextProvides library users a way to store data within the planner session and access it within rules.Interfaceorg.apache.calcite.planCalcite
ContextsUtilities for Context.Classorg.apache.calcite.planCalcite
ControlFlowExceptionException intended to be used for control flow, as opposed to the usual use of exceptions which is to signal an error condition.Classorg.apache.calcite.utilCalcite
ConventionCalling convention trait.Interfaceorg.apache.calcite.planCalcite
ConventionTraitDefDefinition of the the convention trait.Classorg.apache.calcite.planCalcite
ConversionUtilClassorg.apache.calcite.utilCalcite
ConverterA relational expression implements the interface Converter to indicate that it converts a physical attribute, orInterfaceorg.apache.calcite.rel.convertCalcite
ConverterImplAbstract implementation of Converter.Classorg.apache.calcite.rel.convertCalcite
ConverterRuleAbstract base class for a rule which converts from one calling convention to another without changing semantics.Classorg.apache.calcite.rel.convertCalcite
CorrelateA relational operator that performs nested-loop joins.Classorg.apache.calcite.rel.coreCalcite
CorrelateJoinTypeenum CorrelateJoinTypeSpecifies the type of correlation operation: inner, left, semi, or anti.Classorg.apache.calcite.linq4jCalcite
CorrelationIdDescribes the necessary parameters for an implementation in order to identify and set dynamic variablesClassorg.apache.calcite.rel.coreCalcite
CorrelationReferenceFinderClassorg.apache.calcite.sql2relCalcite
CsvFilterableTableTable based on a CSV file that can implement simple filtering.Classorg.apache.calcite.adapter.csvCalcite
CsvProjectTableScanRulePlanner rule that projects from a CsvTableScan scan just the columns needed to satisfy a projection.Classorg.apache.calcite.adapter.csvCalcite
CsvScannableTableTable based on a CSV file.Classorg.apache.calcite.adapter.csvCalcite
CsvSchemaSchema mapped onto a directory of CSV files.Classorg.apache.calcite.adapter.csvCalcite
CsvSchemaFactoryFactory that creates a CsvSchema.Classorg.apache.calcite.adapter.csvCalcite
CsvTableBase class for table that reads CSV files.Classorg.apache.calcite.adapter.csvCalcite
CsvTableFactoryFactory that creates a CsvTranslatableTable.Classorg.apache.calcite.adapter.csvCalcite
CsvTableScanRelational expression representing a scan of a CSV file.Classorg.apache.calcite.adapter.csvCalcite
CsvTranslatableTableTable based on a CSV file.Classorg.apache.calcite.adapter.csvCalcite
CursorInterface to an iteration that is similar to, and can easily support, a JDBC ResultSet, but is simpler to implement.Interfaceorg.apache.calcite.avatica.utilCalcite
CursorReturnTypeInferenceReturns the rowtype of a cursor of the operand at a particular 0-basedSee Also:OrdinalReturnTypeInferenceClassorg.apache.calcite.sql.typeCalcite
CycleDetectorDetects cycles in directed graphs.Classorg.apache.calcite.util.graphCalcite
CyclicMetadataExceptionException that indicates that a cycle has been detected while computing metadata.Classorg.apache.calcite.rel.metadataCalcite
DataContextRuntime context allowing access to the tables in a database.Interfaceorg.apache.calciteCalcite
DateTimeUtilsUtility functions for datetime types: date, time, timestamp.Classorg.apache.calcite.avatica.utilCalcite
DeclarationStatementExpression that declares and optionally initializes a variable.Classorg.apache.calcite.linq4j.treeCalcite
DeduplicateCorrelateVariablesRewrites relations to ensure the same correlation is referenced by the same correlation variable.Classorg.apache.calcite.sql2relCalcite
DefaultDirectedGraphDefault implementation of DirectedGraph.Classorg.apache.calcite.util.graphCalcite
DefaultEdgeDefault implementation of Edge.Classorg.apache.calcite.util.graphCalcite
DefaultEnumerable that implements the extension methods by calling into the Extensions The are two abstract methods:Classorg.apache.calcite.linq4jCalcite
DefaultExpressionRepresents the default value of a type or an empty expression.Classorg.apache.calcite.linq4j.treeCalcite
DefaultRelMetadataProviderDefaultRelMetadataProvider supplies a default implementation of the RelMetadataProvider interface.Classorg.apache.calcite.rel.metadataCalcite
DefaultValueFactoryDefaultValueFactory supplies default values for INSERT, UPDATE, and NEW.Interfaceorg.apache.calcite.sql2relCalcite
DelegatingAvaticaHandlerAn AvaticaHandler implementation that delegates to a provided Jetty Handler instance.Classorg.apache.calcite.avatica.serverCalcite
DelegatingEnumeratorSimple enumerator that just delegates all calls to the passed enumerator.Classorg.apache.calcite.linq4jCalcite
DelegatingInvocationHandlerA class derived from DelegatingInvocationHandler handles a method call by looking for a method in itself with identical parameters.Classorg.apache.calcite.utilCalcite
DelegatingLatticeStatisticProvider to an underlying provider.Classorg.apache.calcite.materializeCalcite
DelegatingNamespaceAn implementation of SqlValidatorNamespace that delegates all methods to an underlying object.Classorg.apache.calcite.sql.validateCalcite
DelegatingSchema an underlying schema.Classorg.apache.calcite.schema.implCalcite
DelegatingScopeA scope which delegates all requests to its parent scope.Classorg.apache.calcite.sql.validateCalcite
DelegatingSqlValidatorCatalogReader SqlValidatorCatalogReader that passes all calls to a parent catalog reader.Classorg.apache.calcite.sql.validateCalcite
DelegatingSqlValidatorTable delegating to a parent table.Classorg.apache.calcite.sql.validateCalcite
DeltaRelational operator that converts a relation to a stream.Classorg.apache.calcite.rel.streamCalcite
DemoClassorg.apache.calciteCalcite
DepthFirstIteratorIterates over the vertices in a directed graph in depth-first order.Classorg.apache.calcite.util.graphCalcite
DeterministicCodeOptimizerFactors out deterministic expressions to final static fields.Classorg.apache.calcite.linq4j.treeCalcite
DirectedGraphInterfaceorg.apache.calcite.util.graphCalcite
DoubleFunction1Function that takes one parameter and returns a native double value.Interfaceorg.apache.calcite.linq4j.functionCalcite
DriverAvatica Remote JDBC driver.Classorg.apache.calcite.avatica.remoteCalcite
DriverCalcite JDBC driver.Classorg.apache.calcite.jdbcCalcite
DriverVersionDriver version information.Classorg.apache.calcite.avaticaCalcite
DynamicExpressionRepresents a dynamic operation.Classorg.apache.calcite.linq4j.treeCalcite
ElementInitRepresents an initializer for a single element of an Enumerable collection.Classorg.apache.calcite.linq4j.treeCalcite
EnumerableExposes the enumerator, which supports a simple iteration over a collection.Interfaceorg.apache.calcite.linq4jCalcite
EnumerableAggregate enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableBindableRelational expression that converts an enumerable input to interpretable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableCalc enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableCollect enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableConventionenum EnumerableConventionFamily of calling conventions that return results as anClassorg.apache.calcite.adapter.enumerableCalcite
EnumerableCorrelate enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableCorrelateRuleClassorg.apache.calcite.adapter.enumerableCalcite
EnumerableDefaultsDefault implementations of methods in the Enumerable interface.Classorg.apache.calcite.linq4jCalcite
EnumerableFilter enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableFilterToCalcRuleVariant of FilterToCalcRule for enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableInterpretableRelational expression that converts an enumerable input to interpretable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableInterpreterRelational expression that executes its children using an interpreter.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableInterpreterRulePlanner rule that converts BindableRel to EnumerableRel by creatingClassorg.apache.calcite.adapter.enumerableCalcite
EnumerableIntersect enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableJoin enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableLimitRelational expression that applies a limit and/or offset to its input.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableMergeJoinClassorg.apache.calcite.adapter.enumerableCalcite
EnumerableMinus enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableProject enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableProjectToCalcRuleVariant of ProjectToCalcRule for enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableRelA relational expression of one of the EnumerableConvention callingInterfaceorg.apache.calcite.adapter.enumerableCalcite
EnumerableRelImplementorSubclass of RelImplementor for relational operators of EnumerableConvention calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableRulesRules and relational operators for the enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerablesUtilities for processing Enumerable This class is a place to put things not yet added to linq4j.Classorg.apache.calcite.runtimeCalcite
EnumerableSemiJoin enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableSort enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableTableFunctionScan enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableTableFunctionScanRulePlanner rule that converts a LogicalTableFunctionScanClassorg.apache.calcite.adapter.enumerableCalcite
EnumerableTableModify enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableTableModifyRulePlanner rule that converts a relational expressionClassorg.apache.calcite.adapter.enumerableCalcite
EnumerableTableScan enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableTableScanRulePlanner rule that converts a LogicalTableFunctionScanClassorg.apache.calcite.adapter.enumerableCalcite
EnumerableThetaJoin enumerable calling convention that allows conditions that are not just = (equals).Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableToSparkConverterRelational expression that converts input of EnumerableConvention into Spark convention.Classorg.apache.calcite.adapter.sparkCalcite
EnumerableToSparkConverterRuleClassorg.apache.calcite.adapter.sparkCalcite
EnumerableUncollect enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableUnion enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableValues enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumerableValuesRulePlanner rule that converts a relational expressionClassorg.apache.calcite.adapter.enumerableCalcite
EnumerableWindow enumerable calling convention.Classorg.apache.calcite.adapter.enumerableCalcite
EnumeratorSupports a simple iteration over a collection.Interfaceorg.apache.calcite.linq4jCalcite
EnumeratorCursor returns a record for each row.Classorg.apache.calcite.runtimeCalcite
EnumUtilsClassorg.apache.calcite.adapter.enumerableCalcite
EqualityComparerCompares values for equality.Interfaceorg.apache.calcite.linq4j.functionCalcite
EquiJoinBase class for any join whose condition is based on column equality.Classorg.apache.calcite.rel.coreCalcite
EquiJoinBase class for any join whose condition is based on column equality.Classorg.apache.calcite.rel.rulesCalcite
ExchangeRelational expression that imposes a particular distribution on its input without otherwise changing its content.Classorg.apache.calcite.rel.coreCalcite
ExplicitOperandTypeInferenceExplicitOperandTypeInferences implements SqlOperandTypeInference by explicitly supplying a type for each parameter.Classorg.apache.calcite.sql.typeCalcite
ExplicitOperatorBindingExplicitOperatorBinding implements SqlOperatorBinding via an underlying array of known operand types.Classorg.apache.calcite.sqlCalcite
ExplicitReturnTypeInferenceA SqlReturnTypeInference which always returns the same SQL type.Classorg.apache.calcite.sql.typeCalcite
ExpressionAnalogous to LINQ's System.Classorg.apache.calcite.linq4j.treeCalcite
ExpressionsUtility methods for expressions, including a lot of factory methods.Classorg.apache.calcite.linq4j.treeCalcite
ExpressionTypeAnalogous to LINQ's System.Classorg.apache.calcite.linq4j.treeCalcite
ExpressionVisitorRepresents a visitor or rewriter for expression trees.Interfaceorg.apache.calcite.linq4j.treeCalcite
ExtendedEnumerableExtension methods in Enumerable.Interfaceorg.apache.calcite.linq4jCalcite
ExtendedOrderedEnumerableExtension methods for OrderedEnumerable.Interfaceorg.apache.calcite.linq4jCalcite
ExtendedOrderedQueryableExtension methods for OrderedQueryable.Interfaceorg.apache.calcite.linq4jCalcite
ExtensibleTableTable whose row type can be extended to include extra fields.Interfaceorg.apache.calcite.schemaCalcite
ExtensionsContains what, in LINQ.Classorg.apache.calcite.linq4jCalcite
ExtraSqlTypesHolds constants associated with SQL types introduced after the earliest version of Java supported by Farrago (this currently means anythingInterfaceorg.apache.calcite.sql.typeCalcite
FamilyOperandTypeCheckerClassorg.apache.calcite.sql.typeCalcite
FeatureSQL language feature.Classorg.apache.calcite.runtimeCalcite
FieldDeclarationDeclaration of a field.Classorg.apache.calcite.linq4j.treeCalcite
FilterRelational expression that iterates over its input and returns elements for which condition evaluates toClassorg.apache.calcite.rel.coreCalcite
FilterableTableTable that can be scanned, optionally applying supplied filter expressions, without creating an intermediate relational expression.Interfaceorg.apache.calcite.schemaCalcite
FilterAggregateTransposeRulePlanner rule that pushes a FilterSee Also:AggregateFilterTransposeRuleClassorg.apache.calcite.rel.rulesCalcite
FilteratorFiltered iterator class: an iterator that includes only elements that are instanceof a specified class.Classorg.apache.calcite.utilCalcite
FilterCalcMergeRulePlanner rule that merges a LogicalFilter and aClassorg.apache.calcite.rel.rulesCalcite
FilterCorrelateRulePlanner rule that pushes a Filter above a Correlate into the inputs of the Correlate.Classorg.apache.calcite.rel.rulesCalcite
FilterJoinRulePlanner rule that pushes filters above and within a join node into the join node and/or its children nodes.Classorg.apache.calcite.rel.rulesCalcite
FilterMergeRuleClassorg.apache.calcite.rel.rulesCalcite
FilterMultiJoinMergeRulePlanner rule that merges a creating a richer MultiJoin.Classorg.apache.calcite.rel.rulesCalcite
FilterNodeClassorg.apache.calcite.interpreterCalcite
FilterProjectTransposeRulePlanner rule that pushes past a LogicalProject.Classorg.apache.calcite.rel.rulesCalcite
FilterRemoveIsNotDistinctFromRulePlanner rule that replaces IS NOT DISTINCT FROM with logically equivalent operations.Classorg.apache.calcite.rel.rulesCalcite
FilterSetOpTransposeRuleClassorg.apache.calcite.rel.rulesCalcite
FilterTableFunctionTransposeRulePlanner rule that pushes past a LogicalTableFunctionScan.Classorg.apache.calcite.rel.rulesCalcite
FilterTableScanRulePlanner rule that converts of a FilterableTableClassorg.apache.calcite.rel.rulesCalcite
FilterToCalcRulePlanner rule that converts a The rule does NOT fire if the child is aClassorg.apache.calcite.rel.rulesCalcite
FlatListsSpace-efficient, comparable, immutable lists.Classorg.apache.calcite.runtimeCalcite
FlightRecorderProfilerCaptures Flight Recorder log.Classorg.apache.calcite.benchmarksCalcite
FloatFunction1Function that takes one parameter and returns a native float value.Interfaceorg.apache.calcite.linq4j.functionCalcite
ForStatementRepresents an infinite loop.Classorg.apache.calcite.linq4j.treeCalcite
FrameworkConfigInterface that describes how to configure planning sessions generated using the Frameworks tools.Interfaceorg.apache.calcite.toolsCalcite
FrameworksClassorg.apache.calcite.toolsCalcite
FunctionNamed expression that accepts parameters and returns a result.Interfaceorg.apache.calcite.schemaCalcite
Function0Function with no parameters.Interfaceorg.apache.calcite.linq4j.functionCalcite
Function1Function with one parameter.Interfaceorg.apache.calcite.linq4j.functionCalcite
Function2Function with two parameters.Interfaceorg.apache.calcite.linq4j.functionCalcite
FunctionExpressionRepresents a strongly typed lambda expression as a data structure in the form of an expression tree.Classorg.apache.calcite.linq4j.treeCalcite
FunctionParameterParameter to a Function.Interfaceorg.apache.calcite.schemaCalcite
FunctionsUtilities relating to functions.Classorg.apache.calcite.linq4j.functionCalcite
GlossaryA collection of terms.Interfaceorg.apache.calcite.utilCalcite
GotoExpressionKindenum GotoExpressionKindSpecifies what kind of jump a GotoStatement represents.Classorg.apache.calcite.linq4j.treeCalcite
GotoStatementRepresents an unconditional jump.Classorg.apache.calcite.linq4j.treeCalcite
GraphsMiscellaneous graph utilities.Classorg.apache.calcite.util.graphCalcite
GroupingRepresents a collection of objects that have a common key.Interfaceorg.apache.calcite.linq4jCalcite
HandlerCalled at various points in the JDBC lifecycle.Interfaceorg.apache.calcite.avaticaCalcite
HandlerAPI for text request-response calls to an Avatica server.Interfaceorg.apache.calcite.avatica.remoteCalcite
HandlerClassorg.apache.calcite.pigletCalcite
HandlerFactoryFactory that instantiates the desired implementation, typically differing on the method used to serialize messages, for use in the Avatica server.Classorg.apache.calcite.avatica.serverCalcite
HandlerImpl It is recommended implementations of Handler use this as a base class, to ensure forward compatibility.Classorg.apache.calcite.avaticaCalcite
HelperUtility methods, mainly concerning error-handling.Classorg.apache.calcite.avaticaCalcite
HepMatchOrderHepMatchOrder specifies the order of graph traversal when looking for ruleEnum Constant SummaryClassorg.apache.calcite.plan.hepCalcite
HepPlannerClassorg.apache.calcite.plan.hepCalcite
HepProgramHepProgram specifies the order in which rules should be attempted by HepPlanner.Classorg.apache.calcite.plan.hepCalcite
HepProgramBuilderHepProgramBuilder creates instances of HepProgram.Classorg.apache.calcite.plan.hepCalcite
HepRelVertexHepRelVertex wraps a real RelNode as a vertex in a DAG representing the entire query expression.Classorg.apache.calcite.plan.hepCalcite
HepRuleCallHepRuleCall implements RelOptRuleCall for a HepPlanner.Classorg.apache.calcite.plan.hepCalcite
HolderA mutable slot that can contain one object.Classorg.apache.calcite.utilCalcite
HookCollection of hooks that can be set by observers and are executed at various parts of the query preparation process.Classorg.apache.calcite.runtimeCalcite
HttpServerAvatica HTTP server.Classorg.apache.calcite.avatica.serverCalcite
HttpUtilsUtilities for connecting to Splunk via HTTP.Classorg.apache.calcite.adapter.splunk.utilCalcite
IdentifierNamespaceClassorg.apache.calcite.sql.validateCalcite
ImmutableBitSetAn immutable list of bits.Classorg.apache.calcite.utilCalcite
ImmutableIntListAn immutable list of Integer values backed by an array ofReturns a copy of this list with one element added.Classorg.apache.calcite.utilCalcite
ImmutableNullableListAn immutable list that may contain null values.Classorg.apache.calcite.utilCalcite
ImplementableAggFunctionFunction that can be translated to java code.Interfaceorg.apache.calcite.schemaCalcite
ImplementableFunctionFunction that can be translated to java code.Interfaceorg.apache.calcite.schemaCalcite
IndexExpressionRepresents indexing a property or array.Classorg.apache.calcite.linq4j.treeCalcite
InferTypesStrategies for inferring operand types.Classorg.apache.calcite.sql.typeCalcite
IntegerFunction1Function that takes one parameter and returns a native int value.Interfaceorg.apache.calcite.linq4j.functionCalcite
IntegerIntervalSetA set of non-negative integers defined by a sequence of points, intervals,Parses a range of integers expressed as a string.Classorg.apache.calcite.utilCalcite
InternalPropertyenum InternalPropertyDefinitions of properties that drive the behavior ofClassorg.apache.calcite.avaticaCalcite
InterpretableConventionenum InterpretableConventionCalling convention that returns results as anClassorg.apache.calcite.interpreterCalcite
InterpretableConverterRelational expression that converts any relational expression input to InterpretableConvention, by wrappingClassorg.apache.calcite.interpreterCalcite
InterpretableRelRelational expression that can implement itself using an interpreter.Interfaceorg.apache.calcite.interpreterCalcite
Interpreter Contains the context for interpreting relational expressions.Classorg.apache.calcite.interpreterCalcite
InterpretersUtilities relating to Interpreter and InterpretableConvention.Classorg.apache.calcite.interpreterCalcite
IntersectRelational expression that returns the intersection of the rows of its If all is true, performs then multiset intersection; otherwise,Classorg.apache.calcite.rel.coreCalcite
IntervalSqlTypeIntervalSqlType represents a standard SQL datetime interval type.Classorg.apache.calcite.sql.typeCalcite
IntListExtension to ArrayList to help build an array of intSee Also:Serialized FormClassorg.apache.calcite.utilCalcite
IntPairAn immutable pair of integers.Classorg.apache.calcite.util.mappingCalcite
InvalidRelExceptionException that indicates that a relational expression would be invalid with given parameters.Classorg.apache.calcite.relCalcite
InvocationExpressionRepresents an expression that applies a delegate or lambda expression to a list of argument expressions.Classorg.apache.calcite.linq4j.treeCalcite
IteratorCursor on top of an Iterator that returns a record for each row.Classorg.apache.calcite.avatica.utilCalcite
JaninoCompilerClassorg.apache.calcite.util.javacCalcite
JaninoRexCompilerCompiles a scalar expression (RexNode) to an expression that can be evaluated (Scalar) by generating a Java AST and compiling itClassorg.apache.calcite.interpreterCalcite
JavaCompilerThe interface JavaCompiler represents an interface to invoke a regular Java compiler.Interfaceorg.apache.calcite.util.javacCalcite
JavaCompilerArgsA JavaCompilerArgs holds the arguments for a Specific implementations of JavaCompiler may override Classorg.apache.calcite.util.javacCalcite
JavaRecordTypeRecord type based on a Java class.Classorg.apache.calcite.jdbcCalcite
JavaRelImplementorAbstract base class for implementations of RelImplementor that generate java code.Classorg.apache.calcite.adapter.enumerableCalcite
JavaRowFormatHow a row is represented as a Java value.Classorg.apache.calcite.adapter.enumerableCalcite
JavaToSqlTypeConversionRulesJavaToSqlTypeConversionRules defines mappings from common Java types to corresponding SQL types.Classorg.apache.calcite.sql.typeCalcite
JavaTypeFactoryType factory that can register Java classes as record types.Interfaceorg.apache.calcite.adapter.javaCalcite
JavaTypeFactoryImpl NOTE: This class is experimental and subject to change/removal without notice.Classorg.apache.calcite.jdbcCalcite
JdbcConventionCalling convention for relational operations that occur in a JDBC The convention is a slight misnomer.Classorg.apache.calcite.adapter.jdbcCalcite
JdbcImplementorState for generating a SQL statement.Classorg.apache.calcite.adapter.jdbcCalcite
JdbcMetaClassorg.apache.calcite.avatica.jdbcCalcite
JdbcQueryProviderClassorg.apache.calcite.adapter.jdbcCalcite
JdbcRelRelational expression that uses JDBC calling convention.Interfaceorg.apache.calcite.adapter.jdbcCalcite
JdbcRulesRules and relational operators for calling convention.Classorg.apache.calcite.adapter.jdbcCalcite
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 downClassorg.apache.calcite.adapter.jdbcCalcite
JdbcTableScanRelational expression representing a scan of a table in a JDBC data source.Classorg.apache.calcite.adapter.jdbcCalcite
JdbcToEnumerableConverterRelational expression representing a scan of a table in a JDBC data source.Classorg.apache.calcite.adapter.jdbcCalcite
JdbcToEnumerableConverterRuleRule to convert a relational expression from EnumerableConvention.Classorg.apache.calcite.adapter.jdbcCalcite
JdbcToSparkConverterRelational expression representing a scan of a table in a JDBC data source that returns its results as a Spark RDD.Classorg.apache.calcite.adapter.sparkCalcite
JdbcToSparkConverterRuleClassorg.apache.calcite.adapter.sparkCalcite
JoinRelational expression that combines two relational expressions according to Each output row has columns from the left and right inputs.Classorg.apache.calcite.rel.coreCalcite
JoinAddRedundantSemiJoinRuleRule to add a semi-join into a join.Classorg.apache.calcite.rel.rulesCalcite
JoinAssociateRulePlanner rule that changes a join based on the associativity rule.Classorg.apache.calcite.rel.rulesCalcite
JoinCommuteRulePlanner rule that permutes the inputs to a Permutation of outer joins can be turned on/off by specifying theClassorg.apache.calcite.rel.rulesCalcite
JoinConditionTypeenum JoinConditionTypeEnumerates the types of condition in a join expression.Classorg.apache.calcite.sqlCalcite
JoinExtractFilterRule cartesian inner join.Classorg.apache.calcite.rel.rulesCalcite
JoinInfoAn analyzed join condition.Classorg.apache.calcite.rel.coreCalcite
JoinNodeClassorg.apache.calcite.interpreterCalcite
JoinProjectTransposeRulePlanner rule that matches a Join one of whose inputs is aClassorg.apache.calcite.rel.rulesCalcite
JoinPushExpressionsRulePlanner rule that pushes down expressions in equal join condition.Classorg.apache.calcite.rel.rulesCalcite
JoinPushThroughJoinRuleRule 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.Classorg.apache.calcite.rel.rulesCalcite
JoinPushTransitivePredicatesRulePlanner rule that infers predicates from on a Filters if those predicates can be pushedClassorg.apache.calcite.rel.rulesCalcite
JoinRelTypeEnumeration of join types.Classorg.apache.calcite.rel.coreCalcite
JoinScopeThe name-resolution context for expression inside a JOIN clause.Classorg.apache.calcite.sql.validateCalcite
JoinToCorrelateRuleRule that converts a LogicalJoin into a LogicalCorrelate, which canClassorg.apache.calcite.rel.rulesCalcite
JoinToMultiJoinRulePlanner rule to flatten a tree of into a single MultiJoin with N inputs.Classorg.apache.calcite.rel.rulesCalcite
JoinTypeEnumerates the types of join.Classorg.apache.calcite.sqlCalcite
JoinUnionTransposeRulePlanner rule that pushes a past a non-distinct LogicalUnion.Classorg.apache.calcite.rel.rulesCalcite
JsonBuilderBuilder for JSON documents (represented as List, Map, String, Boolean, Long).Classorg.apache.calcite.utilCalcite
JsonColumnJSON object representing a column.Classorg.apache.calcite.modelCalcite
JsonCustomSchemaJSON schema element that represents a custom schema.Classorg.apache.calcite.modelCalcite
JsonCustomTableCustom table schema element.Classorg.apache.calcite.modelCalcite
JsonFunctionFunction schema element.Classorg.apache.calcite.modelCalcite
JsonHandler that decodes JSON requests, sends them to a Service, and encodes the responses into JSON.Classorg.apache.calcite.avatica.remoteCalcite
JsonJdbcSchemaJSON object representing a schema that maps to a JDBC database.Classorg.apache.calcite.modelCalcite
JsonLatticeElement that describes a star schema and provides a framework for defining, recognizing, and recommending materialized views at various levels ofClassorg.apache.calcite.modelCalcite
JsonMapSchemaJSON object representing a schema whose tables are explicitly specified.Classorg.apache.calcite.modelCalcite
JsonMaterializationElement that describes how a table is a materialization of a query.Classorg.apache.calcite.modelCalcite
JsonMeasureAn aggregate function applied to a column (or columns) of a lattice.Classorg.apache.calcite.modelCalcite
JsonRootRoot schema element.Classorg.apache.calcite.modelCalcite
JsonSchemaSchema schema element.Classorg.apache.calcite.modelCalcite
JsonService that encodes requests and responses as JSON.Classorg.apache.calcite.avatica.remoteCalcite
JsonStreamInformation about whether a table allows streaming.Classorg.apache.calcite.modelCalcite
JsonTableTable based on a JSON file.Classorg.apache.calcite.adapter.csvCalcite
JsonTableTable schema element.Classorg.apache.calcite.modelCalcite
JsonTileMaterialized view within a JsonLattice.Classorg.apache.calcite.modelCalcite
JsonViewView schema element.Classorg.apache.calcite.modelCalcite
LabelStatementRepresents a label, which can be put in any Expression context.Classorg.apache.calcite.linq4j.treeCalcite
LabelTargetUsed to represent the target of a GotoStatement.Classorg.apache.calcite.linq4j.treeCalcite
LambdaExpressionDescribes a lambda expression.Classorg.apache.calcite.linq4j.treeCalcite
LatticeStructure that allows materialized views based upon a star schema to be recognized and recommended.Classorg.apache.calcite.materializeCalcite
LatticesUtilities for Lattice, LatticeStatisticProvider.Classorg.apache.calcite.materializeCalcite
LatticeStatisticProviderEstimates row counts for a lattice and its attributes.Interfaceorg.apache.calcite.materializeCalcite
LexNamed, built-in lexical policy.Classorg.apache.calcite.configCalcite
LikeUtilities for converting SQL LIKE and SIMILAR operators to regular expressions.Classorg.apache.calcite.runtimeCalcite
Linq4jUtility and factory methods for Linq4j.Classorg.apache.calcite.linq4jCalcite
ListInitExpressionRepresents a constructor call that has a collection initializer.Classorg.apache.calcite.linq4j.treeCalcite
ListIteratorCursor returns a List for each row.Classorg.apache.calcite.avatica.utilCalcite
ListScopeAbstract base for a scope which is defined by a list of child namespaces and which inherits from a parent scope.Classorg.apache.calcite.sql.validateCalcite
ListSqlOperatorTableClassorg.apache.calcite.sql.utilCalcite
LiteralOperandTypeCheckerParameter type-checking strategy type must be a literal (whether null is allowed is determined by the constructor).Classorg.apache.calcite.sql.typeCalcite
LitmusCallback to be called when a test for validity succeeds or fails.Interfaceorg.apache.calcite.utilCalcite
LocalJsonService that goes to an in-process instance of Service.Classorg.apache.calcite.avatica.remoteCalcite
LocalProtobufServiceA 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 whichClassorg.apache.calcite.avatica.remoteCalcite
LocalServiceClassorg.apache.calcite.avatica.remoteCalcite
LogicalAggregateLogicalAggregate is a relational operator which eliminates duplicates and computes totals.Classorg.apache.calcite.rel.logicalCalcite
LogicalCalcA relational expression which computes project expressions and also filters.Classorg.apache.calcite.rel.logicalCalcite
LogicalChi not targeted at any particular engine or calling convention.Classorg.apache.calcite.rel.streamCalcite
LogicalCorrelateA relational operator that performs nested-loop joins.Classorg.apache.calcite.rel.logicalCalcite
LogicalDelta not targeted at any particular engine or calling convention.Classorg.apache.calcite.rel.streamCalcite
LogicalExchangeSub-class of Exchange not targeted at any particular engine or calling convention.Classorg.apache.calcite.rel.logicalCalcite
LogicalFilter not targeted at any particular engine or calling convention.Classorg.apache.calcite.rel.logicalCalcite
LogicalIntersectSub-class of Intersect not targeted at any particular engine or calling convention.Classorg.apache.calcite.rel.logicalCalcite
LogicalJoin not targeted at any particular engine or calling convention.Classorg.apache.calcite.rel.logicalCalcite
LogicalMinus not targeted at any particular engine or calling convention.Classorg.apache.calcite.rel.logicalCalcite
LogicalProjectSub-class of Project not targeted at any particular engine or calling convention.Classorg.apache.calcite.rel.logicalCalcite
LogicalSortSub-class of Sort not targeted at any particular engine or calling convention.Classorg.apache.calcite.rel.logicalCalcite
LogicalTableFunctionScanSub-class of TableFunctionScan not targeted at any particular engine or calling convention.Classorg.apache.calcite.rel.logicalCalcite
LogicalTableModifySub-class of TableModify not targeted at any particular engine or calling convention.Classorg.apache.calcite.rel.logicalCalcite
LogicalTableScanA LogicalTableScan reads all the rows from a If the table is a net.Classorg.apache.calcite.rel.logicalCalcite
LogicalUnion not targeted at any particular engine or calling convention.Classorg.apache.calcite.rel.logicalCalcite
LogicalValues not targeted at any particular engine or calling convention.Classorg.apache.calcite.rel.logicalCalcite
LogicalWindow not targeted at any particular engine or calling convention.Classorg.apache.calcite.rel.logicalCalcite
LogicVisitorVisitor pattern for traversing a tree of RexNode objects.Classorg.apache.calcite.rexCalcite
LongFunction1Function that takes one parameter and returns a native long value.Interfaceorg.apache.calcite.linq4j.functionCalcite
LookupRepresents a collection of keys each mapped to one or more values.Interfaceorg.apache.calcite.linq4jCalcite
LoptJoinTreeUtility class used to store a Join tree and the factors that make up the tree.Classorg.apache.calcite.rel.rulesCalcite
LoptMultiJoinUtility class that keeps track of the join factors that make up a MultiJoin.Classorg.apache.calcite.rel.rulesCalcite
LoptOptimizeJoinRulePlanner rule that implements the heuristic planner for determining optimal It is triggered by the patternClassorg.apache.calcite.rel.rulesCalcite
LoptSemiJoinOptimizer semi-joins to be used in processing joins in a query.Classorg.apache.calcite.rel.rulesCalcite
MainJetty handler that executes Avatica JSON request-responses.Classorg.apache.calcite.avatica.serverCalcite
MapAnnotation that indicates that a field is a map type.Classorg.apache.calcite.adapter.javaCalcite
MapIteratorCursor returns a Map for each row.Classorg.apache.calcite.avatica.utilCalcite
MappingA Mapping is a relationship between a source domain to target domain of integers.Interfaceorg.apache.calcite.util.mappingCalcite
MappingsUtility functions related to mappings.Classorg.apache.calcite.util.mappingCalcite
MappingTypeDescribes the type of a mapping, from the most general MULTI_FUNCTION (every element in the source and target domain canClassorg.apache.calcite.util.mappingCalcite
MapSqlTypeClassorg.apache.calcite.sql.typeCalcite
MatchReturnTypeInferenceReturns the first type that matches a set of given SqlTypeNames.Classorg.apache.calcite.sql.typeCalcite
MaterializationKeyUnique identifier for a materialization.Classorg.apache.calcite.materializeCalcite
MaterializationServiceManages the collection of materialized tables known to the system, and the process by which they become valid and invalid.Classorg.apache.calcite.materializeCalcite
MaterializedViewSubstitutionVisitorExtension to SubstitutionVisitor.Classorg.apache.calcite.planCalcite
MaterializedViewTableTable that is a materialized view.Classorg.apache.calcite.schema.implCalcite
MazeTableUser-defined table function that generates a Maze and prints it in textTable function that generates a maze.Classorg.apache.calcite.example.mazeCalcite
MemberA named expression in a schema.Interfaceorg.apache.calcite.schemaCalcite
MemberAssignmentRepresents assignment operation for a field or property of an object.Classorg.apache.calcite.linq4j.treeCalcite
MemberBindingProvides the base class from which the classes that represent bindings that are used to initialize members of a newly created object derive.Classorg.apache.calcite.linq4j.treeCalcite
MemberDeclarationDeclaration of a member of a class.Classorg.apache.calcite.linq4j.treeCalcite
MemberExpressionRepresents accessing a field or property.Classorg.apache.calcite.linq4j.treeCalcite
MemberInitExpressionClassorg.apache.calcite.linq4j.treeCalcite
MemberListBindingClassorg.apache.calcite.linq4j.treeCalcite
MemberMemberBindingRepresents initializing members of a member of a newly created object.Classorg.apache.calcite.linq4j.treeCalcite
MetaCommand handler for getting various metadata.Interfaceorg.apache.calcite.avaticaCalcite
MetadataMetadata about a relational expression.Interfaceorg.apache.calcite.rel.metadataCalcite
MetadataFactorySource of metadata about relational expressions.Interfaceorg.apache.calcite.rel.metadataCalcite
MetadataFactoryImpl RelMetadataProvider and stores them in a cache.Classorg.apache.calcite.rel.metadataCalcite
MetaDataOperationenum MetaDataOperationIdentifies an operation from DatabaseMetaData which returns a ResultSet.Classorg.apache.calcite.avatica.remoteCalcite
MetaImplBasic implementation of Meta.Classorg.apache.calcite.avaticaCalcite
MethodCallExpressionRepresents a call to either a static or an instance method.Classorg.apache.calcite.linq4j.treeCalcite
MethodDeclarationDeclaration of a method.Classorg.apache.calcite.linq4j.treeCalcite
MinusRelational expression that returns the rows of its first input minus any matching rows from its other inputs.Classorg.apache.calcite.rel.coreCalcite
MissingResultsExceptionAn Exception which denotes that a cached Statement is present but has no ResultSet.Classorg.apache.calcite.avaticaCalcite
MockJsonServiceMock implementation of Service that encodes its requests and responses as JSONClassorg.apache.calcite.avatica.remoteCalcite
MockProtobufServiceA mock implementation of ProtobufService for testing.Classorg.apache.calcite.avatica.remoteCalcite
ModelHandlerReads a model and creates schema objects accordingly.Classorg.apache.calcite.modelCalcite
ModifiableTableA table that can be modified.Interfaceorg.apache.calcite.schemaCalcite
ModifiableViewA modifiable view onto ModifiableTable.Interfaceorg.apache.calcite.schemaCalcite
MongoAggregateClassorg.apache.calcite.adapter.mongodbCalcite
MongoFilter relational expression in MongoDB.Classorg.apache.calcite.adapter.mongodbCalcite
MongoMethodBuiltin methods in the MongoDB adapter.Classorg.apache.calcite.adapter.mongodbCalcite
MongoProject relational expression in MongoDB.Classorg.apache.calcite.adapter.mongodbCalcite
MongoRelRelational expression that uses Mongo calling convention.Interfaceorg.apache.calcite.adapter.mongodbCalcite
MongoRulesRules and relational operators for calling convention.Classorg.apache.calcite.adapter.mongodbCalcite
MongoSchemaSchema mapped onto a directory of MONGO files.Classorg.apache.calcite.adapter.mongodbCalcite
MongoSchemaFactoryFactory that creates a MongoSchema.Classorg.apache.calcite.adapter.mongodbCalcite
MongoSort relational expression in MongoDB.Classorg.apache.calcite.adapter.mongodbCalcite
MongoTableTable based on a MongoDB collection.Classorg.apache.calcite.adapter.mongodbCalcite
MongoTableScanRelational expression representing a scan of a MongoDB collection.Classorg.apache.calcite.adapter.mongodbCalcite
MongoToEnumerableConverterRelational expression representing a scan of a table in a Mongo data source.Classorg.apache.calcite.adapter.mongodbCalcite
MongoToEnumerableConverterRuleRule to convert a relational expression from MongoRel.Classorg.apache.calcite.adapter.mongodbCalcite
MulticastRelOptListenerMulticastRelOptListener implements the RelOptListener interface by forwarding events on to a collection of other listeners.Classorg.apache.calcite.planCalcite
MultiJoinA MultiJoin represents a join of N inputs, whereas regular Joins represent strictly binary joins.Classorg.apache.calcite.rel.rulesCalcite
MultiJoinOptimizeBushyRulePlanner rule that finds an approximately optimal ordering for join operators using a heuristic algorithm.Classorg.apache.calcite.rel.rulesCalcite
MultiJoinProjectTransposeRuleMultiJoinProjectTransposeRule implements the rule for pulling LogicalProjects that are on top of aClassorg.apache.calcite.rel.rulesCalcite
MultisetOperandTypeCheckerParameter type-checking strategy types must be [nullable] Multiset, [nullable] Multiset and the two types must have the same element typeClassorg.apache.calcite.sql.typeCalcite
MultisetSqlTypeMultisetSqlType represents a standard SQL2003 multiset type.Classorg.apache.calcite.sql.typeCalcite
NestedBlockBuilderAllows to build nested code blocks with tracking of current context and the nullability of particular RexNode expressions.Interfaceorg.apache.calcite.adapter.enumerableCalcite
NestedBlockBuilderImplAllows to build nested code blocks with tracking of current context and the nullability of particular RexNode expressions.Classorg.apache.calcite.adapter.enumerableCalcite
NewArrayExpressionClassorg.apache.calcite.linq4j.treeCalcite
NewExpressionRepresents a constructor call.Classorg.apache.calcite.linq4j.treeCalcite
NlsStringA string, optionally with character set and SqlCollation.Classorg.apache.calcite.utilCalcite
NodeRelational expression that can be executed using an interpreter.Interfaceorg.apache.calcite.interpreterCalcite
NodeInterfaceorg.apache.calcite.linq4j.treeCalcite
NodesClassorg.apache.calcite.interpreterCalcite
NonDeterministicSpecifies that function is NOT deterministic (i.Classorg.apache.calcite.linq4j.functionCalcite
NoneConverterClassorg.apache.calcite.rel.convertCalcite
NoneToBindableConverterRuleRule to convert a relational expression from to BindableConvention.Classorg.apache.calcite.interpreterCalcite
NoSuchConnectionExceptionAn Exception that denotes that the given Connection is not cached.Classorg.apache.calcite.avaticaCalcite
NoSuchStatementExceptionAn Exception that denotes that the given Statement is not cached.Classorg.apache.calcite.avaticaCalcite
NotNullImplementorSimplified version of that does not know about null semantics.Interfaceorg.apache.calcite.adapter.enumerableCalcite
NullableBigDecimalFunction1Interfaceorg.apache.calcite.linq4j.functionCalcite
NullableDoubleFunction1Interfaceorg.apache.calcite.linq4j.functionCalcite
NullableFloatFunction1Interfaceorg.apache.calcite.linq4j.functionCalcite
NullableIntegerFunction1Interfaceorg.apache.calcite.linq4j.functionCalcite
NullableLongFunction1Interfaceorg.apache.calcite.linq4j.functionCalcite
NullCollationStrategy 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.Classorg.apache.calcite.configCalcite
NullPolicyDescribes when a function/operator will return null.Classorg.apache.calcite.adapter.enumerableCalcite
NumberUtilUtility functions for working with numbers This class is JDK 1.Classorg.apache.calcite.utilCalcite
ObjectEnumeratorCursor returns an Object for each row.Classorg.apache.calcite.runtimeCalcite
ObjectSqlTypeObjectSqlType represents an SQL structured user-defined type.Classorg.apache.calcite.sql.typeCalcite
OperandsTypeCheckingStrategies to check for allowed operand types of an operator call.Classorg.apache.calcite.sql.typeCalcite
OperandTypesStrategies for checking operand types.Classorg.apache.calcite.sql.typeCalcite
OptimizeVisitorVisitor that optimizes expressions.Classorg.apache.calcite.linq4j.treeCalcite
OpTypeClassorg.apache.calcite.linq4jCalcite
OrdPair of an element and an ordinal.Classorg.apache.calcite.linq4jCalcite
OrderByScopeRepresents the name-resolution context for expressions in an ORDER BY clause.Classorg.apache.calcite.sql.validateCalcite
OrderedEnumerableInterfaceorg.apache.calcite.linq4jCalcite
OrderedQueryableRepresents the result of applying a sorting operation to a Queryable.Interfaceorg.apache.calcite.linq4jCalcite
OrdinalReturnTypeInferenceReturns the type of the operand at a particular 0-based ordinal position.Classorg.apache.calcite.sql.typeCalcite
OverScopeThe name-resolution scope of a OVER clause.Classorg.apache.calcite.sql.validateCalcite
PackageMarkerThis is a dummy annotation that forces javac to produce output for otherwise empty package-info.Classorg.apache.calcite.avatica.utilCalcite
PackageMarkerThis is a dummy annotation that forces javac to produce output for otherwise empty package-info.Classorg.apache.calcite.linq4jCalcite
Pair Because a pair implements equals(Object), hashCode() and compareTo(Pair), it can be used in any kind ofClassorg.apache.calcite.utilCalcite
ParameterAnnotation that supplies metadata about a function parameter.Classorg.apache.calcite.linq4j.functionCalcite
ParameterExpressionRepresents a named parameter expression.Classorg.apache.calcite.linq4j.treeCalcite
ParameterScopeA scope which contains nothing besides a few parameters.Classorg.apache.calcite.sql.validateCalcite
ParserBenchmarkClassorg.apache.calcite.benchmarksCalcite
ParserBenchmark_jmhTypeClassorg.apache.calcite.benchmarks.generatedCalcite
ParserBenchmark_jmhType_B1Classorg.apache.calcite.benchmarks.generatedCalcite
ParserBenchmark_jmhType_B2Classorg.apache.calcite.benchmarks.generatedCalcite
ParserBenchmark_jmhType_B3Classorg.apache.calcite.benchmarks.generatedCalcite
ParserBenchmark_parseCached_jmhTestClassorg.apache.calcite.benchmarks.generatedCalcite
ParserBenchmark_parseNonCached_jmhTestClassorg.apache.calcite.benchmarks.generatedCalcite
PartiallyOrderedSetPartially-ordered set.Classorg.apache.calcite.utilCalcite
PathPath from a root schema to a particular object (schema, table, function).Interfaceorg.apache.calcite.schemaCalcite
PermutationRepresents a mapping which reorders elements in an array.Classorg.apache.calcite.utilCalcite
PhysTypePhysical type of a row.Interfaceorg.apache.calcite.adapter.enumerableCalcite
PhysTypeImplClassorg.apache.calcite.adapter.enumerableCalcite
PigRelBuilderExtension to RelBuilder for Pig relational operators.Classorg.apache.calcite.toolsCalcite
PlannerInterfaceorg.apache.calcite.toolsCalcite
PlannerImplClassorg.apache.calcite.prepareCalcite
PositionedCursorAbstract implementation of Cursor that caches its current row.Classorg.apache.calcite.avatica.utilCalcite
PreconditionTestClassorg.apache.calcite.benchmarksCalcite
Predicate1Function with one parameter returning a native boolean value.Interfaceorg.apache.calcite.linq4j.functionCalcite
Predicate2Function with two parameters returning a native boolean value.Interfaceorg.apache.calcite.linq4j.functionCalcite
PrepareAbstract base for classes that implement the process of preparing and executing SQL expressions.Classorg.apache.calcite.prepareCalcite
PrimitiveEnumeration of Java's primitive types.Classorg.apache.calcite.linq4j.treeCalcite
ProcedureNamespaceNamespace whose contents are defined by the result of a call to a user-defined procedure.Classorg.apache.calcite.sql.validateCalcite
ProgramProgram that transforms a relational expression into another relational A planner is a sequence of programs, each of which is sometimes calledInterfaceorg.apache.calcite.toolsCalcite
ProgramsUtilities for creating Programs.Classorg.apache.calcite.toolsCalcite
ProjectRelational expression that computes a set of 'select expressions' from its input relational expression.Classorg.apache.calcite.rel.coreCalcite
ProjectableFilterableTableTable that can be scanned, optionally applying supplied filter expressions, and projecting a given list of columns,Interfaceorg.apache.calcite.schemaCalcite
ProjectCalcMergeRulePlanner rule which merges a LogicalProject and aClassorg.apache.calcite.rel.rulesCalcite
ProjectFilterTransposeRuleClassorg.apache.calcite.rel.rulesCalcite
ProjectJoinTransposeRulePlanner rule that pushes a Project by splitting the projection into a projection on top of each child ofClassorg.apache.calcite.rel.rulesCalcite
ProjectMergeRuleProjectMergeRule merges a Project into provided the projects aren't projecting identical sets of input references.Classorg.apache.calcite.rel.rulesCalcite
ProjectMultiJoinMergeRulePlanner rule that pushes creating a richer MultiJoin.Classorg.apache.calcite.rel.rulesCalcite
ProjectNodeClassorg.apache.calcite.interpreterCalcite
ProjectRemoveRule given a Project node that merely returns its input, converts the node into its child.Classorg.apache.calcite.rel.rulesCalcite
ProjectSetOpTransposeRulePlanner rule that pushes The children of the SetOp will projectClassorg.apache.calcite.rel.rulesCalcite
ProjectSortTransposeRulePlanner rule that pushesSee Also:SortProjectTransposeRuleClassorg.apache.calcite.rel.rulesCalcite
ProjectTableScanRulePlanner rule that converts a Project of a ProjectableFilterableTableClassorg.apache.calcite.rel.rulesCalcite
ProjectToCalcRule LogicalProject to a The rule does not fire if the child is aClassorg.apache.calcite.rel.rulesCalcite
ProjectToWindowRulePlanner rule that slices a into sections which contain windowedClassorg.apache.calcite.rel.rulesCalcite
ProjectWindowTransposeRulePlanner rule that pushes past a LogicalWindow.Classorg.apache.calcite.rel.rulesCalcite
ProtobufHandlerDispatches serialized protocol buffer messages to the provided Service by converting them to the POJO Request.Classorg.apache.calcite.avatica.remoteCalcite
ProtobufServiceService implementation that encodes requests and responses as protocol buffers.Classorg.apache.calcite.avatica.remoteCalcite
ProtobufTranslationGeneric interface to support parsing of serialized protocol buffers between client and server.Interfaceorg.apache.calcite.avatica.remoteCalcite
ProtobufTranslationImpl protobuf requests to POJO requests.Classorg.apache.calcite.avatica.remoteCalcite
PruneEmptyRulesCollection of rules which remove sections of a query plan known never to Conventionally, the way to represent an empty relational expression isClassorg.apache.calcite.rel.rulesCalcite
PseudoFieldContains the parts of the Field class needed for code generation, but might be implemented differently.Interfaceorg.apache.calcite.linq4j.treeCalcite
PushProjectorPushProjector is a utility class used to perform operations used in push Pushing is particularly interesting in the case of join, because thereClassorg.apache.calcite.rel.rulesCalcite
QueryableProvides functionality to evaluate queries against a specific data source wherein the type of the data is known.Interfaceorg.apache.calcite.linq4jCalcite
QueryableDefaultsDefault implementations for methods in the Queryable interface.Classorg.apache.calcite.linq4jCalcite
QueryableFactoryFactory for building Queryable objects.Interfaceorg.apache.calcite.linq4jCalcite
QueryableRecorder and returns an object that can replay the event when you call its QueryableDefaults.Classorg.apache.calcite.linq4jCalcite
QueryableTableExtension to Table that can translate itself to a Queryable.Interfaceorg.apache.calcite.schemaCalcite
QueryProviderDefines methods to create and execute queries that are described by a Analogous to LINQ's System.Interfaceorg.apache.calcite.linq4jCalcite
QueryProviderImplPartial implementation of QueryProvider.Classorg.apache.calcite.linq4jCalcite
QueryStateClassorg.apache.calcite.avaticaCalcite
QuotingSyntax for quoting identifiers in SQL statements.Classorg.apache.calcite.avatica.utilCalcite
RawEnumerableExposes the enumerator, which supports a simple iteration over a collection, without the extension methods.Interfaceorg.apache.calcite.linq4jCalcite
RawQueryableCore methods that define a Queryable.Interfaceorg.apache.calcite.linq4jCalcite
RecordEnumeratorCursor returns a record for each row.Classorg.apache.calcite.runtimeCalcite
RecordIteratorCursor returns a record for each row.Classorg.apache.calcite.avatica.utilCalcite
ReduceDecimalsRuleReduceDecimalsRule is a rule which reduces decimal operations (such as casts or arithmetic) into operations involving more primitive types (such as longsClassorg.apache.calcite.rel.rulesCalcite
ReduceExpressionsRuleCollection of planner rules that apply various simplifying transformations on RexNode trees.Classorg.apache.calcite.rel.rulesCalcite
ReflectedPseudoFieldClassorg.apache.calcite.linq4j.treeCalcite
ReflectiveCallNotNullImplementor that calls a given Method.Classorg.apache.calcite.adapter.enumerableCalcite
ReflectiveConvertletTable any method of the form public RexNode convertXxx(ConvertletContext, SqlNode) or public RexNode convertXxx(ConvertletContext,Classorg.apache.calcite.sql2relCalcite
ReflectiveFunctionBase This class mainly solves conversion of method parameter types to List form.Classorg.apache.calcite.schema.implCalcite
ReflectiveRelMetadataProvider metadata methods to methods on a given object via reflection.Classorg.apache.calcite.rel.metadataCalcite
ReflectiveSchema public fields and methods in a Java object.Classorg.apache.calcite.adapter.javaCalcite
ReflectiveSqlOperatorTableReflectiveSqlOperatorTable implements the SqlOperatorTable interface by reflecting the public fields of a subclass.Classorg.apache.calcite.sql.utilCalcite
ReflectiveVisitDispatcherInterface for looking up methods relating to reflective visitation.Interfaceorg.apache.calcite.utilCalcite
ReflectiveVisitorObject which can be a target for a reflective visitation (see ReflectUtil.Interfaceorg.apache.calcite.utilCalcite
ReflectUtilStatic utilities for Java reflection.Classorg.apache.calcite.utilCalcite
RelBuilderBuilder for relational expressions.Classorg.apache.calcite.toolsCalcite
RelBuilderFactoryA partially-created RelBuilder.Interfaceorg.apache.calcite.toolsCalcite
RelCollationDescription of the physical ordering of a relational expression.Interfaceorg.apache.calcite.relCalcite
RelCollationImplSimple implementation of RelCollation.Classorg.apache.calcite.relCalcite
RelCollationsUtilities concerning RelCollation and RelFieldCollation.Classorg.apache.calcite.relCalcite
RelCollationTraitDefDefinition of the ordering trait.Classorg.apache.calcite.relCalcite
RelColumnMappingMapping from an input column of a RelNode to one of its output columns.Classorg.apache.calcite.rel.metadataCalcite
RelColumnOriginRelColumnOrigin is a data structure describing one of the origins of an output column produced by a relational expression.Classorg.apache.calcite.rel.metadataCalcite
RelConversionExceptionAn Exception thrown when attempting conversion to a set ofSee Also:Serialized FormClassorg.apache.calcite.toolsCalcite
RelCrossTypeType of the cartesian product of two or more sets of records.Classorg.apache.calcite.rel.typeCalcite
RelDataTypeRelDataType represents the type of a scalar expression or entire row returned from a relational expression.Interfaceorg.apache.calcite.rel.typeCalcite
RelDataTypeComparabilityenum RelDataTypeComparabilityRelDataTypeComparability is an enumeration of the categories of comparisonClassorg.apache.calcite.rel.typeCalcite
RelDataTypeFactoryRelDataTypeFactory is a factory for datatype descriptors.Interfaceorg.apache.calcite.rel.typeCalcite
RelDataTypeFactoryImplAbstract base for implementations of RelDataTypeFactory.Classorg.apache.calcite.rel.typeCalcite
RelDataTypeFieldRelDataTypeField represents the definition of a field in a structured Extends the Map.Interfaceorg.apache.calcite.rel.typeCalcite
RelDataTypeFieldImplDefault implementation of RelDataTypeField.Classorg.apache.calcite.rel.typeCalcite
RelDataTypeImplRelDataTypeImpl is an abstract base for implementations of Identity is based upon the digest field, which each derived classClassorg.apache.calcite.rel.typeCalcite
RelDataTypePrecedenceListRelDataTypePrecedenceList defines a type precedence list for a particularSQL 99 spec:Part 2 Section 9.Interfaceorg.apache.calcite.rel.typeCalcite
RelDataTypeSystem Provides behaviors concerning type limits and behaviors.Interfaceorg.apache.calcite.rel.typeCalcite
RelDataTypeSystemImplDefault implementation of providing parameters from the SQL standard.Classorg.apache.calcite.rel.typeCalcite
RelDecorrelatorRelDecorrelator replaces all correlated expressions (corExp) in a relational expression (RelNode) tree with non-correlated expressions that are producedClassorg.apache.calcite.sql2relCalcite
RelDistributionDescription of the physical distribution of a relational expression.Interfaceorg.apache.calcite.relCalcite
RelDistributionsUtilities concerning RelDistribution.Classorg.apache.calcite.relCalcite
RelDistributionTraitDefDefinition of the distribution trait.Classorg.apache.calcite.relCalcite
RelFactoriesClassorg.apache.calcite.rel.coreCalcite
RelFieldCollationDefinition of the ordering of one field of a RelNode whose output is to be sorted.Classorg.apache.calcite.relCalcite
RelFieldTrimmerTransformer that walks over a tree of relational expressions, replacing each RelNode with a 'slimmed down' relational expression that projectsClassorg.apache.calcite.sql2relCalcite
RelHomogeneousShuttleClassorg.apache.calcite.relCalcite
RelImplementorThis is a marker interface for a callback used to convert a tree of relational expressions into a plan.Interfaceorg.apache.calcite.planCalcite
RelInputContext from which a relational expression can initialize itself, reading from a serialized form of the relational expression.Interfaceorg.apache.calcite.relCalcite
RelJsonClassorg.apache.calcite.rel.externalizeCalcite
RelJsonReaderReads a JSON plan and converts it back to a tree of relational expressions.Classorg.apache.calcite.rel.externalizeCalcite
RelJsonWriterCallback for a relational expression to dump itself as JSON.Classorg.apache.calcite.rel.externalizeCalcite
RelMdCollationRelMdCollation supplies a default implementation of RelMetadataQuery.Classorg.apache.calcite.rel.metadataCalcite
RelMdColumnOriginsRelMdColumnOrigins supplies a default implementation of RelMetadataQuery.Classorg.apache.calcite.rel.metadataCalcite
RelMdColumnUniquenessRelMdColumnUniqueness supplies a default implementation of RelMetadataQuery.Classorg.apache.calcite.rel.metadataCalcite
RelMdDistinctRowCountRelMdDistinctRowCount supplies a default implementation of RelMetadataQuery.Classorg.apache.calcite.rel.metadataCalcite
RelMdDistributionRelMdCollation supplies a default implementation of RelMetadataQuery.Classorg.apache.calcite.rel.metadataCalcite
RelMdExplainVisibilityRelMdExplainVisibility supplies a default implementation of RelMetadataQuery.Classorg.apache.calcite.rel.metadataCalcite
RelMdMaxRowCountRelMdMaxRowCount supplies a default implementation of RelMetadataQuery.Classorg.apache.calcite.rel.metadataCalcite
RelMdMemoryDefault implementations of the BuiltInMetadata.Classorg.apache.calcite.rel.metadataCalcite
RelMdParallelismDefault implementations of the BuiltInMetadata.Classorg.apache.calcite.rel.metadataCalcite
RelMdPercentageOriginalRowsRelMdPercentageOriginalRows supplies a default implementation of RelMetadataQuery.Classorg.apache.calcite.rel.metadataCalcite
RelMdPopulationSizeRelMdPopulationSize supplies a default implementation of RelMetadataQuery.Classorg.apache.calcite.rel.metadataCalcite
RelMdPredicatesUtility to infer Predicates that are applicable above a RelNode.Classorg.apache.calcite.rel.metadataCalcite
RelMdRowCountRelMdRowCount supplies a default implementation of RelMetadataQuery.Classorg.apache.calcite.rel.metadataCalcite
RelMdSelectivityRelMdSelectivity supplies a default implementation of RelMetadataQuery.Classorg.apache.calcite.rel.metadataCalcite
RelMdSizeDefault implementations of the BuiltInMetadata.Classorg.apache.calcite.rel.metadataCalcite
RelMdUniqueKeysRelMdUniqueKeys supplies a default implementation of RelMetadataQuery.Classorg.apache.calcite.rel.metadataCalcite
RelMdUtilRelMdUtil provides utility methods used by the metadata provider methods.Classorg.apache.calcite.rel.metadataCalcite
RelMetadataProviderRelMetadataProvider defines an interface for obtaining metadata about relational expressions.Interfaceorg.apache.calcite.rel.metadataCalcite
RelMetadataQueryRelMetadataQuery provides a strongly-typed facade on top of RelMetadataProvider for the set of relational expression metadataClassorg.apache.calcite.rel.metadataCalcite
RelMultipleTraitTrait for which a given relational expression can have multiple values.Interfaceorg.apache.calcite.planCalcite
RelNodeA RelNode is a relational expression.Interfaceorg.apache.calcite.relCalcite
RelNodesUtilities concerning relational expressions.Classorg.apache.calcite.relCalcite
RelOptAbstractTablePartial implementation of RelOptTable.Classorg.apache.calcite.planCalcite
RelOptClusterAn environment for related relational expressions during the optimization of a query.Classorg.apache.calcite.planCalcite
RelOptConnectionThe planner's view of a connection to a database.Interfaceorg.apache.calcite.planCalcite
RelOptCostRelOptCost defines an interface for optimizer cost in terms of number of rows processed, CPU cost, and I/O cost.Interfaceorg.apache.calcite.planCalcite
RelOptCostFactoryCost model for query planning.Interfaceorg.apache.calcite.planCalcite
RelOptCostImplRelOptCostImpl provides a default implementation for the RelOptCost interface.Classorg.apache.calcite.planCalcite
RelOptLatticeUse of a lattice by the query optimizer.Classorg.apache.calcite.planCalcite
RelOptListenerRelOptListener defines an interface for listening to events which occur during the optimization process.Interfaceorg.apache.calcite.planCalcite
RelOptMaterializationRecords that a particular query is materialized by a particular table.Classorg.apache.calcite.planCalcite
RelOptNodeReturns the cluster this relational expression belongs to.Interfaceorg.apache.calcite.planCalcite
RelOptPlannerA RelOptPlanner is a query optimizer: it transforms a relational expression into a semantically equivalent relational expression, according toInterfaceorg.apache.calcite.planCalcite
RelOptPredicateListPredicates that are known to hold in the output of a particular relational Pulled up predicates (field pulledUpPredicates areClassorg.apache.calcite.planCalcite
RelOptQueryA RelOptQuery represents a set of relational expressions which derive from the sameClassorg.apache.calcite.planCalcite
RelOptRuleA RelOptRule transforms an expression into another.Classorg.apache.calcite.planCalcite
RelOptRuleCallA RelOptRuleCall is an invocation of a RelOptRule with a set of relational expressions as arguments.Classorg.apache.calcite.planCalcite
RelOptRuleOperandOperand that determines whether a RelOptRule can be applied to a particular expression.Classorg.apache.calcite.planCalcite
RelOptRuleOperandChildPolicyenum RelOptRuleOperandChildPolicyPolicy by which operands will be matched by relational expressions withClassorg.apache.calcite.planCalcite
RelOptRuleOperandChildrenChildren of a RelOptRuleOperand and the policy for matching them.Classorg.apache.calcite.planCalcite
RelOptSamplingParametersRelOptSamplingParameters represents the parameters necessary to produce a sample of a relation.Classorg.apache.calcite.planCalcite
RelOptSchemaA RelOptSchema is a set of RelOptTable objects.Interfaceorg.apache.calcite.planCalcite
RelOptSchemaWithSamplingExtension to RelOptSchema with support for sample data-sets.Interfaceorg.apache.calcite.planCalcite
RelOptTableRepresents a relational dataset in a RelOptSchema.Interfaceorg.apache.calcite.planCalcite
RelOptTableImplClassorg.apache.calcite.prepareCalcite
RelOptUtilClassorg.apache.calcite.planCalcite
RelProtoDataTypeCan be converted into a RelDataType given a RelDataTypeFactory.Interfaceorg.apache.calcite.rel.typeCalcite
RelRecordTypeRelRecordType represents a structured type having named fields.Classorg.apache.calcite.rel.typeCalcite
RelRootRoot of a tree of RelNode.Classorg.apache.calcite.relCalcite
RelRunnerRuns a relational expression.Interfaceorg.apache.calcite.toolsCalcite
RelRunnersRuns a relational expression by creating a JDBC connection.Classorg.apache.calcite.toolsCalcite
RelShuttleVisitor that has methods for the common logical relational expressions.Interfaceorg.apache.calcite.relCalcite
RelShuttleImplBasic implementation of RelShuttle that calls RelNode.Classorg.apache.calcite.relCalcite
RelStructuredTypeFlattenerRelStructuredTypeFlattener removes all structured types from a tree of relational expressions.Classorg.apache.calcite.sql2relCalcite
RelSubsetSubset of an equivalence class where all relational expressions have the same physical properties.Classorg.apache.calcite.plan.volcanoCalcite
RelToSqlConverterUtility to convert relational expressions to SQL abstract syntax tree.Classorg.apache.calcite.rel.rel2sqlCalcite
RelTraitRelTrait represents the manifestation of a relational expression trait within a trait definition.Interfaceorg.apache.calcite.planCalcite
RelTraitDefRelTraitDef represents a class of RelTraits.Classorg.apache.calcite.planCalcite
RelTraitPropagationVisitorRelTraitPropagationVisitor traverses a RelNode and its unregistered children, making sure that each has a full complement of traits.Classorg.apache.calcite.planCalcite
RelTraitSetRelTraitSet represents an ordered set of RelTraits.Classorg.apache.calcite.planCalcite
RelVisitorA RelVisitor is a Visitor role in the visitor pattern andClassorg.apache.calcite.relCalcite
RelWriterCallback for an expression to dump itself to.Interfaceorg.apache.calcite.relCalcite
RelWriterImplClassorg.apache.calcite.rel.externalizeCalcite
RelXmlWriterCallback for a relational expression to dump in XML format.Classorg.apache.calcite.rel.externalizeCalcite
RemoteProtobufServiceProtobufService implementation that queries against a remote implementation, using protocol buffers as the serialized form.Classorg.apache.calcite.avatica.remoteCalcite
RemoteService that translates requests into JSON and sends them to a remote server, usually an HTTP server.Classorg.apache.calcite.avatica.remoteCalcite
RequestsClassorg.apache.calcite.avatica.protoCalcite
RequestTranslatorEncapsulate the logic of transforming a protobuf Request message into the Avatica POJO request.Classorg.apache.calcite.avatica.remoteCalcite
ResourcesDefining wrapper classes around resources that allow the compiler to check whether the resources exist and have the argument types that your codeClassorg.apache.calcite.runtimeCalcite
ResponsesClassorg.apache.calcite.avatica.protoCalcite
ResponseTranslatorEncapsulate the logic of transforming a protobuf Response message into the Avatica POJO Response.Classorg.apache.calcite.avatica.remoteCalcite
ResultSetEnumerableExecutes a SQL statement and returns the result as an Enumerable.Classorg.apache.calcite.runtimeCalcite
ReturnTypesA collection of return-type inference strategies.Classorg.apache.calcite.sql.typeCalcite
RexActionA RexAction is called when a RexPattern finds a match.Interfaceorg.apache.calcite.rexCalcite
RexBiVisitorVisitor pattern for traversing a tree of RexNode objects and passing a payload to each.Interfaceorg.apache.calcite.rexCalcite
RexBuilderFactory for row expressions.Classorg.apache.calcite.rexCalcite
RexCallAn expression formed by a call to an operator with zero or more expressions Operators may be binary, unary, functions, special syntactic constructsClassorg.apache.calcite.rexCalcite
RexCallBindingRexCallBinding implements SqlOperatorBinding by referring to an underlying collection of RexNode operands.Classorg.apache.calcite.rexCalcite
RexCheckerVisitor which checks the validity of a RexNode expression.Classorg.apache.calcite.rexCalcite
RexCorrelVariableReference to the current row of a correlating relational expression.Classorg.apache.calcite.rexCalcite
RexDynamicParamDynamic parameter reference in a row-expression.Classorg.apache.calcite.rexCalcite
RexExecutableResult of compiling code generated from a RexNode expression.Classorg.apache.calcite.rexCalcite
RexExecutorImplEvaluates a RexNode expression.Classorg.apache.calcite.rexCalcite
RexFieldAccessAccess to a field of a row-expression.Classorg.apache.calcite.rexCalcite
RexFieldCollationExpression combined with sort flags (DESCENDING, NULLS LAST).Classorg.apache.calcite.rexCalcite
RexImplicationCheckerChecks whether one condition logically implies another.Classorg.apache.calcite.planCalcite
RexImpTableContains implementations of Rex operators as Java code.Classorg.apache.calcite.adapter.enumerableCalcite
RexInputRefVariable which references a field of an input relational expression.Classorg.apache.calcite.rexCalcite
RexLiteralConstant value in a row-expression.Classorg.apache.calcite.rexCalcite
RexLocalRef Identity is based upon type and index.Classorg.apache.calcite.rexCalcite
RexMultisetUtilUtility class for various methods related to multisets.Classorg.apache.calcite.rexCalcite
RexNode Every row-expression has a type.Classorg.apache.calcite.rexCalcite
RexOverCall to an aggregate function over a window.Classorg.apache.calcite.rexCalcite
RexPatternA RexPattern represents an expression with holes in it.Interfaceorg.apache.calcite.rexCalcite
RexPermutationShuttleVisitor which replaces RexLocalRef objects after the expressions in a RexProgram have been reordered.Classorg.apache.calcite.rexCalcite
RexPermuteInputsShuttleShuttle which applies a permutation to its input fields.Classorg.apache.calcite.rexCalcite
RexProgramA collection of expressions which read inputs, compute output expressions, and optionally use a condition to filter rows.Classorg.apache.calcite.rexCalcite
RexProgramBuilderWorkspace for constructing a RexProgram.Classorg.apache.calcite.rexCalcite
RexRangeRefReference to a range of columns.Classorg.apache.calcite.rexCalcite
RexShuttlePasses over a row-expression, calling a handler method for each node, appropriate to the type of the node.Classorg.apache.calcite.rexCalcite
RexSlotAbstract base class for RexInputRef and RexLocalRef.Classorg.apache.calcite.rexCalcite
RexSqlConvertletConverts a RexNode expression into a SqlNode expression.Interfaceorg.apache.calcite.rexCalcite
RexSqlConvertletTableCollection of RexSqlConvertlets.Interfaceorg.apache.calcite.rexCalcite
RexSqlReflectiveConvertletTableClassorg.apache.calcite.rexCalcite
RexSqlStandardConvertletTableStandard implementation of RexSqlConvertletTable.Classorg.apache.calcite.rexCalcite
RexSubQueryScalar expression that represents an IN, EXISTS or scalar sub-query.Classorg.apache.calcite.rexCalcite
RexToLixTranslatorTranslates REX expressions to linq4j expressions.Classorg.apache.calcite.adapter.enumerableCalcite
RexToSqlNodeConverterConverts expressions from RexNode to SqlNode.Interfaceorg.apache.calcite.rexCalcite
RexToSqlNodeConverterImplStandard implementation of RexToSqlNodeConverter.Classorg.apache.calcite.rexCalcite
RexTransformerTakes a tree of RexNode objects and transforms it into another in one sense equivalent tree.Classorg.apache.calcite.rexCalcite
RexUtilUtility methods concerning row-expressions.Classorg.apache.calcite.rexCalcite
RexVariableA row-expression which references a field.Classorg.apache.calcite.rexCalcite
RexVisitorVisitor pattern for traversing a tree of RexNode objects.Interfaceorg.apache.calcite.rexCalcite
RexVisitorImplDefault implementation of RexVisitor, which visits each node but does nothing while it's there.Classorg.apache.calcite.rexCalcite
RexWindowSpecification of the window of rows over which a RexOver windowed aggregate is evaluated.Classorg.apache.calcite.rexCalcite
RexWindowBoundClassorg.apache.calcite.rexCalcite
RowClassorg.apache.calcite.interpreterCalcite
RuleSetA set rules associated with a particular type of invocation of the Planner.Interfaceorg.apache.calcite.toolsCalcite
RuleSetsUtilities for creating and composing rule sets.Classorg.apache.calcite.toolsCalcite
SaffronPropertiesProvides an environment for debugging information, et cetera, used by getIntProperty(java.Classorg.apache.calcite.utilCalcite
SameOperandTypeCheckerParameter type-checking strategy where all operand types must be the same.Classorg.apache.calcite.sql.typeCalcite
SampleRelational expression that returns a sample of the rows from its input.Classorg.apache.calcite.rel.coreCalcite
ScalarCompiled scalar expression.Interfaceorg.apache.calcite.interpreterCalcite
ScalarFunctionFunction that returns a scalar result.Interfaceorg.apache.calcite.schemaCalcite
ScalarFunctionImplClassorg.apache.calcite.schema.implCalcite
ScannableTableTable that can be scanned without creating an intermediate relationalReturns an enumerator over the rows in this Table.Interfaceorg.apache.calcite.schemaCalcite
SchemaA namespace for tables and functions.Interfaceorg.apache.calcite.schemaCalcite
SchemaFactoryFactory for Schema objects.Interfaceorg.apache.calcite.schemaCalcite
SchemaPlusExtension to the Schema interface.Interfaceorg.apache.calcite.schemaCalcite
SchemasUtility functions for schemas.Classorg.apache.calcite.schemaCalcite
SearchResultListenerCalled each time a search returns a record.Interfaceorg.apache.calcite.adapter.splunk.searchCalcite
SelectNamespaceNamespace offered by a subquery.Classorg.apache.calcite.sql.validateCalcite
SelectScopeThe name-resolution scope of a SELECT clause.Classorg.apache.calcite.sql.validateCalcite
SemiJoinRelational expression that joins two relational expressions according to some condition, but outputs only columns from the left input, and eliminatesClassorg.apache.calcite.rel.coreCalcite
SemiJoinFilterTransposeRulePlanner rule that pushes SemiJoins down in a tree pastClassorg.apache.calcite.rel.rulesCalcite
SemiJoinJoinTransposeRulePlanner rule that pushes a SemiJoin down in a tree past a JoinClassorg.apache.calcite.rel.rulesCalcite
SemiJoinProjectTransposeRulePlanner rule that pushes a SemiJoin down in a tree pastClassorg.apache.calcite.rel.rulesCalcite
SemiJoinRemoveRulePlanner rule that removes a SemiJoins It is invoked after attempts have been made to convert a SemiJoin to anClassorg.apache.calcite.rel.rulesCalcite
SemiJoinRuleClassorg.apache.calcite.rel.rulesCalcite
SemiJoinTypeEnumeration representing different join types used in correlationEnum Constant SummaryClassorg.apache.calcite.sqlCalcite
SemiMutableSchemaSchema to which materializations can be added.Interfaceorg.apache.calcite.schemaCalcite
SerializableCharsetSerializable wrapper around a Charset.Classorg.apache.calcite.utilCalcite
ServiceAPI for request-response calls to an Avatica server.Interfaceorg.apache.calcite.avatica.remoteCalcite
SetOpSetOp is an abstract base for relational set operators such as UNION, MINUS (aka EXCEPT), and INTERSECT.Classorg.apache.calcite.rel.coreCalcite
SetopNamespaceNamespace based upon a set operation (UNION, INTERSECT, EXCEPT).Classorg.apache.calcite.sql.validateCalcite
SetopOperandTypeCheckerParameter type-checking strategy for a set operator (UNION, INTERSECT, Both arguments must be records with the same number of fields, and theClassorg.apache.calcite.sql.typeCalcite
SingleRelAbstract base class for relational expressions with a single input.Classorg.apache.calcite.relCalcite
SinkSink to which to send rows.Interfaceorg.apache.calcite.interpreterCalcite
SocketFactoryImpl created sockets inherit a set of options whose values are set in the 1.Classorg.apache.calcite.adapter.splunk.utilCalcite
SortRelational expression that imposes a particular sort order on its input without otherwise changing its content.Classorg.apache.calcite.rel.coreCalcite
SortedMultiMapMap that allows you to partition values into lists according to a common key, and then convert those lists into an iterator of sorted arrays.Classorg.apache.calcite.runtimeCalcite
SortExchangeRelational expression that performs Exchange and Sort Whereas a Sort produces output with a particularClassorg.apache.calcite.rel.coreCalcite
SortJoinTransposeRulePlanner rule that pushes a Sort past a At the moment, we only consider left/right outer joins.Classorg.apache.calcite.rel.rulesCalcite
SortNodeClassorg.apache.calcite.interpreterCalcite
SortProjectTransposeRulePlanner rule that pushesSee Also:ProjectSortTransposeRuleClassorg.apache.calcite.rel.rulesCalcite
SortRemoveRulePlanner rule that removes a Sort if its input is already sorted.Classorg.apache.calcite.rel.rulesCalcite
SortUnionTransposeRuleClassorg.apache.calcite.rel.rulesCalcite
Source Corresponds to an input of a relational expression.Interfaceorg.apache.calcite.interpreterCalcite
SpacerEfficiently writes strings of spaces.Classorg.apache.calcite.avatica.utilCalcite
SpacesUtilities for creating strings of spaces.Classorg.apache.calcite.avatica.utilCalcite
SparkHandlerImpl CalcitePrepare.Classorg.apache.calcite.adapter.sparkCalcite
SparkMethodBuilt-in methods in the Spark adapter.Classorg.apache.calcite.adapter.sparkCalcite
SparkRelRelational expression that uses Spark calling convention.Interfaceorg.apache.calcite.adapter.sparkCalcite
SparkRulesRules for the Spark calling convention.Classorg.apache.calcite.adapter.sparkCalcite
SparkRuntimeRuntime utilities for Calcite's Spark adapter.Classorg.apache.calcite.adapter.sparkCalcite
SparkToEnumerableConverterRelational expression that converts input of into EnumerableConvention.Classorg.apache.calcite.adapter.sparkCalcite
SplunkConnectionConnection to Splunk.Interfaceorg.apache.calcite.adapter.splunk.searchCalcite
SplunkConnectionImplClassorg.apache.calcite.adapter.splunk.searchCalcite
SplunkDriverJDBC driver for Splunk.Classorg.apache.calcite.adapter.splunkCalcite
SplunkPushDownRulePlanner rule to push filters and projections to Splunk.Classorg.apache.calcite.adapter.splunkCalcite
SplunkQueryQuery against Splunk.Classorg.apache.calcite.adapter.splunkCalcite
SplunkSchemaClassorg.apache.calcite.adapter.splunkCalcite
SplunkTableScanRelational expression representing a scan of Splunk.Classorg.apache.calcite.adapter.splunkCalcite
SqlAbstractGroupFunctionClassorg.apache.calcite.sql.funCalcite
SqlAbstractParserImplAbstract base for parsers generated from CommonParser.Classorg.apache.calcite.sql.parserCalcite
SqlAbstractTimeFunctionBase class for time functions such as LOCALTIME, LOCALTIME(n).Classorg.apache.calcite.sql.funCalcite
SqlAccessEnumEnumeration representing different access typesEnum Constant SummaryClassorg.apache.calcite.sqlCalcite
SqlAccessTypeClassorg.apache.calcite.sqlCalcite
SqlAdvisorAn assistant which offers hints and corrections to a partially-formed SQL statement.Classorg.apache.calcite.sql.adviseCalcite
SqlAdvisorGetHintsFunctionTable function that returns completion hints for a given SQL statement.Classorg.apache.calcite.sql.adviseCalcite
SqlAdvisorHintThis class is used to return values for (String, int, String[]).Classorg.apache.calcite.sql.adviseCalcite
SqlAdvisorValidatorSqlAdvisorValidator is used by SqlAdvisor to traverse the parse tree of a SQL statement, not for validation purpose but for settingClassorg.apache.calcite.sql.adviseCalcite
SqlAggFunctionAbstract base class for the definition of an aggregate function: an operator which aggregates sets of values into a result.Classorg.apache.calcite.sqlCalcite
SqlArrayQueryConstructorClassorg.apache.calcite.sql.funCalcite
SqlArrayValueConstructorClassorg.apache.calcite.sql.funCalcite
SqlAsOperatorThe AS operator associates an expression with an alias.Classorg.apache.calcite.sqlCalcite
SqlAvgAggFunctionAvg is an aggregator which returns the average of the values which go into it.Classorg.apache.calcite.sql.funCalcite
SqlBasicCallClassorg.apache.calcite.sqlCalcite
SqlBasicVisitorBasic implementation of SqlVisitor which does nothing at each node.Classorg.apache.calcite.sql.utilCalcite
SqlBetweenOperatorDefines the BETWEEN operator.Classorg.apache.calcite.sql.funCalcite
SqlBinaryOperatorSqlBinaryOperator is a binary operator.Classorg.apache.calcite.sqlCalcite
SqlBinaryStringLiteralA binary (or hexadecimal) string literal.Classorg.apache.calcite.sqlCalcite
SqlBuilderExtension to StringBuilder for the purposes of creating SQL queries Using this class helps to prevent SQL injection attacks, incorrectlyClassorg.apache.calcite.sql.utilCalcite
SqlCallA SqlCall is a call to an operator.Classorg.apache.calcite.sqlCalcite
SqlCallBindingSqlCallBinding implements SqlOperatorBinding by analyzing to the operands of a SqlCall with a SqlValidator.Classorg.apache.calcite.sqlCalcite
SqlCaseA SqlCase is a node of a parse tree which represents a case statement.Classorg.apache.calcite.sql.funCalcite
SqlCaseOperatorAn operator describing a CASE, NULLIF or COALESCE expression.Classorg.apache.calcite.sql.funCalcite
SqlCastFunctionSqlCastFunction.Classorg.apache.calcite.sql.funCalcite
SqlCharStringLiteralA character string literal.Classorg.apache.calcite.sqlCalcite
SqlCoalesceFunctionThe COALESCE function.Classorg.apache.calcite.sql.funCalcite
SqlCollationA SqlCollation is an object representing a Collate statement.Classorg.apache.calcite.sqlCalcite
SqlCollectionTableOperatorSqlCollectionTableOperator is the table function derived table operator.Classorg.apache.calcite.sql.funCalcite
SqlColumnListConstructorSqlColumnListConstructor defines the non-standard constructor used to pass a COLUMN_LIST parameter to a UDX.Classorg.apache.calcite.sql.funCalcite
SqlConformanceEnumeration of valid SQL compatiblity modes.Classorg.apache.calcite.sql.validateCalcite
SqlConvertFunctionClassorg.apache.calcite.sql.funCalcite
SqlCountAggFunctionDefinition of the SQL COUNT aggregation function.Classorg.apache.calcite.sql.funCalcite
SqlCovarAggFunctionCovar is an aggregator which returns the Covariance of the values which go into it.Classorg.apache.calcite.sql.funCalcite
SqlCurrentDateFunctionThe CURRENT_DATE function.Classorg.apache.calcite.sql.funCalcite
SqlCursorConstructorClassorg.apache.calcite.sql.funCalcite
SqlDataTypeSpecRepresents a SQL data type specification in a parse tree.Classorg.apache.calcite.sqlCalcite
SqlDateLiteralA SQL literal representing a DATE value, such as DATE Create values using SqlLiteral.Classorg.apache.calcite.sqlCalcite
SqlDatetimeSubtractionOperatorA special operator for the subtraction of two DATETIMEs.Classorg.apache.calcite.sql.funCalcite
SqlDeleteClassorg.apache.calcite.sqlCalcite
SqlDialectSqlDialect encapsulates the differences between dialects of SQL.Classorg.apache.calcite.sqlCalcite
SqlDynamicParamA SqlDynamicParam represents a dynamic parameter marker in an SQL statement.Classorg.apache.calcite.sqlCalcite
SqlExplainA SqlExplain is a node of a parse tree which represents an EXPLAIN PLAN statement.Classorg.apache.calcite.sqlCalcite
SqlExplainLevelenum SqlExplainLevelSqlExplainLevel defines detail levels for EXPLAIN PLAN.Classorg.apache.calcite.sqlCalcite
SqlExtractFunctionThe SQL EXTRACT operator.Classorg.apache.calcite.sql.funCalcite
SqlFilterOperatorAn operator that applies a filter before rows are included in an aggregate Operands are as follows:Classorg.apache.calcite.sqlCalcite
SqlFirstLastValueAggFunctionFIRST_VALUE and LAST_VALUE aggregate functions return the first or the last value in a list of values that are input to theClassorg.apache.calcite.sql.funCalcite
SqlFloorFunctionDefinition of the FLOOR and CEIL built-in SQL functions.Classorg.apache.calcite.sql.funCalcite
SqlFormatOptionsData structure to hold options for SqlPrettyWriter.Classorg.apache.calcite.sql.prettyCalcite
SqlFunctionA SqlFunction is a type of operator which has conventional function-call syntax.Classorg.apache.calcite.sqlCalcite
SqlFunctionalOperatorClassorg.apache.calcite.sqlCalcite
SqlFunctionCategoryenum SqlFunctionCategoryEnumeration of the categories ofClassorg.apache.calcite.sqlCalcite
SqlFunctionsHelper methods to implement SQL functions in generated code.Classorg.apache.calcite.runtimeCalcite
SqlHistogramAggFunctionHISTOGRAM is the base operator that supports the Histogram MIN/MAX aggregate functions.Classorg.apache.calcite.sql.funCalcite
SqlIdentifierA SqlIdentifier is an identifier, possibly compound.Classorg.apache.calcite.sqlCalcite
SqlIdentifierMonikerAn implementation of SqlMoniker that encapsulates the normalized name information of a SqlIdentifier.Classorg.apache.calcite.sql.validateCalcite
SqlImplementorState for generating a SQL statement.Classorg.apache.calcite.rel.rel2sqlCalcite
SqlInfixOperatorA generalization of a binary operator to involve several (two or more) arguments, and keywords between each pair of arguments.Classorg.apache.calcite.sqlCalcite
SqlInOperatorDefinition of the SQL IN operator, which tests for a value's membership in a subquery or a list of values.Classorg.apache.calcite.sql.funCalcite
SqlInsertClassorg.apache.calcite.sqlCalcite
SqlInsertKeywordenum SqlInsertKeywordDefines the keywords that can occur immediately after the INSERT keyword.Classorg.apache.calcite.sqlCalcite
SqlInternalOperatorGeneric operator for nodes with internal syntax.Classorg.apache.calcite.sqlCalcite
SqlIntervalLiteralA SQL literal representing a time interval.Classorg.apache.calcite.sqlCalcite
SqlIntervalQualifierRepresents an INTERVAL qualifier.Classorg.apache.calcite.sqlCalcite
SqlJdbcFunctionCallA SqlJdbcFunctionCall is a node of a parse tree which represents a JDBC function call.Classorg.apache.calcite.sqlCalcite
SqlJoinParse tree node representing a JOIN clause.Classorg.apache.calcite.sqlCalcite
SqlKindEnumerates the possible types of SqlNode.Classorg.apache.calcite.sqlCalcite
SqlLeadLagAggFunctionLEAD and LAG aggregate functions return the value of given expression evaluated at given offset.Classorg.apache.calcite.sql.funCalcite
SqlLikeOperatorAn operator describing the LIKE and SIMILAR Syntax of the two operators:Classorg.apache.calcite.sql.funCalcite
SqlLiteralA SqlLiteral is a constant.Classorg.apache.calcite.sqlCalcite
SqlLiteralChainOperatorInternal operator, by which the parser represents a continued string literal.Classorg.apache.calcite.sql.funCalcite
SqlMapQueryConstructorDefinition of the MAP query constructor, Like the MAP type, not standard SQL.Classorg.apache.calcite.sql.funCalcite
SqlMapValueConstructorDefinition of the MAP constructor, MAP [, , .Classorg.apache.calcite.sql.funCalcite
SqlMergeClassorg.apache.calcite.sqlCalcite
SqlMinMaxAggFunctionDefinition of the MIN and MAX aggregate functions, returning the returns the smallest/largest of the values which go into it.Classorg.apache.calcite.sql.funCalcite
SqlModalityRelational or streaming.Classorg.apache.calcite.sql.validateCalcite
SqlMonikerInterfaceorg.apache.calcite.sql.validateCalcite
SqlMonikerImplA generic implementation of SqlMoniker.Classorg.apache.calcite.sql.validateCalcite
SqlMonikerTypeAn enumeration of moniker types.Classorg.apache.calcite.sql.validateCalcite
SqlMonotonicBinaryOperatorBase class for binary operators such as addition, subtraction, and multiplication which are monotonic for the patterns m op c andClassorg.apache.calcite.sql.funCalcite
SqlMonotonicityenum SqlMonotonicityEnumeration of types of monotonicity.Classorg.apache.calcite.sql.validateCalcite
SqlMonotonicUnaryFunctionClassorg.apache.calcite.sql.funCalcite
SqlMultisetMemberOfOperatorMultiset MEMBER OF.Classorg.apache.calcite.sql.funCalcite
SqlMultisetQueryConstructorDefinition of the SQL:2003 standard MULTISET query constructor, MULTISET ().Classorg.apache.calcite.sql.funCalcite
SqlMultisetSetOperatorAn operator which performs set operations on multisets, such as MULTISET Not to be confused with SqlMultisetValueConstructor orClassorg.apache.calcite.sql.funCalcite
SqlMultisetValueConstructorDefinition of the SQL:2003 standard MULTISET constructor, MULTISET Derived classes construct other kinds of collections.Classorg.apache.calcite.sql.funCalcite
SqlNewOperatorSqlNewOperator represents an SQL new specification such as NEW UDT(1, 2).Classorg.apache.calcite.sql.funCalcite
SqlNodeA SqlNode is a SQL parse tree.Classorg.apache.calcite.sqlCalcite
SqlNodeListA SqlNodeList is a list of SqlNodes.Classorg.apache.calcite.sqlCalcite
SqlNodeToRexConverterConverts expressions from SqlNode to RexNode.Interfaceorg.apache.calcite.sql2relCalcite
SqlNodeToRexConverterImplStandard implementation of SqlNodeToRexConverter.Classorg.apache.calcite.sql2relCalcite
SqlNtileAggFunctionNTILE aggregate function return the value of given expression evaluated at given offset.Classorg.apache.calcite.sql.funCalcite
SqlNullifFunctionThe NULLIF function.Classorg.apache.calcite.sql.funCalcite
SqlNullSemanticsenum SqlNullSemanticsSqlNullSemantics defines the possible comparison rules for values which mightClassorg.apache.calcite.sqlCalcite
SqlNumericLiteralA numeric SQL literal.Classorg.apache.calcite.sqlCalcite
SqlOperandCountRangeA class that describes how many operands an operator can take.Interfaceorg.apache.calcite.sqlCalcite
SqlOperandCountRangesHelpers for SqlOperandCountRange.Classorg.apache.calcite.sql.typeCalcite
SqlOperandTypeCheckerStrategy interface to check for allowed operand types of an operator call.Interfaceorg.apache.calcite.sql.typeCalcite
SqlOperandTypeInferenceStrategy to infer unknown types of the operands of an operator call.Interfaceorg.apache.calcite.sql.typeCalcite
SqlOperatorA SqlOperator is a type of node in a SQL parse tree (it is NOT a node in a SQL parse tree).Classorg.apache.calcite.sqlCalcite
SqlOperatorBindingSqlOperatorBinding represents the binding of an SqlOperator to actual operands, along with any additional informationClassorg.apache.calcite.sqlCalcite
SqlOperatorTableSqlOperatorTable defines a directory interface for enumerating and looking up SQL operators and functions.Interfaceorg.apache.calcite.sqlCalcite
SqlOrderByParse tree node that represents an ORDER BY on a query other than a SELECT (e.Classorg.apache.calcite.sqlCalcite
SqlOverlapsOperatorSqlOverlapsOperator represents the SQL:1999 standard OVERLAPS function.Classorg.apache.calcite.sql.funCalcite
SqlOverlayFunctionThe OVERLAY function.Classorg.apache.calcite.sql.funCalcite
SqlOverOperatorAn operator describing a window function specification.Classorg.apache.calcite.sqlCalcite
SqlParseExceptionSqlParseException defines a checked exception corresponding toSee Also:Serialized FormClassorg.apache.calcite.sql.parserCalcite
SqlParserA SqlParser parses a SQL statement.Classorg.apache.calcite.sql.parserCalcite
SqlParserImplFactory SqlAbstractParserImpl objects.Interfaceorg.apache.calcite.sql.parserCalcite
SqlParserPosSqlParserPos represents the position of a parsed token within SQL statementSee Also:Serialized FormClassorg.apache.calcite.sql.parserCalcite
SqlParserUtilUtility methods relating to parsing SQL.Classorg.apache.calcite.sql.parserCalcite
SqlPositionFunctionThe POSITION function.Classorg.apache.calcite.sql.funCalcite
SqlPostfixOperatorA postfix unary operator.Classorg.apache.calcite.sqlCalcite
SqlPrefixOperatorClassorg.apache.calcite.sqlCalcite
SqlPrettyWriterPretty printer for SQL statements.Classorg.apache.calcite.sql.prettyCalcite
SqlProcedureCallOperatorSqlProcedureCallOperator represents the CALL statement.Classorg.apache.calcite.sqlCalcite
SqlQualifiedFully-qualified identifier.Classorg.apache.calcite.sql.validateCalcite
SqlQuarterFunctionSqlQuarterFunction represents the SQL:1999 standard QUARTER function.Classorg.apache.calcite.sql.funCalcite
SqlRankFunctionOperator which aggregates sets of values into a result.Classorg.apache.calcite.sqlCalcite
SqlReturnTypeInferenceStrategy interface to infer the type of an operator call from the type of the This interface is an example of theInterfaceorg.apache.calcite.sql.typeCalcite
SqlReturnTypeInferenceChainStrategy 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.Classorg.apache.calcite.sql.typeCalcite
SqlRexContextContains the context necessary for a SqlRexConvertlet to convert a SqlNode expression into a RexNode.Interfaceorg.apache.calcite.sql2relCalcite
SqlRexConvertletInterfaceorg.apache.calcite.sql2relCalcite
SqlRexConvertletTableCollection of SqlRexConvertlets.Interfaceorg.apache.calcite.sql2relCalcite
SqlRowOperatorSqlRowOperator represents the special ROW constructor.Classorg.apache.calcite.sql.funCalcite
SqlSampleSpecSpecification of a SQL sample.Classorg.apache.calcite.sqlCalcite
SqlScopedShuttleRefinement to SqlShuttle which maintains a stack of scopes.Classorg.apache.calcite.sql.validateCalcite
SqlSelectA SqlSelect is a node of a parse tree which represents a select statement.Classorg.apache.calcite.sqlCalcite
SqlSelectKeywordenum SqlSelectKeywordDefines the keywords which can occur immediately after the SELECT keyword.Classorg.apache.calcite.sqlCalcite
SqlSelectOperatorAn operator describing a query.Classorg.apache.calcite.sqlCalcite
SqlSequenceValueOperatorOperator that returns the current or next value of a sequence.Classorg.apache.calcite.sql.funCalcite
SqlSetOperatorSqlSetOperator represents a relational set theory operator (UNION, INTERSECT, MINUS).Classorg.apache.calcite.sqlCalcite
SqlSetOptionSQL parse tree node to represent SET and RESET statements, optionally preceded by ALTER SYSTEM or ALTER SESSION.Classorg.apache.calcite.sqlCalcite
SqlShuttleBasic implementation of SqlVisitor which returns each leaf node This class is useful as a base class for classes which implement theClassorg.apache.calcite.sql.utilCalcite
SqlSimpleParserA simple parser that takes an incomplete and turn it into a syntactically correct statement.Classorg.apache.calcite.sql.adviseCalcite
SqlSingleOperandTypeCheckerSqlSingleOperandTypeChecker is an extension of SqlOperandTypeChecker for implementations which are capable of checking the type of a singleInterfaceorg.apache.calcite.sql.typeCalcite
SqlSingleValueAggFunctionSINGLE_VALUE aggregate function returns the input value if there is only one value in the input; Otherwise it triggers a run-time error.Classorg.apache.calcite.sql.funCalcite
SqlSpecialOperatorGeneric operator for nodes with special syntax.Classorg.apache.calcite.sqlCalcite
SqlSplittableAggFunctionAggregate function that can be split into partial aggregates.Interfaceorg.apache.calcite.sqlCalcite
SqlStateCodesContains Glossary.Classorg.apache.calcite.sqlCalcite
SqlStdOperatorTable the standard operators and functions.Classorg.apache.calcite.sql.funCalcite
SqlStringString that represents a kocher SQL statement, expression, or fragment.Classorg.apache.calcite.sql.utilCalcite
SqlStringContextVariableBase class for functions such as USER, CURRENT_ROLE, and CURRENT_PATH.Classorg.apache.calcite.sql.funCalcite
SqlSubstringFunctionDefinition of the SUBSTRING builtin SQL function.Classorg.apache.calcite.sql.funCalcite
SqlSumAggFunctionSum is an aggregator which returns the sum of the values which go into it.Classorg.apache.calcite.sql.funCalcite
SqlSumEmptyIsZeroAggFunctionSum0 is an aggregator which returns the sum of the values which go into it like Sum.Classorg.apache.calcite.sql.funCalcite
SqlSyntaxEnumeration of possible syntactic types of operators.Classorg.apache.calcite.sqlCalcite
SqlThrowOperatorAn internal operator that throws an exception.Classorg.apache.calcite.sql.funCalcite
SqlTimeLiteralA SQL literal representing a TIME value, for example TIME Create values using SqlLiteral.Classorg.apache.calcite.sqlCalcite
SqlTimeoutExceptionIndicates that an operation timed out.Classorg.apache.calcite.jdbcCalcite
SqlTimestampLiteralA SQL literal representing a TIMESTAMP value, for example TIMESTAMP '1969-07-21 03:15 GMT'.Classorg.apache.calcite.sqlCalcite
SqlToRelConverterConverts a SQL parse tree (consisting of SqlNode objects) into a relational algebraClassorg.apache.calcite.sql2relCalcite
SqlTrimFunctionDefinition of the TRIM builtin SQL function.Classorg.apache.calcite.sql.funCalcite
SqlType The information in the following conversions tables (from the JDBC 4.Classorg.apache.calcite.avaticaCalcite
SqlTypeAssignmentRulesClass to hold rules to determine if a type is assignable from another type.Classorg.apache.calcite.sql.typeCalcite
SqlTypeExplicitPrecedenceListSqlTypeExplicitPrecedenceList implements the RelDataTypePrecedenceList interface via an explicit list ofClassorg.apache.calcite.sql.typeCalcite
SqlTypeFactoryImplSqlTypeFactoryImpl provides a default implementation of RelDataTypeFactory which supports SQL types.Classorg.apache.calcite.sql.typeCalcite
SqlTypeFamilySqlTypeFamily provides SQL type categorization.Classorg.apache.calcite.sql.typeCalcite
SqlTypeNameEnumeration of the type names which can be used to construct a SQL type.Classorg.apache.calcite.sql.typeCalcite
SqlTypeTransformStrategy to transform one type to another.Interfaceorg.apache.calcite.sql.typeCalcite
SqlTypeTransformCascadeStrategy to infer the type of an operator call from the type of the operands by using one SqlReturnTypeInference rule and a combination ofClassorg.apache.calcite.sql.typeCalcite
SqlTypeTransformsSqlTypeTransforms defines a number of reusable instances of NOTE: avoid anonymous inner classes here except for unique,Classorg.apache.calcite.sql.typeCalcite
SqlTypeUtilContains utility methods used during SQL validation or type derivation.Classorg.apache.calcite.sql.typeCalcite
SqlUnnestOperatorThe UNNEST operator.Classorg.apache.calcite.sqlCalcite
SqlUnresolvedFunctionPlaceholder for an unresolved function.Classorg.apache.calcite.sqlCalcite
SqlUpdateClassorg.apache.calcite.sqlCalcite
SqlUserDefinedAggFunctionUser-defined aggregate function.Classorg.apache.calcite.sql.validateCalcite
SqlUserDefinedFunctionUser-defined scalar function.Classorg.apache.calcite.sql.validateCalcite
SqlUserDefinedTableFunctionUser-defined table function.Classorg.apache.calcite.sql.validateCalcite
SqlUserDefinedTableMacroUser-defined table macro.Classorg.apache.calcite.sql.validateCalcite
SqlUtilContains utility functions related to SQL parsing, all static.Classorg.apache.calcite.sqlCalcite
SqlValidatorValidates the parse tree of a SQL statement, and provides semantic information about the parse tree.Interfaceorg.apache.calcite.sql.validateCalcite
SqlValidatorCatalogReaderSupplies catalog information for SqlValidator.Interfaceorg.apache.calcite.sql.validateCalcite
SqlValidatorExceptionException thrown while validating a SQL statement.Classorg.apache.calcite.sql.validateCalcite
SqlValidatorImplDefault implementation of SqlValidator.Classorg.apache.calcite.sql.validateCalcite
SqlValidatorNamespaceA namespace describes the relation returned by a section of a SQL query.Interfaceorg.apache.calcite.sql.validateCalcite
SqlValidatorScopeName-resolution scope.Interfaceorg.apache.calcite.sql.validateCalcite
SqlValidatorTableSupplies a SqlValidator with the metadata for a table.Interfaceorg.apache.calcite.sql.validateCalcite
SqlValidatorUtilUtility methods related to validation.Classorg.apache.calcite.sql.validateCalcite
SqlValidatorWithHints qualified names of sql objects, alternative valid sql objects that can be used in the SQL statement (dubbed as hints)Interfaceorg.apache.calcite.sql.validateCalcite
SqlValuesOperatorThe VALUES operator.Classorg.apache.calcite.sqlCalcite
SqlVisitorVisitor class, follows the The type parameter R is the return type of each Interfaceorg.apache.calcite.sql.utilCalcite
SqlWindowSQL window specification.Classorg.apache.calcite.sqlCalcite
SqlWithThe WITH clause of a query.Classorg.apache.calcite.sqlCalcite
SqlWithItemAn item in a WITH clause of a query.Classorg.apache.calcite.sqlCalcite
SqlWriterA SqlWriter is the target to construct a SQL statement from a parse tree.Interfaceorg.apache.calcite.sqlCalcite
StacksUtilities to make vanilla lists look like stacks.Classorg.apache.calcite.utilCalcite
StackWriterA helper class for generating formatted text.Classorg.apache.calcite.utilCalcite
StandardConvertletTableStandard implementation of SqlRexConvertletTable.Classorg.apache.calcite.sql2relCalcite
StarTableVirtual table that is composed of two or more tables joined together.Classorg.apache.calcite.schema.implCalcite
StatementClassorg.apache.calcite.linq4j.treeCalcite
StatementInfoAll we know about a statement.Classorg.apache.calcite.avatica.jdbcCalcite
StatementTestCompares Statement vs PreparedStatement.Classorg.apache.calcite.benchmarksCalcite
StatementTest_bindExecute_jmhTestClassorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_executeQuery_jmhTestClassorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_forEach_jmhTestClassorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_HrConnection_jmhTypeClassorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_HrConnection_jmhType_B1Classorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_HrConnection_jmhType_B2Classorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_HrConnection_jmhType_B3Classorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_HrPreparedStatement_jmhTypeClassorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_HrPreparedStatement_jmhType_B1Classorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_HrPreparedStatement_jmhType_B2Classorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_HrPreparedStatement_jmhType_B3Classorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_jmhTypeClassorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_jmhType_B1Classorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_jmhType_B2Classorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_jmhType_B3Classorg.apache.calcite.benchmarks.generatedCalcite
StatementTest_prepareBindExecute_jmhTestClassorg.apache.calcite.benchmarks.generatedCalcite
StaticDefinitions of objects to be statically imported.Classorg.apache.calcite.utilCalcite
StatisticStatistics about a Table.Interfaceorg.apache.calcite.schemaCalcite
StatisticsUtility functions regarding Statistic.Classorg.apache.calcite.schemaCalcite
StreamableTableTable that can be converted to a stream.Interfaceorg.apache.calcite.schemaCalcite
StreamRulesRules and relational operators for streaming relational expressions.Classorg.apache.calcite.rel.streamCalcite
StrictAggImplementorThe base implementation of strict aggregate function.Classorg.apache.calcite.adapter.enumerableCalcite
StrictWinAggImplementorThe base implementation of strict window aggregate function.Classorg.apache.calcite.adapter.enumerableCalcite
StringUtilsUtility methods for encoding and decoding strings for Splunk REST calls.Classorg.apache.calcite.adapter.splunk.utilCalcite
StrongUtilities for strong predicates.Classorg.apache.calcite.planCalcite
StructImplClassorg.apache.calcite.avatica.utilCalcite
SubqueryConverterSubqueryConverter provides the interface for classes that convert subqueries into equivalent expressions.Interfaceorg.apache.calcite.sql2relCalcite
SubQueryRemoveRuleTransform that converts IN, EXISTS and scalar sub-queries into joins.Classorg.apache.calcite.rel.rulesCalcite
SubstitutionVisitorSubstitutes part of a tree of relational expressions with another tree.Classorg.apache.calcite.planCalcite
SwitchCaseRepresents one case of a SwitchStatement.Classorg.apache.calcite.linq4j.treeCalcite
SwitchStatementRepresents a control expression that handles multiple selections by passing control to SwitchCase.Classorg.apache.calcite.linq4j.treeCalcite
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.Interfaceorg.apache.calcite.schemaCalcite
TableAccessMapTableAccessMap represents the tables accessed by a query plan, with READ/WRITE information.Classorg.apache.calcite.planCalcite
TableConstructorNamespaceNamespace for a table constructor VALUES (expr, expr, .Classorg.apache.calcite.sql.validateCalcite
TableFactoryFactory for Table objects.Interfaceorg.apache.calcite.schemaCalcite
TableFunctionFunction that returns a table during execution time.Interfaceorg.apache.calcite.schemaCalcite
TableFunctionImplClassorg.apache.calcite.schema.implCalcite
TableFunctionReturnTypeInferenceTableFunctionReturnTypeInference implements rules for deriving table function output row types by expanding references to cursor parameters.Classorg.apache.calcite.sql.typeCalcite
TableFunctionScanRelational expression that calls a table-valued function.Classorg.apache.calcite.rel.coreCalcite
TableMacroFunction that returns a Table.Interfaceorg.apache.calcite.schemaCalcite
TableMacroImplClassorg.apache.calcite.schema.implCalcite
TableModifyRelational expression that modifies a table.Classorg.apache.calcite.rel.coreCalcite
TableScanRelational operator that returns the contents of a table.Classorg.apache.calcite.rel.coreCalcite
TableScanNodeClassorg.apache.calcite.interpreterCalcite
TableScanRulePlanner rule that converts a LogicalTableScan to the resultClassorg.apache.calcite.rel.rulesCalcite
Template It is extended from MessageFormat to allow parameters to be substituted by name as well as by position.Classorg.apache.calcite.utilCalcite
TernaryExpressionRepresents an expression that has a ternary operator.Classorg.apache.calcite.linq4j.treeCalcite
ThrowStatementRepresents a throw statement.Classorg.apache.calcite.linq4j.treeCalcite
TileKeyDefinition of a particular combination of dimensions and measures of a lattice that is the basis of a materialization.Classorg.apache.calcite.materializeCalcite
TileSuggesterAlgorithm that suggests a set of initial tiles (materialized aggregate views) for a given lattice.Classorg.apache.calcite.materializeCalcite
TimeUnitEnumeration of time units used to construct an interval.Classorg.apache.calcite.avatica.utilCalcite
TimeUnitRangeA range of time units.Classorg.apache.calcite.avatica.utilCalcite
TopologicalOrderIteratorIterates over the edges of a graph in topological order.Classorg.apache.calcite.util.graphCalcite
TpcdsSchemaSchema that provides TPC-DS tables, populated according to a particular scale factor.Classorg.apache.calcite.adapter.tpcdsCalcite
TpcdsSchemaFactoryFactory that creates a TpcdsSchema.Classorg.apache.calcite.adapter.tpcdsCalcite
TpchSchemaSchema that provides TPC-H tables, populated according to a particular scale factor.Classorg.apache.calcite.adapter.tpchCalcite
TpchSchemaFactoryFactory that creates a TpchSchema.Classorg.apache.calcite.adapter.tpchCalcite
TraitMatchingRuleTraitMatchingRule adapts a converter rule, restricting it to fire only when its input already matches the expected output trait.Classorg.apache.calcite.rel.convertCalcite
TransformedEnumeratorClassorg.apache.calcite.linq4jCalcite
TranslatableTableExtension to Table that specifies how it is to be translated to It is optional for a Table to implement this interface.Interfaceorg.apache.calcite.schemaCalcite
TrustAllSslSocketFactorySocket factory that trusts all SSL connections.Classorg.apache.calcite.adapter.splunk.utilCalcite
TryStatementRepresents a try .Classorg.apache.calcite.linq4j.treeCalcite
TryThreadLocalThread-local variable that returns a handle that can be closed.Classorg.apache.calcite.utilCalcite
TypeBinaryExpressionRepresents an operation between an expression and a type.Classorg.apache.calcite.linq4j.treeCalcite
TypedAdds type information to a Enumerable.Interfaceorg.apache.calcite.runtimeCalcite
TypedValue There are 3 representations: JDBC - the representation used by JDBC get and set methodsClassorg.apache.calcite.avatica.remoteCalcite
TypesClassorg.apache.calcite.linq4j.treeCalcite
UnaryExpressionRepresents an expression that has a unary operator.Classorg.apache.calcite.linq4j.treeCalcite
UnboundMetadataMetadata that needs to be bound to a RelNode and RelMetadataQuery before it can be used.Interfaceorg.apache.calcite.rel.metadataCalcite
UncollectRelational expression that unnests its input's columns into a relation.Classorg.apache.calcite.rel.coreCalcite
UnionRelational expression that returns the union of the rows of its inputs, optionally eliminating duplicates.Classorg.apache.calcite.rel.coreCalcite
UnionEliminatorRuleUnionEliminatorRule checks to see if its possible to optimize a Union call by eliminating the Union operator altogether in the case the callClassorg.apache.calcite.rel.rulesCalcite
UnionMergeRuleUnionMergeRule implements the rule for combining two non-distinct UnionsClassorg.apache.calcite.rel.rulesCalcite
UnionNodeClassorg.apache.calcite.interpreterCalcite
UnionToDistinctRulePlanner rule that translates a distinct on top of a non-distinct UnionClassorg.apache.calcite.rel.rulesCalcite
UnitSynthetic record with zero fields.Classorg.apache.calcite.runtimeCalcite
UnmodifiableArrayListA view onto an array that cannot be modified by the client.Classorg.apache.calcite.utilCalcite
UnregisteredDriver You can easily create a vanity driver that recognizes its own URL prefix as a sub-class of this class.Classorg.apache.calcite.avaticaCalcite
UtilMiscellaneous utility functions.Classorg.apache.calcite.utilCalcite
UtilitiesUtility methods called by generated code.Classorg.apache.calcite.runtimeCalcite
ValidationExceptionAn Exception thrown when attempting to validate a SQL parse tree.Classorg.apache.calcite.toolsCalcite
ValuesClassorg.apache.calcite.rel.coreCalcite
ValuesNodeClassorg.apache.calcite.interpreterCalcite
ValuesReduceRulePlanner rule that folds projections and filters into an underlying Returns a simplified Values, perhaps containing zero tuplesClassorg.apache.calcite.rel.rulesCalcite
ViewTableTable whose contents are defined using an SQL statement.Classorg.apache.calcite.schema.implCalcite
VisitorClassorg.apache.calcite.linq4j.treeCalcite
VisitorDataContextClassorg.apache.calcite.planCalcite
VolcanoPlannerVolcanoPlanner optimizes queries by transforming expressions selectively according to a dynamic programming algorithm.Classorg.apache.calcite.plan.volcanoCalcite
VolcanoPlannerPhaseenum VolcanoPlannerPhaseVolcanoPlannerPhase represents the phases of operation that theClassorg.apache.calcite.plan.volcanoCalcite
VolcanoPlannerPhaseRuleMappingInitializerVolcanoPlannerPhaseRuleMappingInitializer describes an inteface for initializing the mapping of VolcanoPlannerPhases to sets of ruleInterfaceorg.apache.calcite.plan.volcanoCalcite
VolcanoRelMetadataProviderVolcanoRelMetadataProvider implements the RelMetadataProvider interface by combining metadata from the rels making up an equivalence class.Classorg.apache.calcite.plan.volcanoCalcite
VolcanoRuleCallVolcanoRuleCall implements the RelOptRuleCall interface for VolcanoPlanner.Classorg.apache.calcite.plan.volcanoCalcite
WhileStatementRepresents a while statement.Classorg.apache.calcite.linq4j.treeCalcite
WinAggAddContextInformation for a call to AggImplementor.Interfaceorg.apache.calcite.adapter.enumerableCalcite
WinAggAddContextImplClassorg.apache.calcite.adapter.enumerable.implCalcite
WinAggContextMarker interface to allow to tell if it is used in regular or windowed context.Interfaceorg.apache.calcite.adapter.enumerableCalcite
WinAggFrameContextProvides information on the current window.Interfaceorg.apache.calcite.adapter.enumerableCalcite
WinAggFrameResultContextInterfaceorg.apache.calcite.adapter.enumerableCalcite
WinAggImplementor initialize, add to, and get a result from, an accumulator.Interfaceorg.apache.calcite.adapter.enumerableCalcite
WinAggResetContextInformation for a call to AggImplementor.Interfaceorg.apache.calcite.adapter.enumerableCalcite
WinAggResetContextImpl WinAggResetContext.Classorg.apache.calcite.adapter.enumerable.implCalcite
WinAggResultContextInformation for a call to AggImplementor.Interfaceorg.apache.calcite.adapter.enumerableCalcite
WinAggResultContextImpl WinAggResultContext.Classorg.apache.calcite.adapter.enumerable.implCalcite
WindowA relational expression representing a set of window aggregates.Classorg.apache.calcite.rel.coreCalcite
WindowNodeClassorg.apache.calcite.interpreterCalcite
WithNamespaceNamespace for WITH clause.Classorg.apache.calcite.sql.validateCalcite
XmlOutputStreaming XML output.Classorg.apache.calcite.utilCalcite
ZonelessDateZonelessDate is a date value without a time zone.Classorg.apache.calcite.utilCalcite
ZonelessDatetimeZonelessDatetime is an abstract class for dates, times, or timestamps that contain a zoneless time value.Classorg.apache.calcite.utilCalcite
ZonelessTimeZonelessTime is a time value without a time zone.Classorg.apache.calcite.utilCalcite
ZonelessTimestampZonelessTimestamp is a timestamp value without a time zone.Classorg.apache.calcite.utilCalcite