Modifier and Type | Method and Description |
---|---|
default void |
BulkDecodingFormat.applyFilters(List<ResolvedExpression> filters)
Provides a list of filters in conjunctive form for filtering on a best-effort basis.
|
Modifier and Type | Method and Description |
---|---|
List<ResolvedExpression> |
SupportsFilterPushDown.Result.getAcceptedFilters() |
List<ResolvedExpression> |
SupportsFilterPushDown.Result.getRemainingFilters() |
Modifier and Type | Method and Description |
---|---|
SupportsFilterPushDown.Result |
SupportsFilterPushDown.applyFilters(List<ResolvedExpression> filters)
Provides a list of filters in conjunctive form.
|
static SupportsFilterPushDown.Result |
SupportsFilterPushDown.Result.of(List<ResolvedExpression> acceptedFilters,
List<ResolvedExpression> remainingFilters)
Constructs a filter push-down result.
|
static SupportsFilterPushDown.Result |
SupportsFilterPushDown.Result.of(List<ResolvedExpression> acceptedFilters,
List<ResolvedExpression> remainingFilters)
Constructs a filter push-down result.
|
Modifier and Type | Method and Description |
---|---|
ResolvedExpression |
Parser.parseSqlExpression(String sqlExpression,
TableSchema inputSchema)
Entry point for parsing SQL expressions expressed as a String.
|
Modifier and Type | Method and Description |
---|---|
TypeInferenceUtil.Result |
PlannerTypeInferenceUtil.runTypeInference(UnresolvedCallExpression unresolvedCall,
List<ResolvedExpression> resolvedArgs)
Same behavior as
TypeInferenceUtil#runTypeInference(TypeInference, CallContext) . |
Modifier and Type | Class and Description |
---|---|
class |
CallExpression
Resolved and validated call expression for calling a function.
|
class |
FieldReferenceExpression
A reference to a field in an input.
|
class |
LocalReferenceExpression
Reference to entity local to a certain
QueryOperation . |
class |
TableReferenceExpression
Expression that references another table.
|
class |
TypeLiteralExpression
Expression that wraps
DataType as a literal. |
class |
ValueLiteralExpression
Expression for constant literal values.
|
Modifier and Type | Method and Description |
---|---|
List<ResolvedExpression> |
TableReferenceExpression.getResolvedChildren() |
List<ResolvedExpression> |
LocalReferenceExpression.getResolvedChildren() |
List<ResolvedExpression> |
FieldReferenceExpression.getResolvedChildren() |
List<ResolvedExpression> |
ValueLiteralExpression.getResolvedChildren() |
List<ResolvedExpression> |
ResolvedExpression.getResolvedChildren() |
List<ResolvedExpression> |
CallExpression.getResolvedChildren() |
List<ResolvedExpression> |
TypeLiteralExpression.getResolvedChildren() |
Modifier and Type | Method and Description |
---|---|
CallExpression |
UnresolvedCallExpression.resolve(List<ResolvedExpression> args,
DataType dataType) |
TypeInferenceUtil.Result |
PlannerTypeInferenceUtilImpl.runTypeInference(UnresolvedCallExpression unresolvedCall,
List<ResolvedExpression> resolvedArgs) |
Constructor and Description |
---|
CallExpression(FunctionDefinition functionDefinition,
List<ResolvedExpression> args,
DataType dataType) |
CallExpression(FunctionIdentifier functionIdentifier,
FunctionDefinition functionDefinition,
List<ResolvedExpression> args,
DataType dataType) |
Modifier and Type | Method and Description |
---|---|
List<ResolvedExpression> |
ExpressionResolver.resolve(List<Expression> expressions)
Resolves given expressions with configured set of rules.
|
Modifier and Type | Method and Description |
---|---|
CallExpression |
ExpressionResolver.PostResolverFactory.array(DataType dataType,
ResolvedExpression... expression) |
CallExpression |
ExpressionResolver.PostResolverFactory.as(ResolvedExpression expression,
String alias) |
CallExpression |
ExpressionResolver.PostResolverFactory.cast(ResolvedExpression expression,
DataType dataType) |
CallExpression |
ExpressionResolver.PostResolverFactory.get(ResolvedExpression composite,
ValueLiteralExpression key,
DataType dataType) |
CallExpression |
ExpressionResolver.PostResolverFactory.map(DataType dataType,
ResolvedExpression... expression) |
CallExpression |
ExpressionResolver.PostResolverFactory.row(DataType dataType,
ResolvedExpression... expression) |
CallExpression |
ExpressionResolver.PostResolverFactory.wrappingCall(BuiltInFunctionDefinition definition,
ResolvedExpression expression) |
Modifier and Type | Method and Description |
---|---|
protected abstract T |
ResolvedExpressionDefaultVisitor.defaultMethod(ResolvedExpression expression) |
Modifier and Type | Method and Description |
---|---|
List<ResolvedExpression> |
FileSystemFormatFactory.ReaderContext.getPushedDownFilters()
Pushed down filters, reader can try its best to filter records.
|
Modifier and Type | Method and Description |
---|---|
SupportsFilterPushDown.Result |
FileSystemTableSource.applyFilters(List<ResolvedExpression> filters) |
Modifier and Type | Method and Description |
---|---|
ResolvedExpression |
JoinQueryOperation.getCondition() |
ResolvedExpression |
FilterQueryOperation.getCondition() |
Modifier and Type | Method and Description |
---|---|
List<ResolvedExpression> |
AggregateQueryOperation.getAggregateExpressions() |
List<ResolvedExpression> |
WindowAggregateQueryOperation.getAggregateExpressions() |
List<ResolvedExpression> |
CalculatedQueryOperation.getArguments() |
List<ResolvedExpression> |
AggregateQueryOperation.getGroupingExpressions() |
List<ResolvedExpression> |
WindowAggregateQueryOperation.getGroupingExpressions() |
List<ResolvedExpression> |
SortQueryOperation.getOrder() |
List<ResolvedExpression> |
ProjectQueryOperation.getProjectList() |
List<List<ResolvedExpression>> |
ValuesQueryOperation.getValues() |
List<ResolvedExpression> |
WindowAggregateQueryOperation.getWindowPropertiesExpressions() |
Constructor and Description |
---|
FilterQueryOperation(ResolvedExpression condition,
QueryOperation child) |
JoinQueryOperation(QueryOperation left,
QueryOperation right,
JoinQueryOperation.JoinType joinType,
ResolvedExpression condition,
boolean correlated) |
Modifier and Type | Method and Description |
---|---|
static List<Optional<String>> |
OperationExpressionsUtils.extractNames(List<ResolvedExpression> expressions)
Extracts names from given expressions if they have one.
|
Modifier and Type | Method and Description |
---|---|
ResolvedExpression |
ParserImpl.parseSqlExpression(String sqlExpression,
TableSchema inputSchema) |
Modifier and Type | Method and Description |
---|---|
ResolvedExpression |
ParserImpl.parseSqlExpression(String sqlExpression,
TableSchema inputSchema) |
Modifier and Type | Class and Description |
---|---|
class |
RexNodeExpression
Dummy wrapper for expressions that were converted to RexNode in a different way.
|
Modifier and Type | Method and Description |
---|---|
protected ResolvedExpression |
DeclarativeExpressionResolver.defaultMethod(Expression expression) |
ResolvedExpression |
CallExpressionResolver.resolve(Expression expression) |
abstract ResolvedExpression |
DeclarativeExpressionResolver.toAccInputExpr(String name,
int localIndex)
When accumulate phase, for inputs.
|
abstract ResolvedExpression |
DeclarativeExpressionResolver.toAggBufferExpr(String name,
int localIndex)
For aggregate buffer.
|
abstract ResolvedExpression |
DeclarativeExpressionResolver.toMergeInputExpr(String name,
int localIndex)
When merge phase, for inputs.
|
static ResolvedExpression |
DeclarativeExpressionResolver.toRexDistinctKey(org.apache.calcite.tools.RelBuilder builder,
String name,
LogicalType t) |
static ResolvedExpression |
DeclarativeExpressionResolver.toRexInputRef(org.apache.calcite.tools.RelBuilder builder,
int i,
LogicalType t) |
Modifier and Type | Method and Description |
---|---|
List<ResolvedExpression> |
RexNodeExpression.getResolvedChildren() |
Modifier and Type | Method and Description |
---|---|
TypeInferenceUtil.Result |
PlannerTypeInferenceUtilImpl.runTypeInference(UnresolvedCallExpression unresolvedCall,
List<ResolvedExpression> resolvedArgs) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.