Modifier and Type | Field and Description |
---|---|
protected RelBuilder |
RelDecorrelator.relBuilder |
Modifier and Type | Method and Description |
---|---|
static org.apache.calcite.rel.RelNode |
RelDecorrelator.decorrelateQuery(org.apache.calcite.rel.RelNode rootRel,
RelBuilder relBuilder)
Decorrelates a query.
|
Constructor and Description |
---|
RelDecorrelator(RelDecorrelator.CorelMap cm,
org.apache.calcite.plan.Context context,
RelBuilder relBuilder) |
Modifier and Type | Method and 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 an
Aggregate with multiple calls. |
RelBuilder |
RelBuilder.aggregate(RelBuilder.GroupKey groupKey,
List<org.apache.calcite.rel.core.AggregateCall> aggregateCalls)
Creates an
Aggregate with an array of AggregateCall s. |
RelBuilder |
RelBuilder.aggregate(RelBuilder.GroupKey groupKey,
RelBuilder.AggCall... aggCalls)
Creates an
Aggregate 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 a
Correlate with a CorrelationId 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 a
Correlate with a CorrelationId 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 an
Aggregate 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 a
Filter 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 a
Filter 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 a
Filter of a list of correlation variables and an array of predicates. |
RelBuilder |
RelBuilder.filter(org.apache.calcite.rex.RexNode... predicates)
Creates a
Filter 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 a
TableFunctionScan . |
RelBuilder |
RelBuilder.functionScan(org.apache.calcite.sql.SqlOperator operator,
int inputCount,
org.apache.calcite.rex.RexNode... operands)
Creates a
TableFunctionScan . |
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 an
Intersect of the two most recent relational expressions on the stack. |
RelBuilder |
RelBuilder.intersect(boolean all,
int n)
Creates an
Intersect of the n 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 a
Join with multiple conditions. |
RelBuilder |
RelBuilder.join(org.apache.calcite.rel.core.JoinRelType joinType,
org.apache.calcite.rex.RexNode condition)
Creates a
Join with one condition. |
RelBuilder |
RelBuilder.join(org.apache.calcite.rel.core.JoinRelType joinType,
org.apache.calcite.rex.RexNode condition0,
org.apache.calcite.rex.RexNode... conditions)
Creates a
Join with an array of conditions. |
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 a
Join with correlating variables. |
RelBuilder |
RelBuilder.join(org.apache.calcite.rel.core.JoinRelType joinType,
String... fieldNames)
Creates a
Join using USING syntax. |
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 a
Match . |
RelBuilder |
RelBuilder.minus(boolean all)
Creates a
Minus of the two most recent relational expressions on the stack. |
RelBuilder |
RelBuilder.minus(boolean all,
int n)
Creates a
Minus of the n 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 a
Project of the given list of expressions. |
RelBuilder |
RelBuilder.project(Iterable<? extends org.apache.calcite.rex.RexNode> nodes,
Iterable<? extends String> fieldNames)
Creates a
Project of the given list of expressions and field names. |
RelBuilder |
RelBuilder.project(Iterable<? extends org.apache.calcite.rex.RexNode> nodes,
Iterable<? extends String> fieldNames,
boolean force)
Creates a
Project of the given list of expressions, using the given names. |
RelBuilder |
RelBuilder.project(org.apache.calcite.rex.RexNode... nodes)
Creates a
Project of the given expressions. |
RelBuilder |
RelBuilder.projectExcept(Iterable<org.apache.calcite.rex.RexNode> expressions)
Creates a
Project of all original fields, except the given list of expressions. |
RelBuilder |
RelBuilder.projectExcept(org.apache.calcite.rex.RexNode... expressions)
Creates a
Project of all original fields, except the given expressions. |
RelBuilder |
RelBuilder.projectNamed(Iterable<? extends org.apache.calcite.rex.RexNode> nodes,
@Nullable Iterable<? extends String> fieldNames,
boolean force)
Creates a
Project of the given expressions and field names, and optionally
optimizing. |
RelBuilder |
RelBuilder.projectPlus(Iterable<org.apache.calcite.rex.RexNode> nodes)
Creates a
Project of all original fields, plus the given list of expressions. |
RelBuilder |
RelBuilder.projectPlus(org.apache.calcite.rex.RexNode... nodes)
Creates a
Project 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 String> fieldNames)
Ensures that the field names match those given.
|
RelBuilder |
RelBuilder.repeatUnion(String tableName,
boolean all)
Creates a
RepeatUnion associated to a TransientTable without a maximum number
of iterations, i.e. repeatUnion(tableName, all, -1). |
RelBuilder |
RelBuilder.repeatUnion(String tableName,
boolean all,
int iterationLimit)
Creates a
RepeatUnion associated to a TransientTable of the two most recent
relational expressions on the stack. |
RelBuilder |
RelBuilder.scan(Iterable<String> tableNames)
Creates a
TableScan of the table with a given name. |
RelBuilder |
RelBuilder.scan(String... tableNames)
Creates a
TableScan of the table with a given name. |
RelBuilder |
RelBuilder.semiJoin(Iterable<? extends org.apache.calcite.rex.RexNode> conditions)
Creates a
Join with JoinRelType.SEMI . |
RelBuilder |
RelBuilder.semiJoin(org.apache.calcite.rex.RexNode... conditions)
Creates a
Join with JoinRelType.SEMI . |
RelBuilder |
RelBuilder.snapshot(org.apache.calcite.rex.RexNode period)
Creates a
Snapshot of a given snapshot period. |
RelBuilder |
RelBuilder.sort(int... fields)
Creates a
Sort by field ordinals. |
RelBuilder |
RelBuilder.sort(Iterable<? extends org.apache.calcite.rex.RexNode> nodes)
Creates a
Sort by expressions. |
RelBuilder |
RelBuilder.sort(org.apache.calcite.rel.RelCollation collation)
Creates a
Sort by specifying collations. |
RelBuilder |
RelBuilder.sort(org.apache.calcite.rex.RexNode... nodes)
Creates a
Sort 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 a
Sort by a list of expressions, with limit and offset. |
RelBuilder |
RelBuilder.sortLimit(int offset,
int fetch,
org.apache.calcite.rex.RexNode... nodes)
Creates a
Sort 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 a
Sort 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 a
TableScan on a TransientTable 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 a
TableScan on a TransientTable with the given name and type. |
RelBuilder |
RelBuilder.uncollect(List<String> itemAliases,
boolean withOrdinality)
Creates an
Uncollect with given item aliases. |
RelBuilder |
RelBuilder.union(boolean all)
Creates a
Union of the two most recent relational expressions on the stack. |
RelBuilder |
RelBuilder.union(boolean all,
int n)
Creates a
Union of the n 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(Iterable<? extends List<org.apache.calcite.rex.RexLiteral>> tupleList,
org.apache.calcite.rel.type.RelDataType rowType)
Creates a
Values with a specified row type. |
RelBuilder |
RelBuilder.values(org.apache.calcite.rel.type.RelDataType rowType)
Creates a
Values with a specified row type and zero rows. |
RelBuilder |
RelBuilder.values(org.apache.calcite.rel.type.RelDataType rowType,
Object... columnValues)
Creates a
Values with a specified row type. |
RelBuilder |
RelBuilder.values(@Nullable String[] fieldNames,
Object... values)
Creates a
Values . |
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.
|
Modifier and Type | Method and 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 the
current 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.
|
Modifier and Type | Method and Description |
---|---|
RelBuilder |
CalciteContext.createRelBuilder()
Create a builder for relational expressions provided by Flink's table planner.
|
Modifier and Type | Class and Description |
---|---|
class |
FlinkRelBuilder
Flink-specific
RelBuilder . |
Modifier and Type | Method and 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.
|
Modifier and Type | Method and 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. |
Modifier and Type | Method and Description |
---|---|
RelBuilder |
DefaultCalciteContext.createRelBuilder() |
Modifier and Type | Method and Description |
---|---|
static ResolvedExpression |
DeclarativeExpressionResolver.toRexDistinctKey(RelBuilder builder,
String name,
LogicalType t) |
static ResolvedExpression |
DeclarativeExpressionResolver.toRexInputRef(RelBuilder builder,
int i,
LogicalType t) |
Constructor and Description |
---|
CallExpressionResolver(RelBuilder relBuilder) |
DeclarativeExpressionResolver(RelBuilder relBuilder,
DeclarativeAggregateFunction function,
boolean isMerge) |
SqlAggFunctionVisitor(RelBuilder relBuilder) |
Modifier and Type | Method and Description |
---|---|
RelBuilder |
CallExpressionConvertRule.ConvertContext.getRelBuilder() |
Constructor and Description |
---|
ExpressionConverter(RelBuilder relBuilder) |
Modifier and Type | Method and 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) |
Modifier and Type | Method and 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) |
Modifier and Type | Method and 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) |
Modifier and Type | Method and 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 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 sources
SupportsFilterPushDown and creates a
new TableSourceTable with the supplied predicates. |
Modifier and Type | Method and 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) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.