| Package | Description |
|---|---|
| org.apache.hadoop.hive.ql.optimizer.calcite.rules.jdbc |
JDBC external table rules that pushes down operators as much as possible to the external jdbc table.
|
| Class and Description |
|---|
| JDBCAbstractSplitFilterRule
JDBCAbstractSplitFilterRule split a
HiveFilter into
two HiveFilter operators where the lower operator
could be pushed down below the
HiveJdbcConverter}
operator and therefore could be sent to the external table. |
| JDBCAggregationPushDownRule
JDBCAggregationPushDownRule convert a
HiveAggregate
into a org.apache.calcite.adapter.jdbc.JdbcRules.JdbcAggregateRule.JdbcAggregate
and pushes it down below the HiveJdbcConverter
operator so it will be sent to the external table. |
| JDBCExtractJoinFilterRule
JDBCExtractJoinFilterRule extracts out the
HiveFilter
from a HiveJoin operator. |
| JDBCFilterJoinRule
Rule that tries to push filter expressions into a join condition and into
the inputs of the join.
|
| JDBCFilterPushDownRule
JDBCExtractJoinFilterRule extracts out the
HiveFilter
from a HiveJoin operator. |
| JDBCJoinPushDownRule
JDBCJoinPushDownRule convert a
HiveJoin
into a JdbcRules.JdbcJoin
and pushes it down below the HiveJdbcConverter}
operator so it will be sent to the external table. |
| JDBCProjectPushDownRule
JDBCProjectPushDownRule convert a
HiveProject
into a org.apache.calcite.adapter.jdbc.JdbcRules.JdbcAggregateRule.JdbcProject
and pushes it down below the HiveJdbcConverter}
operator so it will be sent to the external table. |
| JDBCSortPushDownRule
JDBCSortPushDownRule convert a
HiveSortLimit
into a JdbcRules.JdbcSort
and pushes it down below the HiveJdbcConverter}
operator so it will be sent to the external table. |
| JDBCUnionPushDownRule
JDBCUnionPushDownRule convert a
HiveUnion
into a JdbcRules.JdbcUnion
and pushes it down below the HiveJdbcConverter}
operator so it will be sent to the external table. |
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.