Uses of Class
org.apache.calcite.tools.RelBuilder
-
-
Uses of RelBuilder in org.apache.calcite.sql2rel
Fields in org.apache.calcite.sql2rel declared as RelBuilder Modifier and Type Field Description protected RelBuilder
RelDecorrelator. relBuilder
Methods in org.apache.calcite.sql2rel with parameters of type RelBuilder Modifier and Type Method Description static org.apache.calcite.rel.RelNode
RelDecorrelator. decorrelateQuery(org.apache.calcite.rel.RelNode rootRel, RelBuilder relBuilder)
Decorrelates a query.Constructors in org.apache.calcite.sql2rel with parameters of type RelBuilder Constructor Description RelDecorrelator(RelDecorrelator.CorelMap cm, org.apache.calcite.plan.Context context, RelBuilder relBuilder)
-
Uses of RelBuilder in org.apache.calcite.tools
Methods in org.apache.calcite.tools that return RelBuilder Modifier and Type Method Description RelBuilder
RelBuilder. adoptConvention(org.apache.calcite.plan.Convention convention)
Returns new RelBuilder that adopts the convention provided.RelBuilder
RelBuilder. aggregate(RelBuilder.GroupKey groupKey, Iterable<RelBuilder.AggCall> aggCalls)
Creates anAggregate
with multiple calls.RelBuilder
RelBuilder. aggregate(RelBuilder.GroupKey groupKey, List<org.apache.calcite.rel.core.AggregateCall> aggregateCalls)
Creates anAggregate
with an array ofAggregateCall
s.RelBuilder
RelBuilder. aggregate(RelBuilder.GroupKey groupKey, RelBuilder.AggCall... aggCalls)
Creates anAggregate
with an array of calls.RelBuilder
RelBuilder. antiJoin(Iterable<? extends org.apache.calcite.rex.RexNode> conditions)
Creates an anti-join.RelBuilder
RelBuilder. antiJoin(org.apache.calcite.rex.RexNode... conditions)
Creates an anti-join.RelBuilder
RelBuilder. as(String alias)
Assigns a table alias to the top entry on the stack.RelBuilder
RelBuilder. convert(org.apache.calcite.rel.type.RelDataType castRowType, boolean rename)
Creates a projection that converts the current relational expression's output to a desired row type.RelBuilder
RelBuilder. correlate(org.apache.calcite.rel.core.JoinRelType joinType, org.apache.calcite.rel.core.CorrelationId correlationId, Iterable<? extends org.apache.calcite.rex.RexNode> requiredFields)
Creates aCorrelate
with aCorrelationId
and a list of fields that are used by correlation.RelBuilder
RelBuilder. correlate(org.apache.calcite.rel.core.JoinRelType joinType, org.apache.calcite.rel.core.CorrelationId correlationId, org.apache.calcite.rex.RexNode... requiredFields)
Creates aCorrelate
with aCorrelationId
and an array of fields that are used by correlation.static RelBuilder
RelBuilder. create(org.apache.calcite.tools.FrameworkConfig config)
Creates a RelBuilder.RelBuilder
RelBuilder. distinct()
Creates anAggregate
that makes the relational expression distinct on all fields.RelBuilder
RelBuilder. empty()
Creates a relational expression that reads from an input and throws all of the rows away.RelBuilder
RelBuilder. exchange(org.apache.calcite.rel.RelDistribution distribution)
Creates an Exchange by distribution.RelBuilder
RelBuilder. filter(Iterable<? extends org.apache.calcite.rex.RexNode> predicates)
Creates aFilter
of a list of predicates.RelBuilder
RelBuilder. filter(Iterable<org.apache.calcite.rel.core.CorrelationId> variablesSet, Iterable<? extends org.apache.calcite.rex.RexNode> predicates)
Creates aFilter
of a list of correlation variables and a list of predicates.RelBuilder
RelBuilder. filter(Iterable<org.apache.calcite.rel.core.CorrelationId> variablesSet, org.apache.calcite.rex.RexNode... predicates)
Creates aFilter
of a list of correlation variables and an array of predicates.RelBuilder
RelBuilder. filter(org.apache.calcite.rex.RexNode... predicates)
Creates aFilter
of an array of predicates.RelBuilder
RelBuilder. functionScan(org.apache.calcite.sql.SqlOperator operator, int inputCount, Iterable<? extends org.apache.calcite.rex.RexNode> operands)
Creates aTableFunctionScan
.RelBuilder
RelBuilder. functionScan(org.apache.calcite.sql.SqlOperator operator, int inputCount, org.apache.calcite.rex.RexNode... operands)
Creates aTableFunctionScan
.RelBuilder
RelBuilder. hints(Iterable<org.apache.calcite.rel.hint.RelHint> hints)
Attaches multiple hints to the stack top relational expression.RelBuilder
RelBuilder. hints(org.apache.calcite.rel.hint.RelHint... hints)
Attaches an array of hints to the stack top relational expression.RelBuilder
RelBuilder. intersect(boolean all)
Creates anIntersect
of the two most recent relational expressions on the stack.RelBuilder
RelBuilder. intersect(boolean all, int n)
Creates anIntersect
of then
most recent relational expressions on the stack.RelBuilder
RelBuilder. join(org.apache.calcite.rel.core.JoinRelType joinType, Iterable<? extends org.apache.calcite.rex.RexNode> conditions)
Creates aJoin
with multiple conditions.RelBuilder
RelBuilder. join(org.apache.calcite.rel.core.JoinRelType joinType, String... fieldNames)
Creates aJoin
using USING syntax.RelBuilder
RelBuilder. join(org.apache.calcite.rel.core.JoinRelType joinType, org.apache.calcite.rex.RexNode condition)
Creates aJoin
with one condition.RelBuilder
RelBuilder. join(org.apache.calcite.rel.core.JoinRelType joinType, org.apache.calcite.rex.RexNode condition, Set<org.apache.calcite.rel.core.CorrelationId> variablesSet)
Creates aJoin
with correlating variables.RelBuilder
RelBuilder. join(org.apache.calcite.rel.core.JoinRelType joinType, org.apache.calcite.rex.RexNode condition0, org.apache.calcite.rex.RexNode... conditions)
Creates aJoin
with an array of conditions.RelBuilder
RelBuilder. limit(int offset, int fetch)
Creates a limit without a sort.RelBuilder
RelBuilder. match(org.apache.calcite.rex.RexNode pattern, boolean strictStart, boolean strictEnd, Map<String,org.apache.calcite.rex.RexNode> patternDefinitions, Iterable<? extends org.apache.calcite.rex.RexNode> measureList, org.apache.calcite.rex.RexNode after, Map<String,? extends SortedSet<String>> subsets, boolean allRows, Iterable<? extends org.apache.calcite.rex.RexNode> partitionKeys, Iterable<? extends org.apache.calcite.rex.RexNode> orderKeys, org.apache.calcite.rex.RexNode interval)
Creates aMatch
.RelBuilder
RelBuilder. minus(boolean all)
Creates aMinus
of the two most recent relational expressions on the stack.RelBuilder
RelBuilder. minus(boolean all, int n)
Creates aMinus
of then
most recent relational expressions on the stack.RelBuilder
RelBuilder. permute(org.apache.calcite.util.mapping.Mapping mapping)
RelBuilder
RelBuilder. pivot(RelBuilder.GroupKey groupKey, Iterable<? extends RelBuilder.AggCall> aggCalls, Iterable<? extends org.apache.calcite.rex.RexNode> axes, Iterable<? extends Map.Entry<String,? extends Iterable<? extends org.apache.calcite.rex.RexNode>>> values)
Creates a Pivot.RelBuilder
RelBuilder. project(Iterable<? extends org.apache.calcite.rex.RexNode> nodes)
Creates aProject
of the given list of expressions.RelBuilder
RelBuilder. project(Iterable<? extends org.apache.calcite.rex.RexNode> nodes, Iterable<? extends @Nullable String> fieldNames)
Creates aProject
of the given list of expressions and field names.RelBuilder
RelBuilder. project(Iterable<? extends org.apache.calcite.rex.RexNode> nodes, Iterable<? extends @Nullable String> fieldNames, boolean force)
Creates aProject
of the given list of expressions, using the given names.RelBuilder
RelBuilder. project(Iterable<? extends org.apache.calcite.rex.RexNode> nodes, Iterable<? extends @Nullable String> fieldNames, boolean force, Iterable<org.apache.calcite.rel.core.CorrelationId> variablesSet)
The same withproject(Iterable, Iterable, boolean)
, with additional variablesSet param.RelBuilder
RelBuilder. project(org.apache.calcite.rex.RexNode... nodes)
Creates aProject
of the given expressions.RelBuilder
RelBuilder. projectExcept(Iterable<org.apache.calcite.rex.RexNode> expressions)
Creates aProject
of all original fields, except the given list of expressions.RelBuilder
RelBuilder. projectExcept(org.apache.calcite.rex.RexNode... expressions)
Creates aProject
of all original fields, except the given expressions.RelBuilder
RelBuilder. projectNamed(Iterable<? extends org.apache.calcite.rex.RexNode> nodes, @Nullable Iterable<? extends @Nullable String> fieldNames, boolean force)
Creates aProject
of the given expressions and field names, and optionally optimizing.RelBuilder
RelBuilder. projectNamed(Iterable<? extends org.apache.calcite.rex.RexNode> nodes, @Nullable Iterable<? extends @Nullable String> fieldNames, boolean force, Iterable<org.apache.calcite.rel.core.CorrelationId> variablesSet)
Creates aProject
of the given expressions and field names, and optionally optimizing.RelBuilder
RelBuilder. projectPlus(Iterable<? extends org.apache.calcite.rex.RexNode> nodes)
Creates aProject
of all original fields, plus the given list of expressions.RelBuilder
RelBuilder. projectPlus(org.apache.calcite.rex.RexNode... nodes)
Creates aProject
of all original fields, plus the given expressions.RelBuilder
RelBuilder. push(org.apache.calcite.rel.RelNode node)
Adds a relational expression to be the input to the next relational expression constructed.RelBuilder
RelBuilder. pushAll(Iterable<? extends org.apache.calcite.rel.RelNode> nodes)
Pushes a collection of relational expressions.RelBuilder
RelBuilder. rename(List<? extends @Nullable String> fieldNames)
Ensures that the field names match those given.RelBuilder
RelBuilder. repeatUnion(String tableName, boolean all)
Creates aRepeatUnion
associated to aTransientTable
without a maximum number of iterations, i.e. repeatUnion(tableName, all, -1).RelBuilder
RelBuilder. repeatUnion(String tableName, boolean all, int iterationLimit)
Creates aRepeatUnion
associated to aTransientTable
of the two most recent relational expressions on the stack.RelBuilder
RelBuilder. scan(Iterable<String> tableNames)
Creates aTableScan
of the table with a given name.RelBuilder
RelBuilder. scan(String... tableNames)
Creates aTableScan
of the table with a given name.RelBuilder
RelBuilder. semiJoin(Iterable<? extends org.apache.calcite.rex.RexNode> conditions)
Creates aJoin
withJoinRelType.SEMI
.RelBuilder
RelBuilder. semiJoin(org.apache.calcite.rex.RexNode... conditions)
Creates aJoin
withJoinRelType.SEMI
.RelBuilder
RelBuilder. snapshot(org.apache.calcite.rex.RexNode period)
Creates aSnapshot
of a given snapshot period.RelBuilder
RelBuilder. sort(int... fields)
Creates aSort
by field ordinals.RelBuilder
RelBuilder. sort(Iterable<? extends org.apache.calcite.rex.RexNode> nodes)
Creates aSort
by expressions.RelBuilder
RelBuilder. sort(org.apache.calcite.rel.RelCollation collation)
Creates aSort
by specifying collations.RelBuilder
RelBuilder. sort(org.apache.calcite.rex.RexNode... nodes)
Creates aSort
by expressions.RelBuilder
RelBuilder. sortExchange(org.apache.calcite.rel.RelDistribution distribution, org.apache.calcite.rel.RelCollation collation)
Creates a SortExchange by distribution and collation.RelBuilder
RelBuilder. sortLimit(int offset, int fetch, Iterable<? extends org.apache.calcite.rex.RexNode> nodes)
Creates aSort
by a list of expressions, with limit and offset.RelBuilder
RelBuilder. sortLimit(int offset, int fetch, org.apache.calcite.rex.RexNode... nodes)
Creates aSort
by expressions, with limit and offset.RelBuilder
RelBuilder. sortLimit(@Nullable org.apache.calcite.rex.RexNode offsetNode, @Nullable org.apache.calcite.rex.RexNode fetchNode, Iterable<? extends org.apache.calcite.rex.RexNode> nodes)
Creates aSort
by a list of expressions, with limitNode and offsetNode.RelBuilder
RelBuilder. transform(UnaryOperator<RelBuilder.Config> transform)
Creates a copy of this RelBuilder, with the same state as this, applying a transform to the config.RelBuilder
RelBuilder. transientScan(String tableName)
Creates aTableScan
on aTransientTable
with the given name, using as type the top of the stack's type.RelBuilder
RelBuilder. transientScan(String tableName, org.apache.calcite.rel.type.RelDataType rowType)
Creates aTableScan
on aTransientTable
with the given name and type.RelBuilder
RelBuilder. uncollect(List<String> itemAliases, boolean withOrdinality)
Creates anUncollect
with given item aliases.RelBuilder
RelBuilder. union(boolean all)
Creates aUnion
of the two most recent relational expressions on the stack.RelBuilder
RelBuilder. union(boolean all, int n)
Creates aUnion
of then
most recent relational expressions on the stack.RelBuilder
RelBuilder. unpivot(boolean includeNulls, Iterable<String> measureNames, Iterable<String> axisNames, Iterable<? extends Map.Entry<? extends List<? extends org.apache.calcite.rex.RexLiteral>,? extends List<? extends org.apache.calcite.rex.RexNode>>> axisMap)
Creates an Unpivot.RelBuilder
RelBuilder. values(@Nullable String[] fieldNames, @Nullable Object... values)
Creates aValues
.RelBuilder
RelBuilder. values(Iterable<? extends List<org.apache.calcite.rex.RexLiteral>> tupleList, org.apache.calcite.rel.type.RelDataType rowType)
Creates aValues
with a specified row type.RelBuilder
RelBuilder. values(org.apache.calcite.rel.type.RelDataType rowType)
Creates aValues
with a specified row type and zero rows.RelBuilder
RelBuilder. values(org.apache.calcite.rel.type.RelDataType rowType, Object... columnValues)
Creates aValues
with a specified row type.RelBuilder
RelBuilder. variable(org.apache.calcite.util.Holder<org.apache.calcite.rex.RexCorrelVariable> v)
Creates a correlation variable for the current input, and writes it into a Holder.Method parameters in org.apache.calcite.tools with type arguments of type RelBuilder Modifier and Type Method Description org.apache.calcite.rex.RexNode
RelBuilder. all(org.apache.calcite.rex.RexNode node, org.apache.calcite.sql.SqlOperator op, Function<RelBuilder,org.apache.calcite.rel.RelNode> f)
Creates an ALL predicate.org.apache.calcite.rex.RexSubQuery
RelBuilder. arrayQuery(Function<RelBuilder,org.apache.calcite.rel.RelNode> f)
Creates an ARRAY sub-query.org.apache.calcite.rex.RexSubQuery
RelBuilder. exists(Function<RelBuilder,org.apache.calcite.rel.RelNode> f)
Creates an EXISTS predicate.org.apache.calcite.rex.RexNode
RelBuilder. in(org.apache.calcite.rex.RexNode arg, Function<RelBuilder,org.apache.calcite.rel.RelNode> f)
Creates an IN predicate with a sub-query.<R> R
RelBuilder. let(Function<RelBuilder,R> consumer)
Performs an action on this RelBuilder.org.apache.calcite.rex.RexSubQuery
RelBuilder. mapQuery(Function<RelBuilder,org.apache.calcite.rel.RelNode> f)
Creates a MAP sub-query.org.apache.calcite.rex.RexSubQuery
RelBuilder. multisetQuery(Function<RelBuilder,org.apache.calcite.rel.RelNode> f)
Creates a MULTISET sub-query.org.apache.calcite.rex.RexSubQuery
RelBuilder. scalarQuery(Function<RelBuilder,org.apache.calcite.rel.RelNode> f)
Creates a scalar sub-query.org.apache.calcite.rex.RexSubQuery
RelBuilder. some(org.apache.calcite.rex.RexNode node, org.apache.calcite.sql.SqlOperator op, Function<RelBuilder,org.apache.calcite.rel.RelNode> f)
Creates a SOME (or ANY) predicate.org.apache.calcite.rex.RexSubQuery
RelBuilder. unique(Function<RelBuilder,org.apache.calcite.rel.RelNode> f)
Creates a UNIQUE predicate.<E> E
RelBuilder. with(org.apache.calcite.rel.RelNode r, Function<RelBuilder,E> fn)
Evaluates an expression with a relational expression temporarily on the stack.<E> E
RelBuilder. withPredicates(org.apache.calcite.rel.metadata.RelMetadataQuery mq, Function<RelBuilder,E> fn)
Performs an action using predicates of thecurrent node
to simplify.<E> E
RelBuilder. withSimplifier(BiFunction<RelBuilder,org.apache.calcite.rex.RexSimplify,org.apache.calcite.rex.RexSimplify> simplifierTransform, Function<RelBuilder,E> fn)
Performs an action with a temporary simplifier.<E> E
RelBuilder. withSimplifier(BiFunction<RelBuilder,org.apache.calcite.rex.RexSimplify,org.apache.calcite.rex.RexSimplify> simplifierTransform, Function<RelBuilder,E> fn)
Performs an action with a temporary simplifier. -
Uses of RelBuilder in org.apache.flink.table.calcite.bridge
Methods in org.apache.flink.table.calcite.bridge that return RelBuilder Modifier and Type Method Description RelBuilder
CalciteContext. createRelBuilder()
Create a builder for relational expressions provided by Flink's table planner. -
Uses of RelBuilder in org.apache.flink.table.planner.calcite
Subclasses of RelBuilder in org.apache.flink.table.planner.calcite Modifier and Type Class Description class
FlinkRelBuilder
Flink-specificRelBuilder
.Methods in org.apache.flink.table.planner.calcite that return RelBuilder Modifier and Type Method Description RelBuilder
FlinkRelBuilder. aggregate(RelBuilder.GroupKey groupKey, Iterable<RelBuilder.AggCall> aggCalls)
Build non-window aggregate for either aggregate or table aggregate.RelBuilder
FlinkRelBuilder. expand(List<List<org.apache.calcite.rex.RexNode>> projects, int expandIdIndex)
static RelBuilder
FlinkRelBuilder. pushFunctionScan(RelBuilder relBuilder, org.apache.calcite.sql.SqlOperator operator, int inputCount, Iterable<org.apache.calcite.rex.RexNode> operands, List<String> aliases)
functionScan(SqlOperator, int, Iterable)
cannot work smoothly with aliases which is why we implement a custom one.RelBuilder
FlinkRelBuilder. queryOperation(QueryOperation queryOperation)
RelBuilder
FlinkRelBuilder. rank(org.apache.calcite.util.ImmutableBitSet partitionKey, org.apache.calcite.rel.RelCollation orderKey, RankType rankType, RankRange rankRange, org.apache.calcite.rel.type.RelDataTypeField rankNumberType, boolean outputRankNumber)
RelBuilder
FlinkRelBuilder. scan(ObjectIdentifier identifier, Map<String,String> dynamicOptions)
RelBuilder
FlinkRelBuilder. transform(UnaryOperator<RelBuilder.Config> transform)
RelBuilder
FlinkRelBuilder. watermark(int rowtimeFieldIndex, org.apache.calcite.rex.RexNode watermarkExpr)
Build watermark assigner relational node.RelBuilder
FlinkRelBuilder. windowAggregate(org.apache.flink.table.planner.plan.logical.LogicalWindow window, RelBuilder.GroupKey groupKey, List<NamedWindowProperty> namedProperties, Iterable<RelBuilder.AggCall> aggCalls)
Build window aggregate for either aggregate or table aggregate.Methods in org.apache.flink.table.planner.calcite with parameters of type RelBuilder Modifier and Type Method Description static RelBuilder
FlinkRelBuilder. pushFunctionScan(RelBuilder relBuilder, org.apache.calcite.sql.SqlOperator operator, int inputCount, Iterable<org.apache.calcite.rex.RexNode> operands, List<String> aliases)
functionScan(SqlOperator, int, Iterable)
cannot work smoothly with aliases which is why we implement a custom one. -
Uses of RelBuilder in org.apache.flink.table.planner.delegation
Methods in org.apache.flink.table.planner.delegation that return RelBuilder Modifier and Type Method Description RelBuilder
DefaultCalciteContext. createRelBuilder()
-
Uses of RelBuilder in org.apache.flink.table.planner.expressions
Methods in org.apache.flink.table.planner.expressions with parameters of type RelBuilder Modifier and Type Method Description static ResolvedExpression
DeclarativeExpressionResolver. toRexDistinctKey(RelBuilder builder, String name, LogicalType t)
static ResolvedExpression
DeclarativeExpressionResolver. toRexInputRef(RelBuilder builder, int i, LogicalType t)
Constructors in org.apache.flink.table.planner.expressions with parameters of type RelBuilder Constructor Description CallExpressionResolver(RelBuilder relBuilder)
DeclarativeExpressionResolver(RelBuilder relBuilder, DeclarativeAggregateFunction function, boolean isMerge)
SqlAggFunctionVisitor(RelBuilder relBuilder)
-
Uses of RelBuilder in org.apache.flink.table.planner.expressions.converter
Methods in org.apache.flink.table.planner.expressions.converter that return RelBuilder Modifier and Type Method Description RelBuilder
CallExpressionConvertRule.ConvertContext. getRelBuilder()
Constructors in org.apache.flink.table.planner.expressions.converter with parameters of type RelBuilder Constructor Description ExpressionConverter(RelBuilder relBuilder)
-
Uses of RelBuilder in org.apache.flink.table.planner.plan.nodes.exec.batch
Methods in org.apache.flink.table.planner.plan.nodes.exec.batch with parameters of type RelBuilder Modifier and Type Method Description protected Transformation<RowData>
BatchExecLookupJoin. createSyncLookupJoinWithState(Transformation<RowData> inputTransformation, org.apache.calcite.plan.RelOptTable temporalTable, ExecNodeConfig config, ClassLoader classLoader, Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys, TableFunction<?> syncLookupFunction, RelBuilder relBuilder, RowType inputRowType, RowType tableSourceRowType, RowType resultRowType, boolean isLeftOuterJoin, boolean isObjectReuseEnabled, boolean lookupKeyContainsPrimaryKey)
-
Uses of RelBuilder in org.apache.flink.table.planner.plan.nodes.exec.common
Methods in org.apache.flink.table.planner.plan.nodes.exec.common with parameters of type RelBuilder Modifier and Type Method Description protected ProcessFunction<RowData,RowData>
CommonExecLookupJoin. createSyncLookupJoinFunction(org.apache.calcite.plan.RelOptTable temporalTable, ExecNodeConfig config, ClassLoader classLoader, Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys, TableFunction<?> syncLookupFunction, RelBuilder relBuilder, RowType inputRowType, RowType tableSourceRowType, RowType resultRowType, boolean isLeftOuterJoin, boolean isObjectReuseEnabled)
protected abstract Transformation<RowData>
CommonExecLookupJoin. createSyncLookupJoinWithState(Transformation<RowData> inputTransformation, org.apache.calcite.plan.RelOptTable temporalTable, ExecNodeConfig config, ClassLoader classLoader, Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys, TableFunction<?> syncLookupFunction, RelBuilder relBuilder, RowType inputRowType, RowType tableSourceRowType, RowType resultRowType, boolean isLeftOuterJoin, boolean isObjectReuseEnabled, boolean lookupKeyContainsPrimaryKey)
protected org.apache.calcite.rel.type.RelDataType
CommonExecLookupJoin. getProjectionOutputRelDataType(RelBuilder relBuilder)
static Tuple2<Pattern<RowData,RowData>,List<String>>
CommonExecMatch. translatePattern(MatchSpec matchSpec, ReadableConfig config, ClassLoader classLoader, RelBuilder relBuilder, RowType inputRowType)
-
Uses of RelBuilder in org.apache.flink.table.planner.plan.nodes.exec.stream
Methods in org.apache.flink.table.planner.plan.nodes.exec.stream with parameters of type RelBuilder Modifier and Type Method Description protected Transformation<RowData>
StreamExecLookupJoin. createSyncLookupJoinWithState(Transformation<RowData> inputTransformation, org.apache.calcite.plan.RelOptTable temporalTable, ExecNodeConfig config, ClassLoader classLoader, Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys, TableFunction<?> syncLookupFunction, RelBuilder relBuilder, RowType inputRowType, RowType tableSourceRowType, RowType resultRowType, boolean isLeftOuterJoin, boolean isObjectReuseEnabled, boolean lookupKeyContainsPrimaryKey)
-
Uses of RelBuilder in org.apache.flink.table.planner.plan.rules.logical
Methods in org.apache.flink.table.planner.plan.rules.logical with parameters of type RelBuilder Modifier and Type Method Description protected List<org.apache.calcite.rex.RexNode>
PushFilterIntoSourceScanRuleBase. convertExpressionToRexNode(List<ResolvedExpression> expressions, RelBuilder relBuilder)
protected org.apache.calcite.rex.RexNode
PushFilterIntoSourceScanRuleBase. createRemainingCondition(RelBuilder relBuilder, List<ResolvedExpression> expressions, org.apache.calcite.rex.RexNode[] unconvertedPredicates)
protected void
WindowAggregateReduceFunctionsRule. newAggregateRel(RelBuilder relBuilder, org.apache.calcite.rel.core.Aggregate oldAgg, List<org.apache.calcite.rel.core.AggregateCall> newCalls)
protected void
WindowAggregateReduceFunctionsRule. newCalcRel(RelBuilder relBuilder, org.apache.calcite.rel.type.RelDataType rowType, List<org.apache.calcite.rex.RexNode> exprs)
protected scala.Tuple2<SupportsFilterPushDown.Result,org.apache.flink.table.planner.plan.schema.TableSourceTable>
PushFilterIntoSourceScanRuleBase. resolveFiltersAndCreateTableSourceTable(org.apache.calcite.rex.RexNode[] convertiblePredicates, org.apache.flink.table.planner.plan.schema.TableSourceTable oldTableSourceTable, org.apache.calcite.rel.core.TableScan scan, RelBuilder relBuilder)
Resolves filters using the underlying sourcesSupportsFilterPushDown
and creates a newTableSourceTable
with the supplied predicates. -
Uses of RelBuilder in org.apache.flink.table.planner.plan.utils
Methods in org.apache.flink.table.planner.plan.utils with parameters of type RelBuilder Modifier and Type Method Description static List<org.apache.calcite.rex.RexNode>
SetOpRewriteUtil. generateEqualsCondition(RelBuilder relBuilder, org.apache.calcite.rel.RelNode left, org.apache.calcite.rel.RelNode right, List<Integer> keys)
Generate equals condition by keys (The index on both sides is the same) to join left relNode and right relNode.static org.apache.calcite.rel.RelNode
SetOpRewriteUtil. replicateRows(RelBuilder relBuilder, org.apache.calcite.rel.type.RelDataType outputRelDataType, List<Integer> fields)
Use table function to replicate the row N times. -
Uses of RelBuilder in org.apache.flink.table.planner.utils
Methods in org.apache.flink.table.planner.utils with parameters of type RelBuilder Modifier and Type Method Description static org.apache.flink.table.planner.calcite.FlinkContext
ShortcutUtils. unwrapContext(RelBuilder relBuilder)
static org.apache.flink.table.planner.calcite.FlinkTypeFactory
ShortcutUtils. unwrapTypeFactory(RelBuilder relBuilder)
-