123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230 |
- # -*- coding: utf-8 -*-
- import os
- import sys
- root_dir = os.path.dirname(os.path.dirname(os.path.realpath(__file__)))
- if root_dir not in sys.path:
- sys.path.append(root_dir)
- print("******** sys.path ********")
- print(sys.path)
- from multiprocessing import Process
- from odps import ODPS
- import threading
- from my_utils import RedisHelper, execute_sql_from_odps
- from my_config import set_config
- from log import Log
- import json
- from datetime import datetime, timedelta
- from queue import Queue
- from tqdm import tqdm
- import time
- config_, _ = set_config()
- log_ = Log()
- redis_helper = RedisHelper()
- REDIS_PREFIX = "item_rt_fea_1h_"
- EXPIRE_TIME = 24 * 3600
- TIME_LIMIT_TABLE = 40
- TIME_LIMIT_TASK = 60
- def worker(queue, executor):
- while True:
- row = queue.get()
- if row is None: # 结束信号
- queue.task_done()
- break
- executor(row)
- queue.task_done()
- def records_process_for_list(records, executor, max_size=50, num_workers=10):
- # 创建一个线程安全的队列
- queue = Queue(maxsize=max_size) # 可以调整 maxsize 以控制内存使用
- # 设置线程池大小
- num_workers = num_workers
- # 启动工作线程
- threads = []
- for _ in range(num_workers):
- t = threading.Thread(target=worker, args=(queue, executor))
- t.start()
- threads.append(t)
- # 读取数据并放入队列
- for row in tqdm(records):
- queue.put(row)
- # 发送结束信号
- for _ in range(num_workers):
- queue.put(None)
- # 等待所有任务完成
- queue.join()
- # 等待所有工作线程结束
- for t in threads:
- t.join()
- def process_and_store(row):
- table_key, json_str = row
- key = REDIS_PREFIX + str(table_key)
- expire_time = EXPIRE_TIME
- redis_helper.set_data_to_redis(key, json_str, expire_time)
- def check_data(project, table, partition) -> int:
- """检查数据是否准备好,输出数据条数"""
- odps = ODPS(
- access_id=config_.ODPS_CONFIG['ACCESSID'],
- secret_access_key=config_.ODPS_CONFIG['ACCESSKEY'],
- project=project,
- endpoint=config_.ODPS_CONFIG['ENDPOINT'],
- connect_timeout=3000,
- read_timeout=500000,
- pool_maxsize=1000,
- pool_connections=1000
- )
- try:
- t = odps.get_table(name=table)
- log_.info(f"检查分区是否存在-【 dt={partition} 】")
- check_res = t.exist_partition(partition_spec=f'dt={partition}')
- if check_res:
- sql = f'select * from {project}.{table} where dt = {partition}'
- log_.info(sql)
- with odps.execute_sql(sql=sql).open_reader() as reader:
- data_count = reader.count
- else:
- log_.info("表{}分区{}不存在".format(table, partition))
- data_count = 0
- except Exception as e:
- log_.error("table:{},partition:{} no data. return data_count=0,报错原因是:{}".format(table, partition, e))
- data_count = 0
- return data_count
- def get_sql(date, previous_date_str, project):
- sql = '''
- SELECT videoid
- ,CONCAT_WS(',',COLLECT_LIST(CONCAT(dt,":",view_uv))) AS view_uv_list_1h
- ,CONCAT_WS(',',COLLECT_LIST(CONCAT(dt,":",view_pv))) AS view_pv_list_1h
- ,CONCAT_WS(',',COLLECT_LIST(CONCAT(dt,":",play_uv))) AS play_uv_list_1h
- ,CONCAT_WS(',',COLLECT_LIST(CONCAT(dt,":",play_pv))) AS play_pv_list_1h
- ,CONCAT_WS(',',COLLECT_LIST(CONCAT(dt,":",share_uv))) AS share_uv_list_1h
- ,CONCAT_WS(',',COLLECT_LIST(CONCAT(dt,":",share_pv))) AS share_pv_list_1h
- ,CONCAT_WS(',',COLLECT_LIST(CONCAT(dt,":",return_uv))) AS return_uv_list_1h
- ,CONCAT_WS(',',COLLECT_LIST(CONCAT(dt,":",p_return_uv))) AS p_return_uv_list_1h
- FROM (
- SELECT videoid
- ,dt
- ,SUM(lastonehour_view) AS view_uv
- ,SUM(lastonehour_view_total) AS view_pv
- ,SUM(lastonehour_play) AS play_uv
- ,SUM(lastonehour_play_total) AS play_pv
- ,SUM(lastonehour_share) AS share_uv
- ,SUM(lastonehour_share_total) AS share_pv
- ,SUM(lastonehour_return) AS return_uv
- ,SUM(platform_return) AS p_return_uv
- FROM loghubods.video_each_hour_update_no_province_apptype
- WHERE dt <= '{}23'
- AND dt >= '{}00'
- GROUP BY videoid
- ,dt
- )
- GROUP BY videoid
- '''.format(date, previous_date_str)
- print("sql:" + sql)
- records = execute_sql_from_odps(project=project, sql=sql)
- video_list = []
- with records.open_reader() as reader:
- for record in reader:
- video_id = record['videoid']
- m = dict()
- try:
- m["view_uv_list_1h"] = record['view_uv_list_1h']
- except Exception as e:
- log_.error(e)
- try:
- m["view_pv_list_1h"] = record['view_pv_list_1h']
- except Exception as e:
- log_.error(e)
- try:
- m["play_uv_list_1h"] = record['play_uv_list_1h']
- except Exception as e:
- log_.error(e)
- try:
- m["play_pv_list_1h"] = record['play_pv_list_1h']
- except Exception as e:
- log_.error(e)
- try:
- m["share_uv_list_1h"] = record['share_uv_list_1h']
- except Exception as e:
- log_.error(e)
- try:
- m["share_pv_list_1h"] = record['share_pv_list_1h']
- except Exception as e:
- log_.error(e)
- try:
- m["return_uv_list_1h"] = record['return_uv_list_1h']
- except Exception as e:
- log_.error(e)
- try:
- m["p_return_uv_list_1h"] = record['p_return_uv_list_1h']
- except Exception as e:
- log_.error(e)
- json_str = json.dumps(m)
- video_list.append([video_id, json_str])
- return video_list
- def main():
- try:
- date = sys.argv[1]
- hour = sys.argv[2]
- except Exception as e:
- date = datetime.now().strftime('%Y%m%d')
- hour = datetime.now().hour
- log_.info("没有读取到参数,采用系统时间: {}".format(e))
- log_.info("使用时间参数-日期:{},小时:{}".format(date, str(hour)))
- if hour in []:
- log_.info(f"hour={hour}不执行,直接返回。")
- return
- # 1 判断上游数据表是否生产完成
- project = "loghubods"
- table = "video_each_hour_update_no_province_apptype"
- partition = str(date) + str(hour)
- run_flag = True
- begin_ts = int(time.time())
- table_data_cnt = 0
- while run_flag:
- if int(time.time()) - begin_ts >= 60 * TIME_LIMIT_TABLE:
- log_.info("等待上游数据超过40分钟了,认为失败退出:过了{}秒。".format(int(time.time()) - begin_ts))
- sys.exit(1)
- table_data_cnt = check_data(project, table, partition)
- if table_data_cnt == 0:
- log_.info("上游数据{}未就绪{}/{},等待...".format(table, date, hour))
- log_.info("等待2分钟")
- time.sleep(60 * 2)
- else:
- run_flag = False
- log_.info("上游数据就绪,count={},开始读取数据表".format(table_data_cnt))
- # 2 读取数据表 处理特征
- previous_date_str = (datetime.strptime(date, "%Y%m%d") - timedelta(days=1)).strftime("%Y%m%d")
- video_list = get_sql(date, previous_date_str, project)
- # 3 写入redis
- records_process_for_list(video_list, process_and_store, max_size=50, num_workers=8)
- redis_helper.set_data_to_redis(REDIS_PREFIX + "partition", partition, 24 * 3600)
- if __name__ == '__main__':
- log_.info("开始执行:" + datetime.now().strftime("%Y-%m-%d %H:%M:%S"))
- process = Process(target=main)
- process.start()
- # 等待子进程完成或超时
- timeout = 60 * TIME_LIMIT_TASK
- process.join(timeout=timeout) # 设置超时为3600秒(1小时)
- if process.is_alive():
- print("脚本执行时间超过1小时,执行失败,经过了{}秒。".format(timeout))
- process.terminate() # 终止子进程
- sys.exit(1) # 直接退出主进程并返回状态码999
- log_.info("完成执行:" + datetime.now().strftime("%Y-%m-%d %H:%M:%S"))
- # cd /root/zhangbo/rov-offline
- # python alg_recsys_rank_item_realtime_1h.py 20240702 14
|