github.com/apache/beam/sdks/v2@v2.48.2/java/testing/tpcds/src/main/resources/queries/query71.sql (about)

     1  -- Licensed to the Apache Software Foundation (ASF) under one
     2  -- or more contributor license agreements.  See the NOTICE file
     3  -- distributed with this work for additional information
     4  -- regarding copyright ownership.  The ASF licenses this file
     5  -- to you under the Apache License, Version 2.0 (the
     6  -- "License"); you may not use this file except in compliance
     7  -- with the License.  You may obtain a copy of the License at
     8  --
     9  --     http://www.apache.org/licenses/LICENSE-2.0
    10  --
    11  -- Unless required by applicable law or agreed to in writing, software
    12  -- distributed under the License is distributed on an "AS IS" BASIS,
    13  -- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    14  -- See the License for the specific language governing permissions and
    15  -- limitations under the License.
    16  
    17  select i_brand_id brand_id, i_brand brand,t_hour,t_minute,
    18   	sum(ext_price) ext_price
    19   from item, (select ws_ext_sales_price as ext_price, 
    20                          ws_sold_date_sk as sold_date_sk,
    21                          ws_item_sk as sold_item_sk,
    22                          ws_sold_time_sk as time_sk  
    23                   from web_sales,date_dim
    24                   where d_date_sk = ws_sold_date_sk
    25                     and d_moy=12
    26                     and d_year=2000
    27                   union all
    28                   select cs_ext_sales_price as ext_price,
    29                          cs_sold_date_sk as sold_date_sk,
    30                          cs_item_sk as sold_item_sk,
    31                          cs_sold_time_sk as time_sk
    32                   from catalog_sales,date_dim
    33                   where d_date_sk = cs_sold_date_sk
    34                     and d_moy=12
    35                     and d_year=2000
    36                   union all
    37                   select ss_ext_sales_price as ext_price,
    38                          ss_sold_date_sk as sold_date_sk,
    39                          ss_item_sk as sold_item_sk,
    40                          ss_sold_time_sk as time_sk
    41                   from store_sales,date_dim
    42                   where d_date_sk = ss_sold_date_sk
    43                     and d_moy=12
    44                     and d_year=2000
    45                   ) tmp,time_dim
    46   where
    47     sold_item_sk = i_item_sk
    48     and i_manager_id=1
    49     and time_sk = t_time_sk
    50     and (t_meal_time = 'breakfast' or t_meal_time = 'dinner')
    51   group by i_brand, i_brand_id,t_hour,t_minute
    52   order by ext_price desc, i_brand_id