1、主類
package com.example.demo.flink; import com.example.demo.flink.impl.CountAverageWithMapState; import com.example.demo.flink.impl.CountAverageWithReduceState; import org.apache.flink.api.java.tuple.Tuple2; import org.apache.flink.configuration.Configuration; import org.apache.flink.streaming.api.datastream.DataStreamSource; import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment; /** * @program: demo * @description: valuestate * @author: yang * @create: 2020-12-28 15:46 */ public class TestKeyedReduceStateMain { public static void main(String[] args) throws Exception{ //獲取執行環境 StreamExecutionEnvironment env = StreamExecutionEnvironment.createLocalEnvironmentWithWebUI(new Configuration()); //StreamExecutionEnvironment.getExecutionEnvironment(); //設置並行度 env.setParallelism(16); //獲取數據源 DataStreamSource<Tuple2<Long, Long>> dataStreamSource = env.fromElements( Tuple2.of(1L, 3L), Tuple2.of(1L, 7L), Tuple2.of(2L, 4L), Tuple2.of(1L, 5L), Tuple2.of(2L, 2L), Tuple2.of(2L, 6L)); // 輸出: //(1,5.0) //(2,4.0) dataStreamSource .keyBy(0) .flatMap(new CountAverageWithReduceState()) .print(); env.execute("TestStatefulApi"); } }
2、處理實現類
package com.example.demo.flink.impl; /** * @program: demo * @description: valuestate * @author: yang * @create: 2020-12-28 16:26 */ import org.apache.flink.api.common.functions.ReduceFunction; import org.apache.flink.api.common.functions.RichFlatMapFunction; import org.apache.flink.api.common.state.MapState; import org.apache.flink.api.common.state.MapStateDescriptor; import org.apache.flink.api.common.state.ReducingState; import org.apache.flink.api.common.state.ReducingStateDescriptor; import org.apache.flink.api.common.typeinfo.Types; import org.apache.flink.api.java.tuple.Tuple2; import org.apache.flink.configuration.Configuration; import org.apache.flink.shaded.guava18.com.google.common.collect.Lists; import org.apache.flink.util.Collector; import java.util.List; import java.util.UUID; /** * ValueState<T> :這個狀態為每一個 key 保存一個值 * value() 獲取狀態值 * update() 更新狀態值 * clear() 清除狀態 * * IN,輸入的數據類型 * OUT:數據出的數據類型 */ public class CountAverageWithReduceState extends RichFlatMapFunction<Tuple2<Long, Long>, Tuple2<Long, Long>> { private ReducingState<Long> reducingState; /***狀態初始化*/ @Override public void open(Configuration parameters) throws Exception { ReducingStateDescriptor descriptor = new ReducingStateDescriptor("ReducingDescriptor", new ReduceFunction<Long>() { @Override public Long reduce(Long v1, Long v2) throws Exception { return v1 + v2; } },Long.class); reducingState = getRuntimeContext().getReducingState(descriptor); } @Override public void flatMap(Tuple2<Long, Long> element, Collector<Tuple2<Long, Long>> collector) throws Exception { //將狀態放入 reducingState.add(element.f1); collector.collect(Tuple2.of(element.f0,reducingState.get())); } }