Flink高级API(四)v2

举报
Maynor学长 发表于 2022/07/22 22:31:55 2022/07/22
【摘要】 Flink状态管理状态就是基于 key 或者 算子 operator 的中间结果Flink state 分为两种 : Managed state - 托管状态 , Raw state - 原始状态Managed state 分为 两种:keyed state 基于 key 上的状态支持的数据结构 valueState listState mapState broadcastStateope...

Flink状态管理

  • 状态就是基于 key 或者 算子 operator 的中间结果

  • Flink state 分为两种 : Managed state - 托管状态 , Raw state - 原始状态

  • Managed state 分为 两种:

    1. keyed state 基于 key 上的状态

      支持的数据结构 valueState listState mapState broadcastState

    2. operator state 基于操作的状态

      字节数组, ListState

Flink keyed state 案例

  • 需求

    使用KeyedState中的ValueState获取数据中的最大值(实际中直接使用maxBy即可),使用值状态自定义,

    <hello,1>

    <hello,3>

    <hello,2>

    输入Tuple2<String/单词/, Long/长度/> 输出 Tuple3<String/单词/, Long/长度/, Long/历史最大值/> 类型

  • 开发

    package cn.itcast.flink.state;
    
    import org.apache.flink.api.common.functions.RichMapFunction;
    import org.apache.flink.api.common.state.ValueState;
    import org.apache.flink.api.common.state.ValueStateDescriptor;
    import org.apache.flink.api.java.tuple.Tuple2;
    import org.apache.flink.api.java.tuple.Tuple3;
    import org.apache.flink.configuration.Configuration;
    import org.apache.flink.streaming.api.datastream.DataStreamSource;
    import org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator;
    import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
    
    /**
     * Author itcast
     * Date 2021/6/21 8:34
     * Desc TODO
     */
    public class KeyedStateDemo {
        public static void main(String[] args) throws Exception {
            //1.env 设置并发度为1
            StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
            env.setParallelism(1);
            //2.Source 参看课件 <城市,次数> => <城市,最大次数>
            DataStreamSource<Tuple2<String, Long>> tupleDS = env.fromElements(
                    Tuple2.of("北京", 1L),
                    Tuple2.of("上海", 2L),
                    Tuple2.of("北京", 6L),
                    Tuple2.of("上海", 8L),
                    Tuple2.of("北京", 3L),
                    Tuple2.of("上海", 4L)
            );
            //3.Transformation
            //使用KeyState中的ValueState获取流数据中的最大值(实际中直接使用maxBy即可)
            //实现方式1:直接使用maxBy--开发中使用该方式即可
            SingleOutputStreamOperator<Tuple2<String, Long>> result1 = tupleDS.keyBy(t -> t.f0)
                    //min只会求出最小的那个字段,其他的字段不管
                    //minBy会求出最小的那个字段和对应的其他的字段
                    //max只会求出最大的那个字段,其他的字段不管
                    //maxBy会求出最大的那个字段和对应的其他的字段
                    .maxBy(1);
            //实现方式2:通过managed state输入的state
            //3.1.先根据字符串f0分组然后进行 map 操作,将Tuple2<String/*城市*/, Long/*次数*/> 输出 Tuple3<String/*城市*/, Long/*次数*/, Long/*历史最大值*/>
            //
            SingleOutputStreamOperator<Tuple3<String, Long, Long>> result2 = tupleDS
                    .keyBy(t->t.f0)
                    .map(new RichMapFunction<Tuple2<String, Long>, Tuple3<String/*城市*/, Long/*次数*/, Long/*历史最大值*/>>() {
                ValueState<Long> maxState = null;
    
                //-1.定义值类型的状态用来存储最大值
                //3.2.重写 RichMapFunction 的open 方法
                @Override
                public void open(Configuration parameters) throws Exception {
                    //-2.定义状态描述符
                    //-3.从当前上下文获取内存中的状态值
                    ValueStateDescriptor maxStateDesc = new ValueStateDescriptor("maxState", Long.class);
                    maxState = getRuntimeContext().getState(maxStateDesc);
                }
    
                //3.3.重写 map 方法
                //-4.获取state中历史最大值value和当前元素的最大值并比较
                @Override
                public Tuple3<String, Long, Long> map(Tuple2<String, Long> value) throws Exception {
                    //内存中state的存储的最大值
                    Long maxValue = maxState.value();
                    //当前的值
                    Long curValue = value.f1;
                    if (maxValue == null || curValue > maxValue) {
                        maxState.update(curValue);
                        return Tuple3.of(value.f0, value.f1, curValue);
                    } else {
                        return Tuple3.of(value.f0, value.f1, maxValue);
                    }
                }
            });
    
    
            //-5.如果当前值大或历史值为空更新状态;返回Tuple3元祖结果
            //4.Sink 打印输出
            //result1.print();
            result2.print();
            //5.execute 执行环境
            env.execute();
        }
    }
    

Flink operator state 案例

  • 需求

    使用ListState存储offset模拟消费Kafka的offset维护

  • 实现

    package cn.itcast.flink.state;
    
    import org.apache.flink.api.common.restartstrategy.RestartStrategies;
    import org.apache.flink.api.common.state.ListState;
    import org.apache.flink.api.common.state.ListStateDescriptor;
    import org.apache.flink.runtime.state.FunctionInitializationContext;
    import org.apache.flink.runtime.state.FunctionSnapshotContext;
    import org.apache.flink.runtime.state.filesystem.FsStateBackend;
    import org.apache.flink.streaming.api.CheckpointingMode;
    import org.apache.flink.streaming.api.checkpoint.CheckpointedFunction;
    import org.apache.flink.streaming.api.datastream.DataStreamSource;
    import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
    import org.apache.flink.streaming.api.functions.source.RichParallelSourceFunction;
    
    import java.util.Iterator;
    
    /**
     * Author itcast
     * Date 2021/6/21 9:18
     * Desc TODO
     */
    public class OperatorStateDemo {
        public static void main(String[] args) throws Exception {
            //1.创建流环境,便于观察设置并行度为 1
            StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
            env.setParallelism(1);
            //2.开启checkpoint ,并将状态保存到 file:///D:/chk ,先开启checkpoint ,state管理
            env.enableCheckpointing(1000);
            env.setStateBackend(new FsStateBackend("file:///D:/chk"));
            //3.设置checkpoint的配置 外部chk,仅一次语义等
            env.getCheckpointConfig().setCheckpointingMode(CheckpointingMode.EXACTLY_ONCE);
            //4.开启重启策略 3秒钟尝试重启3次
            env.setRestartStrategy(RestartStrategies.fixedDelayRestart(3,3000));
            //5.添加数据源比如 MyMonitorKafkaSource , 实例化创建 MyMonitorKafkaSource
            DataStreamSource<String> source = env.addSource(new MyMonitorKafkaSource());
            //6.打印输出
            source.print();
            //7.执行
            env.execute();
    
    
        }
        //创建 MyMonitorKafkaSource 继承 RichParallelSourceFunction<String> 并实现 CheckpointedFunction
        public static class MyMonitorKafkaSource extends RichParallelSourceFunction<String>
        implements CheckpointedFunction{
            //重写initializeState方法 ListStateDescriptor 状态描述和通过context获取 offsetState
            ListState<Long> offsetState = null;
            boolean flag = true;
            Long offset = 0L;
            @Override
            public void initializeState(FunctionInitializationContext context) throws Exception {
                ListStateDescriptor<Long> offsetStateDesc = new ListStateDescriptor<>("offsetState", Long.class);
                offsetState = context.getOperatorStateStore().getListState(offsetStateDesc);
            }
            //重写run方法 读取出 offset 并 循环读取offset+=1,拿到执行的核心编号,输出(核编号和offset),一秒一条,每5条模拟一个异常
            @Override
            public void run(SourceContext<String> ctx) throws Exception {
                Iterator<Long> iterator = offsetState.get().iterator();
                if(iterator.hasNext()){
                    offset = iterator.next();
                }
                while(flag){
                    offset = offset + 1;
                    //处理 CPU 核心Index
                    int idx = getRuntimeContext().getIndexOfThisSubtask();
                    System.out.println("index:"+idx+" offset:"+offset);
                    Thread.sleep(1000);
                    if(offset % 5 ==0){
                        System.out.println("当前程序出错了....");
                        throw new Exception("程序出BUG...");
                    }
                }
            }
            //重写cancel方法
            @Override
            public void cancel() {
                flag = false;
            }
    
            //重写snapshotState方法 , 清空 offsetState ,并将最新的offset添加进去
            @Override
            public void snapshotState(FunctionSnapshotContext context) throws Exception {
                offsetState.clear();
                offsetState.add(offset);
            }
        }
    }
    

IndexOfThisSubtask();
System.out.println(“index:”+idx+" offset:"+offset);
Thread.sleep(1000);
if(offset % 5 ==0){
System.out.println(“当前程序出错了…”);
throw new Exception(“程序出BUG…”);
}
}
}
//重写cancel方法
@Override
public void cancel() {
flag = false;
}

      //重写snapshotState方法 , 清空 offsetState ,并将最新的offset添加进去
      @Override
      public void snapshotState(FunctionSnapshotContext context) throws Exception {
          offsetState.clear();
          offsetState.add(offset);
      }
  }

}


【版权声明】本文为华为云社区用户原创内容,转载时必须标注文章的来源(华为云社区)、文章链接、文章作者等基本信息, 否则作者和本社区有权追究责任。如果您发现本社区中有涉嫌抄袭的内容,欢迎发送邮件进行举报,并提供相关证据,一经查实,本社区将立刻删除涉嫌侵权内容,举报邮箱: cloudbbs@huaweicloud.com
  • 点赞
  • 收藏
  • 关注作者

评论(0

0/1000
抱歉,系统识别当前为高风险访问,暂不支持该操作

全部回复

上滑加载中

设置昵称

在此一键设置昵称,即可参与社区互动!

*长度不超过10个汉字或20个英文字符,设置后3个月内不可修改。

*长度不超过10个汉字或20个英文字符,设置后3个月内不可修改。

举报
请填写举报理由
0/200