【入门Flink】- 11Flink实现动态TopN

基本处理函数(ProcessFunction)

stream.process(new MyProcessFunction())

方法需要传入一个 ProcessFunction 作为参数,ProcessFunction 不是接口 , 而是一个抽象类 ,继承了AbstractRichFunction,所有的处理函数,都是富函数(RichFunction),拥有富函数所有功能。

// 泛型:
// Type parameters:<I> – Type of the input elements.  输入类型
// 				   <O> – Type of the output elements. 输出类型
public abstract class ProcessFunction<I, O> extends AbstractRichFunction {
    
    public abstract void processElement(I value, Context ctx, Collector<O> out) throws Exception;
    
    public void onTimer(long timestamp, OnTimerContext ctx, Collector<O> out) throws Exception {}
} 

1)抽象方法.processElement()

“处理元素”,定义了处理的核心逻辑。这个方法对于流中的每个元素都会调用一次,参数包括三个:输入数据值 value,上下文 ctx,以及“收集器”(Collector)out。

  • value:当前流中的输入元素
  • ctx:类型是 ProcessFunction 中定义的内部抽象类 Context,表示当前运行的上下文,可以获取到当前的时间戳,并提供了用于查询时间和注册定时器的“定时服务”(TimerService),以及可以将数据发送到“侧输出流”(side output)的方法.output()。
  • out:“收集器”(类型为 Collector),用于返回输出数据。调用 out.collect()方法就可以向下游发出一个数据。这个方法可以多次调用,也可以不调用

ProcessFunction 可以轻松实现flatMap、map、filter 这样的基本转换功能;而通过富函数提供的获取上下文方法.getRuntimeContext(),也可以自定义状态(state)进行处理。

2)非抽象方法.onTimer()

只有在注册好的定时器触发的时候才会调用,而定时器是通过“定时服务”TimerService 来注册的。

三个参数:时间戳(timestamp),上下文(ctx),以及收集器(out)。

  • timestamp:指设定好的触发时间,事件时间语义下是水位线

  • ctx:同样可以调用定时服务(TimerService)

  • 采集器:任意输出处理之后的数据

.onTimer()方法定时触发,因此ProcessFunction可以自定义数据按照时间分组 、 定时触发计算输出结果;这 就实现了**窗口(window )**的功能。所以说ProcessFunction 可以实现一切功能

注意:在 Flink 中,只有**“按键分区流”KeyedStream 才支持设置定时器的操作**。

处理函数的分类(8大处理函数)

1)ProcessFunction

最基本的处理函数,基于 DataStream 直接调用.process()时作为参数传入。

2)KeyedProcessFunction

流按键分区后的处理函数,基于 KeyedStream 调用.process()时作为参数传入。要想使用定时器,必须基于 KeyedStream

3)ProcessWindowFunction

开窗之后的处理函数,也是全窗口函数的代表。基于 WindowedStream调用.process()时作为参数传入。

4)ProcessAllWindowFunction

同样是开窗之后的处理函数,基于 AllWindowedStream 调用.process()时作为参数传入

5)CoProcessFunction

合并(connect)两条流之后的处理函数,基于 ConnectedStreams 调用.process()时作为参数传入

6)ProcessJoinFunction

间隔连接(interval join)两条流之后的处理函数,基于 IntervalJoined 调用.process()时作为参数传入。

7)BroadcastProcessFunction

广播连接流处理函数,基于 BroadcastConnectedStream 调用.process()时作为参数传入。

“广播连接流”BroadcastConnectedStream,是一个未 keyBy 的普通DataStream与一个广播流(BroadcastStream)做连接(conncet)之后的产物。

8)KeyedBroadcastProcessFunction

按键分区的广播连接流处理函数,同样是基于 BroadcastConnectedStream调用.process()时作为参数传 入 。 一个KeyedStream 与广播流(BroadcastStream)做连接之后的产物。

按键分区处理函数(KeyedProcessFunction)

定时器(Timer)和定时服务(TimerService)

ProcessFunction 的上下文(Context)中提供了.timerService()方法,可以直接返回一个 TimerService 对象。

TimerService包含以下六个方法:

// 获取当前的处理时间
long currentProcessingTime();
// 获取当前的水位线(事件时间)
long currentWatermark();
// 注册处理时间定时器,当处理时间超过 time 时触发
void registerProcessingTimeTimer(long time);
// 注册事件时间定时器,当水位线超过 time 时触发
void registerEventTimeTimer(long time);
// 删除触发时间为 time 的处理时间定时器
void deleteProcessingTimeTimer(long time);
// 删除触发时间为 time 的处理时间定时器
void deleteEventTimeTimer(long time);

六个方法可以分成两大类:基于处理时间和基于事件时间

TimerService 会以键(key)和时间戳为标准,对定时器进行去重每个key和时间戳,最多只有一个定时器,如果注册了多次,onTimer()方法也将只被调用一次

案例

public class KeyedProcessTimerDemo {
    public static void main(String[] args) throws Exception {
        StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
        env.setParallelism(1);
        SingleOutputStreamOperator<WaterSensor> sensorDS = env.socketTextStream("124.222.253.33", 7777)
                .map(new WaterSensorMapFunction())
                .assignTimestampsAndWatermarks(
                        WatermarkStrategy
                                .<WaterSensor>forBoundedOutOfOrderness(Duration.ofSeconds(3))
                                .withTimestampAssigner((element, ts) -> element.getTs() * 1000L)
                );

        // 传感器Id keyBy
        KeyedStream<WaterSensor, String> sensorKS = sensorDS.keyBy(WaterSensor::getId);

        sensorKS.process(new KeyedProcessFunction<String, WaterSensor, String>() {

            /**
             * 来一条数据调用一次
             */
            @Override
            public void processElement(WaterSensor value, KeyedProcessFunction<String, WaterSensor, String>.Context ctx, Collector<String> out) throws Exception {

                // 获取当前数据的 key
                String currentKey = ctx.getCurrentKey();
                // TODO 1.定时器注册
                TimerService timerService = ctx.timerService();
                // 1、事件时间的案例
                Long currentEventTime = ctx.timestamp();//数据中提取出来的事件时间
                timerService.registerEventTimeTimer(5000L);
                System.out.println(" 当前key=" + currentKey + ",当前时间=" + currentEventTime + ",注册了一个5s 的定时器");
                // 2、处理时间的案例
                // long currentTs = timerService.currentProcessingTime();
                // timerService.registerProcessingTimeTimer(currentTs + 5000L);
                // System.out.println(" 当前key="+currentKey + ",当前时间=" + currentTs + ",注册了一个5s 后的定时器");
                // 3、获取 process 的 当前watermark
                // long currentWatermark = timerService.currentWatermark();
                // System.out.println("当前数据=" +value+",当前 watermark=" + currentWatermark);
                // 注册定时器: 处理时间、事件时间
                // timerService.registerProcessingTimeTimer();
                // timerService.registerEventTimeTimer();
                // 删除定时器: 处理时间、事件时间
                // timerService.deleteEventTimeTimer();
                // timerService.deleteProcessingTimeTimer();
                // 获取当前时间进展: 处理时间-当前系统时间,事件时间-当前 watermark
                // long currentTs = timerService.currentProcessingTime();
            }

            /**
             * .时间进展到定时器注册的时间,调用该方法
             * @param timestamp 当前时间进展,就是定时器被触发时的时间
             */
            @Override
            public void onTimer(long timestamp, KeyedProcessFunction<String, WaterSensor, String>.OnTimerContext ctx, Collector<String> out) throws Exception {
                super.onTimer(timestamp, ctx, out);

                String currentKey = ctx.getCurrentKey();
                System.out.println("key=" + currentKey + "现在时间是" + timestamp + "定时器触发");
            }
        }).print();

        env.execute();
    }
}

测试结果:

image-20231113220719287

注册多个定时器,但是时间到了只触发一次。

窗口处理函数

ProcessWindowFunction 和 ProcessAllWindowFunction(ProcessAllWindowFunction,没有 keyBy 的数据流直接开窗并调用.process()方法)

stream.keyBy( t -> t.f0 )
.window( TumblingEventTimeWindows.of(Time.seconds(10)))
    .process(new MyProcessWindowFunction())
/* 泛型
 * Type parameters:
 *		<IN> – The type of the input value. 输入类型
 *		<OUT> – The type of the output value. 输出类型
 *		<KEY> – The type of the key. key类型
 *		<W> – The type of Window that this window function can be applied on. 窗口类型
 */
public abstract class ProcessWindowFunction<IN, OUT, KEY, W extends Window>
        extends AbstractRichFunction {
    
    public abstract void process(
            KEY key, Context context, Iterable<IN> elements, Collector<OUT> out) throws Exception;
    public void clear(Context context) throws Exception {}
}

抽象方法process

  • key:窗口做统计计算基于的键,也就是之前 keyBy 用来分区的字段。
  • context:当前窗口进行计算的上下文,它的类型就是ProcessWindowFunction内部定义的抽象类 Context。
  • elements:窗口收集到用来计算的所有数据,这是一个可迭代的集合类型。
  • out:收集器

上下文调用函数:

public abstract class Context implements java.io.Serializable {
        public abstract W window();

        public abstract long currentProcessingTime();
    
        public abstract long currentWatermark();
		
    	// 窗口状态
        public abstract KeyedStateStore windowState();
		
    	// 全局状态
        public abstract KeyedStateStore globalState();

    	// 定义侧输出流
        public abstract <X> void output(OutputTag<X> outputTag, X value);
    }

TopN

需求:实时统计一段时间内的出现次数最多的水位。例如,统计最近10 秒钟内出现次数最多的两个水位,并且每 5 秒钟更新一次。

创建实体类:

public class WaterSensor {

    /**
     * 传感器Id
     */
    public String id;

    /**
     * 时间戳
     */
    public Long ts;

    /**
     * 水位
     */
    public Integer vc;
}

方法一:使用 ProcessAllWindowFunction

public class ProcessAllWindowTopNDemo {

    public static void main(String[] args) {
        StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
        env.setParallelism(1);
        SingleOutputStreamOperator<WaterSensor> sensorDS = env.socketTextStream("124.222.253.33", 7777)
                .map(new WaterSensorMapFunction())
                .assignTimestampsAndWatermarks(
                        WatermarkStrategy
                                .<WaterSensor>forBoundedOutOfOrderness(Duration.ofSeconds(3))
                                .withTimestampAssigner((element, ts) -> element.getTs() * 1000L)
                );

        // 滑动窗口
        sensorDS.windowAll(SlidingEventTimeWindows.of(Time.seconds(10), Time.seconds(5)))
                .process(new MyTopNPAWF())
                .print();

    }
}

// 抽取窗口函数
public class MyTopNPAWF extends ProcessAllWindowFunction<WaterSensor, String, TimeWindow> {

    @Override
    public void process(ProcessAllWindowFunction<WaterSensor, String, TimeWindow>.Context context, Iterable<WaterSensor> elements, Collector<String> out) throws Exception {
        Map<Integer, Integer> vcCountMap = new HashMap<>();

        for (WaterSensor element : elements) {
            // 统计不同水位出现次数
            vcCountMap.put(element.getVc(), vcCountMap.getOrDefault(element.getVc(), 0) + 1);
        }

        // 对 count 值进行排序: 利用 List 来实现排序
        List<Tuple2<Integer, Integer>> datas = new ArrayList<>();
        for (Integer vc : vcCountMap.keySet()) {
            datas.add(Tuple2.of(vc, vcCountMap.get(vc)));
        }
        // 对 List 进行排序,根据 count 值 降序
        datas.sort(new Comparator<Tuple2<Integer, Integer>>() {
            @Override
            public int compare(Tuple2<Integer, Integer> o1, Tuple2<Integer, Integer> o2) {
                // 降序, 后 减 前
                return o2.f1 - o1.f1;
            }
        });

        StringBuilder outStr = new StringBuilder();
        outStr.append("================================\n");
        // 遍历 排序后的 List,取出前 2 个, 考虑可能List 不够2个的情况==》 List 中元素的个数 和 2 取最小值
        for (int i = 0; i < Math.min(2, datas.size()); i++) {
            Tuple2<Integer, Integer> vcCount = datas.get(i);
            outStr.append("Top").append(i + 1).append("\n");
            outStr.append("vc=").append(vcCount.f0).append("\n");
            outStr.append("count=").append(vcCount.f1).append("\n");
            outStr.append(" 窗 口 结束时间=").append(DateFormatUtils.format(context.window().getEnd(), "yyyy-MM-ddHH:mm:ss.SSS")).append("\n");
            outStr.append("================================\n");
        }
        out.collect(outStr.toString());
    }
}

无论并行度如何设置,并行度只为1。效率不高

方法二:使用 KeyedProcessFunction ☆

从两个方面去做优化:一是对数据进行按键分区,分别统计vc 的出现次数;二是进行增量聚合,得到结果最后再做排序输出。

public class KeyedProcessFunctionTopNDemo {
    public static void main(String[] args) throws Exception {
        StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
        env.setParallelism(1);
        SingleOutputStreamOperator<WaterSensor> sensorDS = env.socketTextStream("124.222.253.33", 7777)
                .map(new WaterSensorMapFunction())
                .assignTimestampsAndWatermarks(
                        WatermarkStrategy
                                .<WaterSensor>forBoundedOutOfOrderness(Duration.ofSeconds(3))
                                .withTimestampAssigner((element, ts) -> element.getTs() * 1000L)
                );

        // 【水位分组】
        KeyedStream<WaterSensor, Integer> keyedStream = sensorDS.keyBy(WaterSensor::getVc);

        /*
        思路二: 使用 KeyedProcessFunction 实现
        1、按照 vc 做 keyby,开窗,分别 count
            ==》 增量聚合,计算 count
            ==》 全窗口,对计算结果 count 值封装,带上窗口结束时间的标签
            ==》 为了让同一个窗口时间范围的计算结果到一起去
        2、对同一个窗口范围的 count 值进行处理:排序、取前N 个
            =》 按照 windowEnd 做 keyby
            =》 使用 process, 来一条调用一次,需要先存,分开存,用HashMap,key=windowEnd,value=List
            =》 使用定时器,对 存起来的结果 进行排序、取前N个
            */
        // 1. 按照 vc 分组、开窗、聚合(增量计算+全量打标签)
        // 开窗聚合后,就是普通的流,没有了窗口信息,需要自己打上窗口的标记windowEnd
        SingleOutputStreamOperator<Tuple3<Integer, Integer, Long>> windowAgg = keyedStream
            .window(SlidingEventTimeWindows.of(Time.seconds(10), Time.seconds(5)))
            .aggregate(
           		new VcCountAgg(),
            	new WindowResult()
                );
        // 2. 按照窗口标签(窗口结束时间)keyby,保证同一个窗口时间范围的结果,到一起去。排序、取 TopN
        windowAgg.keyBy(r -> r.f2)
                .process(new TopN(2))
                .print();
        env.execute();
    }

    // 【同水位累加】
    public static class VcCountAgg implements AggregateFunction<WaterSensor, Integer, Integer>{
        @Override
        public Integer createAccumulator() {
            return 0;
        }

        @Override
        public Integer add(WaterSensor value, Integer accumulator) {
            return accumulator + 1;
        }

        @Override
        public Integer getResult(Integer accumulator) {
            return accumulator;
        }

        @Override
        public Integer merge(Integer a, Integer b) {
            return null;
        }
    }

    /**
     * 【打时间标签】
     * 泛型如下:
     * 第一个:输入类型 = 增量函数的输出 count 值,Integer
     * 第二个:输出类型 = Tuple3(vc,count,windowEnd) ,带上窗口结束时间的标签
     * 第三个:key 类型 , vc,Integer
     * 第四个:窗口类型
     */
    public static class WindowResult extends ProcessWindowFunction<Integer, Tuple3<Integer, Integer, Long>, Integer, TimeWindow> {
        @Override
        public void process(Integer key, Context context, Iterable<Integer> elements, Collector<Tuple3<Integer, Integer, Long>> out) throws Exception {
            // 迭代器里面只有一条数据,next 一次即可
            Integer count = elements.iterator().next();
            long windowEnd = context.window().getEnd();
            out.collect(Tuple3.of(key, count, windowEnd));
        }
    }

    public static class TopN extends KeyedProcessFunction<Long, Tuple3<Integer, Integer, Long>, String> {
        // 存不同窗口的 统计结果,key=windowEnd,value=list 数据
        private Map<Long, List<Tuple3<Integer, Integer, Long>>> dataListMap;
        // 要取的 Top 数量
        private int threshold;

        public TopN(int threshold) {
            this.threshold = threshold;
            dataListMap = new HashMap<>();
        }

        @Override
        public void processElement(Tuple3<Integer, Integer, Long> value, Context ctx, Collector<String> out) throws Exception {
            // 进入这个方法,只是一条数据,要排序,得到齐才行===》存起来,不同窗口分开存
            // 1. 存到 HashMap 中
            Long windowEnd = value.f2;
            if (dataListMap.containsKey(windowEnd)) {
                // 1.1 包含 vc,不是该 vc 的第一条,直接添加到List中
                List<Tuple3<Integer, Integer, Long>> dataList = dataListMap.get(windowEnd);
                dataList.add(value);
            } else {
                // 1.1 不包含 vc,是该 vc 的第一条,需要初始化list
                List<Tuple3<Integer, Integer, Long>> dataList = new ArrayList<>();
                dataList.add(value);
                dataListMap.put(windowEnd, dataList);
            }
            // 2. 注册一个定时器, windowEnd+1ms 即可 延迟1ms 触发即可,及时性
            ctx.timerService().registerEventTimeTimer(windowEnd + 1);
        }

        @Override
        public void onTimer(long timestamp, OnTimerContext ctx, Collector<String> out) throws Exception {
            super.onTimer(timestamp, ctx, out);
            // 定时器触发,同一个窗口范围的计算结果攒齐了,开始排序、取TopN
            Long windowEnd = ctx.getCurrentKey();
            // 1. 排序
            List<Tuple3<Integer, Integer, Long>> dataList = dataListMap.get(windowEnd);
            dataList.sort(new Comparator<Tuple3<Integer, Integer, Long>>() {
                @Override
                public int compare(Tuple3<Integer, Integer, Long> o1, Tuple3<Integer, Integer, Long> o2) {
                    return o2.f1 - o1.f1;
                }
            });
            // 2. 取 TopN
            StringBuilder outStr = new StringBuilder();
            outStr.append("================================\n");
            for (int i = 0; i < Math.min(threshold, dataList.size()); i++) {
                Tuple3<Integer, Integer, Long> vcCount = dataList.get(i);
                outStr.append("Top").append(i + 1).append("\n");
                outStr.append("vc=").append(vcCount.f0).append("\n");
                outStr.append("count=").append(vcCount.f1).append("\n");
                outStr.append("窗口结束时间=").append(vcCount.f2).append("\n");
                outStr.append("================================\n");
            }
            // 用完的 List,及时清理,节省资源
            dataList.clear();
            out.collect(outStr.toString());
        }
    }
}

增量聚合、开窗处理

  1. 水位线分组
  2. 增量聚合,相同水位线数量+1
  3. 窗口函数打时间标签
  4. 按上述打的时间标签分组,排序获取topN(process)

侧输出流

process函数带侧输出流

案例:对每个传感器,水位超过 10 的输出告警信息

public class SideOutputDemo {
    public static void main(String[] args) throws Exception {
        StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
        env.setParallelism(1);
        SingleOutputStreamOperator<WaterSensor> sensorDS = env.socketTextStream("124.222.253.33", 7777)
                .map(new WaterSensorMapFunction());
        OutputTag<String> warnTag = new OutputTag<>("warn", Types.STRING);

        // 传感器分组
        SingleOutputStreamOperator<WaterSensor> process = sensorDS.keyBy(WaterSensor::getId)
                .process(
                        new KeyedProcessFunction<String, WaterSensor, WaterSensor>() {
                            @Override
     public void processElement(WaterSensor value, Context ctx, Collector<WaterSensor> out) throws Exception {
         // 使用侧输出流告警
         String currentKey = ctx.getCurrentKey();

         if (value.getVc() > 10) {
             ctx.output(warnTag, "当前传感器=" + currentKey + ",当前水位=" + value.getVc() + ",大于阈值 10!!!");
         }
         // 主流正常 发送数据
         out.collect(value);
     }
   }
 );
        process.print("主流");
        process.getSideOutput(warnTag).printToErr("warn");
        env.execute();
    }
}

测流输出的同时不影响主流

image-20231113232621663

本文来自互联网用户投稿,该文观点仅代表作者本人,不代表本站立场。本站仅提供信息存储空间服务,不拥有所有权,不承担相关法律责任。如若转载,请注明出处:/a/144087.html

如若内容造成侵权/违法违规/事实不符,请联系我们进行投诉反馈qq邮箱809451989@qq.com,一经查实,立即删除!

相关文章

墓园殡仪馆服务预约小程序的作用

生老病死是人之常情&#xff0c;也是每个人需要面对的&#xff0c;墓园作为生活服务行业里特殊的细分类别&#xff0c;往往不被人提起&#xff0c;但又有很高的需求度&#xff0c;几乎可以说每天都有大小生意&#xff0c;比如殡葬用品、祭扫预约、位置服务等。 对墓园管理公司而…

新能源充电桩物联网应用之工业4G路由器

新能源充电桩是智慧城市建设中不可缺少且可持续发展的重要设施&#xff0c;而工业4G路由器物联网应用为其提供了更加高效、智能、实时的管理方式。充电桩通过工业4G路由器可以与充电运营商的管理中心建立稳定的连接&#xff0c;实现双向数据传输&#xff0c;为用户提供优质的充…

深度学习 机器视觉 车位识别车道线检测 - python opencv 计算机竞赛

0 前言 &#x1f525; 优质竞赛项目系列&#xff0c;今天要分享的是 &#x1f6a9; 深度学习 机器视觉 车位识别车道线检测 该项目较为新颖&#xff0c;适合作为竞赛课题方向&#xff0c;学长非常推荐&#xff01; &#x1f947;学长这里给一个题目综合评分(每项满分5分) …

在线预览编辑PDF::RAD PDF for ASP.NET

RAD PDF for ASP.NET作为功​​能最齐全的基于 HTML 的 PDF 查看器、编辑器和 ASP.NET 表单填充器&#xff0c;RAD PDF 为传统 PDF 解决方案提供了灵活而强大的替代方案。与 Adob​​e Acrobat Reader 不同&#xff0c;RAD PDF 几乎可以在任何现代网络浏览器中运行&#xff0c;…

macOS 13.6 及后续系统安装 Asahi Linux 将破坏引导

导读Asahi Linux 是一个致力于为 Apple Silicon 设备带来 Linux 支持的项目&#xff0c;日前有用户反馈称&#xff0c;若在相关设备上安装了 macOS 13.6-14&#xff0c;再安装 Asahi Linux &#xff0c;就会导致系统引导失败&#xff0c;出现“黑屏”情况。 目前 Asahi Linux 项…

第六章(微分方程)

简介 函数是客观事物的内部联系在数量方面的反映&#xff0c;利用两数关系又可以对客观事物的规律性进行研究.因此如何寻求函数关系&#xff0c;在实践中具有重要意义•在许多问题中&#xff0c;往往不能直接找出所需要的函数关系&#xff0c;但是根据问题所提供的情况&#xf…

基于SPI+DMA方式的ws2812b氛围灯控制

好处&#xff1a;相比于gpio控制&#xff0c;可以大大节省CPU的时间&#xff0c;CPU只要将要传输的数据计算好放入内存中&#xff0c;然后发动DMA传输即可&#xff0c;后续整个过程并不需要CPU干预&#xff0c;CPU可以用于做其他的事情。特别是某些带蓝牙的芯片&#xff0c;需要…

P6入门:项目初始化9-项目详情之资源Resource

前言 使用项目详细信息查看和编辑有关所选项目的详细信息&#xff0c;在项目创建完成后&#xff0c;初始化项目是一项非常重要的工作&#xff0c;涉及需要设置的内容包括项目名&#xff0c;ID,责任人&#xff0c;日历&#xff0c;预算&#xff0c;资金&#xff0c;分类码等等&…

基于51单片机PCF8591数字电压表LCD1602液晶显示设计( proteus仿真+程序+设计报告+讲解视频)

基于 51单片机PCF8591数字电压表LCD1602液晶设计 ( proteus仿真程序设计报告讲解视频&#xff09; 仿真图proteus7.8及以上 程序编译器&#xff1a;keil 4/keil 5 编程语言&#xff1a;C语言 设计编号&#xff1a;S0060 51单片机PCF8591数字电压表LCD1602液晶设计 1.主要功…

C# +.Net检验科信息管理系统源码 LIS系统源码

检验科信息管理系统&#xff08;LIS&#xff09; LIS系统集申请、采样、核收、计费、检验、审核、发布、质控、查询、耗材控制等检验科工作为一体的网络管理系统。它的开发和应用将加快检验科管理的统一化、网络化、标准化的进程。 主要包括以下功能&#xff1a; 1、数据采集…

分享一下微信签到领取积分的小程序怎么做

在当前的数字化时代&#xff0c;微信作为中国最流行的社交平台&#xff0c;其影响力已经渗透到生活的各个角落。除了基础的聊天功能&#xff0c;微信还提供了许多实用的附加功能&#xff0c;其中就包括微信签到领取积分这一独特的小程序。本文将探讨微信签到领取积分小程序的魅…

C++代码实现调用OpenAi接口Api

在网上找了一圈C如何调用OpenAi的接口&#xff0c;找到的例子比较简单&#xff0c;完全照搬下来修改一下也能用&#xff0c;不过i整合在自己的类里面就莫名奇妙的问题&#xff1a; 1. 比如 coredump url_easy_perform的执行和curl_easy_setopt放在了两个函数中就出问题了&…

简单实现接口自动化测试(基于python+unittest)

简介 本文通过从Postman获取基本的接口测试Code简单的接口测试入手&#xff0c;一步步调整优化接口调用&#xff0c;以及增加基本的结果判断&#xff0c;讲解Python自带的Unittest框架调用&#xff0c;期望各位可以通过本文对接口自动化测试有一个大致的了解。 引言 为什么要做…

设置虚拟机静态IP

1、修改配置文件 /etc/sysconfig/network-scripts/ifcfg-ens160 将BOOTPROTOdhcp改为static&#xff0c;天机IPADDR192.168.10.13 2、重启网络服务 systemctl restart network

亚马逊云科技携手普华永道,在跨境数据传输方面打造适合中企的安全合规方案

第六届中国国际进口博览会于昨日圆满落下帷幕。11月9日下午&#xff0c;在普华永道解码数字产品与解决方案之道专场中&#xff0c;亚马逊云科技安全合规服务总监白帆先生和普华永道中国网络安全及隐私保护合伙人黄思维先生带来了基于跨境数据传输的合规性讨论&#xff0c;并正式…

技术管理责任制度《二》

技术管理责任制度《二》 彩虹图纸管理软件_图纸管理系统_图纸文档管理软件系统_彩虹EDM【官网】 1、技术档案&#xff0c;指本企业进行生产经营活动所用的一切重要图片、图纸、光碟、图书、报表、技术资料、有关设备、技术的文字说明等技术文件&#xff0c;整理后归并文件档案…

求推荐哪个好用的ERP或CRM软件?有ERP、CRM一体化的软件吗?

推荐好用的ERP或CRM软件&#xff1f;那么&#xff0c;有软件能够实现ERP、CRM一体化吗&#xff1f; 当然有&#xff0c;我们公司就在使用这样一个一体化平台。 只要你能够准确地理解业务逻辑&#xff0c;即使没有编程经验和代码基础&#xff0c;也能够利用简道云轻松创建各种…

动静态库。

gcc去 1、默认路径/usr/include里面去找 2、当前目录去找 但是mymath.h根本不在这里面&#xff0c;所以就报错了 你可以在.c中 #include “./lib/include/” 指明头文件在哪里&#xff0c;但是不推荐 &#xff0c;建议在gcc时处理

使用 PYTORCH 进行图像风格迁移

一、介绍 本教程介绍如何实现 由 Leon A. Gatys、Alexander S. Ecker 和 Matthias Bethge 开发的神经风格算法。神经风格或神经传输允许您拍摄图像并以新的艺术风格再现它。该算法采用三幅图像&#xff0c;即输入图像、内容图像和风格图像&#xff0c;并将输入更改为类似于内容…

python使用redis模块来跟redis实现交互

大家早好、午好、晚好吖 ❤ ~欢迎光临本文章 如果有什么疑惑/资料需要的可以点击文章末尾名片领取源码 redis模块的使用&#xff1a; 1.安装模块: pip3 install redis 2.导入模块&#xff1a;import redis 3.连接方式&#xff1a; 严格连接模式&#xff1a;rredis.StrictR…