Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



#Org.apache.calcite.rel Classes and Interfaces - 267 results found.
NameDescriptionTypePackageFramework
AbstractRelNodeBase class for every relational expression (RelNode).Classorg.apache.calcite.relCalcite
AggregateRelational operator that eliminates duplicates and computes totals.Classorg.apache.calcite.rel.coreCalcite
Aggregate .AggCallBinding aggregate call applied to a set of operands in the context of a LogicalAggregate.Classorg.apache.calcite.rel.core.AggregateCalcite
Aggregate .GroupClassorg.apache.calcite.rel.core.AggregateCalcite
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
AggregateJoinTransposeRuleClassorg.apache.calcite.rel.rulesCalcite
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
BiRelAbstract base class for relational expressions with a two inputs.Classorg.apache.calcite.relCalcite
BuiltInMetadataContains the interfaces for several common forms of metadata.Classorg.apache.calcite.rel.metadataCalcite
BuiltInMetadata .CollationMetadata about which columns are sorted.Interfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .ColumnOriginMetadata about the origins of columns.Interfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .ColumnUniquenessMetadata about whether a set of columns uniquely identifies a row.Interfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .CumulativeCostMetadata about the cost of evaluating a relational expression, includingEstimates the cost of executing a relational expression, including theInterfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .DistinctRowCountMetadata about the number of distinct rows returned by a set of columns in a relational expression.Interfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .DistributionMetadata about how a relational expression is distributed.Interfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .ExplainVisibilityMetadata about whether a relational expression should appear in a plan.Interfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .MaxRowCountMetadata about the maximum number of rows returned by a relationalEstimates the max number of rows which will be returned by a relationalInterfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .MemoryMetadata about the memory use of an operator.Interfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .NonCumulativeCostMetadata about the cost of evaluating a relational expression, not including its inputs.Interfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .ParallelismMetadata about the degree of parallelism of a relational expression, and how its operators are assigned to processes with independent resourceInterfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .PercentageOriginalRowsMetadata about the proportion of original rows that remain in a relationalEstimates the percentage of the number of rows actually produced by aInterfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .PopulationSizeMetadata about the number of distinct values in the original source of a column or set of columns.Interfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .PredicatesMetadata about the predicates that hold in the rows emitted from a relational expression.Interfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .RowCountMetadata about the number of rows returned by a relational expression.Interfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .SelectivityMetadata about the selectivity of a predicate.Interfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .SizeMetadata about the size of rows and columns.Interfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
BuiltInMetadata .UniqueKeysMetadata about which combinations of columns are unique identifiers.Interfaceorg.apache.calcite.rel.metadata.BuiltInMetadataCalcite
CachingRelMetadataProvider interface that caches results from an underlying provider.Classorg.apache.calcite.rel.metadataCalcite
CalcClassorg.apache.calcite.rel.coreCalcite
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
CalcRelSplitter .RelTypeType of relational expression.Classorg.apache.calcite.rel.rules.CalcRelSplitterCalcite
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
ChainedRelMetadataProvider Glossary.Classorg.apache.calcite.rel.metadataCalcite
ChiRelational operator that converts a stream to a relation.Classorg.apache.calcite.rel.streamCalcite
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
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
CorrelationIdDescribes the necessary parameters for an implementation in order to identify and set dynamic variablesClassorg.apache.calcite.rel.coreCalcite
CyclicMetadataExceptionException that indicates that a cycle has been detected while computing metadata.Classorg.apache.calcite.rel.metadataCalcite
DefaultRelMetadataProviderDefaultRelMetadataProvider supplies a default implementation of the RelMetadataProvider interface.Classorg.apache.calcite.rel.metadataCalcite
DeltaRelational operator that converts a relation to a stream.Classorg.apache.calcite.rel.streamCalcite
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
FilterRelational expression that iterates over its input and returns elements for which condition evaluates toClassorg.apache.calcite.rel.coreCalcite
FilterAggregateTransposeRulePlanner rule that pushes a FilterSee Also:AggregateFilterTransposeRuleClassorg.apache.calcite.rel.rulesCalcite
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
FilterJoinRule .FilterIntoJoinRuleRule that tries to push filter expressions into a join condition and into the inputs of the join.Classorg.apache.calcite.rel.rules.FilterJoinRuleCalcite
FilterJoinRule .JoinConditionPushRuleRule that pushes parts of the join condition to its inputs.Classorg.apache.calcite.rel.rules.FilterJoinRuleCalcite
FilterJoinRule .PredicatePredicate that returns whether a filter is valid in the ON clause of a join for this particular kind of join.Interfaceorg.apache.calcite.rel.rules.FilterJoinRuleCalcite
FilterMergeRuleClassorg.apache.calcite.rel.rulesCalcite
FilterMultiJoinMergeRulePlanner rule that merges a creating a richer MultiJoin.Classorg.apache.calcite.rel.rulesCalcite
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
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
InvalidRelExceptionException that indicates that a relational expression would be invalid with given parameters.Classorg.apache.calcite.relCalcite
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
JoinExtractFilterRule cartesian inner join.Classorg.apache.calcite.rel.rulesCalcite
JoinInfoAn analyzed join condition.Classorg.apache.calcite.rel.coreCalcite
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
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
JoinUnionTransposeRulePlanner rule that pushes a past a non-distinct LogicalUnion.Classorg.apache.calcite.rel.rulesCalcite
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
LoptJoinTreeUtility class used to store a Join tree and the factors that make up the tree.Classorg.apache.calcite.rel.rulesCalcite
LoptJoinTree .BinaryTreeSimple binary tree class that stores an id in the leaf nodes and keeps track of the parent LoptJoinTree object associated with the binary tree.Classorg.apache.calcite.rel.rules.LoptJoinTreeCalcite
LoptJoinTree .LeafBinary tree node that has no children.Classorg.apache.calcite.rel.rules.LoptJoinTreeCalcite
LoptJoinTree .NodeBinary tree node that has two children.Classorg.apache.calcite.rel.rules.LoptJoinTreeCalcite
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
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
MinusRelational expression that returns the rows of its first input minus any matching rows from its other inputs.Classorg.apache.calcite.rel.coreCalcite
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
NoneConverterClassorg.apache.calcite.rel.convertCalcite
ProjectRelational expression that computes a set of 'select expressions' from its input relational expression.Classorg.apache.calcite.rel.coreCalcite
Project .FlagsClassorg.apache.calcite.rel.core.ProjectCalcite
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
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
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
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
PushProjector .ExprConditionA functor that replies true or false for a given expression.Interfaceorg.apache.calcite.rel.rules.PushProjectorCalcite
PushProjector .OperatorExprConditionAn expression condition that evaluates to true if the expression is a call to one of a set of operators.Classorg.apache.calcite.rel.rules.PushProjectorCalcite
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
ReduceExpressionsRule .CalcReduceExpressionsRuleRule that reduces constants inside a Calc.Classorg.apache.calcite.rel.rules.ReduceExpressionsRuleCalcite
ReduceExpressionsRule .CaseShuttleShuttle that pushes predicates into a CASE.Classorg.apache.calcite.rel.rules.ReduceExpressionsRuleCalcite
ReduceExpressionsRule .FilterReduceExpressionsRuleRule that reduces constants inside a Filter.Classorg.apache.calcite.rel.rules.ReduceExpressionsRuleCalcite
ReduceExpressionsRule .JoinReduceExpressionsRuleRule that reduces constants inside a Join.Classorg.apache.calcite.rel.rules.ReduceExpressionsRuleCalcite
ReduceExpressionsRule .ProjectReduceExpressionsRuleRule that reduces constants inside a Project.Classorg.apache.calcite.rel.rules.ReduceExpressionsRuleCalcite
ReduceExpressionsRule .ReducibleExprLocatorHelper class used to locate expressions that either can be reduced to literals or contain redundant casts.Classorg.apache.calcite.rel.rules.ReduceExpressionsRuleCalcite
ReduceExpressionsRule .RexReplacerReplaces expressions with their reductions.Classorg.apache.calcite.rel.rules.ReduceExpressionsRuleCalcite
ReflectiveRelMetadataProvider metadata methods to methods on a given object via reflection.Classorg.apache.calcite.rel.metadataCalcite
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
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
RelDataTypeFactory .FieldInfoCallback which provides enough information to create fields.Interfaceorg.apache.calcite.rel.type.RelDataTypeFactoryCalcite
RelDataTypeFactory .FieldInfoBuilderClassorg.apache.calcite.rel.type.RelDataTypeFactoryCalcite
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
RelDistributionDescription of the physical distribution of a relational expression.Interfaceorg.apache.calcite.relCalcite
RelDistribution .TypeType of distribution.Classorg.apache.calcite.rel.RelDistributionCalcite
RelDistributionsUtilities concerning RelDistribution.Classorg.apache.calcite.relCalcite
RelDistributionTraitDefDefinition of the distribution trait.Classorg.apache.calcite.relCalcite
RelFactoriesClassorg.apache.calcite.rel.coreCalcite
RelFactories .AggregateFactoryCan create a LogicalAggregate of the appropriate type for this rule's calling convention.Interfaceorg.apache.calcite.rel.core.RelFactoriesCalcite
RelFactories .CorrelateFactoryCan create a correlate of the appropriate type for a rule's calling The result is typically a Correlate.Interfaceorg.apache.calcite.rel.core.RelFactoriesCalcite
RelFactories .FilterFactoryCan create a LogicalFilter of the appropriate type for this rule's calling convention.Interfaceorg.apache.calcite.rel.core.RelFactoriesCalcite
RelFactories .JoinFactoryCan create a join of the appropriate type for a rule's calling convention.Interfaceorg.apache.calcite.rel.core.RelFactoriesCalcite
RelFactories .ProjectFactory LogicalProject of the appropriate type for this rule's calling convention.Interfaceorg.apache.calcite.rel.core.RelFactoriesCalcite
RelFactories .SemiJoinFactoryInterfaceorg.apache.calcite.rel.core.RelFactoriesCalcite
RelFactories .SetOpFactoryCan create a SetOp for a particular kind of set operation (UNION, EXCEPT, INTERSECT) and of the appropriate typeInterfaceorg.apache.calcite.rel.core.RelFactoriesCalcite
RelFactories .SortFactoryCan create a Sort of the appropriate type for this rule's calling convention.Interfaceorg.apache.calcite.rel.core.RelFactoriesCalcite
RelFactories .TableScanFactoryInterfaceorg.apache.calcite.rel.core.RelFactoriesCalcite
RelFactories .ValuesFactoryInterfaceorg.apache.calcite.rel.core.RelFactoriesCalcite
RelFieldCollationDefinition of the ordering of one field of a RelNode whose output is to be sorted.Classorg.apache.calcite.relCalcite
RelFieldCollation .DirectionDirection that a field is ordered in.Classorg.apache.calcite.rel.RelFieldCollationCalcite
RelFieldCollation .NullDirectionClassorg.apache.calcite.rel.RelFieldCollationCalcite
RelHomogeneousShuttleClassorg.apache.calcite.relCalcite
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
RelNodeA RelNode is a relational expression.Interfaceorg.apache.calcite.relCalcite
RelNodesUtilities concerning relational expressions.Classorg.apache.calcite.relCalcite
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
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
RelToSqlConverterUtility to convert relational expressions to SQL abstract syntax tree.Classorg.apache.calcite.rel.rel2sqlCalcite
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
SampleRelational expression that returns a sample of the rows from its input.Classorg.apache.calcite.rel.coreCalcite
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
SetOpSetOp is an abstract base for relational set operators such as UNION, MINUS (aka EXCEPT), and INTERSECT.Classorg.apache.calcite.rel.coreCalcite
SingleRelAbstract base class for relational expressions with a single input.Classorg.apache.calcite.relCalcite
SortRelational expression that imposes a particular sort order on its input without otherwise changing its content.Classorg.apache.calcite.rel.coreCalcite
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
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
SqlImplementorState for generating a SQL statement.Classorg.apache.calcite.rel.rel2sqlCalcite
SqlImplementor .ClauseClauses in a SQL query.Classorg.apache.calcite.rel.rel2sql.SqlImplementorCalcite
StreamRulesRules and relational operators for streaming relational expressions.Classorg.apache.calcite.rel.streamCalcite
StreamRules .DeltaAggregateTransposeRulePlanner rule that pushes a Delta through an Aggregate.Classorg.apache.calcite.rel.stream.StreamRulesCalcite
StreamRules .DeltaFilterTransposeRulePlanner rule that pushes a Delta through a Filter.Classorg.apache.calcite.rel.stream.StreamRulesCalcite
StreamRules .DeltaJoinTransposeRulePlanner rule that pushes a Delta through a Join.Classorg.apache.calcite.rel.stream.StreamRulesCalcite
StreamRules .DeltaProjectTransposeRulePlanner rule that pushes a Delta through a Project.Classorg.apache.calcite.rel.stream.StreamRulesCalcite
StreamRules .DeltaSortTransposeRulePlanner rule that pushes a Delta through an Sort.Classorg.apache.calcite.rel.stream.StreamRulesCalcite
StreamRules .DeltaTableScanRulePlanner rule that pushes a Delta into a TableScan of a Very likely, the stream was only represented as a table for uniformityClassorg.apache.calcite.rel.stream.StreamRulesCalcite
StreamRules .DeltaTableScanToEmptyRulePlanner rule that converts Delta over a TableScan of a table other than StreamableTable toClassorg.apache.calcite.rel.stream.StreamRulesCalcite
StreamRules .DeltaUnionTransposeRulePlanner rule that pushes a Delta through an Union.Classorg.apache.calcite.rel.stream.StreamRulesCalcite
SubQueryRemoveRuleTransform that converts IN, EXISTS and scalar sub-queries into joins.Classorg.apache.calcite.rel.rulesCalcite
TableFunctionScanRelational expression that calls a table-valued function.Classorg.apache.calcite.rel.coreCalcite
TableModifyRelational expression that modifies a table.Classorg.apache.calcite.rel.coreCalcite
TableModify .OperationReturns the enum constant of this type with the specified name.Classorg.apache.calcite.rel.core.TableModifyCalcite
TableScanRelational operator that returns the contents of a table.Classorg.apache.calcite.rel.coreCalcite
TableScanRulePlanner rule that converts a LogicalTableScan to the resultClassorg.apache.calcite.rel.rulesCalcite
TraitMatchingRuleTraitMatchingRule adapts a converter rule, restricting it to fire only when its input already matches the expected output trait.Classorg.apache.calcite.rel.convertCalcite
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
UnionToDistinctRulePlanner rule that translates a distinct on top of a non-distinct UnionClassorg.apache.calcite.rel.rulesCalcite
ValuesClassorg.apache.calcite.rel.coreCalcite
ValuesReduceRulePlanner rule that folds projections and filters into an underlying Returns a simplified Values, perhaps containing zero tuplesClassorg.apache.calcite.rel.rulesCalcite
WindowA relational expression representing a set of window aggregates.Classorg.apache.calcite.rel.coreCalcite
Window .GroupGroup of windowed aggregate calls that have the same window specification.Classorg.apache.calcite.rel.core.WindowCalcite
Window .RexWinAggCallA call to a windowed aggregate function.Classorg.apache.calcite.rel.core.WindowCalcite