Merge pull request #41223 from ClickHouse/vdimir/exponential_rewrite_21557

This commit is contained in:
Vladimir C 2022-09-19 10:07:24 +02:00 committed by GitHub
commit b6b5932efc
No known key found for this signature in database
GPG Key ID: 4AEE18F83AFDEB23
9 changed files with 544 additions and 47 deletions

View File

@ -115,7 +115,7 @@ std::map<size_t, std::vector<ASTPtr>> moveExpressionToJoinOn(
const Aliases & aliases)
{
std::map<size_t, std::vector<ASTPtr>> asts_to_join_on;
for (const auto & node : collectConjunctions(ast))
for (const auto & node : splitConjunctionsAst(ast))
{
if (const auto * func = node->as<ASTFunction>(); func && func->name == NameEquals::name)
{

View File

@ -322,22 +322,35 @@ std::optional<size_t> IdentifierMembershipCollector::getIdentsMembership(ASTPtr
return IdentifierSemantic::getIdentsMembership(ast, tables, aliases);
}
static void collectConjunctions(const ASTPtr & node, std::vector<ASTPtr> & members)
void splitConjunctionsAst(const ASTPtr & node, ASTs & result)
{
if (const auto * func = node->as<ASTFunction>(); func && func->name == "and")
{
for (const auto & child : func->arguments->children)
collectConjunctions(child, members);
if (!node)
return;
result.emplace_back(node);
for (size_t idx = 0; idx < result.size();)
{
ASTPtr expression = result.at(idx);
if (const auto * function = expression->as<ASTFunction>(); function && function->name == "and")
{
result.erase(result.begin() + idx);
for (auto & child : function->arguments->children)
result.emplace_back(child);
continue;
}
++idx;
}
members.push_back(node);
}
std::vector<ASTPtr> collectConjunctions(const ASTPtr & node)
ASTs splitConjunctionsAst(const ASTPtr & node)
{
std::vector<ASTPtr> members;
collectConjunctions(node, members);
return members;
std::vector<ASTPtr> result;
splitConjunctionsAst(node, result);
return result;
}
}

View File

@ -105,6 +105,7 @@ private:
};
/// Split expression `expr_1 AND expr_2 AND ... AND expr_n` into vector `[expr_1, expr_2, ..., expr_n]`
std::vector<ASTPtr> collectConjunctions(const ASTPtr & node);
ASTs splitConjunctionsAst(const ASTPtr & node);
void splitConjunctionsAst(const ASTPtr & node, ASTs & result);
}

View File

@ -4,6 +4,7 @@
#include <Interpreters/ExtractExpressionInfoVisitor.h>
#include <Interpreters/PredicateRewriteVisitor.h>
#include <Interpreters/getTableExpressions.h>
#include <Interpreters/IdentifierSemantic.h>
#include <Parsers/ASTFunction.h>
#include <Parsers/ASTSelectQuery.h>
#include <Parsers/ASTSelectWithUnionQuery.h>
@ -51,42 +52,14 @@ bool PredicateExpressionsOptimizer::optimize(ASTSelectQuery & select_query)
return false;
}
static ASTs splitConjunctionPredicate(const std::initializer_list<const ASTPtr> & predicates)
{
std::vector<ASTPtr> res;
for (const auto & predicate : predicates)
{
if (!predicate)
continue;
res.emplace_back(predicate);
for (size_t idx = 0; idx < res.size();)
{
ASTPtr expression = res.at(idx);
if (const auto * function = expression->as<ASTFunction>(); function && function->name == "and")
{
res.erase(res.begin() + idx);
for (auto & child : function->arguments->children)
res.emplace_back(child);
continue;
}
++idx;
}
}
return res;
}
std::vector<ASTs> PredicateExpressionsOptimizer::extractTablesPredicates(const ASTPtr & where, const ASTPtr & prewhere)
{
std::vector<ASTs> tables_predicates(tables_with_columns.size());
for (const auto & predicate_expression : splitConjunctionPredicate({where, prewhere}))
ASTs predicate_expressions;
splitConjunctionsAst(where, predicate_expressions);
splitConjunctionsAst(prewhere, predicate_expressions);
for (const auto & predicate_expression : predicate_expressions)
{
ExpressionInfoVisitor::Data expression_info{WithContext{getContext()}, tables_with_columns};
ExpressionInfoVisitor(expression_info).visit(predicate_expression);
@ -186,7 +159,7 @@ bool PredicateExpressionsOptimizer::tryMovePredicatesFromHavingToWhere(ASTSelect
return res;
};
for (const auto & moving_predicate: splitConjunctionPredicate({select_query.having()}))
for (const auto & moving_predicate : splitConjunctionsAst(select_query.having()))
{
TablesWithColumns tables;
ExpressionInfoVisitor::Data expression_info{WithContext{getContext()}, tables};

View File

@ -133,6 +133,36 @@ static void cleanAliasAndCollectIdentifiers(ASTPtr & predicate, std::vector<ASTI
identifiers.emplace_back(identifier);
}
/// Clean aliases and use aliased name
/// Transforms `(a = b as c) AND (x = y)` to `(a = c) AND (x = y)`
static void useAliasInsteadOfIdentifier(const ASTPtr & predicate)
{
if (!predicate->as<ASTSubquery>())
{
for (auto & children : predicate->children)
useAliasInsteadOfIdentifier(children);
}
if (const auto alias = predicate->tryGetAlias(); !alias.empty())
{
if (ASTIdentifier * identifier = predicate->as<ASTIdentifier>())
identifier->setShortName(alias);
predicate->setAlias({});
}
}
static void getConjunctionHashesFrom(const ASTPtr & ast, std::set<IAST::Hash> & hashes)
{
for (const auto & pred : splitConjunctionsAst(ast))
{
/// Clone not to modify `ast`
ASTPtr pred_copy = pred->clone();
useAliasInsteadOfIdentifier(pred_copy);
hashes.emplace(pred_copy->getTreeHash());
}
}
bool PredicateRewriteVisitorData::rewriteSubquery(ASTSelectQuery & subquery, const Names & inner_columns)
{
if ((!optimize_final && subquery.final())
@ -143,12 +173,27 @@ bool PredicateRewriteVisitorData::rewriteSubquery(ASTSelectQuery & subquery, con
return false;
Names outer_columns = table_columns.columns.getNames();
/// Do not add same conditions twice to avoid extra rewrites with exponential blowup
/// (e.g. in case of deep complex query with lots of JOINs)
std::set<IAST::Hash> hashes;
getConjunctionHashesFrom(subquery.where(), hashes);
getConjunctionHashesFrom(subquery.having(), hashes);
bool is_changed = false;
for (const auto & predicate : predicates)
{
std::vector<ASTIdentifier *> identifiers;
ASTPtr optimize_predicate = predicate->clone();
cleanAliasAndCollectIdentifiers(optimize_predicate, identifiers);
auto predicate_hash = optimize_predicate->getTreeHash();
if (hashes.contains(predicate_hash))
continue;
hashes.emplace(predicate_hash);
is_changed = true;
for (const auto & identifier : identifiers)
{
IdentifierSemantic::setColumnShortName(*identifier, table_columns.table);
@ -169,7 +214,7 @@ bool PredicateRewriteVisitorData::rewriteSubquery(ASTSelectQuery & subquery, con
subquery.having() ? makeASTFunction("and", optimize_predicate, subquery.having()) : optimize_predicate);
}
return true;
return is_changed;
}
}

View File

@ -57,7 +57,7 @@ bool removeJoin(ASTSelectQuery & select, TreeRewriterResult & rewriter_result, C
const size_t left_table_pos = 0;
/// Test each argument of `and` function and select ones related to only left table
std::shared_ptr<ASTFunction> new_conj = makeASTFunction("and");
for (auto && node : collectConjunctions(where))
for (auto && node : splitConjunctionsAst(where))
{
if (membership_collector.getIdentsMembership(node) == left_table_pos)
new_conj->arguments->children.push_back(std::move(node));

View File

@ -2,6 +2,18 @@
-- https://github.com/ClickHouse/ClickHouse/issues/21557
EXPLAIN SYNTAX
WITH
x AS ( SELECT number FROM numbers(10) ),
cross_sales AS (
SELECT 1 AS xx
FROM x, x AS d1, x AS d2, x AS d3, x AS d4, x AS d5, x AS d6, x AS d7, x AS d8, x AS d9
WHERE x.number = d9.number
)
SELECT xx FROM cross_sales WHERE xx = 2000 FORMAT Null;
SET max_analyze_depth = 1;
EXPLAIN SYNTAX
WITH
x AS ( SELECT number FROM numbers(10) ),

View File

@ -0,0 +1,452 @@
-- Tags: long
-- https://github.com/ClickHouse/ClickHouse/issues/21557
DROP TABLE IF EXISTS store_returns;
DROP TABLE IF EXISTS catalog_sales;
DROP TABLE IF EXISTS catalog_returns;
DROP TABLE IF EXISTS date_dim;
DROP TABLE IF EXISTS store;
DROP TABLE IF EXISTS customer;
DROP TABLE IF EXISTS customer_demographics;
DROP TABLE IF EXISTS promotion;
DROP TABLE IF EXISTS household_demographics;
DROP TABLE IF EXISTS customer_address;
DROP TABLE IF EXISTS income_band;
DROP TABLE IF EXISTS item;
CREATE TABLE store_sales
(
`ss_sold_date_sk` Nullable(Int64),
`ss_sold_time_sk` Nullable(Int64),
`ss_item_sk` Int64,
`ss_customer_sk` Nullable(Int64),
`ss_cdemo_sk` Nullable(Int64),
`ss_hdemo_sk` Nullable(Int64),
`ss_addr_sk` Nullable(Int64),
`ss_store_sk` Nullable(Int64),
`ss_promo_sk` Nullable(Int64),
`ss_ticket_number` Int64,
`ss_quantity` Nullable(Int64),
`ss_wholesale_cost` Nullable(Float32),
`ss_list_price` Nullable(Float32),
`ss_sales_price` Nullable(Float32),
`ss_ext_discount_amt` Nullable(Float32),
`ss_ext_sales_price` Nullable(Float32),
`ss_ext_wholesale_cost` Nullable(Float32),
`ss_ext_list_price` Nullable(Float32),
`ss_ext_tax` Nullable(Float32),
`ss_coupon_amt` Nullable(Float32),
`ss_net_paid` Nullable(Float32),
`ss_net_paid_inc_tax` Nullable(Float32),
`ss_net_profit` Nullable(Float32),
`ss_promo_sk_nn` Int16,
`ss_promo_sk_n2` Nullable(Int16)
)
ENGINE = MergeTree ORDER BY (ss_item_sk, ss_ticket_number);
CREATE TABLE store_returns
(
`sr_returned_date_sk` Nullable(Int64),
`sr_return_time_sk` Nullable(Int64),
`sr_item_sk` Int64,
`sr_customer_sk` Nullable(Int64),
`sr_cdemo_sk` Nullable(Int64),
`sr_hdemo_sk` Nullable(Int64),
`sr_addr_sk` Nullable(Int64),
`sr_store_sk` Nullable(Int64),
`sr_reason_sk` Nullable(Int64),
`sr_ticket_number` Int64,
`sr_return_quantity` Nullable(Int64),
`sr_return_amt` Nullable(Float32),
`sr_return_tax` Nullable(Float32),
`sr_return_amt_inc_tax` Nullable(Float32),
`sr_fee` Nullable(Float32),
`sr_return_ship_cost` Nullable(Float32),
`sr_refunded_cash` Nullable(Float32),
`sr_reversed_charge` Nullable(Float32),
`sr_store_credit` Nullable(Float32),
`sr_net_loss` Nullable(Float32)
)
ENGINE = MergeTree ORDER BY (sr_item_sk, sr_ticket_number);
CREATE TABLE catalog_sales
(
`cs_sold_date_sk` Nullable(Int64),
`cs_sold_time_sk` Nullable(Int64),
`cs_ship_date_sk` Nullable(Int64),
`cs_bill_customer_sk` Nullable(Int64),
`cs_bill_cdemo_sk` Nullable(Int64),
`cs_bill_hdemo_sk` Nullable(Int64),
`cs_bill_addr_sk` Nullable(Int64),
`cs_ship_customer_sk` Nullable(Int64),
`cs_ship_cdemo_sk` Nullable(Int64),
`cs_ship_hdemo_sk` Nullable(Int64),
`cs_ship_addr_sk` Nullable(Int64),
`cs_call_center_sk` Nullable(Int64),
`cs_catalog_page_sk` Nullable(Int64),
`cs_ship_mode_sk` Nullable(Int64),
`cs_warehouse_sk` Nullable(Int64),
`cs_item_sk` Int64,
`cs_promo_sk` Nullable(Int64),
`cs_order_number` Int64,
`cs_quantity` Nullable(Int64),
`cs_wholesale_cost` Nullable(Float32),
`cs_list_price` Nullable(Float32),
`cs_sales_price` Nullable(Float32),
`cs_ext_discount_amt` Nullable(Float32),
`cs_ext_sales_price` Nullable(Float32),
`cs_ext_wholesale_cost` Nullable(Float32),
`cs_ext_list_price` Nullable(Float32),
`cs_ext_tax` Nullable(Float32),
`cs_coupon_amt` Nullable(Float32),
`cs_ext_ship_cost` Nullable(Float32),
`cs_net_paid` Nullable(Float32),
`cs_net_paid_inc_tax` Nullable(Float32),
`cs_net_paid_inc_ship` Nullable(Float32),
`cs_net_paid_inc_ship_tax` Nullable(Float32),
`cs_net_profit` Nullable(Float32)
)
ENGINE = MergeTree ORDER BY (cs_item_sk, cs_order_number);
CREATE TABLE catalog_returns
(
`cr_returned_date_sk` Nullable(Int64),
`cr_returned_time_sk` Nullable(Int64),
`cr_item_sk` Int64,
`cr_refunded_customer_sk` Nullable(Int64),
`cr_refunded_cdemo_sk` Nullable(Int64),
`cr_refunded_hdemo_sk` Nullable(Int64),
`cr_refunded_addr_sk` Nullable(Int64),
`cr_returning_customer_sk` Nullable(Int64),
`cr_returning_cdemo_sk` Nullable(Int64),
`cr_returning_hdemo_sk` Nullable(Int64),
`cr_returning_addr_sk` Nullable(Int64),
`cr_call_center_sk` Nullable(Int64),
`cr_catalog_page_sk` Nullable(Int64),
`cr_ship_mode_sk` Nullable(Int64),
`cr_warehouse_sk` Nullable(Int64),
`cr_reason_sk` Nullable(Int64),
`cr_order_number` Int64,
`cr_return_quantity` Nullable(Int64),
`cr_return_amount` Nullable(Float32),
`cr_return_tax` Nullable(Float32),
`cr_return_amt_inc_tax` Nullable(Float32),
`cr_fee` Nullable(Float32),
`cr_return_ship_cost` Nullable(Float32),
`cr_refunded_cash` Nullable(Float32),
`cr_reversed_charge` Nullable(Float32),
`cr_store_credit` Nullable(Float32),
`cr_net_loss` Nullable(Float32)
)
ENGINE = MergeTree ORDER BY (cr_item_sk, cr_order_number);
CREATE TABLE date_dim
(
`d_date_sk` Int64,
`d_date_id` String,
`d_date` Nullable(Date),
`d_month_seq` Nullable(Int64),
`d_week_seq` Nullable(Int64),
`d_quarter_seq` Nullable(Int64),
`d_year` Nullable(Int64),
`d_dow` Nullable(Int64),
`d_moy` Nullable(Int64),
`d_dom` Nullable(Int64),
`d_qoy` Nullable(Int64),
`d_fy_year` Nullable(Int64),
`d_fy_quarter_seq` Nullable(Int64),
`d_fy_week_seq` Nullable(Int64),
`d_day_name` Nullable(String),
`d_quarter_name` Nullable(String),
`d_holiday` Nullable(String),
`d_weekend` Nullable(String),
`d_following_holiday` Nullable(String),
`d_first_dom` Nullable(Int64),
`d_last_dom` Nullable(Int64),
`d_same_day_ly` Nullable(Int64),
`d_same_day_lq` Nullable(Int64),
`d_current_day` Nullable(String),
`d_current_week` Nullable(String),
`d_current_month` Nullable(String),
`d_current_quarter` Nullable(String),
`d_current_year` Nullable(String)
)
ENGINE = MergeTree ORDER BY d_date_sk;
CREATE TABLE store
(
`s_store_sk` Int64,
`s_store_id` String,
`s_rec_start_date` Nullable(Date),
`s_rec_end_date` Nullable(Date),
`s_closed_date_sk` Nullable(Int64),
`s_store_name` Nullable(String),
`s_number_employees` Nullable(Int64),
`s_floor_space` Nullable(Int64),
`s_hours` Nullable(String),
`s_manager` Nullable(String),
`s_market_id` Nullable(Int64),
`s_geography_class` Nullable(String),
`s_market_desc` Nullable(String),
`s_market_manager` Nullable(String),
`s_division_id` Nullable(Int64),
`s_division_name` Nullable(String),
`s_company_id` Nullable(Int64),
`s_company_name` Nullable(String),
`s_street_number` Nullable(String),
`s_street_name` Nullable(String),
`s_street_type` Nullable(String),
`s_suite_number` Nullable(String),
`s_city` Nullable(String),
`s_county` Nullable(String),
`s_state` Nullable(String),
`s_zip` Nullable(String),
`s_country` Nullable(String),
`s_gmt_offset` Nullable(Float32),
`s_tax_precentage` Nullable(Float32)
)
ENGINE = MergeTree ORDER BY s_store_sk;
CREATE TABLE customer
(
`c_customer_sk` Int64,
`c_customer_id` String,
`c_current_cdemo_sk` Nullable(Int64),
`c_current_hdemo_sk` Nullable(Int64),
`c_current_addr_sk` Nullable(Int64),
`c_first_shipto_date_sk` Nullable(Int64),
`c_first_sales_date_sk` Nullable(Int64),
`c_salutation` Nullable(String),
`c_first_name` Nullable(String),
`c_last_name` Nullable(String),
`c_preferred_cust_flag` Nullable(String),
`c_birth_day` Nullable(Int64),
`c_birth_month` Nullable(Int64),
`c_birth_year` Nullable(Int64),
`c_birth_country` Nullable(String),
`c_login` Nullable(String),
`c_email_address` Nullable(String),
`c_last_review_date` Nullable(String)
)
ENGINE = MergeTree ORDER BY c_customer_sk;
CREATE TABLE customer_demographics
(
`cd_demo_sk` Int64,
`cd_gender` Nullable(String),
`cd_marital_status` Nullable(String),
`cd_education_status` Nullable(String),
`cd_purchase_estimate` Nullable(Int64),
`cd_credit_rating` Nullable(String),
`cd_dep_count` Nullable(Int64),
`cd_dep_employed_count` Nullable(Int64),
`cd_dep_college_count` Nullable(Int64)
)
ENGINE = MergeTree ORDER BY cd_demo_sk;
CREATE TABLE promotion
(
`p_promo_sk` Int64,
`p_promo_id` String,
`p_start_date_sk` Nullable(Int64),
`p_end_date_sk` Nullable(Int64),
`p_item_sk` Nullable(Int64),
`p_cost` Nullable(Float64),
`p_response_target` Nullable(Int64),
`p_promo_name` Nullable(String),
`p_channel_dmail` Nullable(String),
`p_channel_email` Nullable(String),
`p_channel_catalog` Nullable(String),
`p_channel_tv` Nullable(String),
`p_channel_radio` Nullable(String),
`p_channel_press` Nullable(String),
`p_channel_event` Nullable(String),
`p_channel_demo` Nullable(String),
`p_channel_details` Nullable(String),
`p_purpose` Nullable(String),
`p_discount_active` Nullable(String)
)
ENGINE = MergeTree ORDER BY p_promo_sk;
CREATE TABLE household_demographics
(
`hd_demo_sk` Int64,
`hd_income_band_sk` Nullable(Int64),
`hd_buy_potential` Nullable(String),
`hd_dep_count` Nullable(Int64),
`hd_vehicle_count` Nullable(Int64)
)
ENGINE = MergeTree ORDER BY hd_demo_sk;
CREATE TABLE customer_address
(
`ca_address_sk` Int64,
`ca_address_id` String,
`ca_street_number` Nullable(String),
`ca_street_name` Nullable(String),
`ca_street_type` Nullable(String),
`ca_suite_number` Nullable(String),
`ca_city` Nullable(String),
`ca_county` Nullable(String),
`ca_state` Nullable(String),
`ca_zip` Nullable(String),
`ca_country` Nullable(String),
`ca_gmt_offset` Nullable(Float32),
`ca_location_type` Nullable(String)
)
ENGINE = MergeTree ORDER BY ca_address_sk;
CREATE TABLE income_band
(
`ib_income_band_sk` Int64,
`ib_lower_bound` Nullable(Int64),
`ib_upper_bound` Nullable(Int64)
)
ENGINE = MergeTree ORDER BY ib_income_band_sk;
CREATE TABLE item
(
`i_item_sk` Int64,
`i_item_id` String,
`i_rec_start_date` Nullable(Date),
`i_rec_end_date` Nullable(Date),
`i_item_desc` Nullable(String),
`i_current_price` Nullable(Float32),
`i_wholesale_cost` Nullable(Float32),
`i_brand_id` Nullable(Int64),
`i_brand` Nullable(String),
`i_class_id` Nullable(Int64),
`i_class` Nullable(String),
`i_category_id` Nullable(Int64),
`i_category` Nullable(String),
`i_manufact_id` Nullable(Int64),
`i_manufact` Nullable(String),
`i_size` Nullable(String),
`i_formulation` Nullable(String),
`i_color` Nullable(String),
`i_units` Nullable(String),
`i_container` Nullable(String),
`i_manager_id` Nullable(Int64),
`i_product_name` Nullable(String)
)
ENGINE = MergeTree ORDER BY i_item_sk;
EXPLAIN SYNTAX
WITH
cs_ui AS
(
SELECT
cs_item_sk,
sum(cs_ext_list_price) AS sale,
sum((cr_refunded_cash + cr_reversed_charge) + cr_store_credit) AS refund
FROM catalog_sales , catalog_returns
WHERE (cs_item_sk = cr_item_sk) AND (cs_order_number = cr_order_number)
GROUP BY cs_item_sk
HAVING sum(cs_ext_list_price) > (2 * sum((cr_refunded_cash + cr_reversed_charge) + cr_store_credit))
),
cross_sales AS
(
SELECT
i_product_name AS product_name,
i_item_sk AS item_sk,
s_store_name AS store_name,
s_zip AS store_zip,
ad1.ca_street_number AS b_street_number,
ad1.ca_street_name AS b_street_name,
ad1.ca_city AS b_city,
ad1.ca_zip AS b_zip,
ad2.ca_street_number AS c_street_number,
ad2.ca_street_name AS c_street_name,
ad2.ca_city AS c_city,
ad2.ca_zip AS c_zip,
d1.d_year AS syear,
d2.d_year AS fsyear,
d3.d_year AS s2year,
count(*) AS cnt,
sum(ss_wholesale_cost) AS s1,
sum(ss_list_price) AS s2,
sum(ss_coupon_amt) AS s3
FROM store_sales
, store_returns
, cs_ui
, date_dim AS d1
, date_dim AS d2
, date_dim AS d3
, store
, customer
, customer_demographics AS cd1
, customer_demographics AS cd2
, promotion
, household_demographics AS hd1
, household_demographics AS hd2
, customer_address AS ad1
, customer_address AS ad2
, income_band AS ib1
, income_band AS ib2
, item
WHERE (ss_store_sk = s_store_sk) AND (ss_sold_date_sk = d1.d_date_sk) AND (ss_customer_sk = c_customer_sk) AND (ss_cdemo_sk = cd1.cd_demo_sk) AND (ss_hdemo_sk = hd1.hd_demo_sk) AND (ss_addr_sk = ad1.ca_address_sk) AND (ss_item_sk = i_item_sk) AND (ss_item_sk = sr_item_sk) AND (ss_ticket_number = sr_ticket_number) AND (ss_item_sk = cs_ui.cs_item_sk) AND (c_current_cdemo_sk = cd2.cd_demo_sk) AND (c_current_hdemo_sk = hd2.hd_demo_sk) AND (c_current_addr_sk = ad2.ca_address_sk) AND (c_first_sales_date_sk = d2.d_date_sk) AND (c_first_shipto_date_sk = d3.d_date_sk) AND (ss_promo_sk = p_promo_sk) AND (hd1.hd_income_band_sk = ib1.ib_income_band_sk) AND (hd2.hd_income_band_sk = ib2.ib_income_band_sk) AND (cd1.cd_marital_status != cd2.cd_marital_status) AND (i_color IN ('maroon', 'burnished', 'dim', 'steel', 'navajo', 'chocolate')) AND ((i_current_price >= 35) AND (i_current_price <= (35 + 10))) AND ((i_current_price >= (35 + 1)) AND (i_current_price <= (35 + 15)))
GROUP BY
i_product_name,
i_item_sk,
s_store_name,
s_zip,
ad1.ca_street_number,
ad1.ca_street_name,
ad1.ca_city,
ad1.ca_zip,
ad2.ca_street_number,
ad2.ca_street_name,
ad2.ca_city,
ad2.ca_zip,
d1.d_year,
d2.d_year,
d3.d_year
)
SELECT
cs1.product_name,
cs1.store_name,
cs1.store_zip,
cs1.b_street_number,
cs1.b_street_name,
cs1.b_city,
cs1.b_zip,
cs1.c_street_number,
cs1.c_street_name,
cs1.c_city,
cs1.c_zip,
cs1.syear,
cs1.cnt,
cs1.s1 AS s11,
cs1.s2 AS s21,
cs1.s3 AS s31,
cs2.s1 AS s12,
cs2.s2 AS s22,
cs2.s3 AS s32,
cs2.syear,
cs2.cnt
FROM cross_sales AS cs1 , cross_sales AS cs2
WHERE (cs1.item_sk = cs2.item_sk) AND (cs1.syear = 2000) AND (cs2.syear = (2000 + 1)) AND (cs2.cnt <= cs1.cnt) AND (cs1.store_name = cs2.store_name) AND (cs1.store_zip = cs2.store_zip)
ORDER BY
cs1.product_name ASC,
cs1.store_name ASC,
cs2.cnt ASC,
cs1.s1 ASC,
cs2.s1 ASC
FORMAT Null
;
SELECT 'Ok';
DROP TABLE IF EXISTS store_returns;
DROP TABLE IF EXISTS catalog_sales;
DROP TABLE IF EXISTS catalog_returns;
DROP TABLE IF EXISTS date_dim;
DROP TABLE IF EXISTS store;
DROP TABLE IF EXISTS customer;
DROP TABLE IF EXISTS customer_demographics;
DROP TABLE IF EXISTS promotion;
DROP TABLE IF EXISTS household_demographics;
DROP TABLE IF EXISTS customer_address;
DROP TABLE IF EXISTS income_band;
DROP TABLE IF EXISTS item;