| Modifier and Type | Field and Description |
|---|---|
LogicalExpression |
IfExpression.IfCondition.condition |
LogicalExpression |
IfExpression.elseExpression |
LogicalExpression |
IfExpression.IfCondition.expression |
| Modifier and Type | Field and Description |
|---|---|
org.apache.drill.shaded.guava.com.google.common.collect.ImmutableList<LogicalExpression> |
FunctionHolderExpression.args |
protected org.apache.drill.shaded.guava.com.google.common.collect.ImmutableList<LogicalExpression> |
FunctionCall.args |
| Modifier and Type | Method and Description |
|---|---|
LogicalExpression |
FunctionCall.arg(int i) |
static LogicalExpression |
ExpressionFunction.create(String functionName,
List<LogicalExpression> expressions) |
static LogicalExpression |
FunctionCallFactory.createAnyValue(ExpressionPosition ep,
LogicalExpression expr) |
static LogicalExpression |
FunctionCallFactory.createAnyValue(String functionName,
List<LogicalExpression> args) |
static LogicalExpression |
FunctionCallFactory.createBooleanOperator(String functionName,
ExpressionPosition ep,
List<LogicalExpression> args) |
static LogicalExpression |
FunctionCallFactory.createBooleanOperator(String functionName,
List<LogicalExpression> args) |
static LogicalExpression |
FunctionCallFactory.createByOp(List<LogicalExpression> args,
ExpressionPosition ep,
List<String> opTypes) |
static LogicalExpression |
FunctionCallFactory.createCast(TypeProtos.MajorType type,
ExpressionPosition ep,
LogicalExpression expr) |
static LogicalExpression |
FunctionCallFactory.createConvert(String function,
String conversionType,
LogicalExpression expr,
ExpressionPosition ep) |
static LogicalExpression |
FunctionCallFactory.createExpression(String functionName,
ExpressionPosition ep,
List<LogicalExpression> args) |
static LogicalExpression |
FunctionCallFactory.createExpression(String functionName,
ExpressionPosition ep,
LogicalExpression... e) |
static LogicalExpression |
FunctionCallFactory.createExpression(String functionName,
List<LogicalExpression> args) |
LogicalExpression |
LogicalExpression.De.deserialize(com.fasterxml.jackson.core.JsonParser jp,
com.fasterxml.jackson.databind.DeserializationContext ctxt) |
static LogicalExpression |
ValueExpressions.getBigInt(long l) |
static LogicalExpression |
ValueExpressions.getBit(boolean b) |
static LogicalExpression |
ValueExpressions.getChar(String s,
int precision) |
static LogicalExpression |
ValueExpressions.getDate(GregorianCalendar date) |
static LogicalExpression |
ValueExpressions.getDate(long milliSecond) |
static LogicalExpression |
ValueExpressions.getFloat4(float f) |
static LogicalExpression |
ValueExpressions.getFloat8(double d) |
LogicalExpression |
ConvertExpression.getInput() |
LogicalExpression |
CastExpression.getInput() |
LogicalExpression |
AnyValueExpression.getInput() |
static LogicalExpression |
ValueExpressions.getInt(int i) |
static LogicalExpression |
ValueExpressions.getIntervalDay(long intervalInMillis) |
static LogicalExpression |
ValueExpressions.getIntervalYear(int months) |
static LogicalExpression |
ValueExpressions.getNumericExpression(String sign,
String s,
ExpressionPosition ep) |
static LogicalExpression |
ValueExpressions.getParameterExpression(String name,
TypeProtos.MajorType type) |
static LogicalExpression |
ValueExpressions.getTime(GregorianCalendar time) |
static LogicalExpression |
ValueExpressions.getTime(int milliSeconds) |
static LogicalExpression |
ValueExpressions.getTimeStamp(GregorianCalendar date) |
static LogicalExpression |
ValueExpressions.getTimeStamp(long milliSeconds) |
static LogicalExpression |
ValueExpressions.getVarDecimal(BigDecimal input,
int precision,
int scale) |
| Modifier and Type | Method and Description |
|---|---|
List<LogicalExpression> |
FunctionCall.args() |
Iterator<LogicalExpression> |
IfExpression.iterator() |
Iterator<LogicalExpression> |
SchemaPath.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.ValueExpression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.FloatExpression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.IntExpression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.Decimal9Expression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.Decimal18Expression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.Decimal28Expression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.Decimal38Expression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.VarDecimalExpression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.DoubleExpression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.LongExpression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.DateExpression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.TimeExpression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.TimeStampExpression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.IntervalYearExpression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.IntervalDayExpression.iterator() |
Iterator<LogicalExpression> |
ValueExpressions.ParameterExpression.iterator() |
Iterator<LogicalExpression> |
NullExpression.iterator() |
Iterator<LogicalExpression> |
TypedNullConstant.iterator() |
Iterator<LogicalExpression> |
ConvertExpression.iterator() |
Iterator<LogicalExpression> |
MajorTypeInLogicalExpression.iterator() |
Iterator<LogicalExpression> |
FunctionCall.iterator() |
Iterator<LogicalExpression> |
TypedFieldExpr.iterator() |
Iterator<LogicalExpression> |
CastExpression.iterator() |
Iterator<LogicalExpression> |
AnyValueExpression.iterator() |
| Modifier and Type | Method and Description |
|---|---|
static LogicalExpression |
FunctionCallFactory.createAnyValue(ExpressionPosition ep,
LogicalExpression expr) |
static LogicalExpression |
FunctionCallFactory.createCast(TypeProtos.MajorType type,
ExpressionPosition ep,
LogicalExpression expr) |
static LogicalExpression |
FunctionCallFactory.createConvert(String function,
String conversionType,
LogicalExpression expr,
ExpressionPosition ep) |
static LogicalExpression |
FunctionCallFactory.createExpression(String functionName,
ExpressionPosition ep,
LogicalExpression... e) |
void |
LogicalExpression.Se.serialize(LogicalExpression value,
com.fasterxml.jackson.core.JsonGenerator jgen,
com.fasterxml.jackson.databind.SerializerProvider provider) |
IfExpression.Builder |
IfExpression.Builder.setElse(LogicalExpression elseExpression) |
static String |
ExpressionStringBuilder.toString(LogicalExpression expr) |
static void |
ExpressionStringBuilder.toString(LogicalExpression expr,
StringBuilder sb) |
Void |
ExpressionStringBuilder.visitUnknown(LogicalExpression e,
StringBuilder sb) |
| Constructor and Description |
|---|
AnyValueExpression(LogicalExpression input,
ExpressionPosition pos) |
CastExpression(LogicalExpression input,
TypeProtos.MajorType type,
ExpressionPosition pos) |
ConvertExpression(String convertFunction,
String encodingType,
LogicalExpression input,
ExpressionPosition pos) |
IfCondition(LogicalExpression condition,
LogicalExpression expression) |
| Constructor and Description |
|---|
BooleanOperator(String name,
List<LogicalExpression> args,
ExpressionPosition pos) |
FunctionCall(String name,
List<LogicalExpression> args,
ExpressionPosition pos) |
FunctionHolderExpression(String nameUsed,
ExpressionPosition pos,
List<LogicalExpression> args) |
| Modifier and Type | Method and Description |
|---|---|
FunctionHolderExpression |
FuncHolder.getExpr(String name,
List<LogicalExpression> args,
ExpressionPosition pos)
Return a reference to this function given a function alias and a
list of actual arguments.
|
| Modifier and Type | Method and Description |
|---|---|
LogicalExpression |
ConditionalExprOptimizer.visitAnyValueExpression(AnyValueExpression cast,
Void value) |
LogicalExpression |
ConditionalExprOptimizer.visitBooleanOperator(BooleanOperator op,
Void value) |
LogicalExpression |
ConditionalExprOptimizer.visitCastExpression(CastExpression cast,
Void value) |
LogicalExpression |
ConditionalExprOptimizer.visitConvertExpression(ConvertExpression cast,
Void value) |
LogicalExpression |
ConditionalExprOptimizer.visitFunctionCall(FunctionCall call,
Void value) |
LogicalExpression |
ConditionalExprOptimizer.visitFunctionHolderExpression(FunctionHolderExpression holder,
Void value) |
LogicalExpression |
ConditionalExprOptimizer.visitIfExpression(IfExpression ifExpr,
Void value) |
LogicalExpression |
ConditionalExprOptimizer.visitUnknown(LogicalExpression e,
Void value) |
| Modifier and Type | Method and Description |
|---|---|
static boolean |
AggregateChecker.isAggregating(LogicalExpression e,
ErrorCollector errors) |
Boolean |
AggregateChecker.visitUnknown(LogicalExpression e,
ErrorCollector errors) |
Void |
ExpressionValidator.visitUnknown(LogicalExpression e,
ErrorCollector value) |
T |
AbstractExprVisitor.visitUnknown(LogicalExpression e,
VAL value)
Handles implementation-specific expressions not known to the visitor
structure.
|
T |
ExprVisitor.visitUnknown(LogicalExpression e,
VAL value) |
LogicalExpression |
ConditionalExprOptimizer.visitUnknown(LogicalExpression e,
Void value) |
| Modifier and Type | Method and Description |
|---|---|
LogicalExpression |
Order.Ordering.getExpr() |
LogicalExpression |
Flatten.getExpr() |
LogicalExpression |
NamedExpression.getExpr() |
LogicalExpression |
Filter.getExpr() |
LogicalExpression |
JoinCondition.getLeft() |
LogicalExpression |
JoinCondition.getRight() |
| Modifier and Type | Method and Description |
|---|---|
Window.Builder |
Window.Builder.addAggregation(FieldReference ref,
LogicalExpression expr) |
Join.Builder |
Join.Builder.addCondition(String relationship,
LogicalExpression left,
LogicalExpression right) |
GroupingAggregate.Builder |
GroupingAggregate.Builder.addExpr(FieldReference ref,
LogicalExpression expr) |
Project.Builder |
Project.Builder.addExpr(FieldReference ref,
LogicalExpression expr) |
GroupingAggregate.Builder |
GroupingAggregate.Builder.addKey(FieldReference ref,
LogicalExpression expr) |
Order.Builder |
Order.Builder.addOrdering(org.apache.calcite.rel.RelFieldCollation.Direction direction,
LogicalExpression e,
org.apache.calcite.rel.RelFieldCollation.NullDirection collation) |
Window.Builder |
Window.Builder.addWithin(FieldReference within,
LogicalExpression expr) |
| Constructor and Description |
|---|
Filter(LogicalExpression expr) |
Flatten(FieldReference name,
LogicalExpression expr,
boolean drop) |
JoinCondition(String relationship,
LogicalExpression left,
LogicalExpression right) |
NamedExpression(LogicalExpression expr,
FieldReference ref) |
Ordering(org.apache.calcite.rel.RelFieldCollation.Direction direction,
LogicalExpression e) |
Ordering(org.apache.calcite.rel.RelFieldCollation.Direction direction,
LogicalExpression e,
org.apache.calcite.rel.RelFieldCollation.NullDirection nullOrdering) |
Ordering(String strOrderingSpec,
LogicalExpression expr,
String strNullOrdering)
Constructs a sort specification.
|
| Modifier and Type | Method and Description |
|---|---|
static LogicalExpression |
LogicalExpressionParser.parse(String expr)
Initializes logical expression lexer and parser, add error listener that converts all
syntax error into
ExpressionParsingException. |
| Modifier and Type | Method and Description |
|---|---|
LogicalExpression |
ExecTest.parseExpr(String expr) |
| Modifier and Type | Method and Description |
|---|---|
static Set<LogicalExpression> |
ConstantExpressionIdentifier.getConstantExpressionSet(LogicalExpression e)
Get a list of expressions that mark boundaries into a constant space.
|
| Modifier and Type | Method and Description |
|---|---|
static Set<LogicalExpression> |
ConstantExpressionIdentifier.getConstantExpressionSet(LogicalExpression e)
Get a list of expressions that mark boundaries into a constant space.
|
Boolean |
ConstantExpressionIdentifier.visitUnknown(LogicalExpression e,
IdentityHashMap<LogicalExpression,Object> value) |
| Modifier and Type | Class and Description |
|---|---|
class |
BooleanPredicate<C extends Comparable<C>> |
class |
ComparisonPredicate<C extends Comparable<C>>
Comparison predicates for metadata filter pushdown.
|
class |
DrillFuncHolderExpr
Represents the call of a function within a query and includes
the actual arguments and a reference to the function declaration (as a
"function holder.")
|
class |
HiveFuncHolderExpr |
class |
HoldingContainerExpression
Wrapper around a representation of a "Holder" to represent that
Holder as an expression.
|
class |
IsPredicate<C extends Comparable<C>> |
class |
ValueVectorReadExpression
Wraps a value vector field to be read, providing metadata about the field.
|
class |
ValueVectorWriteExpression |
| Modifier and Type | Method and Description |
|---|---|
Iterator<LogicalExpression> |
HiveFuncHolderExpr.iterator() |
Iterator<LogicalExpression> |
ComparisonPredicate.iterator() |
Iterator<LogicalExpression> |
ValueVectorWriteExpression.iterator() |
Iterator<LogicalExpression> |
HoldingContainerExpression.iterator() |
Iterator<LogicalExpression> |
ValueVectorReadExpression.iterator() |
Iterator<LogicalExpression> |
IsPredicate.iterator() |
Iterator<LogicalExpression> |
DrillFuncHolderExpr.iterator() |
| Modifier and Type | Method and Description |
|---|---|
static LogicalExpression |
ExpressionTreeMaterializer.addCastExpression(LogicalExpression fromExpr,
TypeProtos.MajorType toType,
FunctionLookupContext functionLookupContext,
ErrorCollector errorCollector) |
static LogicalExpression |
ExpressionTreeMaterializer.addCastExpression(LogicalExpression fromExpr,
TypeProtos.MajorType toType,
FunctionLookupContext functionLookupContext,
ErrorCollector errorCollector,
boolean exactResolver) |
ClassGenerator.HoldingContainer |
ClassGenerator.addExpr(LogicalExpression ex) |
ClassGenerator.HoldingContainer |
ClassGenerator.addExpr(LogicalExpression ex,
ClassGenerator.BlkCreateMode mode) |
ClassGenerator.HoldingContainer |
EvaluationVisitor.addExpr(LogicalExpression e,
ClassGenerator<?> generator) |
static FilterPredicate<?> |
FilterBuilder.buildFilterPredicate(LogicalExpression expr,
Set<LogicalExpression> constantBoundaries,
UdfUtilities udfUtilities,
boolean omitUnsupportedExprs) |
static LogicalExpression |
ExpressionTreeMaterializer.convertToNullableType(LogicalExpression fromExpr,
TypeProtos.MinorType toType,
FunctionLookupContext functionLookupContext,
ErrorCollector errorCollector) |
static <C extends Comparable<C>> |
ComparisonPredicate.createComparisonPredicate(String function,
LogicalExpression left,
LogicalExpression right) |
static <C extends Comparable<C>> |
IsPredicate.createIsPredicate(String function,
LogicalExpression expr) |
static <V> ColumnStatistics<V> |
StatisticsProvider.getConstantColumnStatistics(V minMaxValue,
LogicalExpression expr)
Returns
ColumnStatistics instance with min and max values set to minMaxValue
and nulls count set to 0. |
static LogicalExpression |
ExpressionTreeMaterializer.materialize(LogicalExpression expr,
Map<VectorAccessible,BatchReference> batches,
ErrorCollector errorCollector,
FunctionLookupContext functionLookupContext,
boolean allowComplexWriterExpr,
boolean unionTypeEnabled)
Materializes logical expression taking into account passed parameters.
|
static LogicalExpression |
ExpressionTreeMaterializer.materialize(LogicalExpression expr,
VectorAccessible batch,
ErrorCollector errorCollector,
FunctionLookupContext functionLookupContext) |
static LogicalExpression |
ExpressionTreeMaterializer.materialize(LogicalExpression expr,
VectorAccessible batch,
ErrorCollector errorCollector,
FunctionLookupContext functionLookupContext,
boolean allowComplexWriterExpr) |
static LogicalExpression |
ExpressionTreeMaterializer.materialize(LogicalExpression expr,
VectorAccessible batch,
ErrorCollector errorCollector,
FunctionLookupContext functionLookupContext,
boolean allowComplexWriterExpr,
boolean unionTypeEnabled)
Materializes logical expression taking into account passed parameters.
|
static LogicalExpression |
ExpressionTreeMaterializer.materializeAndCheckErrors(LogicalExpression expr,
VectorAccessible batch,
FunctionLookupContext functionLookupContext) |
static LogicalExpression |
ExpressionTreeMaterializer.materializeFilterExpr(LogicalExpression expr,
TupleMetadata fieldTypes,
ErrorCollector errorCollector,
FunctionLookupContext functionLookupContext) |
LogicalExpression |
FilterBuilder.visitUnknown(LogicalExpression e,
Set<LogicalExpression> value) |
ColumnStatistics<?> |
StatisticsProvider.visitUnknown(LogicalExpression e,
Void value) |
LogicalExpression |
CloneVisitor.visitUnknown(LogicalExpression e,
Void value) |
Integer |
HashVisitor.visitUnknown(LogicalExpression e,
Void value) |
| Constructor and Description |
|---|
ValueVectorWriteExpression(TypedFieldId fieldId,
LogicalExpression child) |
ValueVectorWriteExpression(TypedFieldId fieldId,
LogicalExpression child,
boolean safe) |
| Constructor and Description |
|---|
DrillFuncHolderExpr(String nameUsed,
DrillFuncHolder holder,
List<LogicalExpression> args,
ExpressionPosition pos) |
HiveFuncHolderExpr(String nameUsed,
HiveFuncHolder holder,
List<LogicalExpression> args,
ExpressionPosition pos) |
| Modifier and Type | Method and Description |
|---|---|
TypeProtos.MajorType |
FunctionTemplate.ReturnType.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes) |
| Modifier and Type | Method and Description |
|---|---|
static LogicalExpression |
FunctionGenerationHelper.getOrderingComparator(boolean null_high,
ClassGenerator.HoldingContainer left,
ClassGenerator.HoldingContainer right,
FunctionLookupContext functionLookupContext)
Finds ordering comparator ("compare_to...") FunctionHolderExpression with
a specified ordering for NULL (and considering NULLS equal).
|
static LogicalExpression |
FunctionGenerationHelper.getOrderingComparatorNullsHigh(ClassGenerator.HoldingContainer left,
ClassGenerator.HoldingContainer right,
FunctionLookupContext registry)
Finds ordering comparator ("compare_to...") FunctionHolderExpression with
a "NULL high" ordering (and considering NULLS equal).
|
| Modifier and Type | Method and Description |
|---|---|
FunctionHolderExpression |
HiveFuncHolder.getExpr(String name,
List<LogicalExpression> args,
ExpressionPosition pos) |
FunctionHolderExpression |
DrillFuncHolder.getExpr(String name,
List<LogicalExpression> args,
ExpressionPosition pos) |
TypeProtos.MajorType |
DrillFuncHolder.getReturnType(List<LogicalExpression> logicalExpressions) |
static TypeProtos.DataMode |
FunctionUtils.getReturnTypeDataMode(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes)
Calculates return type data mode based on give logical expressions.
|
| Modifier and Type | Method and Description |
|---|---|
ValueVectorHashHelper.Hash64 |
ValueVectorHashHelper.getHash64(LogicalExpression[] hashFieldsExp,
TypedFieldId[] hashFieldIds) |
| Modifier and Type | Method and Description |
|---|---|
static void |
InterpreterEvaluator.evaluate(int recordCount,
UdfUtilities udfUtilities,
VectorAccessible incoming,
ValueVector outVV,
LogicalExpression expr) |
static void |
InterpreterEvaluator.evaluate(RecordBatch incoming,
ValueVector outVV,
LogicalExpression expr) |
static ValueHolder |
InterpreterEvaluator.evaluateConstantExpr(UdfUtilities udfUtilities,
LogicalExpression expr) |
ValueHolder |
InterpreterEvaluator.EvalVisitor.visitUnknown(LogicalExpression e,
Integer inIndex) |
| Modifier and Type | Method and Description |
|---|---|
TypeProtos.MajorType |
ReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes) |
TypeProtos.MajorType |
PadReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes)
Defines function return type and sets precision if it pad length parameter is int expression.
|
TypeProtos.MajorType |
DefaultReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes)
Calculates return type and its nullability.
|
TypeProtos.MajorType |
StringCastReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes)
Defines function return type and sets cast length as type precision
if cast length is simple long expression.
|
TypeProtos.MajorType |
SameInOutLengthReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes)
Defines function return type and sets precision and scale if input type has them.
|
TypeProtos.MajorType |
ConcatReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes)
Defines function return type and sets precision if it can be calculated.
|
TypeProtos.MajorType |
DecimalReturnTypeInference.DecimalAddReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes)
This return type is used by add and subtract functions for decimal data type.
|
TypeProtos.MajorType |
DecimalReturnTypeInference.DecimalAggReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes) |
TypeProtos.MajorType |
DecimalReturnTypeInference.DecimalCastReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes) |
TypeProtos.MajorType |
DecimalReturnTypeInference.DecimalDivScaleReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes)
Return type is used by divide functions for decimal data type.
|
TypeProtos.MajorType |
DecimalReturnTypeInference.DecimalMaxScaleReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes) |
TypeProtos.MajorType |
DecimalReturnTypeInference.DecimalModScaleReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes)
Return type is used by divide functions for decimal data type.
|
TypeProtos.MajorType |
DecimalReturnTypeInference.DecimalSetScaleReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes) |
TypeProtos.MajorType |
DecimalReturnTypeInference.DecimalSumAggReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes) |
TypeProtos.MajorType |
DecimalReturnTypeInference.DecimalAvgAggReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes) |
TypeProtos.MajorType |
DecimalReturnTypeInference.DecimalSumScaleReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes) |
TypeProtos.MajorType |
DecimalReturnTypeInference.DecimalZeroScaleReturnTypeInference.getType(List<LogicalExpression> logicalExpressions,
FunctionAttributes attributes)
Return type is used for functions where we need to remove the scale part.
|
| Modifier and Type | Field and Description |
|---|---|
protected LogicalExpression |
AbstractJoinPop.condition |
protected LogicalExpression |
AbstractGroupScanWithMetadata.filter |
protected LogicalExpression |
AbstractGroupScanWithMetadata.GroupScanWithMetadataFilterer.filterExpression |
| Modifier and Type | Method and Description |
|---|---|
LogicalExpression |
AbstractJoinPop.getCondition() |
LogicalExpression |
AbstractGroupScan.getFilter() |
LogicalExpression |
AbstractGroupScanWithMetadata.getFilter() |
LogicalExpression |
GroupScan.getFilter() |
static LogicalExpression |
PhysicalOperatorUtil.materializeExpression(LogicalExpression expr,
VectorAccessible incoming,
FragmentContext context)
Helper method to materialize the given logical expression using the
ExpressionTreeMaterializer. |
| Modifier and Type | Method and Description |
|---|---|
GroupScan |
AbstractGroupScan.applyFilter(LogicalExpression filterExpr,
UdfUtilities udfUtilities,
FunctionImplementationRegistry functionImplementationRegistry,
OptionManager optionManager) |
AbstractGroupScanWithMetadata<?> |
AbstractGroupScanWithMetadata.applyFilter(LogicalExpression filterExpr,
UdfUtilities udfUtilities,
FunctionImplementationRegistry functionImplementationRegistry,
OptionManager optionManager)
Applies specified filter
filterExpr to current group scan and produces filtering at:
table level:
if filter matches all the the data or prunes all the data, sets corresponding value to
AbstractGroupScanWithMetadata.isMatchAllMetadata() and returns null
segment level:
if filter matches all the the data or prunes all the data, sets corresponding value to
AbstractGroupScanWithMetadata.isMatchAllMetadata() and returns null
if segment metadata was pruned, prunes underlying metadata
partition level:
if filter matches all the the data or prunes all the data, sets corresponding value to
AbstractGroupScanWithMetadata.isMatchAllMetadata() and returns null
if partition metadata was pruned, prunes underlying metadata
file level:
if filter matches all the the data or prunes all the data, sets corresponding value to
AbstractGroupScanWithMetadata.isMatchAllMetadata() and returns null
|
GroupScan |
GroupScan.applyFilter(LogicalExpression filterExpr,
UdfUtilities udfUtilities,
FunctionImplementationRegistry functionImplementationRegistry,
OptionManager optionManager) |
B |
AbstractGroupScanWithMetadata.GroupScanWithMetadataFilterer.filterExpression(LogicalExpression filterExpression) |
FilterPredicate<?> |
AbstractGroupScanWithMetadata.getFilterPredicate(LogicalExpression filterExpr,
UdfUtilities udfUtilities,
FunctionLookupContext functionImplementationRegistry,
OptionManager optionManager,
boolean omitUnsupportedExprs) |
static FilterPredicate<?> |
AbstractGroupScanWithMetadata.getFilterPredicate(LogicalExpression filterExpr,
UdfUtilities udfUtilities,
FunctionLookupContext functionImplementationRegistry,
OptionManager optionManager,
boolean omitUnsupportedExprs,
boolean supportsFileImplicitColumns,
TupleMetadata schema)
Returns parquet filter predicate built from specified
filterExpr. |
static LogicalExpression |
PhysicalOperatorUtil.materializeExpression(LogicalExpression expr,
VectorAccessible incoming,
FragmentContext context)
Helper method to materialize the given logical expression using the
ExpressionTreeMaterializer. |
void |
AbstractGroupScanWithMetadata.setFilter(LogicalExpression filter) |
void |
AbstractGroupScanWithMetadata.setFilterForRuntime(LogicalExpression filterExpr,
OptimizerRulesContext optimizerContext)
Set the filter - thus enabling runtime rowgroup pruning
The runtime pruning can be disabled with an option.
|
| Constructor and Description |
|---|
AbstractGroupScanWithMetadata(String userName,
List<SchemaPath> columns,
LogicalExpression filter) |
AbstractJoinPop(PhysicalOperator leftOp,
PhysicalOperator rightOp,
org.apache.calcite.rel.core.JoinRelType joinType,
boolean semiJoin,
LogicalExpression joinCondition,
List<JoinCondition> joinConditions) |
| Modifier and Type | Field and Description |
|---|---|
protected LogicalExpression |
AbstractDeMuxExchange.expr |
| Modifier and Type | Method and Description |
|---|---|
LogicalExpression |
HashPartitionSender.getExpr() |
LogicalExpression |
Filter.getExpr() |
LogicalExpression |
AbstractDeMuxExchange.getExpression() |
LogicalExpression |
HashToRandomExchange.getExpression() |
LogicalExpression |
PartitionRange.getFinish() |
LogicalExpression |
PartitionRange.getStart() |
| Modifier and Type | Method and Description |
|---|---|
void |
TestSimpleFunctions.resolveHash(LogicalExpression arg,
TypeProtos.DataMode expectedBestInputMode,
FunctionImplementationRegistry registry) |
| Modifier and Type | Method and Description |
|---|---|
protected void |
StreamingAggBatch.addRecordValues(ClassGenerator<StreamingAggregator> cg,
LogicalExpression[] valueExprs) |
protected void |
StreamingAggBatch.outputRecordKeys(ClassGenerator<StreamingAggregator> cg,
TypedFieldId[] keyOutputIds,
LogicalExpression[] keyExprs) |
protected void |
StreamingAggBatch.outputRecordKeysPrev(ClassGenerator<StreamingAggregator> cg,
TypedFieldId[] keyOutputIds,
LogicalExpression[] keyExprs) |
void |
HashAggTemplate.setup(HashAggregate hashAggrConfig,
HashTableConfig htConfig,
FragmentContext context,
OperatorContext oContext,
RecordBatch incoming,
HashAggBatch outgoing,
LogicalExpression[] valueExprs,
List<TypedFieldId> valueFieldIds,
ClassGenerator<?> cg,
TypedFieldId[] groupByOutFieldIds,
VectorContainer outContainer,
int extraRowBytes) |
void |
HashAggregator.setup(HashAggregate hashAggrConfig,
HashTableConfig htConfig,
FragmentContext context,
OperatorContext oContext,
RecordBatch incoming,
HashAggBatch outgoing,
LogicalExpression[] valueExprs,
List<TypedFieldId> valueFieldIds,
ClassGenerator<?> cg,
TypedFieldId[] keyFieldIds,
VectorContainer outContainer,
int extraRowBytes) |
protected void |
StreamingAggBatch.setupIsSame(ClassGenerator<StreamingAggregator> cg,
LogicalExpression[] keyExprs) |
protected void |
StreamingAggBatch.setupIsSameApart(ClassGenerator<StreamingAggregator> cg,
LogicalExpression[] keyExprs) |
| Modifier and Type | Class and Description |
|---|---|
class |
ReturnValueExpression |
| Modifier and Type | Method and Description |
|---|---|
LogicalExpression |
ReturnValueExpression.getChild() |
| Modifier and Type | Method and Description |
|---|---|
Iterator<LogicalExpression> |
ReturnValueExpression.iterator() |
| Constructor and Description |
|---|
ReturnValueExpression(LogicalExpression child) |
ReturnValueExpression(LogicalExpression child,
boolean returnTrueOnOne) |
| Modifier and Type | Method and Description |
|---|---|
static void |
JoinUtils.addLeastRestrictiveCasts(LogicalExpression[] leftExpressions,
VectorAccessible leftBatch,
LogicalExpression[] rightExpressions,
VectorAccessible rightBatch,
FragmentContext context)
Utility method used by joins to add implicit casts on one of the sides of the join condition in case the two
expressions have different types.
|
static void |
JoinUtils.addLeastRestrictiveCasts(LogicalExpression[] leftExpressions,
VectorAccessible leftBatch,
LogicalExpression[] rightExpressions,
VectorAccessible rightBatch,
FragmentContext context)
Utility method used by joins to add implicit casts on one of the sides of the join condition in case the two
expressions have different types.
|
| Modifier and Type | Method and Description |
|---|---|
ValueVectorWriteExpression |
ProjectBatchBuilder.addEvalVector(String outputName,
LogicalExpression expr) |
void |
ProjectMemoryManager.addNewField(ValueVector vvOut,
LogicalExpression logicalExpression) |
ValueVectorWriteExpression |
ProjectBatchBuilder.addOutputVector(String name,
LogicalExpression expr) |
OutputWidthExpression |
OutputWidthVisitor.visitUnknown(LogicalExpression logicalExpression,
OutputWidthVisitorState state) |
| Modifier and Type | Method and Description |
|---|---|
protected LogicalExpression |
DrillFilterRelBase.getFilterExpression(DrillParseContext context) |
| Modifier and Type | Field and Description |
|---|---|
protected Set<LogicalExpression> |
MapRDBIndexDescriptor.allFields |
protected Set<LogicalExpression> |
DrillIndexDefinition.allIndexColumns |
Map<LogicalExpression,org.apache.calcite.rel.RelFieldCollation> |
CollationContext.collationMap |
protected List<LogicalExpression> |
DrillIndexDefinition.indexColumns
The indexColumns is the list of column(s) on which this index is created.
|
protected Set<LogicalExpression> |
MapRDBIndexDescriptor.indexedFields |
Set<LogicalExpression> |
IndexPhysicalPlanCallContext.leftOutPathsInFunctions |
Set<LogicalExpression> |
IndexLogicalPlanCallContext.leftOutPathsInFunctions |
protected List<LogicalExpression> |
DrillIndexDefinition.nonIndexColumns
nonIndexColumns: the list of columns that are included in the index as 'covering'
columns but are not themselves indexed.
|
protected List<LogicalExpression> |
DrillIndexDefinition.rowKeyColumns |
List<LogicalExpression> |
IndexPhysicalPlanCallContext.sortExprs |
List<LogicalExpression> |
IndexLogicalPlanCallContext.sortExprs |
| Modifier and Type | Method and Description |
|---|---|
static LogicalExpression |
RexToExpression.toDrill(DrillParseContext context,
DrillProjectRelBase project,
org.apache.calcite.rel.RelNode input,
org.apache.calcite.rex.RexNode expr) |
LogicalExpression |
RexToExpression.RexToDrillExt.visitCall(org.apache.calcite.rex.RexCall call) |
LogicalExpression |
RexToExpression.RexToDrillExt.visitCorrelVariable(org.apache.calcite.rex.RexCorrelVariable correlVariable) |
LogicalExpression |
RexToExpression.RexToDrillExt.visitDynamicParam(org.apache.calcite.rex.RexDynamicParam dynamicParam) |
LogicalExpression |
RexToExpression.RexToDrillExt.visitFieldAccess(org.apache.calcite.rex.RexFieldAccess fieldAccess) |
LogicalExpression |
RexToExpression.RexToDrillExt.visitInputRef(org.apache.calcite.rex.RexInputRef inputRef) |
LogicalExpression |
RexToExpression.RexToDrillExt.visitLocalRef(org.apache.calcite.rex.RexLocalRef localRef) |
LogicalExpression |
RexToExpression.RexToDrillExt.visitOver(org.apache.calcite.rex.RexOver over) |
LogicalExpression |
RexToExpression.RexToDrillExt.visitRangeRef(org.apache.calcite.rex.RexRangeRef rangeRef) |
| Modifier and Type | Method and Description |
|---|---|
Map<LogicalExpression,org.apache.calcite.rel.RelFieldCollation> |
DrillIndexDefinition.getCollationMap() |
Map<LogicalExpression,org.apache.calcite.rel.RelFieldCollation> |
IndexDefinition.getCollationMap()
Get a mapping of the LogicalExpresion/SchemaPath to its field collation
- e.g Ascending/Descending, Nulls First/Nulls Last
|
Map<org.apache.calcite.rex.RexNode,LogicalExpression> |
IndexableExprMarker.getEqualOnCastChar() |
Set<LogicalExpression> |
IndexableExprMarker.getExpressionsOnlyInEquality()
return the expressions that were only in equality condition _and_ only once.
|
Map<LogicalExpression,LogicalExpression> |
MapRDBFunctionalIndexInfo.getExprMap() |
Map<LogicalExpression,LogicalExpression> |
MapRDBFunctionalIndexInfo.getExprMap() |
Map<LogicalExpression,LogicalExpression> |
FunctionalIndexInfo.getExprMap() |
Map<LogicalExpression,LogicalExpression> |
FunctionalIndexInfo.getExprMap() |
static Map<LogicalExpression,Integer> |
IndexPlanUtils.getExprsFromRowType(org.apache.calcite.rel.type.RelDataType indexScanRowType) |
Map<org.apache.calcite.rex.RexNode,LogicalExpression> |
IndexableExprMarker.getIndexableExpression() |
List<LogicalExpression> |
DrillIndexDefinition.getIndexColumns() |
List<LogicalExpression> |
IndexDefinition.getIndexColumns()
Get the list of columns in the index key.
|
Set<LogicalExpression> |
IndexPhysicalPlanCallContext.getLeftOutPathsInFunctions() |
Set<LogicalExpression> |
IndexLogicalPlanCallContext.getLeftOutPathsInFunctions() |
Set<LogicalExpression> |
IndexCallContext.getLeftOutPathsInFunctions() |
Map<LogicalExpression,Set<org.apache.calcite.rex.RexNode>> |
RexToExpression.RexToDrillExt.getMapExprToRex() |
List<LogicalExpression> |
DrillIndexDefinition.getNonIndexColumns() |
List<LogicalExpression> |
IndexDefinition.getNonIndexColumns()
Get the list of columns that are in the 'included' or 'covered' fields.
|
Map<LogicalExpression,Set<SchemaPath>> |
MapRDBFunctionalIndexInfo.getPathsInFunctionExpr()
Suppose the index key has functions (rather than plain columns): CAST(a as int), CAST(b as varchar(10)),
then we want to maintain a mapping of the logical expression of that function to the schema path of the
base column involved in the function.
|
Map<LogicalExpression,Set<SchemaPath>> |
FunctionalIndexInfo.getPathsInFunctionExpr() |
static Map<LogicalExpression,Integer> |
IndexPlanUtils.getProjectExprs(List<org.apache.calcite.rex.RexNode> projectRexs,
DrillProjectRelBase project,
org.apache.calcite.rel.RelNode input) |
Set<LogicalExpression> |
PathInExpr.getRemainderPaths() |
Set<LogicalExpression> |
PathInExpr.getRemainderPathsInFunctions() |
List<LogicalExpression> |
DrillIndexDefinition.getRowKeyColumns() |
List<LogicalExpression> |
IndexDefinition.getRowKeyColumns()
Get the list of columns (typically 1 column) that constitute the row key (primary key)
|
List<LogicalExpression> |
IndexPhysicalPlanCallContext.getSortExprs() |
List<LogicalExpression> |
IndexLogicalPlanCallContext.getSortExprs() |
List<LogicalExpression> |
IndexCallContext.getSortExprs() |
| Modifier and Type | Method and Description |
|---|---|
int |
DrillIndexDefinition.getIndexColumnOrdinal(LogicalExpression path) |
int |
IndexDefinition.getIndexColumnOrdinal(LogicalExpression path)
Check to see if the field name is an index column and if so return the ordinal position in the index
|
SchemaPath |
MapRDBFunctionalIndexInfo.getNewPathFromExpr(LogicalExpression expr)
return a plain field path if the incoming index expression 'expr' is replaced to be a plain field
|
SchemaPath |
FunctionalIndexInfo.getNewPathFromExpr(LogicalExpression expr)
return a plain field path if the incoming index expression 'expr' is replaced to be a plain field
|
Boolean |
PathInExpr.visitUnknown(LogicalExpression e,
Void value) |
| Modifier and Type | Method and Description |
|---|---|
boolean |
MapRDBIndexDescriptor.allColumnsIndexed(Collection<LogicalExpression> expressions) |
boolean |
DrillIndexDefinition.allColumnsIndexed(Collection<LogicalExpression> columns) |
boolean |
IndexDefinition.allColumnsIndexed(Collection<LogicalExpression> columns)
Check if this index have all the columns specified in the supplied list of columns indexed
|
static org.apache.calcite.rel.RelCollation |
IndexPlanUtils.buildCollationForExpressions(Map<LogicalExpression,Integer> projectExprs,
IndexDescriptor indexDesc,
IndexCallContext context)
Given index, compute the collations for a list of projected expressions(from Scan's rowType or Project's )
in the context
|
protected boolean |
DrillIndexDefinition.columnsInIndexFields(Collection<LogicalExpression> columns,
Collection<LogicalExpression> indexFields) |
protected boolean |
DrillIndexDefinition.columnsInIndexFields(Collection<LogicalExpression> columns,
Collection<LogicalExpression> indexFields) |
static List<org.apache.calcite.rex.RexNode> |
IndexPlanUtils.getLeadingFilters(Map<LogicalExpression,org.apache.calcite.rex.RexNode> leadingPrefixMap,
List<LogicalExpression> indexCols) |
static List<org.apache.calcite.rex.RexNode> |
IndexPlanUtils.getLeadingFilters(Map<LogicalExpression,org.apache.calcite.rex.RexNode> leadingPrefixMap,
List<LogicalExpression> indexCols) |
static org.apache.calcite.rex.RexNode |
IndexPlanUtils.getLeadingPrefixMap(Map<LogicalExpression,org.apache.calcite.rex.RexNode> leadingPrefixMap,
List<LogicalExpression> indexCols,
IndexConditionInfo.Builder builder,
org.apache.calcite.rex.RexNode condition) |
static org.apache.calcite.rex.RexNode |
IndexPlanUtils.getLeadingPrefixMap(Map<LogicalExpression,org.apache.calcite.rex.RexNode> leadingPrefixMap,
List<LogicalExpression> indexCols,
IndexConditionInfo.Builder builder,
org.apache.calcite.rex.RexNode condition) |
IndexConditionInfo |
IndexConditionInfo.Builder.indexConditionRelatedToFields(List<LogicalExpression> relevantPaths,
org.apache.calcite.rex.RexNode condition)
Given a list of Index Expressions(usually indexed fields/functions from one or a set of indexes),
separate a filter condition into
1), relevant subset of conditions (by relevant, it means at least one given index Expression was found) and,
2), the rest in remainderCondition
|
boolean |
MapRDBIndexDescriptor.isCoveringIndex(List<LogicalExpression> expressions) |
boolean |
DrillIndexDefinition.isCoveringIndex(List<LogicalExpression> columns) |
boolean |
IndexDefinition.isCoveringIndex(List<LogicalExpression> columns)
Check if this index 'covers' all the columns specified in the supplied list of columns
|
boolean |
DrillIndexDefinition.pathExactIn(SchemaPath path,
Collection<LogicalExpression> exprs) |
org.apache.calcite.rex.RexNode |
SimpleRexRemap.rewriteEqualOnCharToLike(org.apache.calcite.rex.RexNode expr,
Map<org.apache.calcite.rex.RexNode,LogicalExpression> equalOnCastCharExprs) |
org.apache.calcite.rex.RexNode |
SimpleRexRemap.rewriteWithMap(org.apache.calcite.rex.RexNode srcRex,
Map<org.apache.calcite.rex.RexNode,LogicalExpression> mapRexToExpr) |
SimpleRexRemap |
SimpleRexRemap.setExpressionMap(Map<LogicalExpression,LogicalExpression> exprMap)
Set the map of src expression to target expression, expressions not in the map do not have assigned destinations
|
SimpleRexRemap |
SimpleRexRemap.setExpressionMap(Map<LogicalExpression,LogicalExpression> exprMap)
Set the map of src expression to target expression, expressions not in the map do not have assigned destinations
|
void |
IndexPhysicalPlanCallContext.setLeftOutPathsInFunctions(Set<LogicalExpression> exprs) |
void |
IndexLogicalPlanCallContext.setLeftOutPathsInFunctions(Set<LogicalExpression> exprs) |
void |
IndexCallContext.setLeftOutPathsInFunctions(Set<LogicalExpression> exprs) |
void |
IndexSelector.DrillIndexProperties.setProperties(Map<LogicalExpression,org.apache.calcite.rex.RexNode> prefixMap,
boolean satisfiesCollation,
org.apache.calcite.rex.RexNode indexColumnsRemainderFilter,
Statistics stats) |
void |
IndexProperties.setProperties(Map<LogicalExpression,org.apache.calcite.rex.RexNode> prefixMap,
boolean satisfiesCollation,
org.apache.calcite.rex.RexNode indexColumnsRemainderFilter,
Statistics stats) |
boolean |
MapRDBIndexDescriptor.someColumnsIndexed(Collection<LogicalExpression> columns) |
boolean |
DrillIndexDefinition.someColumnsIndexed(Collection<LogicalExpression> columns) |
boolean |
IndexDefinition.someColumnsIndexed(Collection<LogicalExpression> columns)
Check if this index has some columns specified in the supplied list of columns indexed
|
protected boolean |
DrillIndexDefinition.someColumnsInIndexFields(Collection<LogicalExpression> columns,
Collection<LogicalExpression> indexFields) |
protected boolean |
DrillIndexDefinition.someColumnsInIndexFields(Collection<LogicalExpression> columns,
Collection<LogicalExpression> indexFields) |
| Constructor and Description |
|---|
AbstractIndexDescriptor(List<LogicalExpression> indexCols,
CollationContext indexCollationContext,
List<LogicalExpression> nonIndexCols,
List<LogicalExpression> rowKeyColumns,
String indexName,
String tableName,
IndexDefinition.IndexType type,
org.apache.calcite.rel.RelFieldCollation.NullDirection nullsDirection) |
AbstractIndexDescriptor(List<LogicalExpression> indexCols,
CollationContext indexCollationContext,
List<LogicalExpression> nonIndexCols,
List<LogicalExpression> rowKeyColumns,
String indexName,
String tableName,
IndexDefinition.IndexType type,
org.apache.calcite.rel.RelFieldCollation.NullDirection nullsDirection) |
AbstractIndexDescriptor(List<LogicalExpression> indexCols,
CollationContext indexCollationContext,
List<LogicalExpression> nonIndexCols,
List<LogicalExpression> rowKeyColumns,
String indexName,
String tableName,
IndexDefinition.IndexType type,
org.apache.calcite.rel.RelFieldCollation.NullDirection nullsDirection) |
CollationContext(Map<LogicalExpression,org.apache.calcite.rel.RelFieldCollation> collationMap,
List<org.apache.calcite.rel.RelFieldCollation> relFieldCollations) |
DrillIndexDefinition(List<LogicalExpression> indexCols,
CollationContext indexCollationContext,
List<LogicalExpression> nonIndexCols,
List<LogicalExpression> rowKeyColumns,
String indexName,
String tableName,
IndexDefinition.IndexType type,
org.apache.calcite.rel.RelFieldCollation.NullDirection nullsDirection) |
DrillIndexDefinition(List<LogicalExpression> indexCols,
CollationContext indexCollationContext,
List<LogicalExpression> nonIndexCols,
List<LogicalExpression> rowKeyColumns,
String indexName,
String tableName,
IndexDefinition.IndexType type,
org.apache.calcite.rel.RelFieldCollation.NullDirection nullsDirection) |
DrillIndexDefinition(List<LogicalExpression> indexCols,
CollationContext indexCollationContext,
List<LogicalExpression> nonIndexCols,
List<LogicalExpression> rowKeyColumns,
String indexName,
String tableName,
IndexDefinition.IndexType type,
org.apache.calcite.rel.RelFieldCollation.NullDirection nullsDirection) |
DrillIndexDescriptor(List<LogicalExpression> indexCols,
CollationContext indexCollationContext,
List<LogicalExpression> nonIndexCols,
List<LogicalExpression> rowKeyColumns,
String indexName,
String tableName,
IndexDefinition.IndexType type,
org.apache.calcite.rel.RelFieldCollation.NullDirection nullsDirection) |
DrillIndexDescriptor(List<LogicalExpression> indexCols,
CollationContext indexCollationContext,
List<LogicalExpression> nonIndexCols,
List<LogicalExpression> rowKeyColumns,
String indexName,
String tableName,
IndexDefinition.IndexType type,
org.apache.calcite.rel.RelFieldCollation.NullDirection nullsDirection) |
DrillIndexDescriptor(List<LogicalExpression> indexCols,
CollationContext indexCollationContext,
List<LogicalExpression> nonIndexCols,
List<LogicalExpression> rowKeyColumns,
String indexName,
String tableName,
IndexDefinition.IndexType type,
org.apache.calcite.rel.RelFieldCollation.NullDirection nullsDirection) |
MapRDBIndexDescriptor(List<LogicalExpression> indexCols,
CollationContext indexCollationContext,
List<LogicalExpression> nonIndexCols,
List<LogicalExpression> rowKeyColumns,
String indexName,
String tableName,
IndexDefinition.IndexType type,
Object desc,
DbGroupScan scan,
org.apache.calcite.rel.RelFieldCollation.NullDirection nullsDirection) |
MapRDBIndexDescriptor(List<LogicalExpression> indexCols,
CollationContext indexCollationContext,
List<LogicalExpression> nonIndexCols,
List<LogicalExpression> rowKeyColumns,
String indexName,
String tableName,
IndexDefinition.IndexType type,
Object desc,
DbGroupScan scan,
org.apache.calcite.rel.RelFieldCollation.NullDirection nullsDirection) |
MapRDBIndexDescriptor(List<LogicalExpression> indexCols,
CollationContext indexCollationContext,
List<LogicalExpression> nonIndexCols,
List<LogicalExpression> rowKeyColumns,
String indexName,
String tableName,
IndexDefinition.IndexType type,
Object desc,
DbGroupScan scan,
org.apache.calcite.rel.RelFieldCollation.NullDirection nullsDirection) |
PathInExpr(Map<LogicalExpression,Set<SchemaPath>> pathsInExpr) |
RexSeparator(List<LogicalExpression> relatedPaths,
org.apache.calcite.rel.RelNode inputRel,
org.apache.calcite.rex.RexBuilder builder) |
| Modifier and Type | Method and Description |
|---|---|
protected LogicalExpression |
DrillWindowRel.toDrill(org.apache.calcite.rel.core.AggregateCall call,
List<String> fn) |
static LogicalExpression |
DrillAggregateRel.toDrill(org.apache.calcite.rel.core.AggregateCall call,
List<String> fn,
DrillImplementor implementor) |
static LogicalExpression |
DrillOptiq.toDrill(DrillParseContext context,
List<org.apache.calcite.rel.RelNode> inputs,
org.apache.calcite.rex.RexNode expr)
Converts a tree of
RexNode operators into a scalar expression in Drill syntax using multiple inputs. |
static LogicalExpression |
DrillOptiq.toDrill(DrillParseContext context,
org.apache.calcite.rel.type.RelDataType type,
org.apache.calcite.rex.RexBuilder builder,
org.apache.calcite.rex.RexNode expr) |
static LogicalExpression |
DrillOptiq.toDrill(DrillParseContext context,
org.apache.calcite.rel.RelNode input,
org.apache.calcite.rex.RexNode expr)
Converts a tree of
RexNode operators into a scalar expression in Drill syntax using one input. |
LogicalExpression |
DrillOptiq.RexToDrill.visitCall(org.apache.calcite.rex.RexCall call) |
LogicalExpression |
DrillOptiq.RexToDrill.visitCorrelVariable(org.apache.calcite.rex.RexCorrelVariable correlVariable) |
LogicalExpression |
DrillOptiq.RexToDrill.visitDynamicParam(org.apache.calcite.rex.RexDynamicParam dynamicParam) |
LogicalExpression |
DrillOptiq.RexToDrill.visitFieldAccess(org.apache.calcite.rex.RexFieldAccess fieldAccess) |
LogicalExpression |
DrillOptiq.RexToDrill.visitInputRef(org.apache.calcite.rex.RexInputRef inputRef) |
LogicalExpression |
DrillOptiq.RexToDrill.visitLiteral(org.apache.calcite.rex.RexLiteral literal) |
LogicalExpression |
DrillOptiq.RexToDrill.visitLocalRef(org.apache.calcite.rex.RexLocalRef localRef) |
LogicalExpression |
DrillOptiq.RexToDrill.visitOver(org.apache.calcite.rex.RexOver over) |
LogicalExpression |
DrillOptiq.RexToDrill.visitRangeRef(org.apache.calcite.rex.RexRangeRef rangeRef) |
| Modifier and Type | Method and Description |
|---|---|
static String |
ExprHelper.getFieldName(LogicalExpression e) |
| Modifier and Type | Method and Description |
|---|---|
protected LogicalExpression |
PruneScanRule.materializePruneExpr(org.apache.calcite.rex.RexNode pruneCondition,
PlannerSettings settings,
org.apache.calcite.rel.RelNode scanRel,
VectorContainer container) |
| Modifier and Type | Field and Description |
|---|---|
static HashPrelUtil.HashExpressionCreatorHelper<LogicalExpression> |
HashPrelUtil.HASH_HELPER_LOGICAL_EXPRESSION
Implementation of
HashPrelUtil.HashExpressionCreatorHelper for LogicalExpression type. |
| Modifier and Type | Method and Description |
|---|---|
protected LogicalExpression |
FlattenPrel.getFlattenExpression(DrillParseContext context) |
static LogicalExpression |
HashPrelUtil.getHash64Expression(LogicalExpression field,
LogicalExpression seed,
boolean hashAsDouble)
Creates hash expression for input field and seed.
|
static LogicalExpression |
HashPrelUtil.getHashExpression(List<DrillDistributionTrait.DistributionField> fields,
org.apache.calcite.rel.type.RelDataType rowType)
Create a distribution hash expression.
|
static LogicalExpression |
HashPrelUtil.getHashExpression(LogicalExpression field,
LogicalExpression seed,
boolean hashAsDouble)
Creates hash expression for input field and seed.
|
protected LogicalExpression |
WindowPrel.toDrill(org.apache.calcite.rel.core.AggregateCall call,
List<String> fn) |
protected LogicalExpression |
AggPrelBase.toDrill(org.apache.calcite.rel.core.AggregateCall call,
List<String> fn) |
| Modifier and Type | Method and Description |
|---|---|
static LogicalExpression |
HashPrelUtil.getHash64Expression(LogicalExpression field,
LogicalExpression seed,
boolean hashAsDouble)
Creates hash expression for input field and seed.
|
static LogicalExpression |
HashPrelUtil.getHashExpression(LogicalExpression field,
LogicalExpression seed,
boolean hashAsDouble)
Creates hash expression for input field and seed.
|
| Modifier and Type | Method and Description |
|---|---|
org.apache.calcite.rex.RexNode |
ConversionContext.toRex(LogicalExpression e) |
| Modifier and Type | Method and Description |
|---|---|
Boolean |
DruidCompareFunctionProcessor.visitCastExpression(CastExpression e,
LogicalExpression valueArg) |
Boolean |
DruidCompareFunctionProcessor.visitConvertExpression(ConvertExpression e,
LogicalExpression valueArg) |
Boolean |
DruidCompareFunctionProcessor.visitSchemaPath(SchemaPath path,
LogicalExpression valueArg) |
Boolean |
DruidCompareFunctionProcessor.visitUnknown(LogicalExpression e,
LogicalExpression valueArg) |
DruidScanSpec |
DruidFilterBuilder.visitUnknown(LogicalExpression e,
Void value) |
| Constructor and Description |
|---|
DruidFilterBuilder(DruidGroupScan groupScan,
LogicalExpression conditionExp) |
| Modifier and Type | Method and Description |
|---|---|
protected io.netty.buffer.ByteBuf |
CompareFunctionsProcessor.getByteBuf(LogicalExpression valueArg,
String encodingType) |
Boolean |
CompareFunctionsProcessor.visitCastExpression(CastExpression e,
LogicalExpression valueArg) |
Boolean |
CompareFunctionsProcessor.visitConvertExpression(ConvertExpression e,
LogicalExpression valueArg) |
Boolean |
CompareFunctionsProcessor.visitFunctionCall(FunctionCall call,
LogicalExpression valueArg) |
Boolean |
CompareFunctionsProcessor.visitSchemaPath(SchemaPath path,
LogicalExpression valueArg) |
Boolean |
CompareFunctionsProcessor.visitUnknown(LogicalExpression e,
LogicalExpression valueArg) |
HBaseScanSpec |
HBaseFilterBuilder.visitUnknown(LogicalExpression e,
Void value) |
| Modifier and Type | Method and Description |
|---|---|
InfoSchemaFilter.ExprNode |
InfoSchemaFilterBuilder.visitUnknown(LogicalExpression e,
Void value) |
| Constructor and Description |
|---|
InfoSchemaFilterBuilder(LogicalExpression filter) |
| Modifier and Type | Method and Description |
|---|---|
List<KafkaPartitionScanSpec> |
KafkaPartitionScanSpecBuilder.visitUnknown(LogicalExpression e,
Void value) |
| Constructor and Description |
|---|
KafkaPartitionScanSpecBuilder(KafkaGroupScan groupScan,
LogicalExpression conditionExp) |
| Modifier and Type | Method and Description |
|---|---|
HBaseScanSpec |
MapRDBFilterBuilder.visitUnknown(LogicalExpression e,
Void value) |
| Constructor and Description |
|---|
MapRDBFilterBuilder(BinaryTableGroupScan groupScan,
LogicalExpression le) |
| Modifier and Type | Method and Description |
|---|---|
org.ojai.store.QueryCondition |
JsonTableGroupScan.convertToQueryCondition(LogicalExpression condition)
Convert a given
LogicalExpression condition into a QueryCondition condition |
JsonScanSpec |
JsonConditionBuilder.visitUnknown(LogicalExpression e,
Void value) |
| Constructor and Description |
|---|
JsonConditionBuilder(JsonTableGroupScan groupScan,
LogicalExpression conditionExp) |
| Modifier and Type | Method and Description |
|---|---|
Boolean |
MongoCompareFunctionProcessor.visitCastExpression(CastExpression e,
LogicalExpression valueArg) |
Boolean |
MongoCompareFunctionProcessor.visitConvertExpression(ConvertExpression e,
LogicalExpression valueArg) |
Boolean |
MongoCompareFunctionProcessor.visitSchemaPath(SchemaPath path,
LogicalExpression valueArg) |
Boolean |
MongoCompareFunctionProcessor.visitUnknown(LogicalExpression e,
LogicalExpression valueArg) |
MongoScanSpec |
MongoFilterBuilder.visitUnknown(LogicalExpression e,
Void value) |
| Constructor and Description |
|---|
MongoFilterBuilder(MongoGroupScan groupScan,
LogicalExpression conditionExp) |
| Modifier and Type | Field and Description |
|---|---|
protected LogicalExpression |
AbstractParquetRowGroupScan.filter |
| Modifier and Type | Method and Description |
|---|---|
LogicalExpression |
AbstractParquetRowGroupScan.getFilter() |
| Modifier and Type | Method and Description |
|---|---|
AbstractGroupScanWithMetadata<?> |
AbstractParquetGroupScan.applyFilter(LogicalExpression filterExpr,
UdfUtilities udfUtilities,
FunctionImplementationRegistry functionImplementationRegistry,
OptionManager optionManager)
Applies specified filter
filterExpr to current group scan and produces filtering at:
table level:
if filter matches all the the data or prunes all the data, sets corresponding value to
AbstractGroupScanWithMetadata.isMatchAllMetadata() and returns null
segment level:
if filter matches all the the data or prunes all the data, sets corresponding value to
AbstractGroupScanWithMetadata.isMatchAllMetadata() and returns null
if segment metadata was pruned, prunes underlying metadata
partition level:
if filter matches all the the data or prunes all the data, sets corresponding value to
AbstractGroupScanWithMetadata.isMatchAllMetadata() and returns null
if partition metadata was pruned, prunes underlying metadata
file level:
if filter matches all the the data or prunes all the data, sets corresponding value to
AbstractGroupScanWithMetadata.isMatchAllMetadata() and returns null
|
static RowsMatch |
FilterEvaluatorUtils.evalFilter(LogicalExpression expr,
MetadataBase.ParquetTableMetadataBase footer,
int rowGroupIndex,
OptionManager options,
FragmentContext fragmentContext) |
static RowsMatch |
FilterEvaluatorUtils.matches(LogicalExpression expr,
Map<SchemaPath,ColumnStatistics<?>> columnsStatistics,
TupleMetadata schema,
long rowCount,
UdfUtilities udfUtilities,
FunctionLookupContext functionImplementationRegistry,
Set<SchemaPath> schemaPathsInExpr) |
Set<SchemaPath> |
FilterEvaluatorUtils.FieldReferenceFinder.visitUnknown(LogicalExpression e,
Void value) |
Copyright © 2021 The Apache Software Foundation. All rights reserved.