大数据抽取清洗及合并

任务二 大数据抽取和清洗

陶运道  QQ:275931339

  • 数据清洗

数据清洗是指对数据进行重新审查和校验,在这一过程中,发现并纠正数据文件中可识别错误,按照一定规则把错误或冲突数据洗掉,包括检查数据一致性,处理无效值和缺失值等。

二、清洗要求

编写Scala代码,使用Spark将ods库中相应表数据全量抽取到Hive的dwd库中对应表中。表中有涉及到timestamp类型的,均要求按照yyyy-MM-dd HH:mm:ss,不记录毫秒数,若原数据中只有年月日,则在时分秒的位置添加00:00:00,添加之后使其符合yyyy-MM-dd HH:mm:ss。(若dwd库中部分表没有数据,正常抽取即可)

    抽取ods库中customer_inf表中昨天分区数据,并结合dwd.customer_inf最新分区现有的数据, 根据customer_id合并数据到dwd库中dwd.customer_inf的分区表(合并是指对dwd层数据进行插入或修改,需修改的数据以customer_id为合并字段,根据modified_time排序取最新的一条),分区字段为etl_date且值与ods库的相对应表该值相等,添加dwd_insert_user、dwd_insert_time、dwd_modify_user、dwd_modify_time四列,其中dwd_insert_user、dwd_modify_user均填写“user1”。若该条记录第一次进入数仓dwd层则dwd_insert_time、dwd_modify_time均存当前操作时间,并进行数据类型转换。若该数据在进入dwd层时发生了合并修改,则dwd_insert_time时间不变,dwd_modify_time存当前操作时间,其余列存最新的值。 使用hive cli执行show partitions dwd.dim_user_info命令。

三、解题思路

本题目实现从ods.customer_info抽取一个分区数据与dwd.customer_inf最新分区的数据根据id进行合并,取出modified_time字段最大的一条数据,分区字段依旧是etldate,并对dwd_insert_user、dwd_insert_time、dwd_modify_user、dwd_modify_time这四个字段填充,本题难点在合并数据上。

实验表介绍

Mysql表结构如下:

 

各表部分数据如下,以理解为什么抽取要全量抽取和增量抽取

Ods_customer_inf数据   全量抽取了昨天以前及昨天的数据

customer_id  customer_name  etl_date

19988 陈玲  20221230

19989 程琴  20221230

19990 庞帅  20221230

19991 曾凤兰     20221230

昨天昨天以前数据

19992 陈涛  20221230

19993 朱斌  20221230

19994 范萍  20221230

19995 姜洋  20221230

19996 黄婷  20221230

19997 解娜  20221230

19998 赵丹丹     20221230

昨天数据

19999 AAA  20231230

20000 BBB  20231230

20001 CCC  20231230

20002 ddd 20231230

从图中可以看出 此表多了三条记录,这三条记录就是昨天新增的记录

注意:此表有两个分区

dwd.customer_inf

19988 陈玲  20231230

19989 程琴  20231230

19990 庞帅  20231230

19991 曾凤兰     20231230

19992 陈涛  20231230

19993 朱斌  20231230

19994 范萍  20231230

19995 姜洋  20231230

19996 黄婷  20231230

19997 解娜  20231230

19998 赵丹丹     20231230

19999 AAA  20231230

20000 BBB  20231230

20001 CCC  20231230

该表有两个分区

一、抽取数据(将mysql表customer_inf数据抽取到hive中ods.customer_inf)

1.创建hive表

 创建ods.customer_inf表  用于抽取mysql数据

 注意创建ods.customer_inf表字段类型与mysql表customer_inf字段类型对应

hive> CREATE TABLE `ods.customer_inf` (

  `customer_inf_id` int ,

  `customer_id` int ,

  `customer_name` string,

  `identity_card_type` tinyint,

  `identity_card_no` string,

  `mobile_phone` string,

  `customer_email` string,

  `gender` string,

  `customer_point` int,

  `register_time` timestamp ,

  `birthday` string ,

  `customer_level` tinyint,

  `customer_money` double,

  `modified_time` timestamp)

 PARTITIONED BY (etl_date STRING) row format delimited fields terminated by ','

  2.按要求全量、增量抽取到ods库中

全量将mysql中customer_inf抽取数据至ods.customer_inf,就是抽取昨天以前数据,本例抽取条件是where modified_time<to_timestamp('2023-1-1')

增量抽取:where modified_time>to_timestamp('2023-1-1')

注意:检查ods.customer_inf表是否有分区,如有则删除分区,否则出现无预期数据

  show show partitions  ods.customer_inf  //显示分区

ALTER TABLE ods_customer_inf  DROP PARTITION (etl_date='2022-01-01') //删除分区

  truncated table ods.customer_inf  //删除表

代码如下:创建环境,连接hive、 mysql

 import org.apache.spark.sql.{SaveMode, SparkSession}

import org.apache.spark.sql.functions.{col, current_timestamp, desc,from_unixtime, lit, row_number, to_timestamp, unix_timestamp}

import org.apache.spark.sql.expressions.Window

object scala_1 {

      def main(argc:Array[String])={

        val spark = SparkSession.builder()

          .master("spark://master:7077")

          .appName("抽取数据")

          .enableHiveSupport()

          .config("spark.sql.warehouse.dir", "hdfs://master:50070/usr/hive/warehouse")

          .config("hive.metastore.uris", "thrift://master:9083")

.config("spark.sql.parquet.writeLegacyFormat", true)
.config("spark.sql.sources.partitionOverwriteMode", "dynamic") //
分区重写

          .getOrCreate()

        spark.read

          .format("jdbc")

          .option("driver", "com.mysql.cj.jdbc.Driver")

          .option("url", "jdbc:mysql://master:3306/ds_db01?serverTimezone=GMT")

          .option("user", "root")

          .option("password", "123456")

          .option("dbtable", "customer_inf")

          .load()

          .createTempView("data")

      //  spark.sql("select * from data").show()

        println("---------------连接hive mysql数据库--------------------")

         //全量抽取 ,抽取昨天以前数据

        spark.sql(

          """

            |insert overwrite table ods.customer_inf partition (etl_date='2022-08-01')

            |select *

            |from data  where modified_time<to_timestamp('2023-1-1');

            |""".stripMargin)

        println("------------抽取数据(全量、增量)显示---------------------------------")

        spark.sql("select * from ods.customer_inf").show()

 // 增量抽取   抽取昨天数据

     spark.sql(

        """

        |insert into table ods.customer_inf partition (etl_date='2023-08-01')

        |select *

        |from data  where modified_time>to_timestamp('2023-1-1');

        |""".stripMargin)

       spark.sql("select * from ods.customer_inf").show()

spark.stop()



}}     

查看抽取结果

hive>select customer_id,customer_name,etl_date from ods.customer_inf

 hive>show partitions ods.customer1_inf

  • 清洗

清洗要做的工作

(1)将ods库全部数据抽取到hive的dwd库中

(2)增加四个字段添加dwd_insert_user、dwd_insert_time、dwd_modify_user、dwd_modify_time四列,其中dwd_insert_user、dwd_modify_user均填写“user1”。若该条记录第一次进入数仓dwd层则dwd_insert_time、dwd_modify_time均存当前操作时间

(3)表中涉及到的timestamp类型或者缺少时分秒字段,需要进行时间格式化,转换为 yyyy-MM-dd HH:mm:ss格式

 注意:dwd.customer_inf不必创建。

val spark = SparkSession.builder()
  .master(
"spark://master:7077")
  .appName(
"清洗数据")
  .enableHiveSupport()
  .config(
"spark.sql.warehouse.dir", "hdfs://master:50070/usr/hive/warehouse")
  .config(
"hive.metastore.uris", "thrift://master:9083")
  .getOrCreate()

//清洗代码 并存入dwd.customer_inf
spark.read.table("ods.customer_inf")
  .withColumn(
"dwd_insert_user", lit("user1"))
  .withColumn(
"dwd_insert_time", to_timestamp(from_unixtime(unix_timestamp(), "yyyy-MM-dd HH:mm:ss")))
  .withColumn(
"dwd_modify_user", lit("user1"))
  .withColumn(
"dwd_modify_time", to_timestamp(from_unixtime(unix_timestamp(), "yyyy-MM-dd HH:mm:ss")))
  .withColumn(
"birthday", to_timestamp(from_unixtime(unix_timestamp(col("birthday"), "yyyy-MM-dd HH:mm:ss"))))
  .write
  .mode(SaveMode.
Overwrite)
  .partitionBy(
"etl_date")
  .saveAsTable(
"dwd.customer_inf")
spark.stop()

 查看清洗数据

Hive> select customer_id,customer_name,etl_date from dwd.customer_inf

Hive>show partitions dwd.customer_inf

  • 合并dwd.customer_inf中生成最新数据

合并数据是指将ods.customer_inf增量分区数据与dwd.customer_inf最新分区合并。在合并使用了中间表dwd.customer_inf,用于存放ods.customer_inf增量分区清洗后数据,此表不必另建,然后将dwd.customer_inf与dwd.customer1_inf合并。

// 合并  1.读入ods.customer_inf最新分区数据 存放表dwd.custoer_inf
spark.read.table("ods.customer_inf").where(col("etl_date") === "2023-08-01") //读取ods的昨天分区数据
 
.withColumn("dwd_insert_user", lit("user1"))
  .withColumn(
"dwd_insert_time", to_timestamp(from_unixtime(unix_timestamp(), "yyyy-MM-dd HH:mm:ss")))
  .withColumn(
"dwd_modify_user", lit("user1"))
  .withColumn(
"dwd_modify_time", to_timestamp(from_unixtime(unix_timestamp(), "yyyy-MM-dd HH:mm:ss")))
  .withColumn(
"birthday", to_timestamp(from_unixtime(unix_timestamp(col("birthday"), "yyyy-MM-dd HH:mm:ss"))))
 
//如不写入表,直接作为ods_user_info,字段etl_date则为当时的日期时间
 
.write
 .mode(SaveMode.
Overwrite)
 .partitionBy(
"etl_date")
 .saveAsTable(
"dwd.customer1_inf")

 
val ods_user_info=spark.table("dwd.customer1_inf")
 
val dwd_user_info = spark // 读取dwd最新分区数据
 
.table("dwd.customer_inf").where("etl_date = (SELECT MAX(etl_date) FROM dwd.customer_inf)")
 dwd_user_info.show
 
//2.合并并去重
 
val m=ods_user_info.union(dwd_user_info).withColumn("rowNumber",row_number().over(Window.partitionBy("customer_id").orderBy(desc("modified_time"))))
   .where(col(
"rowNumber")===1)
   .drop(
"rowNumber")
   
//将数据写入最新区并覆盖此分区数据
   
m.write.mode("overwrite").insertInto("dwd.customer_inf")
  
// 以下是对全表操作, overwrite:重写   append 追加(会出现重复记录)特别注意
    
// m.write
    // .mode("overwrite").partitionBy("etl_date").saveAsTable("dwd.customer_inf")
 
println("--------------------")

在实验过程遇到两个问题

  1. spark在运行时出现空间不足问题:slave1,slave2(worker)节点上目录满情况,删除目录下所有文件
  2. 在ods.customer_inf清洗后直接与dwd.customer_inf合并,会出现新的分区,不会写入到dwd.customer_inf表的新最新分区。

spark.read.table("ods.customer_inf").where(col("etl_date") === "2023-08-01") //读取ods的昨天分区数据
 
.withColumn("dwd_insert_user", lit("user1"))
  .withColumn("dwd_insert_time", to_timestamp(from_unixtime(unix_timestamp(), "yyyy-MM-dd HH:mm:ss")))
  .withColumn("dwd_modify_user", lit("user1"))
  .withColumn("dwd_modify_time", to_timestamp(from_unixtime(unix_timestamp(), "yyyy-MM-dd HH:mm:ss")))
  .withColumn("birthday", to_timestamp(from_unixtime(unix_timestamp(col("birthday"), "yyyy-MM-dd HH:mm:ss"))))

 

附两表合并去重练习

1 创建文件

vi /home/t1

2 wang

3 li

4 zhao

5 chen

6 liu

7 huang

8 yang

9 bai

vi /home/t2

6 liu

7 huang

8 yang

9 bai

2.创建表stu1 stu2并导入数据

Hive> create table stu1(id int,name string) row format delimited fields terminated by ' ';

Hive> create table stu2 (id int,name string) row format delimited fields terminated by ' ';

hive> load data local inpath  '/home/t1'  into table stu1;

hive> load data local inpath  ‘/home/t1’  into table stu1;

3.两表合并

#spark-shell

Scala> import org.apache.spark.sql.expressions.Window

Scala>import org.apache.spark.sql.{SaveMode, SparkSession}

Scala>val spark = SparkSession.builder().appName("abc").master("local[*]").config("hive.metastore.uris", "thrift://192.168.100.100:9083").config("spark.sql.metastore.warehouse","hdfs://master:9000/user/hive/warehouse").enableHiveSupport().getOrCreate()

val f1= spark.table("study.stu1")

val f2= spark.table("study.stu2")  

 //双表合并,添加字段sortid ,根据 id分组,按name排序结果写入该字段,

 val f3 = f1.select(f2.columns.map(col): _*).union(f2).withColumn("sortId", row_number().over(Window.partitionBy("id").orderBy(desc("name"))))

更简单语句

val f3 = f1.union(f2).withColumn("sortId", row_number().over(Window.partitionBy("id").orderBy(desc("name"))))

val  f4=f3. .where(col("sortId")===1).drop("sortId") //去重

注意 表f3 记录无重复字段值sortId为1

            记录有重复字段值sortId分别为1,2

val f4 = f3.filter(col("sortId") === 1).as("f4")

表f4中sortid=1记录

表f5中sortid=2记录

val f5 = f3.filter(col("sortId") === 2).as("f5")

//去重并删除列sortid

val f6=f4.join(f5, f4("id") === f5("id"), "left").select("f4.*").drop("sortId")

附mysql表customer_inf

/*

SQLyog Community v13.2.1 (64 bit)

MySQL - 8.0.12

*********************************************************************

*/

/*!40101 SET NAMES utf8 */;

create table `customer_inf` (

     `customer_inf_id` int (10),

     `customer_id` int (10),

     `customer_name` varchar (60),

     `identity_card_type` tinyint (4),

     `identity_card_no` varchar (60),

     `mobile_phone` varchar (150),

     `customer_email` varchar (150),

     `gender` char (3),

     `customer_point` int (11),

     `register_time` timestamp ,

     `birthday` datetime ,

     `customer_level` tinyint (4),

     `customer_money` Decimal (10),

     `modified_time` timestamp

);

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('1','0','鞠桂芝','1','511325198211210472','18572811239','songjuan@gmail.com','','10564','2022-08-16 08:48:36','1984-07-15 00:00:00','2','13675.00','2022-08-22 03:45:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('2','1','郝桂花','2','533324198602022478','18654171793','yanshi@yahoo.com','','988','2022-08-18 17:52:36','1907-01-21 00:00:00','5','15431.00','2022-08-23 13:22:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('3','2','王志强','3','451223193609298673','15387045553','jingmeng@gmail.com','','10264','2022-08-16 12:01:36','1964-05-12 00:00:00','5','23947.00','2022-08-21 18:23:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('4','3','朱健','3','421087199311093328','13923458889','weicheng@yahoo.com','M','1335','2022-08-16 07:48:36','1995-01-18 00:00:00','1','24922.00','2022-08-21 11:01:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('5','4','徐桂芝','3','152900194809225063','13453563818','tianxiuying@hotmail.com','M','4973','2022-08-15 13:04:36','1931-11-03 00:00:00','3','22209.00','2022-08-23 09:59:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('6','5','吕欢','1','540226199410195543','14565781488','yan39@yahoo.com','','2558','2022-08-18 01:56:36','1930-05-01 00:00:00','1','13555.00','2022-08-21 05:42:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('7','6','刘秀兰','1','451421194609021669','14765392939','longping@yahoo.com','','14168','2022-08-17 23:13:36','1945-05-06 00:00:00','3','29731.00','2022-08-23 17:01:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('8','7','郭凤兰','3','340101194401262481','14584105019','zhongxiulan@yahoo.com','','2839','2022-08-18 02:02:36','1950-03-14 00:00:00','3','21156.00','2022-08-21 19:28:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('9','8','李淑华','1','610727199202218255','13243976996','houyang@hotmail.com','M','15374','2022-08-19 12:55:36','1909-12-20 00:00:00','1','11933.00','2022-08-21 03:15:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('10','9','马婷婷','2','530326200212015803','15776998251','cjin@gmail.com','M','10293','2022-08-20 11:57:36','1982-12-08 00:00:00','5','16135.00','2022-08-21 10:50:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('11','10','左娜','3','120221197701313053','14526674975','jun49@hotmail.com','M','4377','2022-08-17 06:55:36','1979-11-03 00:00:00','5','17494.00','2022-08-21 22:03:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('12','11','白波','2','220401195612226011','18165264389','taojun@hotmail.com','W','18442','2022-08-14 02:15:36','1947-09-24 00:00:00','3','18148.00','2022-08-22 07:00:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('13','12','苏玉兰','1','410803197503228682','14713974367','mogang@gmail.com','W','9024','2022-08-16 22:12:36','1999-02-22 00:00:00','1','18096.00','2022-08-22 20:08:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('14','13','张畅','3','450405199001238968','18133947067','zhengna@hotmail.com','','11505','2022-08-17 01:40:36','1979-02-16 00:00:00','1','16665.00','2022-08-22 11:09:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('15','14','孟伟','1','350901194201232259','14778291509','jie00@yahoo.com','M','17133','2022-08-19 06:40:36','1994-12-11 00:00:00','2','29173.00','2022-08-23 12:20:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('16','15','尹岩','2','110117196407111550','15510064911','huanggang@yahoo.com','M','1057','2022-08-19 22:15:36','1972-09-22 00:00:00','3','10852.00','2022-08-23 21:56:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('17','16','卢柳','2','411500197310156331','18810132022','xiafang@gmail.com','M','13514','2022-08-15 15:54:36','2005-03-25 00:00:00','2','22584.00','2022-08-21 17:26:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('18','17','孙杰','3','542225193411143743','14758929729','changqiang@gmail.com','M','8433','2022-08-14 05:07:36','1967-05-02 00:00:00','5','15670.00','2022-08-22 17:33:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('19','18','张琴','2','152502196702174243','15048885647','osun@hotmail.com','W','13065','2022-08-15 10:33:36','2020-04-15 00:00:00','5','11059.00','2022-08-22 17:02:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('20','19','李岩','1','431023194611015302','14739519058','pyang@gmail.com','M','12084','2022-08-14 17:32:36','1974-04-01 00:00:00','3','29600.00','2022-08-21 23:36:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('21','20','蒋桂香','3','430111198505018419','18818723357','duanna@gmail.com','','13285','2022-08-14 08:24:36','2015-04-22 00:00:00','1','12305.00','2022-08-23 15:21:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('22','21','徐斌','2','231002194101218792','13948422447','lei18@gmail.com','','19994','2022-08-19 23:52:36','1994-03-01 00:00:00','5','25177.00','2022-08-22 14:16:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('23','22','陆辉','3','440301193402241906','18734065448','wei38@gmail.com','W','1884','2022-08-19 18:22:36','1958-12-21 00:00:00','1','11301.00','2022-08-22 19:59:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('24','23','彭文','1','640000197808273919','13810794914','luyong@yahoo.com','','8880','2022-08-14 01:41:36','1920-06-12 00:00:00','3','26720.00','2022-08-23 18:22:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('25','24','海利','2','131028198307233910','15042606725','haoqiang@hotmail.com','','10146','2022-08-20 00:00:36','1963-03-06 00:00:00','5','10889.00','2022-08-21 21:29:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('26','25','李帅','3','360922200307275611','14557371233','uwen@hotmail.com','M','16054','2022-08-19 05:14:36','2010-05-16 00:00:00','1','27277.00','2022-08-20 22:36:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('27','26','王琴','2','330726197408251111','14524554849','yuanjie@hotmail.com','','18881','2022-08-18 16:48:36','1933-11-09 00:00:00','3','27395.00','2022-08-23 23:55:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('28','27','陈明','3','440403194002239439','13897611773','lei50@hotmail.com','M','2142','2022-08-19 20:09:36','1927-03-27 00:00:00','5','13606.00','2022-08-21 19:29:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('29','28','万丽丽','2','411401196102056340','13487400611','kxiang@hotmail.com','','13242','2022-08-19 07:22:36','1997-07-02 00:00:00','2','11542.00','2022-08-23 20:42:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('30','29','孟岩','2','620103195504017504','15099044002','chaoxia@hotmail.com','','8428','2022-08-18 12:42:36','1919-08-28 00:00:00','4','26622.00','2022-08-22 10:15:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('31','30','傅旭','2','230623195501112688','18113233948','jinyan@hotmail.com','M','1372','2022-08-18 00:12:36','2002-10-28 00:00:00','5','10004.00','2022-08-20 22:35:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('32','31','杨玉珍','2','141082198711111173','13784234718','jluo@hotmail.com','','13981','2022-08-13 23:32:36','1944-01-04 00:00:00','3','18925.00','2022-08-23 06:58:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('33','32','沙想','2','210283195411057831','15798865766','vwu@gmail.com','W','9047','2022-08-16 04:11:36','1991-05-16 00:00:00','2','14204.00','2022-08-22 13:11:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('34','33','翟秀华','2','451425194305123581','15353927480','leiwang@hotmail.com','W','3114','2022-08-17 14:52:36','1979-01-14 00:00:00','4','14380.00','2022-08-23 15:42:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('35','34','刘红梅','1','361127200104079767','18943128221','hqiao@gmail.com','','19641','2022-08-20 18:51:36','1910-04-11 00:00:00','3','28695.00','2022-08-23 22:49:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('36','35','陈丽','3','510500197309228820','13372002784','juan37@gmail.com','','794','2022-08-18 10:36:36','1918-07-03 00:00:00','5','18800.00','2022-08-24 02:15:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('37','36','余丹丹','1','53082519870402351X','15720927554','fhu@gmail.com','M','17359','2022-08-16 14:15:36','1943-07-17 00:00:00','5','29117.00','2022-08-21 03:45:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('38','37','刘荣','3','610328194802088919','18508699960','laimin@gmail.com','','1897','2022-08-18 11:22:36','1927-12-06 00:00:00','2','17693.00','2022-08-21 22:37:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('39','38','李秀兰','1','331021197605264238','15994270839','xiuying49@gmail.com','W','2637','2022-08-15 15:30:36','1973-08-30 00:00:00','2','22403.00','2022-08-22 15:00:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('40','39','张宇','2','530824193908179656','18762621127','ehe@gmail.com','','5852','2022-08-15 12:59:36','1999-04-29 00:00:00','1','16514.00','2022-08-22 00:45:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('41','40','吴兰英','3','150924199410277082','15308872602','jun76@hotmail.com','W','17758','2022-08-16 12:48:36','2020-04-26 00:00:00','3','24966.00','2022-08-20 21:36:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('42','41','樊玉兰','3','140222196605278097','15210985172','chao43@hotmail.com','','3937','2022-08-14 17:57:36','2014-06-14 00:00:00','1','24567.00','2022-08-23 15:32:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('43','42','王鹏','2','62060019510429624X','15745356431','syang@hotmail.com','M','10026','2022-08-20 08:38:36','2019-03-18 00:00:00','2','13046.00','2022-08-22 09:04:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('44','43','王淑珍','1','340501193711057421','15383182905','jfeng@hotmail.com','M','5853','2022-08-17 07:32:36','2013-06-14 00:00:00','5','29197.00','2022-08-21 03:33:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('45','44','赵艳','2','420202196904118298','18295882482','qiangpan@hotmail.com','W','11621','2022-08-18 12:31:36','1921-07-02 00:00:00','5','14225.00','2022-08-23 03:05:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('46','45','彭秀英','1','370801193401059888','15386885166','yan67@yahoo.com','W','17873','2022-08-18 21:11:36','1968-07-31 00:00:00','1','14701.00','2022-08-21 10:34:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('47','46','李华','2','410201194709167310','15512076223','yang28@yahoo.com','','3949','2022-08-17 04:59:36','1990-04-27 00:00:00','1','26903.00','2022-08-20 21:37:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('48','47','陈桂荣','3','640402193806087019','15668566930','yangchang@yahoo.com','M','96','2022-08-17 15:15:36','2017-04-23 00:00:00','4','27835.00','2022-08-22 22:12:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('49','48','王金凤','2','140924199011027340','15856633735','weiqiang@yahoo.com','W','3523','2022-08-16 18:47:36','1979-10-23 00:00:00','4','21646.00','2022-08-21 22:29:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('50','49','蒋阳','3','141130200109133264','13396120441','yang25@hotmail.com','W','18817','2022-08-18 12:29:36','1993-02-22 00:00:00','1','19165.00','2022-08-21 10:33:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('51','50','段桂英','1','21021319790225694X','13550034581','mengli@hotmail.com','W','3421','2022-08-17 11:24:36','1980-01-16 00:00:00','4','12605.00','2022-08-21 00:48:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('52','51','郑玉梅','1','371602193805038019','15549519982','na79@hotmail.com','M','7870','2022-08-15 21:12:36','1947-08-08 00:00:00','5','13950.00','2022-08-21 21:32:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('53','52','马冬梅','1','150523195203150808','13290598879','tao37@hotmail.com','W','3478','2022-08-16 08:47:36','2014-06-30 00:00:00','5','12544.00','2022-08-22 08:23:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('54','53','郭秀云','2','640200200301180225','15741206250','duxia@gmail.com','','11897','2022-08-18 19:28:36','1923-08-17 00:00:00','3','12324.00','2022-08-21 16:13:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('55','54','彭秀英','3','420200194310073908','14543095197','na63@yahoo.com','M','8822','2022-08-13 23:46:36','1944-04-05 00:00:00','2','16010.00','2022-08-22 01:53:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('56','55','刘鹏','3','341200198206077916','18987527790','kangna@gmail.com','M','9062','2022-08-15 13:00:36','1994-06-24 00:00:00','3','10832.00','2022-08-20 23:23:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('57','56','胡洁','1','542422193611165877','15739247524','guiying79@gmail.com','M','10876','2022-08-18 18:38:36','2006-09-22 00:00:00','2','14556.00','2022-08-23 15:10:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('58','57','曾健','3','440403199905159301','15701796556','guiying06@yahoo.com','','7648','2022-08-16 18:25:36','1939-09-17 00:00:00','1','23589.00','2022-08-23 16:09:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('59','58','贾成','3','410205196302143258','18876491661','zengli@gmail.com','W','19054','2022-08-15 06:45:36','2010-03-15 00:00:00','2','19600.00','2022-08-22 11:50:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('60','59','黄晶','2','411722193312032229','14569481616','pingwu@hotmail.com','M','17140','2022-08-19 17:10:36','1925-11-11 00:00:00','2','24205.00','2022-08-21 12:08:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('61','60','詹玉珍','1','370523196712072292','14511156760','ehou@yahoo.com','W','3307','2022-08-16 02:43:36','1939-07-21 00:00:00','1','14209.00','2022-08-21 10:54:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('62','61','段刚','3','370125200104262105','15906394268','xionggang@yahoo.com','','7834','2022-08-18 01:35:36','2006-05-16 00:00:00','1','24637.00','2022-08-20 22:38:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('63','62','姚娟','3','532328196002128362','13494762015','phe@gmail.com','','13249','2022-08-19 04:44:36','1983-11-30 00:00:00','4','10328.00','2022-08-23 10:03:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('64','63','霍平','3','150623196206137158','13031369546','xiuyingcao@gmail.com','M','9590','2022-08-15 18:43:36','1911-05-04 00:00:00','4','29615.00','2022-08-23 19:55:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('65','64','闵莹','3','15070119350814324X','13879255578','li24@hotmail.com','M','2751','2022-08-19 21:52:36','1995-03-11 00:00:00','4','19792.00','2022-08-22 04:56:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('66','65','王冬梅','2','130203197702055454','13929007921','pqian@gmail.com','','335','2022-08-16 08:21:36','1924-05-14 00:00:00','3','16105.00','2022-08-22 08:27:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('67','66','刘小红','3','340521198304211856','18197040531','glin@yahoo.com','','15171','2022-08-20 15:53:36','1998-08-08 00:00:00','2','10313.00','2022-08-21 20:12:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('68','67','陈晨','3','37021419730705683X','15764096896','pingye@hotmail.com','','3368','2022-08-20 08:32:36','1982-01-12 00:00:00','4','17821.00','2022-08-23 11:55:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('69','68','刘晨','2','41170019821109453X','14739313361','qiangyao@gmail.com','','6184','2022-08-15 03:40:36','1944-06-30 00:00:00','1','18620.00','2022-08-23 02:35:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('70','69','梁红梅','2','230231194108254093','14555427906','lei03@gmail.com','W','6962','2022-08-15 14:25:36','2005-10-17 00:00:00','4','27680.00','2022-08-21 01:09:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('71','70','胡艳','1','620902197606116112','13418164366','jingzeng@hotmail.com','','3791','2022-08-17 23:30:36','2011-05-18 00:00:00','3','15540.00','2022-08-24 06:46:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('72','71','陈琳','3','653000194109144967','13015024559','jun50@gmail.com','','12342','2022-08-15 09:16:36','2016-06-23 00:00:00','2','20577.00','2022-08-22 20:47:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('73','72','梁凤兰','2','230900194510016871','18728378181','iyi@gmail.com','W','3616','2022-08-19 08:04:36','1911-01-11 00:00:00','1','12283.00','2022-08-22 06:51:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('74','73','韦云','1','421222197908049921','13303097143','wufang@yahoo.com','','10384','2022-08-15 12:29:36','1986-04-13 00:00:00','3','28517.00','2022-08-23 03:13:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('75','74','段娟','2','532800195508229183','13093376172','pingjin@gmail.com','W','14487','2022-08-20 01:20:36','2000-01-08 00:00:00','3','13670.00','2022-08-22 22:44:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('76','75','刘鹏','1','41010820001002142X','15770736733','wenxiulan@hotmail.com','M','6292','2022-08-16 10:41:36','2014-02-21 00:00:00','2','14292.00','2022-08-22 22:46:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('77','76','魏桂香','1','610728199112062716','18918902978','li03@gmail.com','M','5248','2022-08-18 02:55:36','2020-12-21 00:00:00','4','13519.00','2022-08-22 21:44:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('78','77','王洋','1','210401198108088707','15997470494','bshao@gmail.com','M','10492','2022-08-20 15:04:36','1948-07-31 00:00:00','2','24365.00','2022-08-23 07:52:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('79','78','张敏','2','441403195704285929','13210129716','xwang@gmail.com','M','12676','2022-08-19 00:40:36','1978-10-25 00:00:00','3','10308.00','2022-08-23 13:41:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('80','79','戴博','3','450924194504130688','14548211412','cwang@gmail.com','M','9937','2022-08-15 18:14:36','2012-04-26 00:00:00','1','28935.00','2022-08-23 10:25:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('81','80','孙鑫','2','513231199504290646','15946672707','nfu@gmail.com','W','13019','2022-08-17 02:03:36','1970-12-10 00:00:00','3','18159.00','2022-08-21 07:29:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('82','81','袁英','2','130203198501103370','18680281978','yangjie@gmail.com','','15139','2022-08-17 23:57:36','1924-10-29 00:00:00','1','23706.00','2022-08-23 23:49:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('83','82','赵磊','2','150500193902137879','13646939996','ameng@hotmail.com','','581','2022-08-18 01:42:36','1936-05-23 00:00:00','5','12917.00','2022-08-22 02:47:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('84','83','李华','1','533421196604301240','13871155183','nazhu@hotmail.com','M','10571','2022-08-14 03:01:36','1957-02-21 00:00:00','1','27391.00','2022-08-23 22:46:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('85','84','李兰英','1','150104195105219743','18596942567','min97@gmail.com','','495','2022-08-16 13:23:36','2016-09-12 00:00:00','1','11240.00','2022-08-22 22:46:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('86','85','卢秀荣','3','420529193803095763','15800466462','bxia@gmail.com','M','9636','2022-08-15 20:47:36','2021-04-02 00:00:00','1','12547.00','2022-08-21 22:23:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('87','86','陈红霞','1','210904194807298111','13185382595','ping49@hotmail.com','W','5374','2022-08-14 16:06:36','1921-02-10 00:00:00','4','16295.00','2022-08-20 22:47:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('88','87','王成','2','340504199504206048','15556781833','chaozhou@gmail.com','','5302','2022-08-19 23:50:36','1979-09-20 00:00:00','5','13983.00','2022-08-23 14:34:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('89','88','周红梅','2','420581198401167224','13769893839','jingxiang@yahoo.com','W','5330','2022-08-14 21:53:36','1943-11-21 00:00:00','2','14702.00','2022-08-24 03:04:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('90','89','孙梅','3','430382197207300426','15569553175','yshao@gmail.com','','13018','2022-08-18 16:48:36','1940-01-15 00:00:00','5','19060.00','2022-08-21 16:11:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('91','90','孙玉珍','3','65210119491129455X','13310764259','gang08@yahoo.com','W','8652','2022-08-17 22:06:36','1975-11-03 00:00:00','4','21957.00','2022-08-22 10:49:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('92','91','许丹丹','1','440500195311024758','15892320839','xiuyingdong@yahoo.com','M','15072','2022-08-14 07:57:36','1976-10-15 00:00:00','3','15576.00','2022-08-21 21:52:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('93','92','段洋','2','130304199112197621','18506996733','dailei@yahoo.com','M','9119','2022-08-17 15:53:36','1934-06-07 00:00:00','5','21174.00','2022-08-23 11:15:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('94','93','孙畅','1','440113195705052989','18997608407','yiguiying@gmail.com','','7555','2022-08-15 10:19:36','2013-03-20 00:00:00','2','15769.00','2022-08-22 04:39:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('95','94','萧秀荣','2','630221197605227614','15575818726','wlin@gmail.com','W','9200','2022-08-20 20:16:36','2012-12-13 00:00:00','5','27651.00','2022-08-21 00:31:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('96','95','李利','1','44078519950827311X','15279863174','dongjuan@hotmail.com','W','2740','2022-08-15 09:51:36','1986-03-07 00:00:00','2','14819.00','2022-08-22 07:41:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('97','96','陈阳','2','230523196907290600','15146042972','tao62@hotmail.com','','1083','2022-08-15 11:28:36','1999-09-17 00:00:00','2','13032.00','2022-08-23 16:53:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('98','97','张丽华','1','440201198008094298','15239437808','chao02@gmail.com','W','8945','2022-08-16 20:09:36','2000-08-03 00:00:00','3','14485.00','2022-08-23 01:13:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('99','98','李刚','1','370404200110153196','13474351121','taolai@gmail.com','W','16624','2022-08-17 23:20:36','1922-01-12 00:00:00','2','26812.00','2022-08-22 15:42:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('100','99','冯玉珍','1','14072319831106570X','13508491393','pzeng@yahoo.com','W','2787','2022-08-15 07:56:36','1953-10-10 00:00:00','3','18462.00','2022-08-23 15:10:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('101','100','黄利','2','11020019790313456X','15302605826','ekong@hotmail.com','M','10628','2022-08-16 21:11:36','1921-03-08 00:00:00','5','11577.00','2022-08-22 10:41:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('102','101','王慧','2','110228195002101020','13648713309','lixiulan@yahoo.com','W','3262','2022-08-14 18:47:36','2022-08-28 00:00:00','1','21391.00','2022-08-22 03:45:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('103','102','毕建军','1','330681195811126687','13803512177','kangping@hotmail.com','','2251','2022-08-15 20:19:36','2012-01-09 00:00:00','4','10993.00','2022-08-23 02:44:36');

insert into `customer_inf` (`customer_inf_id`, `customer_id`, `customer_name`, `identity_card_type`, `identity_card_no`, `mobile_phone`, `customer_email`, `gender`, `customer_point`, `register_time`, `birthday`, `customer_level`, `customer_money`, `modified_time`) values('104','103','白淑华','2','321003197506254195','18944494564','yan58@hotmail.com','','1542','2022-08-16 19:48:36','1925-03-10 00:00:00','4','26154.00','2022-08-21 05:46:36');

评论
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包
实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

1.余额是钱包充值的虚拟货币,按照1:1的比例进行支付金额的抵扣。
2.余额无法直接购买下载,可以购买VIP、付费专栏及课程。

余额充值