9.Flink实时项目之订单宽表

1.需求分析 订单是统计分析的重要的对象,围绕订单有很多的维度统计需求,比如用户、地区、商品、品类、品牌等等。为了之后统计计算更加方便,减少大表之间的关联,所以在实时计算过程中将围绕订单的相关数据整合成为一张订单的宽表。那究竟哪些数据需要和订单整合在一起?
9.Flink实时项目之订单宽表
文章图片

如上图,由于在之前的操作(BaseDbTask)我们已经把数据分拆成了事实数据和维度数据,事实数据(绿色)进入 kafka 数据流(DWD 层)中,维度数据(蓝色)进入 hbase 中长期保存。那么我们在 DWM 层中要把实时和维度数据进行整合关联在一起,形成宽表。那么这里就要处理有两种关联,事实数据和事实数据关联、事实数据和维度数据关联。

  • 事实数据和事实数据关联,其实就是流与流之间的关联。
  • 事实数据与维度数据关联,其实就是流计算中查询外部数据源。
9.Flink实时项目之订单宽表
文章图片

2. 创建实体类
import java.math.BigDecimal; /** * @author zhangbao * @date 2021/10/25 19:55 * @desc 订单 */ @Data public class OrderInfo { Long id; Long province_id; String order_status; Long user_id; BigDecimal total_amount; BigDecimal activity_reduce_amount; BigDecimal coupon_reduce_amount; BigDecimal original_total_amount; BigDecimal feight_fee; String expire_time; String create_time; String operate_time; String create_date; // 把其他字段处理得到 String create_hour; Long create_ts; }

import java.math.BigDecimal; /** * @author zhangbao * @date 2021/10/25 19:55 * @desc 订单明细 */ @Data public class OrderDetail { Long id; Long order_id ; Long sku_id; BigDecimal order_price ; Long sku_num ; String sku_name; String create_time; BigDecimal split_total_amount; BigDecimal split_activity_amount; BigDecimal split_coupon_amount; Long create_ts; }

3. 消费kafka事实数据 【9.Flink实时项目之订单宽表】在dwm包下创建任务OrderWideApp.java,对订单及明细数据做格式转换,在这个阶段可以做一些ETL操作。
import cn.hutool.core.date.DateTime; import cn.hutool.core.date.DateUnit; import cn.hutool.core.date.DateUtil; import com.alibaba.fastjson.JSONObject; import com.zhangbao.gmall.realtime.bean.OrderDetail; import com.zhangbao.gmall.realtime.bean.OrderInfo; import com.zhangbao.gmall.realtime.utils.MyKafkaUtil; import org.apache.flink.api.common.functions.RichMapFunction; import org.apache.flink.configuration.Configuration; import org.apache.flink.runtime.state.filesystem.FsStateBackend; import org.apache.flink.streaming.api.CheckpointingMode; import org.apache.flink.streaming.api.datastream.DataStreamSource; import org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator; import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment; import org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer; ? /** * @author zhangbao * @date 2021/10/25 19:58 * @desc */ public class OrderWideApp { public static void main(String[] args) { //webui模式,需要添加pom依赖 StreamExecutionEnvironment env = StreamExecutionEnvironment.createLocalEnvironmentWithWebUI(new Configuration()); //StreamExecutionEnvironment env1 = StreamExecutionEnvironment.createLocalEnvironment(); //设置并行度 env.setParallelism(4); //设置检查点 //env.enableCheckpointing(5000, CheckpointingMode.EXACTLY_ONCE); //env.getCheckpointConfig().setCheckpointTimeout(60000); //env.setStateBackend(new FsStateBackend("hdfs://hadoop101:9000/gmall/flink/checkpoint/uniqueVisit")); ////指定哪个用户读取hdfs文件 //System.setProperty("HADOOP_USER_NAME","zhangbao"); ? //从kafka的dwd主题获取订单和订单详情 String orderInfoTopic = "dwd_order_info"; String orderDetailTopic = "dwd_order_detail"; String orderWideTopic = "dwm_order_wide"; String orderWideGroup = "order_wide_group"; ? //订单数据 FlinkKafkaConsumer orderInfoSource = MyKafkaUtil.getKafkaSource(orderInfoTopic, orderWideGroup); DataStreamSource orderInfoDs = env.addSource(orderInfoSource); ? //订单详情数据 FlinkKafkaConsumer orderDetailSource = MyKafkaUtil.getKafkaSource(orderDetailTopic, orderWideGroup); DataStreamSource orderDetailDs = env.addSource(orderDetailSource); ? //对订单数据进行转换 SingleOutputStreamOperator orderInfoObjDs = orderInfoDs.map(new RichMapFunction() { @Override public OrderInfo map(String jsonStr) throws Exception { System.out.println("order info str >>> "+jsonStr); OrderInfo orderInfo = JSONObject.parseObject(jsonStr, OrderInfo.class); DateTime createTime = DateUtil.parse(orderInfo.getCreate_time(), "yyyy-MM-dd HH:mm:ss"); orderInfo.setCreate_ts(createTime.getTime()); return orderInfo; } }); ? //对订单明细数据进行转换 SingleOutputStreamOperator orderDetailObjDs = orderDetailDs.map(new RichMapFunction() { @Override public OrderDetail map(String jsonStr) throws Exception { System.out.println("order detail str >>> "+jsonStr); OrderDetail orderDetail = JSONObject.parseObject(jsonStr, OrderDetail.class); DateTime createTime = DateUtil.parse(orderDetail.getCreate_time(), "yyyy-MM-dd HH:mm:ss"); orderDetail.setCreate_ts(createTime.getTime()); return orderDetail; } }); ? orderInfoDs.print("order info >>>"); orderDetailDs.print("order detail >>>"); ? try { env.execute("order wide task"); } catch (Exception e) { e.printStackTrace(); } } }

4. 双流join准备 在 flink 中的流 join 大体分为两种,一种是基于时间窗口的 join(Time Windowed Join),比如 join、coGroup 等。另一种是基于状态缓存的 join(Temporal Table Join),比如 intervalJoin。这里选用 intervalJoin,因为相比较窗口 join,intervalJoin 使用更简单,而且避免了应匹配的数据处于不同窗口的问题。
intervalJoin 目前只有一个问题,就是还不支持 left join。但是我们这里是订单主表与订单从表之间的关联不需要 left join,所以 intervalJoin 是较好的选择。
官方文档:interval-join
先设置时间水位线,然后在分组
//指定事件时间字段 //订单事件时间字段 SingleOutputStreamOperator orderInfoWithTsDs = orderInfoObjDs.assignTimestampsAndWatermarks( WatermarkStrategy .forBoundedOutOfOrderness(Duration.ofSeconds(3)) .withTimestampAssigner(new SerializableTimestampAssigner() { @Override public long extractTimestamp(OrderInfo orderInfo, long l) { return orderInfo.getCreate_ts(); } }) ); //订单明细指定事件事件字段 SingleOutputStreamOperator orderDetailWithTsDs = orderDetailObjDs.assignTimestampsAndWatermarks( WatermarkStrategy.forBoundedOutOfOrderness(Duration.ofSeconds(3)) .withTimestampAssigner(new SerializableTimestampAssigner() { @Override public long extractTimestamp(OrderDetail orderDetail, long l) { return orderDetail.getCreate_ts(); } }) ); ? //分组 KeyedStream orderInfoKeysDs = orderInfoWithTsDs.keyBy(OrderInfo::getId); KeyedStream orderDetailKeysDs = orderDetailWithTsDs.keyBy(OrderDetail::getId);

5. 建立订单宽表
import lombok.AllArgsConstructor; import lombok.Data; import org.apache.commons.lang3.ObjectUtils; ? import java.math.BigDecimal; ? /** * @author zhangbaohpu * @date2021/11/13 11:10 * @desc 订单宽表 */ @Data @AllArgsConstructor public class OrderWide { Long detail_id; Long order_id ; Long sku_id; BigDecimal order_price ; Long sku_num ; String sku_name; Long province_id; String order_status; Long user_id; BigDecimal total_amount; BigDecimal activity_reduce_amount; BigDecimal coupon_reduce_amount; BigDecimal original_total_amount; BigDecimal feight_fee; BigDecimal split_feight_fee; BigDecimal split_activity_amount; BigDecimal split_coupon_amount; BigDecimal split_total_amount; String expire_time; String create_time; String operate_time; String create_date; // 把其他字段处理得到 String create_hour; String province_name; //查询维表得到 String province_area_code; String province_iso_code; String province_3166_2_code; Integer user_age ; String user_gender; Long spu_id; //作为维度数据 要关联进来 Long tm_id; Long category3_id; String spu_name; String tm_name; String category3_name; public OrderWide(OrderInfo orderInfo, OrderDetail orderDetail){ mergeOrderInfo(orderInfo); mergeOrderDetail(orderDetail); } public void mergeOrderInfo(OrderInfo orderInfo ) { if (orderInfo != null) { this.order_id = orderInfo.id; this.order_status = orderInfo.order_status; this.create_time = orderInfo.create_time; this.create_date = orderInfo.create_date; this.activity_reduce_amount = orderInfo.activity_reduce_amount; this.coupon_reduce_amount = orderInfo.coupon_reduce_amount; this.original_total_amount = orderInfo.original_total_amount; this.feight_fee = orderInfo.feight_fee; this.total_amount = orderInfo.total_amount; this.province_id = orderInfo.province_id; this.user_id = orderInfo.user_id; } } public void mergeOrderDetail(OrderDetail orderDetail ) { if (orderDetail != null) { this.detail_id = orderDetail.id; this.sku_id = orderDetail.sku_id; this.sku_name = orderDetail.sku_name; this.order_price = orderDetail.order_price; this.sku_num = orderDetail.sku_num; this.split_activity_amount=orderDetail.split_activity_amount; this.split_coupon_amount=orderDetail.split_coupon_amount; this.split_total_amount=orderDetail.split_total_amount; } } public void mergeOtherOrderWide(OrderWide otherOrderWide){ this.order_status = ObjectUtils.firstNonNull( this.order_status ,otherOrderWide.order_status); this.create_time = ObjectUtils.firstNonNull(this.create_time,otherOrderWide.create_time); this.create_date = ObjectUtils.firstNonNull(this.create_date,otherOrderWide.create_date); this.coupon_reduce_amount = ObjectUtils.firstNonNull(this.coupon_reduce_amount,otherOrderWide.coupon_reduce_amount); this.activity_reduce_amount = ObjectUtils.firstNonNull(this.activity_reduce_amount,otherOrderWide.activity_reduce_amount); this.original_total_amount = ObjectUtils.firstNonNull(this.original_total_amount,otherOrderWide.original_total_amount); this.feight_fee = ObjectUtils.firstNonNull( this.feight_fee,otherOrderWide.feight_fee); this.total_amount = ObjectUtils.firstNonNull( this.total_amount,otherOrderWide.total_amount); this.user_id = ObjectUtils.firstNonNull(this.user_id,otherOrderWide.user_id); this.sku_id = ObjectUtils.firstNonNull( this.sku_id,otherOrderWide.sku_id); this.sku_name = ObjectUtils.firstNonNull(this.sku_name,otherOrderWide.sku_name); this.order_price = ObjectUtils.firstNonNull(this.order_price,otherOrderWide.order_price); this.sku_num = ObjectUtils.firstNonNull( this.sku_num,otherOrderWide.sku_num); this.split_activity_amount=ObjectUtils.firstNonNull(this.split_activity_amount); this.split_coupon_amount=ObjectUtils.firstNonNull(this.split_coupon_amount); this.split_total_amount=ObjectUtils.firstNonNull(this.split_total_amount); } }

6. 双流join 在做好数据封装,并标记时间水位线,我们可以做订单和订单明细表的双流join操作了。
import cn.hutool.core.date.DateTime; import cn.hutool.core.date.DateUtil; import com.alibaba.fastjson.JSONObject; import com.zhangbao.gmall.realtime.bean.OrderDetail; import com.zhangbao.gmall.realtime.bean.OrderInfo; import com.zhangbao.gmall.realtime.bean.OrderWide; import com.zhangbao.gmall.realtime.utils.MyKafkaUtil; import org.apache.flink.api.common.eventtime.SerializableTimestampAssigner; import org.apache.flink.api.common.eventtime.WatermarkStrategy; import org.apache.flink.api.common.functions.RichMapFunction; import org.apache.flink.configuration.Configuration; import org.apache.flink.streaming.api.datastream.DataStreamSource; import org.apache.flink.streaming.api.datastream.KeyedStream; import org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator; import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment; import org.apache.flink.streaming.api.functions.co.ProcessJoinFunction; import org.apache.flink.streaming.api.windowing.time.Time; import org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer; import org.apache.flink.util.Collector; ? import java.time.Duration; ? /** * @author zhangbao * @date 2021/10/25 19:58 * @desc * 启动服务 *zk > kf > maxwell > hdfs > hbase > baseDbTask > OrderWideApp > mysql配置表 * 业务流程 *模拟生成数据 *maxwell监控mysql数据 *kafka接收maxwell发送的数据,放入ODS层(ods_base_db_m) *baseDbTask消费kafka的主题数据并进行分流 *从mysql读取配置表 *将配置缓存到map集合中 *检查phoenix(hbase的皮肤)是否存在表 *对数据表进行分流发送到不同dwd层主题 */ public class OrderWideApp { public static void main(String[] args) { //webui模式,需要添加pom依赖 StreamExecutionEnvironment env = StreamExecutionEnvironment.createLocalEnvironmentWithWebUI(new Configuration()); //StreamExecutionEnvironment env1 = StreamExecutionEnvironment.createLocalEnvironment(); //设置并行度 env.setParallelism(4); //设置检查点 //env.enableCheckpointing(5000, CheckpointingMode.EXACTLY_ONCE); //env.getCheckpointConfig().setCheckpointTimeout(60000); //env.setStateBackend(new FsStateBackend("hdfs://hadoop101:9000/gmall/flink/checkpoint/uniqueVisit")); ////指定哪个用户读取hdfs文件 //System.setProperty("HADOOP_USER_NAME","zhangbao"); ? ? //从kafka的dwd主题获取订单和订单详情 String orderInfoTopic = "dwd_order_info"; String orderDetailTopic = "dwd_order_detail"; String orderWideTopic = "dwm_order_wide"; String orderWideGroup = "order_wide_group"; ? //订单数据 FlinkKafkaConsumer orderInfoSource = MyKafkaUtil.getKafkaSource(orderInfoTopic, orderWideGroup); DataStreamSource orderInfoDs = env.addSource(orderInfoSource); ? //订单详情数据 FlinkKafkaConsumer orderDetailSource = MyKafkaUtil.getKafkaSource(orderDetailTopic, orderWideGroup); DataStreamSource orderDetailDs = env.addSource(orderDetailSource); ? //对订单数据进行转换 SingleOutputStreamOperator orderInfoObjDs = orderInfoDs.map(new RichMapFunction() { @Override public OrderInfo map(String jsonStr) throws Exception { System.out.println("order info str >>> "+jsonStr); OrderInfo orderInfo = JSONObject.parseObject(jsonStr, OrderInfo.class); DateTime createTime = DateUtil.parse(orderInfo.getCreate_time(), "yyyy-MM-dd HH:mm:ss"); orderInfo.setCreate_ts(createTime.getTime()); return orderInfo; } }); ? //对订单明细数据进行转换 SingleOutputStreamOperator orderDetailObjDs = orderDetailDs.map(new RichMapFunction() { @Override public OrderDetail map(String jsonStr) throws Exception { System.out.println("order detail str >>> "+jsonStr); OrderDetail orderDetail = JSONObject.parseObject(jsonStr, OrderDetail.class); DateTime createTime = DateUtil.parse(orderDetail.getCreate_time(), "yyyy-MM-dd HH:mm:ss"); orderDetail.setCreate_ts(createTime.getTime()); return orderDetail; } }); ? orderInfoObjDs.print("order info >>>"); orderDetailObjDs.print("order detail >>>"); ? //指定事件时间字段 //订单事件时间字段 SingleOutputStreamOperator orderInfoWithTsDs = orderInfoObjDs.assignTimestampsAndWatermarks( WatermarkStrategy .forBoundedOutOfOrderness(Duration.ofSeconds(3)) .withTimestampAssigner(new SerializableTimestampAssigner() { @Override public long extractTimestamp(OrderInfo orderInfo, long l) { return orderInfo.getCreate_ts(); } }) ); //订单明细指定事件事件字段 SingleOutputStreamOperator orderDetailWithTsDs = orderDetailObjDs.assignTimestampsAndWatermarks( WatermarkStrategy.forBoundedOutOfOrderness(Duration.ofSeconds(3)) .withTimestampAssigner(new SerializableTimestampAssigner() { @Override public long extractTimestamp(OrderDetail orderDetail, long l) { return orderDetail.getCreate_ts(); } }) ); ? //分组 KeyedStream orderInfoKeysDs = orderInfoWithTsDs.keyBy(OrderInfo::getId); KeyedStream orderDetailKeysDs = orderDetailWithTsDs.keyBy(OrderDetail::getOrder_id); ? /** * interval-join * https://nightlies.apache.org/flink/flink-docs-release-1.14/docs/dev/datastream/operators/joining/#interval-join */ SingleOutputStreamOperator orderWideDs = orderInfoKeysDs.intervalJoin(orderDetailKeysDs) .between(Time.milliseconds(-5), Time.milliseconds(5)) .process(new ProcessJoinFunction() { @Override public void processElement(OrderInfo orderInfo, OrderDetail orderDetail, ProcessJoinFunction.Context context, Collector out) throws Exception { out.collect(new OrderWide(orderInfo, orderDetail)); } }); orderWideDs.print("order wide ds >>>"); ? try { env.execute("order wide task"); } catch (Exception e) { e.printStackTrace(); } } }

到这里我们就把订单的部分宽表数据给做出来了,下一节,我们再把一些维度数据给关联进来,就形成了一个完整订单宽表。

    推荐阅读