1. 概述
在2.x中,spark有两个用来与kafka整合的代码,版本代号为0.8和0.10,由于在0.8,kafka有两套消费者api,根据高级api得到了Receiver-based Approach,根据低级api得到了Direct Approach,而在0.10由于kafka只有一套消费者api了,所以也只有Direct Approach
2. Direct Approach
由于0.8与0.10的Direct Approach的实现差不多,这里使用0.10来进行描述。该途径由DirectKafkaInputDStream
实现
private[spark] class DirectKafkaInputDStream[K, V](
_ssc: StreamingContext,
locationStrategy: LocationStrategy,
consumerStrategy: ConsumerStrategy[K, V],
ppc: PerPartitionConfig
)
其中,LocationStrategy
表示的是分配topic partition的consumer到executor的策略,有3个取值
PreferConsistent
: 均匀的分布在executor中。原理是使用TopicPartition
的hash值来决定到哪个可用的executor上执行PreferBrokers
:偏向于将consumer分配到指定的topic partition所在的leader上;如果leader集中,会造成负载不均。如果可用的executor中没有leader所在的主机,使用PreferConsistent
PreferFixed
: 指定某些topic partition的consumer分配到指定的机器上,没有指定的topic partition使用PreferConsistent
ConsumerStrategy
用来指定消费的topic partition,也有三个子类来表示不同的策略:
Subscribe
:精确指定用来消费的topicSubscribePattern
:使用正则表达式来指定消费的topicAssign
: 精确指定用来消费的topic partition。上述2个都是消费topic的所有分区,这个可以选择性的消费部分分区
PerPartitionConfig
只有一个实现类DefaultPerPartitionConfig
,用来执行反压
,控制每个分区的消费速率
2.1 执行过程
分为2步,一是DirectKafkaInputDStream
计算每个分区及其消费开始的offset与结束的offset(不包含),二是将上述信息封装到KafkaRDD
中消费每个topic partition,一个topic partition对应一个task
2.2 常用的配置
配置分为两种,一种是传给ConsumerStrategy
,为Kafka Consumer相关的配置,还有一种是传给SparkConf
的。
传给ConsumerStrategy
的kafkaParams
变量名 | 描述 | 其它 |
---|---|---|
heartbeat.interval.ms | 客户端与broker的心跳间隔 | 不小于batchDuration ,在有window操作时,要不小于slideDuration
|
session.timeout.ms | 在该时间内,如果收不到客户端心跳,会移除该客户端 | 推荐3 * heartbeat.interval.ms,但要在范围(group.min.session.timeout.ms, group.max.session.timeout.ms]
|
metadata.broker.list | kafka集群的broker列表,用来获取整个集群拓扑,不用完整 | 等价于bootstrap.servers |
enable.auto.commit | 是否自动提交消费的offset | 在executor端,为false,通常也要设置为false |
auto.commit.interval.ms | 自动提交消费的offset的周期 | 默认为5s |
group.id | 消费组的id | 尽量设置 |
auto.offset.reset | 当指定消费的offset不存在时,采取的行为 | 在executor端为none |
receive.buffer.bytes | The size of the TCP receive buffer (SO_RCVBUF) to use when reading data | 默认65536,设置的时候要大于该值 |
注意上述的默认值要根据使用的版本来确定。
传给SparkConf
的
变量名 | 描述 | 其它 |
---|---|---|
spark.streaming.kafka.consumer.poll.ms | 消费者获取消息等待的最大时间 | 默认值spark.network.timeout |
spark.streaming.kafka.allowNonConsecutiveOffsets | 是否允许消费的offset不连续,通常都是连续的,除非中间的message被删掉了 | 默认值false |
spark.streaming.kafka.consumer.cache.enabled | 在executor端将消费指定topic partition的consumer缓存起来,这个是executor级别的缓存,如果没有使用动态资源分配,可以用来重用consumer | 默认值true |
spark.streaming.kafka.consumer.cache.maxCapacity | 每个executor上能缓存的consumer的最大值 | 默认值64 |
spark.streaming.kafka.consumer.cache.minCapacity | 每个executor上能缓存的consumer的最大值 | 默认值16 |
2.3 at-least-once与 exactly-once语义
用户有三种方式来保存每个分区消费的offset,分别是checkpoint、kafka保存、用户自己处理
- checkpoint:driver端的容错,最不靠谱,由于任务执行与checkpoint是异步执行的,如果消息没有消费完程序报错了,但是已经checkpoint,恢复后则会丢失数据
- kafka保存:设置
enable.auto.commit
为false,需要调用在业务逻辑后加上如下代码。下面的代码注入的offsetRanges
会在下次生成任务的时候被提交。这种方式不会丢数据,当输出端不是幂等的,就只能保证at-least-once,因为输出与保存offset不是一个事务
val kafkaDStream = KafkaUtils.createDirectStream(...)
// 写法一开始
// 一大堆流式处理代码
// 最后
kafkaDStream .foreachRDD { rdd =>
val offsetRanges = rdd.asInstanceOf[HasOffsetRanges].offstietRanges
kafkaDStream .asInstanceOf[CanCommitOffsets].commitAsync(offsetRanges)
}
// 写法一结束
// 写法二
kafkaDStream .transform{ rdd =>
val offsetRanges = rdd.asInstanceOf[HasOffsetRanges].offstietRanges
kafkaDStream .asInstanceOf[CanCommitOffsets].commitAsync(offsetRanges)
rdd
}.一大堆流式处理代码
- 用户自己处理,当输出端不幂等,但是支持事务时,将保存offset与输出封装到一个事务中可以实现
exactly-once
,官方文档streaming-kafka-0-10-integration里提供一种写法,笔者在这里也提供一种,供读者参考
// 故障恢复
val fromOffsets = selectOffsetsFromYourDatabase.map { resultSet =>
new TopicPartition(resultSet.string("topic"), resultSet.int("partition")) -> resultSet.long("offset")
}.toMap
val stream = KafkaUtils.createDirectStream(...)
var offsetBroadCast: Broadcast[Array[OffsetRange]] = null
messages.transform(rdd => {
val ranges = rdd.asInstanceOf[HasOffsetRanges].offsetRanges
offsetBroadCast = ssc.sparkContext.broadcast(ranges)
rdd
}).map(t => (t.key(), t.value())).foreachRDD(rdd => {
val partitions = rdd.getNumPartitions
val offset = offsetBroadCast.value
rdd.mapPartitionsWithIndex((mapId, it) => Iterator((mapId, it)))
.foreachPartition(it => {
val (mapId, realIt) = it.buffered.head
val commitOffRange = offset(mapid)
// 开启事务
// 用 realIt 更新结果
// 用 commitOffRange 更新对应分区的offset
// 提交事务
})
offsetBroadCast.destroy(true)
})
3. 与receiver-based的差别
这里的receiver指的是ReliableKafkaReceiver
并且开启了WAL,如果不开启WAL则可能会导致数据丢失,存储数据的过程如下:
- 添加到
BlockGenerator
的buffer中- 将buffer中的数据写入到WAL,写入到
BlockManager
- 通知给
ReceiverTracker
,并把元数据写入到WAL
- 更新offset到zookeeper
整个过程能保证数据不丢,但是只能保证at-least-once
语义。差别如下:
- receiver-based需要存储一份数据,kafka里面也有一份,这样的数据冗余没有必要
Direct approach
少了receiver,整个架构更简单- receiver-based的topic partition offset只能由zookeeper管理,
Direct approach
更灵活
http://news.hbfzb.com/info.php?id=791519393
https://www.hbfzb.com/news.php?id=791519393
http://zhangjiakou.hbfzb.com/apple.php?id=791519393
http://news.hbfzb.com/apple.php?id=791519393
http://xingtai.hbfzb.com/apple.php?id=791519393
http://chengde.hbfzb.com/apple.php?id=791519393
http://shijiazhuang.hbfzb.com/apple.php?id=791519393
http://baoding.hbfzb.com/apple.php?id=791519393
http://hengshui.hbfzb.com/apple.php?id=791519393
https://www.hbfzb.com/html/qhd.php?id=791519393
https://www.hbfzb.com/html/ts.php?id=791519393
https://www.hbfzb.com/html/apple.php?id=791519393
https://www.hbfzb.com/html/news.php?id=791519393
https://www.hbfzb.com/html/zl.php?id=791519393
https://www.hbfzb.com/html/info.php?id=791519393
https://www.hbfzb.com/html/lf.php?id=791519393
https://www.hbfzb.com/html/shou.php?id=791519393
https://www.hbfzb.com/index.php?id=791519393
http://qinhuangdao.hbfzb.com/apple.php?id=791519393
http://xinji.hbfzb.com/apple.php?id=791519393
http://dingzhou.hbfzb.com/apple.php?id=791519393
http://shipin.hbfzb.com/apple.php?id=791519393
http://wshb.hbfzb.com/apple.php?id=791519393
http://photov.hbfzb.com/apple.php?id=791519393
http://szgc.glodon.com/news.php?id=791519393
http://sz.glodon.com/info.php?id=791519393
http://www.bxysg.com/news.asp?id=791519393
http://www.whbts.com/poser.asp?id=791519393
http://www.cquedp.com/news.php?id=791519393
http://cquedp.com/?id=791519393
http://m.cquedp.com/?id=791519393
http://www.hsfuhui.com/a/news.php?id=791519393
http://mdzz.itlun.cn/index.html?id=791519393
http://www.yqyy.net/news.php??id=791519393
http://www.hnalizs.com/news.php?id=791519393
http://www.gdnhec.com/poser.php?id=791519393
http://www.lygwb.com/poser.php?id=791519393
http://mzhihui.mulangcm.com/news/news.php?id=791519393
http://www.spark-lock.com/poser.asp?id=791519393
http://www.fsruijian.net/poser.php?id=791519393
http://www.xdmonitor.com/news.aspx?id=791519393
https://www.iresearch.com.cn/news.aspx?id=791519393
http://www.keyunit.cn/news.php?id=791519393
http://1798.rongbiz.net/new.php?id=791519393
http://news.hbfzb.com/info.php?id=860002828
https://www.hbfzb.com/news.php?id=860002828
http://zhangjiakou.hbfzb.com/apple.php?id=860002828
http://news.hbfzb.com/apple.php?id=860002828
http://xingtai.hbfzb.com/apple.php?id=860002828
http://chengde.hbfzb.com/apple.php?id=860002828
http://shijiazhuang.hbfzb.com/apple.php?id=860002828
http://baoding.hbfzb.com/apple.php?id=860002828
http://hengshui.hbfzb.com/apple.php?id=860002828
https://www.hbfzb.com/html/qhd.php?id=860002828
https://www.hbfzb.com/html/ts.php?id=860002828
https://www.hbfzb.com/html/apple.php?id=860002828
https://www.hbfzb.com/html/news.php?id=860002828
https://www.hbfzb.com/html/zl.php?id=860002828
https://www.hbfzb.com/html/info.php?id=860002828
https://www.hbfzb.com/html/lf.php?id=860002828
https://www.hbfzb.com/html/shou.php?id=860002828
https://www.hbfzb.com/index.php?id=860002828
http://qinhuangdao.hbfzb.com/apple.php?id=860002828
http://xinji.hbfzb.com/apple.php?id=860002828
http://dingzhou.hbfzb.com/apple.php?id=860002828
http://shipin.hbfzb.com/apple.php?id=860002828
http://wshb.hbfzb.com/apple.php?id=860002828
http://photov.hbfzb.com/apple.php?id=860002828
http://szgc.glodon.com/news.php?id=860002828
http://sz.glodon.com/info.php?id=860002828
http://www.bxysg.com/news.asp?id=860002828
http://www.whbts.com/poser.asp?id=860002828
http://www.cquedp.com/news.php?id=860002828
http://cquedp.com/?id=860002828
http://m.cquedp.com/?id=860002828
http://www.hsfuhui.com/a/news.php?id=860002828
http://mdzz.itlun.cn/index.html?id=860002828
http://www.yqyy.net/news.php??id=860002828
http://www.hnalizs.com/news.php?id=860002828
http://www.gdnhec.com/poser.php?id=860002828
http://www.lygwb.com/poser.php?id=860002828
http://mzhihui.mulangcm.com/news/news.php?id=860002828
http://www.spark-lock.com/poser.asp?id=860002828
http://www.fsruijian.net/poser.php?id=860002828
http://www.xdmonitor.com/news.aspx?id=860002828
https://www.iresearch.com.cn/news.aspx?id=860002828
http://www.keyunit.cn/news.php?id=860002828
http://1798.rongbiz.net/new.php?id=860002828
http://news.hbfzb.com/info.php?id=626204460
https://www.hbfzb.com/news.php?id=626204460
http://zhangjiakou.hbfzb.com/apple.php?id=626204460
http://news.hbfzb.com/apple.php?id=626204460
http://xingtai.hbfzb.com/apple.php?id=626204460
http://chengde.hbfzb.com/apple.php?id=626204460
http://shijiazhuang.hbfzb.com/apple.php?id=626204460
http://baoding.hbfzb.com/apple.php?id=626204460
http://hengshui.hbfzb.com/apple.php?id=626204460
https://www.hbfzb.com/html/qhd.php?id=626204460
https://www.hbfzb.com/html/ts.php?id=626204460
https://www.hbfzb.com/html/apple.php?id=626204460
https://www.hbfzb.com/html/news.php?id=626204460
https://www.hbfzb.com/html/zl.php?id=626204460
https://www.hbfzb.com/html/info.php?id=626204460
https://www.hbfzb.com/html/lf.php?id=626204460
https://www.hbfzb.com/html/shou.php?id=626204460
https://www.hbfzb.com/index.php?id=626204460
http://qinhuangdao.hbfzb.com/apple.php?id=626204460
http://xinji.hbfzb.com/apple.php?id=626204460
http://dingzhou.hbfzb.com/apple.php?id=626204460
http://shipin.hbfzb.com/apple.php?id=626204460
http://wshb.hbfzb.com/apple.php?id=626204460
http://photov.hbfzb.com/apple.php?id=626204460
http://szgc.glodon.com/news.php?id=626204460
http://sz.glodon.com/info.php?id=626204460
http://www.bxysg.com/news.asp?id=626204460
http://www.whbts.com/poser.asp?id=626204460
http://www.cquedp.com/news.php?id=626204460
http://cquedp.com/?id=626204460
http://m.cquedp.com/?id=626204460
http://www.hsfuhui.com/a/news.php?id=626204460
http://mdzz.itlun.cn/index.html?id=626204460
http://www.yqyy.net/news.php??id=626204460
http://www.hnalizs.com/news.php?id=626204460
http://www.gdnhec.com/poser.php?id=626204460
http://www.lygwb.com/poser.php?id=626204460
http://mzhihui.mulangcm.com/news/news.php?id=626204460
http://www.spark-lock.com/poser.asp?id=626204460
http://www.fsruijian.net/poser.php?id=626204460
http://www.xdmonitor.com/news.aspx?id=626204460
https://www.iresearch.com.cn/news.aspx?id=626204460
http://www.keyunit.cn/news.php?id=626204460
http://1798.rongbiz.net/new.php?id=626204460
http://news.hbfzb.com/info.php?id=624406884
https://www.hbfzb.com/news.php?id=624406884
http://zhangjiakou.hbfzb.com/apple.php?id=624406884
http://news.hbfzb.com/apple.php?id=624406884
http://xingtai.hbfzb.com/apple.php?id=624406884
http://chengde.hbfzb.com/apple.php?id=624406884
http://shijiazhuang.hbfzb.com/apple.php?id=624406884
http://baoding.hbfzb.com/apple.php?id=624406884
http://hengshui.hbfzb.com/apple.php?id=624406884
https://www.hbfzb.com/html/qhd.php?id=624406884
https://www.hbfzb.com/html/ts.php?id=624406884
https://www.hbfzb.com/html/apple.php?id=624406884
https://www.hbfzb.com/html/news.php?id=624406884
https://www.hbfzb.com/html/zl.php?id=624406884
https://www.hbfzb.com/html/info.php?id=624406884
https://www.hbfzb.com/html/lf.php?id=624406884
https://www.hbfzb.com/html/shou.php?id=624406884
https://www.hbfzb.com/index.php?id=624406884
http://qinhuangdao.hbfzb.com/apple.php?id=624406884
http://xinji.hbfzb.com/apple.php?id=624406884
http://dingzhou.hbfzb.com/apple.php?id=624406884
http://shipin.hbfzb.com/apple.php?id=624406884
http://wshb.hbfzb.com/apple.php?id=624406884
http://photov.hbfzb.com/apple.php?id=624406884
http://szgc.glodon.com/news.php?id=624406884
http://sz.glodon.com/info.php?id=624406884
http://www.bxysg.com/news.asp?id=624406884
http://www.whbts.com/poser.asp?id=624406884
http://www.cquedp.com/news.php?id=624406884
http://cquedp.com/?id=624406884
http://m.cquedp.com/?id=624406884
http://www.hsfuhui.com/a/news.php?id=624406884
http://mdzz.itlun.cn/index.html?id=624406884
http://www.yqyy.net/news.php??id=624406884
http://www.hnalizs.com/news.php?id=624406884
http://www.gdnhec.com/poser.php?id=624406884
http://www.lygwb.com/poser.php?id=624406884
http://mzhihui.mulangcm.com/news/news.php?id=624406884
http://www.spark-lock.com/poser.asp?id=624406884
http://www.fsruijian.net/poser.php?id=624406884
http://www.xdmonitor.com/news.aspx?id=624406884
https://www.iresearch.com.cn/news.aspx?id=624406884
http://www.keyunit.cn/news.php?id=624406884
http://1798.rongbiz.net/new.php?id=624406884
http://news.hbfzb.com/info.php?id=484008084
https://www.hbfzb.com/news.php?id=484008084
http://zhangjiakou.hbfzb.com/apple.php?id=484008084
http://news.hbfzb.com/apple.php?id=484008084
http://xingtai.hbfzb.com/apple.php?id=484008084
http://chengde.hbfzb.com/apple.php?id=484008084
http://shijiazhuang.hbfzb.com/apple.php?id=484008084
http://baoding.hbfzb.com/apple.php?id=484008084
http://hengshui.hbfzb.com/apple.php?id=484008084
https://www.hbfzb.com/html/qhd.php?id=484008084
https://www.hbfzb.com/html/ts.php?id=484008084
https://www.hbfzb.com/html/apple.php?id=484008084
https://www.hbfzb.com/html/news.php?id=484008084
https://www.hbfzb.com/html/zl.php?id=484008084
https://www.hbfzb.com/html/info.php?id=484008084
https://www.hbfzb.com/html/lf.php?id=484008084
https://www.hbfzb.com/html/shou.php?id=484008084
https://www.hbfzb.com/index.php?id=484008084
http://qinhuangdao.hbfzb.com/apple.php?id=484008084
http://xinji.hbfzb.com/apple.php?id=484008084
http://dingzhou.hbfzb.com/apple.php?id=484008084
http://shipin.hbfzb.com/apple.php?id=484008084
http://wshb.hbfzb.com/apple.php?id=484008084
http://photov.hbfzb.com/apple.php?id=484008084
http://szgc.glodon.com/news.php?id=484008084
http://sz.glodon.com/info.php?id=484008084
http://www.bxysg.com/news.asp?id=484008084
http://www.whbts.com/poser.asp?id=484008084
http://www.cquedp.com/news.php?id=484008084
http://cquedp.com/?id=484008084
http://m.cquedp.com/?id=484008084
http://www.hsfuhui.com/a/news.php?id=484008084
http://mdzz.itlun.cn/index.html?id=484008084
http://www.yqyy.net/news.php??id=484008084
http://www.hnalizs.com/news.php?id=484008084
http://www.gdnhec.com/poser.php?id=484008084
http://www.lygwb.com/poser.php?id=484008084
http://mzhihui.mulangcm.com/news/news.php?id=484008084
http://www.spark-lock.com/poser.asp?id=484008084
http://www.fsruijian.net/poser.php?id=484008084
http://www.xdmonitor.com/news.aspx?id=484008084
https://www.iresearch.com.cn/news.aspx?id=484008084
http://www.keyunit.cn/news.php?id=484008084
http://1798.rongbiz.net/new.php?id=484008084
http://news.hbfzb.com/info.php?id=248042086
https://www.hbfzb.com/news.php?id=248042086
http://zhangjiakou.hbfzb.com/apple.php?id=248042086
http://news.hbfzb.com/apple.php?id=248042086
http://xingtai.hbfzb.com/apple.php?id=248042086
http://chengde.hbfzb.com/apple.php?id=248042086
http://shijiazhuang.hbfzb.com/apple.php?id=248042086
http://baoding.hbfzb.com/apple.php?id=248042086
http://hengshui.hbfzb.com/apple.php?id=248042086
https://www.hbfzb.com/html/qhd.php?id=248042086
https://www.hbfzb.com/html/ts.php?id=248042086
https://www.hbfzb.com/html/apple.php?id=248042086
https://www.hbfzb.com/html/news.php?id=248042086
https://www.hbfzb.com/html/zl.php?id=248042086
https://www.hbfzb.com/html/info.php?id=248042086
https://www.hbfzb.com/html/lf.php?id=248042086
https://www.hbfzb.com/html/shou.php?id=248042086
https://www.hbfzb.com/index.php?id=248042086
http://qinhuangdao.hbfzb.com/apple.php?id=248042086
http://xinji.hbfzb.com/apple.php?id=248042086
http://dingzhou.hbfzb.com/apple.php?id=248042086
http://shipin.hbfzb.com/apple.php?id=248042086
http://wshb.hbfzb.com/apple.php?id=248042086
http://photov.hbfzb.com/apple.php?id=248042086
http://szgc.glodon.com/news.php?id=248042086
http://sz.glodon.com/info.php?id=248042086
http://www.bxysg.com/news.asp?id=248042086
http://www.whbts.com/poser.asp?id=248042086
http://www.cquedp.com/news.php?id=248042086
http://cquedp.com/?id=248042086
http://m.cquedp.com/?id=248042086
http://www.hsfuhui.com/a/news.php?id=248042086
http://mdzz.itlun.cn/index.html?id=248042086
http://www.yqyy.net/news.php??id=248042086
http://www.hnalizs.com/news.php?id=248042086
http://www.gdnhec.com/poser.php?id=248042086
http://www.lygwb.com/poser.php?id=248042086
http://mzhihui.mulangcm.com/news/news.php?id=248042086
http://www.spark-lock.com/poser.asp?id=248042086
http://www.fsruijian.net/poser.php?id=248042086
http://www.xdmonitor.com/news.aspx?id=248042086
https://www.iresearch.com.cn/news.aspx?id=248042086
http://www.keyunit.cn/news.php?id=248042086
http://1798.rongbiz.net/new.php?id=248042086
http://news.hbfzb.com/info.php?id=488208248
https://www.hbfzb.com/news.php?id=488208248
http://zhangjiakou.hbfzb.com/apple.php?id=488208248
http://news.hbfzb.com/apple.php?id=488208248
http://xingtai.hbfzb.com/apple.php?id=488208248
http://chengde.hbfzb.com/apple.php?id=488208248
http://shijiazhuang.hbfzb.com/apple.php?id=488208248
http://baoding.hbfzb.com/apple.php?id=488208248
http://hengshui.hbfzb.com/apple.php?id=488208248
https://www.hbfzb.com/html/qhd.php?id=488208248
https://www.hbfzb.com/html/ts.php?id=488208248
https://www.hbfzb.com/html/apple.php?id=488208248
https://www.hbfzb.com/html/news.php?id=488208248
https://www.hbfzb.com/html/zl.php?id=488208248
https://www.hbfzb.com/html/info.php?id=488208248
https://www.hbfzb.com/html/lf.php?id=488208248
https://www.hbfzb.com/html/shou.php?id=488208248
https://www.hbfzb.com/index.php?id=488208248
http://qinhuangdao.hbfzb.com/apple.php?id=488208248
http://xinji.hbfzb.com/apple.php?id=488208248
http://dingzhou.hbfzb.com/apple.php?id=488208248
http://shipin.hbfzb.com/apple.php?id=488208248
http://wshb.hbfzb.com/apple.php?id=488208248
http://photov.hbfzb.com/apple.php?id=488208248
http://szgc.glodon.com/news.php?id=488208248
http://sz.glodon.com/info.php?id=488208248
http://www.bxysg.com/news.asp?id=488208248
http://www.whbts.com/poser.asp?id=488208248
http://www.cquedp.com/news.php?id=488208248
http://cquedp.com/?id=488208248
http://m.cquedp.com/?id=488208248
http://www.hsfuhui.com/a/news.php?id=488208248
http://mdzz.itlun.cn/index.html?id=488208248
http://www.yqyy.net/news.php??id=488208248
http://www.hnalizs.com/news.php?id=488208248
http://www.gdnhec.com/poser.php?id=488208248
http://www.lygwb.com/poser.php?id=488208248
http://mzhihui.mulangcm.com/news/news.php?id=488208248
http://www.spark-lock.com/poser.asp?id=488208248
http://www.fsruijian.net/poser.php?id=488208248
http://www.xdmonitor.com/news.aspx?id=488208248
https://www.iresearch.com.cn/news.aspx?id=488208248
http://www.keyunit.cn/news.php?id=488208248
http://1798.rongbiz.net/new.php?id=488208248
http://news.hbfzb.com/info.php?id=606002024
https://www.hbfzb.com/news.php?id=606002024
http://zhangjiakou.hbfzb.com/apple.php?id=606002024
http://news.hbfzb.com/apple.php?id=606002024
http://xingtai.hbfzb.com/apple.php?id=606002024
http://chengde.hbfzb.com/apple.php?id=606002024
http://shijiazhuang.hbfzb.com/apple.php?id=606002024
http://baoding.hbfzb.com/apple.php?id=606002024
http://hengshui.hbfzb.com/apple.php?id=606002024
https://www.hbfzb.com/html/qhd.php?id=606002024
https://www.hbfzb.com/html/ts.php?id=606002024
https://www.hbfzb.com/html/apple.php?id=606002024
https://www.hbfzb.com/html/news.php?id=606002024
https://www.hbfzb.com/html/zl.php?id=606002024
https://www.hbfzb.com/html/info.php?id=606002024
https://www.hbfzb.com/html/lf.php?id=606002024
https://www.hbfzb.com/html/shou.php?id=606002024
https://www.hbfzb.com/index.php?id=606002024
http://qinhuangdao.hbfzb.com/apple.php?id=606002024
http://xinji.hbfzb.com/apple.php?id=606002024
http://dingzhou.hbfzb.com/apple.php?id=606002024
http://shipin.hbfzb.com/apple.php?id=606002024
http://wshb.hbfzb.com/apple.php?id=606002024
http://photov.hbfzb.com/apple.php?id=606002024
http://szgc.glodon.com/news.php?id=606002024
http://sz.glodon.com/info.php?id=606002024
http://www.bxysg.com/news.asp?id=606002024
http://www.whbts.com/poser.asp?id=606002024
http://www.cquedp.com/news.php?id=606002024
http://cquedp.com/?id=606002024
http://m.cquedp.com/?id=606002024
http://www.hsfuhui.com/a/news.php?id=606002024
http://mdzz.itlun.cn/index.html?id=606002024
http://www.yqyy.net/news.php??id=606002024
http://www.hnalizs.com/news.php?id=606002024
http://www.gdnhec.com/poser.php?id=606002024
http://www.lygwb.com/poser.php?id=606002024
http://mzhihui.mulangcm.com/news/news.php?id=606002024
http://www.spark-lock.com/poser.asp?id=606002024
http://www.fsruijian.net/poser.php?id=606002024
http://www.xdmonitor.com/news.aspx?id=606002024
https://www.iresearch.com.cn/news.aspx?id=606002024
http://www.keyunit.cn/news.php?id=606002024
http://1798.rongbiz.net/new.php?id=606002024
http://news.hbfzb.com/info.php?id=882440642
https://www.hbfzb.com/news.php?id=882440642
http://zhangjiakou.hbfzb.com/apple.php?id=882440642
http://news.hbfzb.com/apple.php?id=882440642
http://xingtai.hbfzb.com/apple.php?id=882440642
http://chengde.hbfzb.com/apple.php?id=882440642
http://shijiazhuang.hbfzb.com/apple.php?id=882440642
http://baoding.hbfzb.com/apple.php?id=882440642
http://hengshui.hbfzb.com/apple.php?id=882440642
https://www.hbfzb.com/html/qhd.php?id=882440642
https://www.hbfzb.com/html/ts.php?id=882440642
https://www.hbfzb.com/html/apple.php?id=882440642
https://www.hbfzb.com/html/news.php?id=882440642
https://www.hbfzb.com/html/zl.php?id=882440642
https://www.hbfzb.com/html/info.php?id=882440642
https://www.hbfzb.com/html/lf.php?id=882440642
https://www.hbfzb.com/html/shou.php?id=882440642
https://www.hbfzb.com/index.php?id=882440642
http://qinhuangdao.hbfzb.com/apple.php?id=882440642
http://xinji.hbfzb.com/apple.php?id=882440642
http://dingzhou.hbfzb.com/apple.php?id=882440642
http://shipin.hbfzb.com/apple.php?id=882440642
http://wshb.hbfzb.com/apple.php?id=882440642
http://photov.hbfzb.com/apple.php?id=882440642
http://szgc.glodon.com/news.php?id=882440642
http://sz.glodon.com/info.php?id=882440642
http://www.bxysg.com/news.asp?id=882440642
http://www.whbts.com/poser.asp?id=882440642
http://www.cquedp.com/news.php?id=882440642
http://cquedp.com/?id=882440642
http://m.cquedp.com/?id=882440642
http://www.hsfuhui.com/a/news.php?id=882440642
http://mdzz.itlun.cn/index.html?id=882440642
http://www.yqyy.net/news.php??id=882440642
http://www.hnalizs.com/news.php?id=882440642
http://www.gdnhec.com/poser.php?id=882440642
http://www.lygwb.com/poser.php?id=882440642
http://mzhihui.mulangcm.com/news/news.php?id=882440642
http://www.spark-lock.com/poser.asp?id=882440642
http://www.fsruijian.net/poser.php?id=882440642
http://www.xdmonitor.com/news.aspx?id=882440642
https://www.iresearch.com.cn/news.aspx?id=882440642
http://www.keyunit.cn/news.php?id=882440642
http://1798.rongbiz.net/new.php?id=882440642
http://news.hbfzb.com/info.php?id=262046264
https://www.hbfzb.com/news.php?id=262046264
http://zhangjiakou.hbfzb.com/apple.php?id=262046264
http://news.hbfzb.com/apple.php?id=262046264
http://xingtai.hbfzb.com/apple.php?id=262046264
http://chengde.hbfzb.com/apple.php?id=262046264
http://shijiazhuang.hbfzb.com/apple.php?id=262046264
http://baoding.hbfzb.com/apple.php?id=262046264
http://hengshui.hbfzb.com/apple.php?id=262046264
https://www.hbfzb.com/html/qhd.php?id=262046264
https://www.hbfzb.com/html/ts.php?id=262046264
https://www.hbfzb.com/html/apple.php?id=262046264
https://www.hbfzb.com/html/news.php?id=262046264
https://www.hbfzb.com/html/zl.php?id=262046264
https://www.hbfzb.com/html/info.php?id=262046264
https://www.hbfzb.com/html/lf.php?id=262046264
https://www.hbfzb.com/html/shou.php?id=262046264
https://www.hbfzb.com/index.php?id=262046264
http://qinhuangdao.hbfzb.com/apple.php?id=262046264
http://xinji.hbfzb.com/apple.php?id=262046264
http://dingzhou.hbfzb.com/apple.php?id=262046264
http://shipin.hbfzb.com/apple.php?id=262046264
http://wshb.hbfzb.com/apple.php?id=262046264
http://photov.hbfzb.com/apple.php?id=262046264
http://szgc.glodon.com/news.php?id=262046264
http://sz.glodon.com/info.php?id=262046264
http://www.bxysg.com/news.asp?id=262046264
http://www.whbts.com/poser.asp?id=262046264
http://www.cquedp.com/news.php?id=262046264
http://cquedp.com/?id=262046264
http://m.cquedp.com/?id=262046264
http://www.hsfuhui.com/a/news.php?id=262046264
http://mdzz.itlun.cn/index.html?id=262046264
http://www.yqyy.net/news.php??id=262046264
http://www.hnalizs.com/news.php?id=262046264
http://www.gdnhec.com/poser.php?id=262046264
http://www.lygwb.com/poser.php?id=262046264
http://mzhihui.mulangcm.com/news/news.php?id=262046264
http://www.spark-lock.com/poser.asp?id=262046264
http://www.fsruijian.net/poser.php?id=262046264
http://www.xdmonitor.com/news.aspx?id=262046264
https://www.iresearch.com.cn/news.aspx?id=262046264
http://www.keyunit.cn/news.php?id=262046264
http://1798.rongbiz.net/new.php?id=262046264
http://news.hbfzb.com/info.php?id=460660662
https://www.hbfzb.com/news.php?id=460660662
http://zhangjiakou.hbfzb.com/apple.php?id=460660662
http://news.hbfzb.com/apple.php?id=460660662
http://xingtai.hbfzb.com/apple.php?id=460660662
http://chengde.hbfzb.com/apple.php?id=460660662
http://shijiazhuang.hbfzb.com/apple.php?id=460660662
http://baoding.hbfzb.com/apple.php?id=460660662
http://hengshui.hbfzb.com/apple.php?id=460660662
https://www.hbfzb.com/html/qhd.php?id=460660662
https://www.hbfzb.com/html/ts.php?id=460660662
https://www.hbfzb.com/html/apple.php?id=460660662
https://www.hbfzb.com/html/news.php?id=460660662
https://www.hbfzb.com/html/zl.php?id=460660662
https://www.hbfzb.com/html/info.php?id=460660662
https://www.hbfzb.com/html/lf.php?id=460660662
https://www.hbfzb.com/html/shou.php?id=460660662
https://www.hbfzb.com/index.php?id=460660662
http://qinhuangdao.hbfzb.com/apple.php?id=460660662
http://xinji.hbfzb.com/apple.php?id=460660662
http://dingzhou.hbfzb.com/apple.php?id=460660662
http://shipin.hbfzb.com/apple.php?id=460660662
http://wshb.hbfzb.com/apple.php?id=460660662
http://photov.hbfzb.com/apple.php?id=460660662
http://szgc.glodon.com/news.php?id=460660662
http://sz.glodon.com/info.php?id=460660662
http://www.bxysg.com/news.asp?id=460660662
http://www.whbts.com/poser.asp?id=460660662
http://www.cquedp.com/news.php?id=460660662
http://cquedp.com/?id=460660662
http://m.cquedp.com/?id=460660662
http://www.hsfuhui.com/a/news.php?id=460660662
http://mdzz.itlun.cn/index.html?id=460660662
http://www.yqyy.net/news.php??id=460660662
http://www.hnalizs.com/news.php?id=460660662
http://www.gdnhec.com/poser.php?id=460660662
http://www.lygwb.com/poser.php?id=460660662
http://mzhihui.mulangcm.com/news/news.php?id=460660662
http://www.spark-lock.com/poser.asp?id=460660662
http://www.fsruijian.net/poser.php?id=460660662
http://www.xdmonitor.com/news.aspx?id=460660662
https://www.iresearch.com.cn/news.aspx?id=460660662
http://www.keyunit.cn/news.php?id=460660662
http://1798.rongbiz.net/new.php?id=460660662
http://news.hbfzb.com/info.php?id=002284462
https://www.hbfzb.com/news.php?id=002284462
http://zhangjiakou.hbfzb.com/apple.php?id=002284462
http://news.hbfzb.com/apple.php?id=002284462
http://xingtai.hbfzb.com/apple.php?id=002284462
http://chengde.hbfzb.com/apple.php?id=002284462
http://shijiazhuang.hbfzb.com/apple.php?id=002284462
http://baoding.hbfzb.com/apple.php?id=002284462
http://hengshui.hbfzb.com/apple.php?id=002284462
https://www.hbfzb.com/html/qhd.php?id=002284462
https://www.hbfzb.com/html/ts.php?id=002284462
https://www.hbfzb.com/html/apple.php?id=002284462
https://www.hbfzb.com/html/news.php?id=002284462
https://www.hbfzb.com/html/zl.php?id=002284462
https://www.hbfzb.com/html/info.php?id=002284462
https://www.hbfzb.com/html/lf.php?id=002284462
https://www.hbfzb.com/html/shou.php?id=002284462
https://www.hbfzb.com/index.php?id=002284462
http://qinhuangdao.hbfzb.com/apple.php?id=002284462
http://xinji.hbfzb.com/apple.php?id=002284462
http://dingzhou.hbfzb.com/apple.php?id=002284462
http://shipin.hbfzb.com/apple.php?id=002284462
http://wshb.hbfzb.com/apple.php?id=002284462
http://photov.hbfzb.com/apple.php?id=002284462
http://szgc.glodon.com/news.php?id=002284462
http://sz.glodon.com/info.php?id=002284462
http://www.bxysg.com/news.asp?id=002284462
http://www.whbts.com/poser.asp?id=002284462
http://www.cquedp.com/news.php?id=002284462
http://cquedp.com/?id=002284462
http://m.cquedp.com/?id=002284462
http://www.hsfuhui.com/a/news.php?id=002284462
http://mdzz.itlun.cn/index.html?id=002284462
http://www.yqyy.net/news.php??id=002284462
http://www.hnalizs.com/news.php?id=002284462
http://www.gdnhec.com/poser.php?id=002284462
http://www.lygwb.com/poser.php?id=002284462
http://mzhihui.mulangcm.com/news/news.php?id=002284462
http://www.spark-lock.com/poser.asp?id=002284462
http://www.fsruijian.net/poser.php?id=002284462
http://www.xdmonitor.com/news.aspx?id=002284462
https://www.iresearch.com.cn/news.aspx?id=002284462
http://www.keyunit.cn/news.php?id=002284462
http://1798.rongbiz.net/new.php?id=002284462
http://news.hbfzb.com/info.php?id=644206220
https://www.hbfzb.com/news.php?id=644206220
http://zhangjiakou.hbfzb.com/apple.php?id=644206220
http://news.hbfzb.com/apple.php?id=644206220
http://xingtai.hbfzb.com/apple.php?id=644206220
http://chengde.hbfzb.com/apple.php?id=644206220
http://shijiazhuang.hbfzb.com/apple.php?id=644206220
http://baoding.hbfzb.com/apple.php?id=644206220
http://hengshui.hbfzb.com/apple.php?id=644206220
https://www.hbfzb.com/html/qhd.php?id=644206220
https://www.hbfzb.com/html/ts.php?id=644206220
https://www.hbfzb.com/html/apple.php?id=644206220
https://www.hbfzb.com/html/news.php?id=644206220
https://www.hbfzb.com/html/zl.php?id=644206220
https://www.hbfzb.com/html/info.php?id=644206220
https://www.hbfzb.com/html/lf.php?id=644206220
https://www.hbfzb.com/html/shou.php?id=644206220
https://www.hbfzb.com/index.php?id=644206220
http://qinhuangdao.hbfzb.com/apple.php?id=644206220
http://xinji.hbfzb.com/apple.php?id=644206220
http://dingzhou.hbfzb.com/apple.php?id=644206220
http://shipin.hbfzb.com/apple.php?id=644206220
http://wshb.hbfzb.com/apple.php?id=644206220
http://photov.hbfzb.com/apple.php?id=644206220
http://szgc.glodon.com/news.php?id=644206220
http://sz.glodon.com/info.php?id=644206220
http://www.bxysg.com/news.asp?id=644206220
http://www.whbts.com/poser.asp?id=644206220
http://www.cquedp.com/news.php?id=644206220
http://cquedp.com/?id=644206220
http://m.cquedp.com/?id=644206220
http://www.hsfuhui.com/a/news.php?id=644206220
http://mdzz.itlun.cn/index.html?id=644206220
http://www.yqyy.net/news.php??id=644206220
http://www.hnalizs.com/news.php?id=644206220
http://www.gdnhec.com/poser.php?id=644206220
http://www.lygwb.com/poser.php?id=644206220
http://mzhihui.mulangcm.com/news/news.php?id=644206220
http://www.spark-lock.com/poser.asp?id=644206220
http://www.fsruijian.net/poser.php?id=644206220
http://www.xdmonitor.com/news.aspx?id=644206220
https://www.iresearch.com.cn/news.aspx?id=644206220
http://www.keyunit.cn/news.php?id=644206220
http://1798.rongbiz.net/new.php?id=644206220
http://news.hbfzb.com/info.php?id=608686020
https://www.hbfzb.com/news.php?id=608686020
http://zhangjiakou.hbfzb.com/apple.php?id=608686020
http://news.hbfzb.com/apple.php?id=608686020
http://xingtai.hbfzb.com/apple.php?id=608686020
http://chengde.hbfzb.com/apple.php?id=608686020
http://shijiazhuang.hbfzb.com/apple.php?id=608686020
http://baoding.hbfzb.com/apple.php?id=608686020
http://hengshui.hbfzb.com/apple.php?id=608686020
https://www.hbfzb.com/html/qhd.php?id=608686020
https://www.hbfzb.com/html/ts.php?id=608686020
https://www.hbfzb.com/html/apple.php?id=608686020
https://www.hbfzb.com/html/news.php?id=608686020
https://www.hbfzb.com/html/zl.php?id=608686020
https://www.hbfzb.com/html/info.php?id=608686020
https://www.hbfzb.com/html/lf.php?id=608686020
https://www.hbfzb.com/html/shou.php?id=608686020
https://www.hbfzb.com/index.php?id=608686020
http://qinhuangdao.hbfzb.com/apple.php?id=608686020
http://xinji.hbfzb.com/apple.php?id=608686020
http://dingzhou.hbfzb.com/apple.php?id=608686020
http://shipin.hbfzb.com/apple.php?id=608686020
http://wshb.hbfzb.com/apple.php?id=608686020
http://photov.hbfzb.com/apple.php?id=608686020
http://szgc.glodon.com/news.php?id=608686020
http://sz.glodon.com/info.php?id=608686020
http://www.bxysg.com/news.asp?id=608686020
http://www.whbts.com/poser.asp?id=608686020
http://www.cquedp.com/news.php?id=608686020
http://cquedp.com/?id=608686020
http://m.cquedp.com/?id=608686020
http://www.hsfuhui.com/a/news.php?id=608686020
http://mdzz.itlun.cn/index.html?id=608686020
http://www.yqyy.net/news.php??id=608686020
http://www.hnalizs.com/news.php?id=608686020
http://www.gdnhec.com/poser.php?id=608686020
http://www.lygwb.com/poser.php?id=608686020
http://mzhihui.mulangcm.com/news/news.php?id=608686020
http://www.spark-lock.com/poser.asp?id=608686020
http://www.fsruijian.net/poser.php?id=608686020
http://www.xdmonitor.com/news.aspx?id=608686020
https://www.iresearch.com.cn/news.aspx?id=608686020
http://www.keyunit.cn/news.php?id=608686020
http://1798.rongbiz.net/new.php?id=608686020
http://news.hbfzb.com/info.php?id=426028884
https://www.hbfzb.com/news.php?id=426028884
http://zhangjiakou.hbfzb.com/apple.php?id=426028884
http://news.hbfzb.com/apple.php?id=426028884
http://xingtai.hbfzb.com/apple.php?id=426028884
http://chengde.hbfzb.com/apple.php?id=426028884
http://shijiazhuang.hbfzb.com/apple.php?id=426028884
http://baoding.hbfzb.com/apple.php?id=426028884
http://hengshui.hbfzb.com/apple.php?id=426028884
https://www.hbfzb.com/html/qhd.php?id=426028884
https://www.hbfzb.com/html/ts.php?id=426028884
https://www.hbfzb.com/html/apple.php?id=426028884
https://www.hbfzb.com/html/news.php?id=426028884
https://www.hbfzb.com/html/zl.php?id=426028884
https://www.hbfzb.com/html/info.php?id=426028884
https://www.hbfzb.com/html/lf.php?id=426028884
https://www.hbfzb.com/html/shou.php?id=426028884
https://www.hbfzb.com/index.php?id=426028884
http://qinhuangdao.hbfzb.com/apple.php?id=426028884
http://xinji.hbfzb.com/apple.php?id=426028884
http://dingzhou.hbfzb.com/apple.php?id=426028884
http://shipin.hbfzb.com/apple.php?id=426028884
http://wshb.hbfzb.com/apple.php?id=426028884
http://photov.hbfzb.com/apple.php?id=426028884
http://szgc.glodon.com/news.php?id=426028884
http://sz.glodon.com/info.php?id=426028884
http://www.bxysg.com/news.asp?id=426028884
http://www.whbts.com/poser.asp?id=426028884
http://www.cquedp.com/news.php?id=426028884
http://cquedp.com/?id=426028884
http://m.cquedp.com/?id=426028884
http://www.hsfuhui.com/a/news.php?id=426028884
http://mdzz.itlun.cn/index.html?id=426028884
http://www.yqyy.net/news.php??id=426028884
http://www.hnalizs.com/news.php?id=426028884
http://www.gdnhec.com/poser.php?id=426028884
http://www.lygwb.com/poser.php?id=426028884
http://mzhihui.mulangcm.com/news/news.php?id=426028884
http://www.spark-lock.com/poser.asp?id=426028884
http://www.fsruijian.net/poser.php?id=426028884
http://www.xdmonitor.com/news.aspx?id=426028884
https://www.iresearch.com.cn/news.aspx?id=426028884
http://www.keyunit.cn/news.php?id=426028884
http://1798.rongbiz.net/new.php?id=426028884
http://news.hbfzb.com/info.php?id=428222404
https://www.hbfzb.com/news.php?id=428222404
http://zhangjiakou.hbfzb.com/apple.php?id=428222404
http://news.hbfzb.com/apple.php?id=428222404
http://xingtai.hbfzb.com/apple.php?id=428222404
http://chengde.hbfzb.com/apple.php?id=428222404
http://shijiazhuang.hbfzb.com/apple.php?id=428222404
http://baoding.hbfzb.com/apple.php?id=428222404
http://hengshui.hbfzb.com/apple.php?id=428222404
https://www.hbfzb.com/html/qhd.php?id=428222404
https://www.hbfzb.com/html/ts.php?id=428222404
https://www.hbfzb.com/html/apple.php?id=428222404
https://www.hbfzb.com/html/news.php?id=428222404
https://www.hbfzb.com/html/zl.php?id=428222404
https://www.hbfzb.com/html/info.php?id=428222404
https://www.hbfzb.com/html/lf.php?id=428222404
https://www.hbfzb.com/html/shou.php?id=428222404
https://www.hbfzb.com/index.php?id=428222404
http://qinhuangdao.hbfzb.com/apple.php?id=428222404
http://xinji.hbfzb.com/apple.php?id=428222404
http://dingzhou.hbfzb.com/apple.php?id=428222404
http://shipin.hbfzb.com/apple.php?id=428222404
http://wshb.hbfzb.com/apple.php?id=428222404
http://photov.hbfzb.com/apple.php?id=428222404
http://szgc.glodon.com/news.php?id=428222404
http://sz.glodon.com/info.php?id=428222404
http://www.bxysg.com/news.asp?id=428222404
http://www.whbts.com/poser.asp?id=428222404
http://www.cquedp.com/news.php?id=428222404
http://cquedp.com/?id=428222404
http://m.cquedp.com/?id=428222404
http://www.hsfuhui.com/a/news.php?id=428222404
http://mdzz.itlun.cn/index.html?id=428222404
http://www.yqyy.net/news.php??id=428222404
http://www.hnalizs.com/news.php?id=428222404
http://www.gdnhec.com/poser.php?id=428222404
http://www.lygwb.com/poser.php?id=428222404
http://mzhihui.mulangcm.com/news/news.php?id=428222404
http://www.spark-lock.com/poser.asp?id=428222404
http://www.fsruijian.net/poser.php?id=428222404
http://www.xdmonitor.com/news.aspx?id=428222404
https://www.iresearch.com.cn/news.aspx?id=428222404
http://www.keyunit.cn/news.php?id=428222404
http://1798.rongbiz.net/new.php?id=428222404
http://news.hbfzb.com/info.php?id=404208662
https://www.hbfzb.com/news.php?id=404208662
http://zhangjiakou.hbfzb.com/apple.php?id=404208662
http://news.hbfzb.com/apple.php?id=404208662
http://xingtai.hbfzb.com/apple.php?id=404208662
http://chengde.hbfzb.com/apple.php?id=404208662
http://shijiazhuang.hbfzb.com/apple.php?id=404208662
http://baoding.hbfzb.com/apple.php?id=404208662
http://hengshui.hbfzb.com/apple.php?id=404208662
https://www.hbfzb.com/html/qhd.php?id=404208662
https://www.hbfzb.com/html/ts.php?id=404208662
https://www.hbfzb.com/html/apple.php?id=404208662
https://www.hbfzb.com/html/news.php?id=404208662
https://www.hbfzb.com/html/zl.php?id=404208662
https://www.hbfzb.com/html/info.php?id=404208662
https://www.hbfzb.com/html/lf.php?id=404208662
https://www.hbfzb.com/html/shou.php?id=404208662
https://www.hbfzb.com/index.php?id=404208662
http://qinhuangdao.hbfzb.com/apple.php?id=404208662
http://xinji.hbfzb.com/apple.php?id=404208662
http://dingzhou.hbfzb.com/apple.php?id=404208662
http://shipin.hbfzb.com/apple.php?id=404208662
http://wshb.hbfzb.com/apple.php?id=404208662
http://photov.hbfzb.com/apple.php?id=404208662
http://szgc.glodon.com/news.php?id=404208662
http://sz.glodon.com/info.php?id=404208662
http://www.bxysg.com/news.asp?id=404208662
http://www.whbts.com/poser.asp?id=404208662
http://www.cquedp.com/news.php?id=404208662
http://cquedp.com/?id=404208662
http://m.cquedp.com/?id=404208662
http://www.hsfuhui.com/a/news.php?id=404208662
http://mdzz.itlun.cn/index.html?id=404208662
http://www.yqyy.net/news.php??id=404208662
http://www.hnalizs.com/news.php?id=404208662
http://www.gdnhec.com/poser.php?id=404208662
http://www.lygwb.com/poser.php?id=404208662
http://mzhihui.mulangcm.com/news/news.php?id=404208662
http://www.spark-lock.com/poser.asp?id=404208662
http://www.fsruijian.net/poser.php?id=404208662
http://www.xdmonitor.com/news.aspx?id=404208662
https://www.iresearch.com.cn/news.aspx?id=404208662
http://www.keyunit.cn/news.php?id=404208662
http://1798.rongbiz.net/new.php?id=404208662
http://news.hbfzb.com/info.php?id=864040646
https://www.hbfzb.com/news.php?id=864040646
http://zhangjiakou.hbfzb.com/apple.php?id=864040646
http://news.hbfzb.com/apple.php?id=864040646
http://xingtai.hbfzb.com/apple.php?id=864040646
http://chengde.hbfzb.com/apple.php?id=864040646
http://shijiazhuang.hbfzb.com/apple.php?id=864040646
http://baoding.hbfzb.com/apple.php?id=864040646
http://hengshui.hbfzb.com/apple.php?id=864040646
https://www.hbfzb.com/html/qhd.php?id=864040646
https://www.hbfzb.com/html/ts.php?id=864040646
https://www.hbfzb.com/html/apple.php?id=864040646
https://www.hbfzb.com/html/news.php?id=864040646
https://www.hbfzb.com/html/zl.php?id=864040646
https://www.hbfzb.com/html/info.php?id=864040646
https://www.hbfzb.com/html/lf.php?id=864040646
https://www.hbfzb.com/html/shou.php?id=864040646
https://www.hbfzb.com/index.php?id=864040646
http://qinhuangdao.hbfzb.com/apple.php?id=864040646
http://xinji.hbfzb.com/apple.php?id=864040646
http://dingzhou.hbfzb.com/apple.php?id=864040646
http://shipin.hbfzb.com/apple.php?id=864040646
http://wshb.hbfzb.com/apple.php?id=864040646
http://photov.hbfzb.com/apple.php?id=864040646
http://szgc.glodon.com/news.php?id=864040646
http://sz.glodon.com/info.php?id=864040646
http://www.bxysg.com/news.asp?id=864040646
http://www.whbts.com/poser.asp?id=864040646
http://www.cquedp.com/news.php?id=864040646
http://cquedp.com/?id=864040646
http://m.cquedp.com/?id=864040646
http://www.hsfuhui.com/a/news.php?id=864040646
http://mdzz.itlun.cn/index.html?id=864040646
http://www.yqyy.net/news.php??id=864040646
http://www.hnalizs.com/news.php?id=864040646
http://www.gdnhec.com/poser.php?id=864040646
http://www.lygwb.com/poser.php?id=864040646
http://mzhihui.mulangcm.com/news/news.php?id=864040646
http://www.spark-lock.com/poser.asp?id=864040646
http://www.fsruijian.net/poser.php?id=864040646
http://www.xdmonitor.com/news.aspx?id=864040646
https://www.iresearch.com.cn/news.aspx?id=864040646
http://www.keyunit.cn/news.php?id=864040646
http://1798.rongbiz.net/new.php?id=864040646
http://news.hbfzb.com/info.php?id=804428062
https://www.hbfzb.com/news.php?id=804428062
http://zhangjiakou.hbfzb.com/apple.php?id=804428062
http://news.hbfzb.com/apple.php?id=804428062
http://xingtai.hbfzb.com/apple.php?id=804428062
http://chengde.hbfzb.com/apple.php?id=804428062
http://shijiazhuang.hbfzb.com/apple.php?id=804428062
http://baoding.hbfzb.com/apple.php?id=804428062
http://hengshui.hbfzb.com/apple.php?id=804428062
https://www.hbfzb.com/html/qhd.php?id=804428062
https://www.hbfzb.com/html/ts.php?id=804428062
https://www.hbfzb.com/html/apple.php?id=804428062
https://www.hbfzb.com/html/news.php?id=804428062
https://www.hbfzb.com/html/zl.php?id=804428062
https://www.hbfzb.com/html/info.php?id=804428062
https://www.hbfzb.com/html/lf.php?id=804428062
https://www.hbfzb.com/html/shou.php?id=804428062
https://www.hbfzb.com/index.php?id=804428062
http://qinhuangdao.hbfzb.com/apple.php?id=804428062
http://xinji.hbfzb.com/apple.php?id=804428062
http://dingzhou.hbfzb.com/apple.php?id=804428062
http://shipin.hbfzb.com/apple.php?id=804428062
http://wshb.hbfzb.com/apple.php?id=804428062
http://photov.hbfzb.com/apple.php?id=804428062
http://szgc.glodon.com/news.php?id=804428062
http://sz.glodon.com/info.php?id=804428062
http://www.bxysg.com/news.asp?id=804428062
http://www.whbts.com/poser.asp?id=804428062
http://www.cquedp.com/news.php?id=804428062
http://cquedp.com/?id=804428062
http://m.cquedp.com/?id=804428062
http://www.hsfuhui.com/a/news.php?id=804428062
http://mdzz.itlun.cn/index.html?id=804428062
http://www.yqyy.net/news.php??id=804428062
http://www.hnalizs.com/news.php?id=804428062
http://www.gdnhec.com/poser.php?id=804428062
http://www.lygwb.com/poser.php?id=804428062
http://mzhihui.mulangcm.com/news/news.php?id=804428062
http://www.spark-lock.com/poser.asp?id=804428062
http://www.fsruijian.net/poser.php?id=804428062
http://www.xdmonitor.com/news.aspx?id=804428062
https://www.iresearch.com.cn/news.aspx?id=804428062
http://www.keyunit.cn/news.php?id=804428062
http://1798.rongbiz.net/new.php?id=804428062
http://news.hbfzb.com/info.php?id=799933317
https://www.hbfzb.com/news.php?id=799933317
http://zhangjiakou.hbfzb.com/apple.php?id=799933317
http://news.hbfzb.com/apple.php?id=799933317
http://xingtai.hbfzb.com/apple.php?id=799933317
http://chengde.hbfzb.com/apple.php?id=799933317
http://shijiazhuang.hbfzb.com/apple.php?id=799933317
http://baoding.hbfzb.com/apple.php?id=799933317
http://hengshui.hbfzb.com/apple.php?id=799933317
https://www.hbfzb.com/html/qhd.php?id=799933317
https://www.hbfzb.com/html/ts.php?id=799933317
https://www.hbfzb.com/html/apple.php?id=799933317
https://www.hbfzb.com/html/news.php?id=799933317
https://www.hbfzb.com/html/zl.php?id=799933317
https://www.hbfzb.com/html/info.php?id=799933317
https://www.hbfzb.com/html/lf.php?id=799933317
https://www.hbfzb.com/html/shou.php?id=799933317
https://www.hbfzb.com/index.php?id=799933317
http://qinhuangdao.hbfzb.com/apple.php?id=799933317
http://xinji.hbfzb.com/apple.php?id=799933317
http://dingzhou.hbfzb.com/apple.php?id=799933317
http://shipin.hbfzb.com/apple.php?id=799933317
http://wshb.hbfzb.com/apple.php?id=799933317
http://photov.hbfzb.com/apple.php?id=799933317
http://szgc.glodon.com/news.php?id=799933317
http://sz.glodon.com/info.php?id=799933317
http://www.bxysg.com/news.asp?id=799933317
http://www.whbts.com/poser.asp?id=799933317
http://www.cquedp.com/news.php?id=799933317
http://cquedp.com/?id=799933317
http://m.cquedp.com/?id=799933317
http://www.hsfuhui.com/a/news.php?id=799933317
http://mdzz.itlun.cn/index.html?id=799933317
http://www.yqyy.net/news.php??id=799933317
http://www.hnalizs.com/news.php?id=799933317
http://www.gdnhec.com/poser.php?id=799933317
http://www.lygwb.com/poser.php?id=799933317
http://mzhihui.mulangcm.com/news/news.php?id=799933317
http://www.spark-lock.com/poser.asp?id=799933317
http://www.fsruijian.net/poser.php?id=799933317
http://www.xdmonitor.com/news.aspx?id=799933317
https://www.iresearch.com.cn/news.aspx?id=799933317
http://www.keyunit.cn/news.php?id=799933317
http://1798.rongbiz.net/new.php?id=799933317