Flink Table API 与 SQL 编程整理

Flink API总共分为4层这里主要整理Table API的使用

Table API是流处理和批处理通用的关系型APITable API可以基于流输入或者批输入来运行而不需要进行任何修改。Table APISQL语言的超集并专门为Apache Flink设计的,Table APIScalaJava语言集成式的API。与常规SQL语言中将查询指定为字符串不同,Table API查询是以JavaScala中的语言嵌入样式来定义的,具有IDE支持如:自动完成和语法检测。需要引入的pom依赖如下:

<dependency><groupId>org.apache.flink</groupId><artifactId>flink-table_2.12</artifactId><version>1.7.2</version>
</dependency>

Table API & SQL

TableAPI: WordCount案例

tab.groupBy("word").select("word,count(1) as count")

SQL: WordCount案例

SELECT word,COUNT(*) AS cnt FROM MyTable GROUP BY word

【1】声明式: 用户只关系做什么,不用关心怎么做;
【2】高性能: 支持查询优化,可以获取更好的执行性能,因为它的底层有一个优化器,跟SQL底层有优化器是一样的。
【3】流批统一: 相同的统计逻辑,即可以流模型运行,也可以批模式运行;
【4】标准稳定: 语义遵循SQL标准,不易改动。当升级等底层修改,不用考虑API兼容问题;
【5】易理解: 语义明确,所见即所得;

Table API 特点

Table API使得多声明的数据处理写起来比较容易。

1 #例如,我们将a<10的数据过滤插入到xxx表中
2 table.filter(a<10).insertInto("xxx")
3 #我们将a>10的数据过滤插入到yyy表中
4 table.filter(a>10).insertInto("yyy")

TalbeFlink自身的一种API使得更容易扩展标准的SQL(当且仅当需要的时候),两者的关系如下:
在这里插入图片描述

Table API 编程

WordCount编程示例

package org.apache.flink.table.api.example.stream;import org.apache.flink.api.common.typeinfo.Types;
import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
import org.apache.flink.table.api.Table;
import org.apache.flink.table.api.TableEnvironment;
import org.apache.flink.table.api.java.StreamTableEnvironment;
import org.apache.flink.table.descriptors.FileSystem;
import org.apache.flink.table.descriptors.OldCsv;
import org.apache.flink.table.descriptors.Schema;
import org.apache.flink.types.Row;public class JavaStreamWordCount {public static void main(String[] args) throws Exception {//获取执行环境:CTRL + ALT + VStreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();StreamTableEnvironment tEnv = TableEnvironment.getTableEnvironment(env);//指定一个路径String path = JavaStreamWordCount.class.getClassLoader().getResource("words.txt").getPath();//指定文件格式和分隔符,对应的Schema(架构)这里只有一列,类型是StringtEnv.connect(new FileSystem().path(path)).withFormat(new OldCsv().field("word", Types.STRING).lineDelimiter("\n")).withSchema(new Schema().field("word", Types.STRING)).inAppendMode().registerTableSource("fileSource");//将source注册到env中//通过 scan 拿到table,然后执行table的操作。Table result = tEnv.scan("fileSource").groupBy("word").select("word, count(1) as count");//将table输出tEnv.toRetractStream(result, Row.class).print();//执行env.execute();}
}

怎么定义一个 Table

Table myTable = tableEnvironment.scan("myTable") 都是从Environmentscan出来的。而这个myTable 又是我们注册进去的。问题就是有哪些方式可以注册Table
【1】Table descriptor: 类似于上述的WordCount,指定一个文件系统fs,也可以是kafka等,还需要一些格式和Schema等。

tEnv.connect(new FileSystem().path(path)).withFormat(new OldCsv().field("word", Types.STRING).lineDelimiter("\n")).withSchema(new Schema().field("word", Types.STRING)).inAppendMode().registerTableSource("fileSource");//将source注册到env中

【2】自定义一个 Table source: 然后把自己的Table source注册进去。

TableSource csvSource = new CsvTableSource(path,new String[]{"word"},new TypeInformation[]{Types.STRING});
tEnv.registerTableSource("sourceTable2", csvSource);

【3】注册一个 DataStream: 例如下面一个String类型的DataStream,命名为myTable3对应的schema只有一列叫word

DataStream<String> stream = ...
// register the DataStream as table " myTable3" with 
// fields "word"
tableEnv.registerDataStream("myTable3", stream, "word");

动态表

如果流中的数据类型是case class可以直接根据case class的结构生成table

tableEnv.fromDataStream(ecommerceLogDstream)

或者根据字段顺序单独命名:用单引放到字段前面来标识字段名。

tableEnv.fromDataStream(ecommerceLogDstream,'mid,'uid ......)

最后的动态表可以转换为流进行输出,如果不是简单的插入就使用toRetractStream

table.toAppendStream[(String,String)]

如何输出一个table

当我们获取到一个结构表的时候(table类型)执行insertInto目标表中:resultTable.insertInto("TargetTable");

【1】Table descriptor: 类似于注入,最终使用Sink进行输出,例如如下输出到targetTable中,主要是最后一段的区别。

tEnv
.connect(new FileSystem().path(path)).withFormat(new OldCsv().field("word", Types.STRING)
.lineDelimiter("\n")).withSchema(new Schema()
.field("word", Types.STRING))
.registerTableSink("targetTable");

【2】自定义一个 Table sink: 输出到自己的 sinkTable2注册进去。

TableSink csvSink = new CsvTableSink(path,new String[]{"word"},new TypeInformation[]{Types.STRING});
tEnv.registerTableSink("sinkTable2", csvSink);

【3】输出一个 DataStream: 例如下面产生一个RetractStream,对应要给Tuple2的联系。Boolean这行记录时add还是delete。如果使用了groupbytable 转化为流的时候只能使用toRetractStream。得到的第一个boolean型字段标识 true就是最新的数据(Insert),false表示过期老数据(Delete)。如果使用的api包括时间窗口,那么窗口的字段必须出现在groupBy中。

// emit the result table to a DataStream
DataStream<Tuple2<Boolean, Row>> stream = tableEnv.toRetractStream(resultTable, Row.class)
stream.filter(_._1).print()

案例代码:

package com.zzx.flinkimport java.util.Propertiesimport com.alibaba.fastjson.JSON
import org.apache.flink.api.common.serialization.SimpleStringSchema
import org.apache.flink.streaming.api.TimeCharacteristic
import org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
import org.apache.flink.streaming.api.scala._
import org.apache.flink.streaming.api.windowing.time.Time
import org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer011
import org.apache.flink.table.api.java.Tumble
import org.apache.flink.table.api.{StreamTableEnvironment, Table, TableEnvironment}object FlinkTableAndSql {def main(args: Array[String]): Unit = {//执行环境val env: StreamExecutionEnvironment = StreamExecutionEnvironment.getExecutionEnvironment//设置 时间特定为 EventTimeenv.setStreamTimeCharacteristic(TimeCharacteristic.EventTime)//读取数据  MyKafkaConsumer 为自定义的 kafka 工具类,并传入 topicval dstream: DataStream[String] = env.addSource(MyKafkaConsumer.getConsumer("FLINKTABLE&SQL"))//将字符串转换为对象val ecommerceLogDstream:DataStream[SensorReding] = dstream.map{/* 引入如下依赖<dependency><groupId>com.alibaba</groupId><artifactId>fastjson</artifactId><version>1.2.36</version></dependency>*///将 String 转换为 SensorRedingjsonString => JSON.parseObject(jsonString,classOf[SensorReding])}//告知 watermark 和 evetTime如何提取val ecommerceLogWithEventTimeDStream: DataStream[SensorReding] =ecommerceLogDstream.assignTimestampsAndWatermarks(new BoundedOutOfOrdernessTimestampExtractor[SensorReding](Time.seconds(0)) {override def extractTimestamp(t: SensorReding): Long = {t.timestamp}})//设置并行度ecommerceLogDstream.setParallelism(1)//创建 Table 执行环境val tableEnv: StreamTableEnvironment = TableEnvironment.getTableEnvironment(env)var ecommerceTable: Table = tableEnv.fromTableSource(ecommerceLogWithEventTimeDStream ,'mid,'uid,'ch,'ts.rowtime)//通过 table api进行操作//每10秒统计一次各个渠道的个数 table api解决//groupby window=滚动式窗口 用 eventtime 来确定开窗时间val resultTalbe: Table = ecommerceTable.window(Tumble over 10000.millis on 'ts as 'tt).groupBy('ch,'tt).select('ch,'ch.count)var ecommerceTalbe: String = "xxx"//通过 SQL 执行val resultSQLTable: Table = tableEnv.sqlQuery("select ch,count(ch) from "+ ecommerceTalbe +"group by ch,Tumble(ts,interval '10' SECOND")//把 Table 转化成流输出//val appstoreDStream: DataStream[(String,String,Long)] = appstoreTable.toAppendStream[(String,String,Long)]val resultDStream: DataStream[(Boolean,(String,Long))] = resultSQLTable.toRetractStream[(String,Long)]//过滤resultDStream.filter(_._1)env.execute()}
}
object MyKafkaConsumer {def getConsumer(sourceTopic: String): FlinkKafkaConsumer011[String] ={val bootstrapServers = "hadoop1:9092"// kafkaConsumer 需要的配置参数val props = new Properties// 定义kakfa 服务的地址,不需要将所有broker指定上props.put("bootstrap.servers", bootstrapServers)// 制定consumer groupprops.put("group.id", "test")// 是否自动确认offsetprops.put("enable.auto.commit", "true")// 自动确认offset的时间间隔props.put("auto.commit.interval.ms", "1000")// key的序列化类props.put("key.deserializer", "org.apache.kafka.common.serialization.StringDeserializer")// value的序列化类props.put("value.deserializer", "org.apache.kafka.common.serialization.StringDeserializer")//从kafka读取数据,需要实现 SourceFunction 他给我们提供了一个val consumer = new FlinkKafkaConsumer011[String](sourceTopic, new SimpleStringSchema, props)consumer}
}

关于时间窗口

【1】用到时间窗口,必须提前声明时间字段,如果是processTime直接在创建动态表时进行追加就可以。如下的ps.proctime

val ecommerceLogTable: Table = tableEnv.fromDataStream( ecommerceLogWithEtDstream,`mid,`uid,`appid,`area,`os,`ps.proctime )

【2】如果是EventTime要在创建动态表时声明。如下的ts.rowtime

val ecommerceLogTable: Table = tableEnv.fromDataStream( ecommerceLogWithEtDstream,'mid,'uid,'appid,'area,'os,'ts.rowtime)

【3】滚动窗口可以使用Tumble over 10000.millis on来表示

val table: Table = ecommerceLogTable.filter("ch = 'appstore'").window(Tumble over 10000.millis on 'ts as 'tt).groupBy('ch,'tt).select("ch,ch.count")

如何查询一个 table

为了会有GroupedTable等,为了增加限制,写出正确的API
在这里插入图片描述

Table API 操作分类

1、与sql对齐的操作,selectasfilter等;
2、提升Table API易用性的操作;
——Columns Operation易用性: 假设有一张100列的表,我们需要去掉一列,需要怎么操作?第三个API可以帮你完成。我们先获取表中的所有Column,然后通过dropColumn去掉不需要的列即可。主要是一个Table上的算子。

OperatorsExamples
AddColumnsTable orders = tableEnv.scan(“Orders”); Table result = orders.addColumns(“concat(c,‘sunny’)as desc”); 添加新的列,要求是列名不能重复。
addOrReplaceColumnsTable orders = tableEnv.scan(“Orders”); Table result = order.addOrReplaceColumns(“concat(c,‘sunny’) as desc”);添加列,如果存在则覆盖
DropColumnsTable orders = tableEnv.scan(“Orders”); Table result = orders.dropColumns(“b c”);
RenameColumnsTable orders = tableEnv.scan(“Orders”); Table result = orders.RenameColumns("b as b2,c as c2);列重命名

——Columns Function易用性: 假设有一张表,我么需要获取第20-80列,该如何获取。类似一个函数,可以用在列选择的任何地方,例如:Table.select(withColumns(a,1 to 10))GroupBy等等。

语法描述
withColumns(…)选择你指定的列
withoutColumns(…)反选你指定的列

在这里插入图片描述
列的操作语法(建议): 如下,它们都是上层包含下层的关系。

columnOperation:withColumns(columnExprs) / withoutColumns(columnExprs) #可以接收多个参数 columnExpr
columnExprs:columnExpr [, columnExpr]*  #可以分为如下三种情况
columnExpr:columnRef | columnIndex to columnIndex | columnName to columnName #1 cloumn引用  2下标范围操作  3名字的范围操作
columnRef:columnName(The field name that exists in the table) | columnIndex(a positive integer starting at 1)Example: withColumns(a, b, 2 to 10, w to z)

Row based operation/Map operation易用性:

//方法签名: 接收一个 scalarFunction 参数,返回一个 Table
def map(scalarFunction: Expression): Tableclass MyMap extends ScalarFunction {var param : String = ""//eval 方法接收一些输入def eval([user defined inputs]): Row = {val result = new Row(3)// Business processing based on data and parameters// 根据数据和参数进行业务处理,返回最终结果result}//指定结果对应的类型,例如这里 Row的类型,Row有三列override def getResultType(signature: Array[Class[_]]):TypeInformation[_] = {Types.ROW(Types.STRING, Types.INT, Types.LONG)}
}//使用 fun('e) 得到一个 Row 并定义名称 abc 然后获取 ac列
val res = tab
.map(fun('e)).as('a, 'b, 'c)
.select('a, 'c)//好处:当你的列很多的时候,并且每一类都需要返回一个结果的时候
table.select(udf1(), udf2(), udf3().)
VS
table.map(udf())

Map是输入一条输出一条
在这里插入图片描述
FlatMap operation易用性:

//方法签名:出入一个tableFunction
def flatMap(tableFunction: Expression): Table
#tableFunction 实现的列子,返回一个 User类型,是一个 POJOs类型,Flink能够自动识别类型。
case class User(name: String, age: Int)
class MyFlatMap extends TableFunction[User] {def eval([user defined inputs]): Unit = {for(..){collect(User(name, age))}}
}//使用
val res = tab
.flatMap(fun('e,'f)).as('name, 'age)
.select('name, 'age)
Benefit//好处
table.joinLateral(udtf) VS table.flatMap(udtf())

FlatMap是输入一行输出多行
在这里插入图片描述
FlatAggregate operation功能性:

#方法签名:输入 tableAggregateFunction 与 AggregateFunction 很相似
def flatAggregate(tableAggregateFunction: Expression): FlatAggregateTable
class FlatAggregateTable(table: Table, groupKey: Seq[Expression], tableAggFun: Expression)
class TopNAcc {var data: MapView[JInt, JLong] = _ // (rank -> value)...}class TopN(n: Int) extends TableAggregateFunction[(Int, Long), TopNAccum] {def accumulate(acc: TopNAcc, [user defined inputs]) {...}#可以那多 column,进行多个输出def emitValue(acc: TopNAcc, out: Collector[(Int, Long)]): Unit = {...}...retract/merge
}#用法
val res = tab
.groupBy(‘a)
.flatAggregate(
flatAggFunc(‘e,’f) as (‘a, ‘b, ‘c))
.select(‘a, ‘c)#好处
新增了一种agg,输出多行

FlatAggregate operation输入多行输出多行
在这里插入图片描述
AggregateFlatAggregate的区别: 使用MaxTop2的场景比较AggregateFlatAggregate之间的差别。如下有一张输入表,表有三列(IDNAMEPRICE),然后对Price求最大指和Top2
Max操作是蓝线,首先创建累加器,然后在累加器上accumulate操作,例如6过去是6,3过去没有6大还是6等等。得到最终得到8的结果。
TOP2操作时红线,首先创建累加器,然后在累加器上accumulate操作,例如6过去是6,3过去因为是两个元素所以3也保存,当5过来时,和最小的比较,3就被淘汰了等等。得到最终得到8和6的结果。
在这里插入图片描述
总结:
在这里插入图片描述

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

如若内容造成侵权/违法违规/事实不符,请联系编程知识网进行投诉反馈email:809451989@qq.com,一经查实,立即删除!

相关文章

【轻量化篇】YOLOv8改进实战 | 更换主干网络 Backbone 之 RepGhostnet,重参数化实现硬件高效的Ghost模块

YOLOv8专栏导航:点击此处跳转 前言 轻量化网络设计是一种针对移动设备等资源受限环境的深度学习模型设计方法。下面是一些常见的轻量化网络设计方法: 网络剪枝:移除神经网络中冗余的连接和参数,以达到模型压缩和加速的目的。分组卷积:将卷积操作分解为若干个较小的卷积操…

论文解读:On the Integration of Self-Attention and Convolution

自注意力机制与卷积结合&#xff1a;On the Integration of Self-Attention and Convolution(CVPR2022) 引言 1&#xff1a;卷积可以接受比较大的图片的&#xff0c;但自注意力机制如果图片特别大的话&#xff0c;运算规模会特别大&#xff0c;即上图中右边(卷积)会算得比较快…

如何免费搭建私人电影网站(三)

接上一篇文章&#xff1a; 网站模版上传到空间后就进行安装网站了操作如下图&#xff1a; 打开链接地址&#xff1a; 输入前面设置好的FTP密码 进入安装界面 点同意后下一步 需要填入数据库的账号和密码 返回虚拟主机界面进行设置 如下图点初始化 修改数据库的密码 然后…

Guava限流神器:RateLimiter使用指南

1. 引言 可能有些小伙伴听到“限流”这个词就觉得头大&#xff0c;感觉像是一个既复杂又枯燥的话题。别急&#xff0c;小黑今天就要用轻松易懂的方式&#xff0c;带咱们一探RateLimiter的究竟。 想象一下&#xff0c;当你去超市排队结账时&#xff0c;如果收银台开得越多&…

java反射的实战教程(简单且高效)

1. 参考 建议按顺序阅读以下文章 学了这么久的java反射机制&#xff0c;你知道class.forName和classloader的区别吗&#xff1f; Java反射&#xff08;超详细&#xff01;&#xff09; 2. 实战 2.1 通过Class.forName()方法获取字节码 这个方法会去我们的操作系统寻找这个cl…

MyBatis-Plus如何 关闭SQL日志打印

前段时间公司的同事都过来问我&#xff0c;hua哥公司的项目出问题了&#xff0c;关闭不了打印sql日记&#xff0c;项目用宝塔自己部署的&#xff0c;磁盘满了才发现大量的打印sql日记&#xff0c;他们百度过都按照网上的配置修改过不起作用&#xff0c;而且在调试时候也及为不方…

Linux:锁定文件chattr

chattr 锁定 使用该命令进行文件的锁定以提高安全性 chattr i /etc/passwd /etc/shadow chattr i 目标文件 这样这两个文件就不能被修改了&#xff0c;包括root也不能去修改&#xff0c;但是root可以解锁后再去修改 解锁 chattr -i /etc/passwd /etc/shadow chattr -i 目标…

Ubuntu-20.04.2 mate 上安装、配置、测试 qtcreator

一、从repo中安装 Ubuntu-20.04.2的repo中&#xff0c;qtcreator安装包挺全乎的&#xff0c;敲完 sudo apt install qtcreator 看一下同时安装和新软件包将被安装列表&#xff0c;压缩包252MB&#xff0c;解压安装后933MB&#xff0c;集大成的一包。 sudo apt install qtcrea…

卸载MySQL——Windows

1. 停止MySQL服务 winR 打开运行&#xff0c;输入 services.msc 点击 “确定” 调出系统服务。 我这里只有一个&#xff0c;只要是以MySQL开头的全部停止 2. 卸载MySQL相关组件 打开控制面板 —> 卸载程序 —> 卸载MySQL相关所有组件 3. 删除MySQL安装目录 一般是C:\P…

【Ehcache技术专题】「入门到精通」带你一起从零基础进行分析和开发Ehcache框架的实战指南(5-检索开发)

系列文章目录 本系列课程主要针对于Ehcache缓存框架功能的开发实践全流程技术指南&#xff01; 第一节&#xff1a;Ehcache缓存框架的基本概念和简介第二节&#xff1a;Ehcache缓存框架的配置分析和说明第三节&#xff1a;Ehcache缓存框架的缓存方式的探索第四节&#xff1a;E…

Linux:终端定时自动注销

这样防止了&#xff0c;当我们临时离开电脑这个空隙&#xff0c;被坏蛋给趁虚而入 定几十秒或者分钟&#xff0c;如果这个时间段没有输入东西那么就会自动退出 全局生效 这个系统中的所有用户生效 vim /etc/profile在末尾加入TMOUT10 TMOUT10 这个就是10 秒&#xff0c;按…

兼顾陪读|社科老师自费赴英国伦敦大学城市学院访学3年

T老师的孩子即将升入高中&#xff0c;其将访学目标定位在说英语的发达国家&#xff0c;要求当地公立教育资源相对丰富&#xff0c;且尽量延长访学时间&#xff0c;从而达到最优的陪读目标。最终我们获得了英国伦敦大学城市学院的3年访学邀请函&#xff0c;导师为社科院士&#…