python --定时任务

官文

https://apscheduler.readthedocs.io/en/stable/versionhistory.html

装包

pip install APScheduler==2.1.2  (新版不好使)

根据时间间隔执行

from apscheduler.scheduler import Scheduler

sched = Scheduler()  # 实例化

@sched.interval_schedule(seconds=180)  # 时间间隔
def my_task1():
	print('定时任务1开始\n')
	print('定时任务1结束\n')
sched.start()

定时执行

@sched.cron_schedule(hour=23, minute=59)  # 执行的时间
def recovery_send_mes():
    # 恢复今日发送状态
    print('触发')
    user = User.objects.filter(today_mes_is_status='是')
    if user:
        with open(f'{BASE_DIR}/media/recovery.txt', 'a+', encoding='utf-8') as f:
            for i in user:
                i.today_mes_is_status = '否'
                i.save()
                f.write(time.strftime('%Y-%m-%d %H:%M:%S'))
                f.write('\n')
sched.start()

附录

while循环中使用sleep
缺点:不容易控制,而且是个阻塞函数

import time


def timer(n):
    '''''
    每n秒执行一次
    '''
    while True:
        print(time.strftime('%Y-%m-%d %X',time.localtime()))
          # 此处为要执行的任务
        time.sleep(n)

timer(1)

schedule模块
优点:可以管理和调度多个任务,可以进行控制
缺点:阻塞式函数

参考文档: https://www.cnblogs.com/longsongpong/p/10998619.html

import schedule
import time
import datetime

def job1():
    print('Job1:每隔10秒执行一次的任务,每次执行2秒')
    print('Job1-startTime:%s' %(datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S')))
    time.sleep(2)
    print('Job1-endTime:%s' % (datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S')))
    print('------------------------------------------------------------------------')

def job2():
    print('Job2:每隔30秒执行一次,每次执行5秒')
    print('Job2-startTime:%s' % (datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S')))
    time.sleep(5)
    print('Job2-endTime:%s' % (datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S')))
    print('------------------------------------------------------------------------')


def job3():
    print('Job3:每隔1分钟执行一次,每次执行10秒')
    print('Job3-startTime:%s' % (datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S')))
    time.sleep(10)
    print('Job3-endTime:%s' % (datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S')))
    print('------------------------------------------------------------------------')


def job4():
    print('Job4:每天下午17:49执行一次,每次执行20秒')
    print('Job4-startTime:%s' % (datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S')))
    time.sleep(20)
    print('Job4-endTime:%s' % (datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S')))
    print('------------------------------------------------------------------------')


def job5():
    print('Job5:每隔5秒到10秒执行一次,每次执行3秒')
    print('Job5-startTime:%s' % (datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S')))
    time.sleep(3)
    print('Job5-endTime:%s' % (datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S')))
    print('------------------------------------------------------------------------')


if __name__ == '__main__':
    schedule.every(10).seconds.do(job1)
    schedule.every(30).seconds.do(job2)
    schedule.every(1).minutes.do(job3)
    schedule.every().day.at('17:49').do(job4)
    schedule.every(5).to(10).seconds.do(job5)
    while True:
        schedule.run_pending()

Threading模块中的Timer
优点:非阻塞
缺点:不易管理多个任务

from threading import Timer
import datetime
# 每隔两秒执行一次任务
def printHello():
    print('TimeNow:%s' % (datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S')))
    t = Timer(2, printHello)
    t.start()

if __name__ == "__main__":
    printHello()

循环执行

import time
import threading

num = 3


def createTimer():
    t = threading.Timer(1, repeat)
    t.start()


def repeat():
    global num
    if num > 0:
        num -= 1
        print('Now:', time.strftime('%H:%M:%S', time.localtime()))
        createTimer()


repeat()

sched模块

sched模块实现了一个时间调度程序,该程序可以通过单线程执行来处理按照时间尺度进行调度的时间。
通过调用scheduler.enter(delay,priority,func,args)函数,可以将一个任务添加到任务队列里面,当指定的时间到了,就会执行任务(func函数)。

  • delay:任务的间隔时间。

  • priority:如果几个任务被调度到相同的时间执行,将按照priority的增序执行这几个任务。

  • func:要执行的任务函数

  • args:func的参数

    import time, sched
    import datetime
    
    s = sched.scheduler(time.time, time.sleep)
      
    def print_time(a='default'):
        print('Now Time:',datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S'),a)
      
    def print_some_times():
        print(datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S'))
        s.enter(10,1,print_time)
        s.enter(5,2,print_time,argument=('positional',))
        s.run()
        print(datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S'))
    print_some_times()
    

执行结果为:

2021-05-20 16:25:03
Now Time: 2018-09-20 16:25:08 positional
Now Time: 2018-09-20 16:25:13 default
2021-05-20 16:25:13

按顺序执行任务:

import time, sched
import datetime

s = sched.scheduler(time.time, time.sleep)


def event_fun1():
    print("func1 Time:", datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S'))


def perform1(inc):
    s.enter(inc, 0, perform1, (inc,))
    event_fun1()


def event_fun2():
    print("func2 Time:", datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S'))


def perform2(inc):
    s.enter(inc, 0, perform2, (inc,))
    event_fun2()


def mymain(func, inc=2):
    if func == "1":
        s.enter(0, 0, perform1, (10,))# 每隔10秒执行一次perform1
    if func == "2":
        s.enter(0, 0, perform2, (20,))# 每隔20秒执行一次perform2
if __name__ == '__main__':
    mymain('1')
    mymain('2')
    s.run()

执行结果为:

func1 Time: 2021-09-20 16:30:28
func2 Time: 2021-09-20 16:30:28
func1 Time: 2021-09-20 16:30:38
func2 Time: 2021-09-20 16:30:48
func1 Time: 2021-09-20 16:30:48
func1 Time: 2021-09-20 16:30:58
func2 Time: 2021-09-20 16:31:08
func1 Time: 2021-09-20 16:31:08
func1 Time: 2021-09-20 16:31:18
func2 Time: 2021-09-20 16:31:28
func1 Time: 2021-09-20 16:31:28
func1 Time: 202-09-20  16:31:38

s.run()会阻塞当前线程的执行
可以用

t=threading.Thread(target=s.run)
t.start()

也可以用s.cancal(action)来取消sched中的某个action

定时框架APScheduler(正文开头)

APScheduler是python的一个定时任务框架,它提供了基于日期date、固定时间间隔interval、以及linux上的crontab类型的定时任务。该矿机不仅可以添加、删除定时任务,还可以将任务存储到数据库中、实现任务的持久化。

APScheduler有四种组件:

  • triggers(触发器):触发器包含调度逻辑,每一个作业有它自己的触发器,用于决定接下来哪一个作业会运行,除了他们自己初始化配置外,触发器完全是无状态的。

  • job stores(作业存储):用来存储被调度的作业,默认的作业存储器是简单地把作业任务保存在内存中,其它作业存储器可以将任务作业保存到各种数据库中,支持MongoDB、Redis、SQLAlchemy存储方式。当对作业任务进行持久化存储的时候,作业的数据将被序列化,重新读取作业时在反序列化。

  • executors(执行器):执行器用来执行定时任务,只是将需要执行的任务放在新的线程或者线程池中运行。当作业任务完成时,执行器将会通知调度器。对于执行器,默认情况下选择ThreadPoolExecutor就可以了,但是如果涉及到一下特殊任务如比较消耗CPU的任务则可以选择ProcessPoolExecutor,当然根据根据实际需求可以同时使用两种执行器。

  • schedulers(调度器):调度器是将其它部分联系在一起,一般在应用程序中只有一个调度器,应用开发者不会直接操作触发器、任务存储以及执行器,相反调度器提供了处理的接口。通过调度器完成任务的存储以及执行器的配置操作,如可以添加。修改、移除任务作业。

APScheduler提供了七种调度器:

  • BlockingScheduler:适合于只在进程中运行单个任务的情况,通常在调度器是你唯一要运行的东西时使用。
  • BackgroundScheduler: 适合于要求任何在程序后台运行的情况,当希望调度器在应用后台执行时使用。
  • AsyncIOScheduler:适合于使用asyncio异步框架的情况
  • GeventScheduler: 适合于使用gevent框架的情况
  • TornadoScheduler: 适合于使用Tornado框架的应用
  • TwistedScheduler: 适合使用Twisted框架的应用
  • QtScheduler: 适合使用QT的情况

APScheduler提供了四种存储方式:

  • MemoryJobStore
  • sqlalchemy
  • mongodb
  • redis

APScheduler提供了三种任务触发器:

  • data:固定日期触发器:任务只运行一次,运行完毕自动清除;若错过指定运行时间,任务不会被创建

  • interval:时间间隔触发器

  • cron:cron风格的任务触发

    示例1、

    import time
    from apscheduler.schedulers.blocking import BlockingScheduler
    
    def job():
        print(time.strftime('%Y-%m-%d %H:%M:%S', time.localtime(time.time())))
    
    
    if __name__ == '__main__':
        # 该示例代码生成了一个BlockingScheduler调度器,使用了默认的任务存储MemoryJobStore,以及默认的执行器ThreadPoolExecutor,并且最大线程数为10。
      
        # BlockingScheduler:在进程中运行单个任务,调度器是唯一运行的东西
        scheduler = BlockingScheduler()
        # 采用阻塞的方式
    
        # 采用固定时间间隔(interval)的方式,每隔5秒钟执行一次
        scheduler.add_job(job, 'interval', seconds=5)
      
        scheduler.start()
    

示例2

import time
from apscheduler.schedulers.blocking import BlockingScheduler

def job():
    print(time.strftime('%Y-%m-%d %H:%M:%S', time.localtime(time.time())))
    
if __name__ == '__main__':
    # BlockingScheduler:在进程中运行单个任务,调度器是唯一运行的东西
    scheduler = BlockingScheduler()
    # 采用阻塞的方式
    
    # 采用date的方式,在特定时间只执行一次
    scheduler.add_job(job, 'date', run_date='2018-09-21 15:30:00')

    scheduler.start() 

示例3、

import time
from apscheduler.schedulers.background import BackgroundScheduler

def job():
    print('job:', time.strftime('%Y-%m-%d %H:%M:%S', time.localtime(time.time())))

if __name__ == '__main__':
    # BackgroundScheduler: 适合于要求任何在程序后台运行的情况,当希望调度器在应用后台执行时使用。
    scheduler = BackgroundScheduler()
    # 采用非阻塞的方式

    # 采用固定时间间隔(interval)的方式,每隔3秒钟执行一次
    scheduler.add_job(job, 'interval', seconds=3)
    # 这是一个独立的线程
    scheduler.start()
    
    # 其他任务是独立的线程
    while True:
        print('main-start:', time.strftime('%Y-%m-%d %H:%M:%S', time.localtime(time.time())))
        time.sleep(2)
        print('main-end:', time.strftime('%Y-%m-%d %H:%M:%S', time.localtime(time.time())))

运行结果为:
main-start: 2018-09-21 15:54:28
main-end: 2018-09-21 15:54:30
main-start: 2018-09-21 15:54:30
job: 2018-09-21 15:54:31
main-end: 2018-09-21 15:54:32
main-start: 2018-09-21 15:54:32
main-end: 2018-09-21 15:54:34
main-start: 2018-09-21 15:54:34
job: 2018-09-21 15:54:34
main-end: 2018-09-21 15:54:36
main-start: 2018-09-21 15:54:36

示例4

import time
from apscheduler.schedulers.background import BackgroundScheduler

def job():
    print('job:', time.strftime('%Y-%m-%d %H:%M:%S', time.localtime(time.time())))

if __name__ == '__main__':
    # BackgroundScheduler: 适合于要求任何在程序后台运行的情况,当希望调度器在应用后台执行时使用。
    scheduler = BackgroundScheduler()
    # 采用非阻塞的方式

    # 采用date的方式,在特定时间里执行一次
    scheduler.add_job(job, 'date', run_date='2018-09-21 15:53:00')
    # 这是一个独立的线程
    scheduler.start()

    # 其他任务是独立的线程
    while True:
        print('main-start:', time.strftime('%Y-%m-%d %H:%M:%S', time.localtime(time.time())))
        time.sleep(2)
        print('main-end:', time.strftime('%Y-%m-%d %H:%M:%S', time.localtime(time.time())))



结果为:
main-start: 2018-09-21 15:52:57
main-end: 2018-09-21 15:52:59
main-start: 2018-09-21 15:52:59
job: 2018-09-21 15:53:00
main-end: 2018-09-21 15:53:01

示例5

import time
from apscheduler.schedulers.background import BackgroundScheduler


def job():
    print(time.strftime('%Y-%m-%d %H:%M:%S', time.localtime(time.time())))


if __name__ == '__main__':
    # BackgroundScheduler: 适合于要求任何在程序后台运行的情况,当希望调度器在应用后台执行时使用
    scheduler = BackgroundScheduler()
    # 采用非阻塞的方式

    # 采用corn的方式
    scheduler.add_job(job, 'cron', day_of_week='fri', second='*/5')
    '''
    year (int|str) – 4-digit year
    month (int|str) – month (1-12)
    day (int|str) – day of the (1-31)
    week (int|str) – ISO week (1-53)
    day_of_week (int|str) – number or name of weekday (0-6 or mon,tue,wed,thu,fri,sat,sun)
    hour (int|str) – hour (0-23)
    minute (int|str) – minute (0-59)
    econd (int|str) – second (0-59)
            
    start_date (datetime|str) – earliest possible date/time to trigger on (inclusive)
    end_date (datetime|str) – latest possible date/time to trigger on (inclusive)
    timezone (datetime.tzinfo|str) – time zone to use for the date/time calculations (defaults to scheduler timezone)
        
    *    any    Fire on every value
    */a    any    Fire every a values, starting from the minimum
    a-b    any    Fire on any value within the a-b range (a must be smaller than b)
    a-b/c    any    Fire every c values within the a-b range
    xth y    day    Fire on the x -th occurrence of weekday y within the month
    last x    day    Fire on the last occurrence of weekday x within the month
    last    day    Fire on the last day within the month
    x,y,z    any    Fire on any matching expression; can combine any number of any of the above expressions
    '''
    scheduler.start()
    
    # 其他任务是独立的线程
    while True:
        print('main-start:', time.strftime('%Y-%m-%d %H:%M:%S', time.localtime(time.time())))
        time.sleep(2)
        print('main-end:', time.strftime('%Y-%m-%d %H:%M:%S', time.localtime(time.time())))


运行结果:

main-start: 2018-09-21 16:02:55
main-end: 2018-09-21 16:02:57
main-start: 2018-09-21 16:02:57
main-end: 2018-09-21 16:02:59
main-start: 2018-09-21 16:02:59
2018-09-21 16:03:00
main-end: 2018-09-21 16:03:01
main-start: 2018-09-21 16:03:01
main-end: 2018-09-21 16:03:03
main-start: 2018-09-21 16:03:03
2018-09-21 16:03:05
main-end: 2018-09-21 16:03:05
main-start: 2018-09-21 16:03:05
main-end: 2018-09-21 16:03:07
main-start: 2018-09-21 16:03:07
main-end: 2018-09-21 16:03:09
main-start: 2018-09-21 16:03:09
2018-09-21 16:03:10

示例6、

import time
from apscheduler.schedulers.background import BackgroundScheduler


def job():
    print(time.strftime('%Y-%m-%d %H:%M:%S', time.localtime(time.time())))


if __name__ == '__main__':
    # BackgroundScheduler: 适合于要求任何在程序后台运行的情况,当希望调度器在应用后台执行时使用
    scheduler = BackgroundScheduler()
    # 采用阻塞的方式

    # 采用corn的方式
    scheduler.add_job(job, 'cron', day_of_week='fri', second='*/5')
    '''
    year (int|str) – 4-digit year
    month (int|str) – month (1-12)
    day (int|str) – day of the (1-31)
    week (int|str) – ISO week (1-53)
    day_of_week (int|str) – number or name of weekday (0-6 or mon,tue,wed,thu,fri,sat,sun)
    hour (int|str) – hour (0-23)
    minute (int|str) – minute (0-59)
    econd (int|str) – second (0-59)
            
    start_date (datetime|str) – earliest possible date/time to trigger on (inclusive)
    end_date (datetime|str) – latest possible date/time to trigger on (inclusive)
    timezone (datetime.tzinfo|str) – time zone to use for the date/time calculations (defaults to scheduler timezone)
        
    *    any    Fire on every value
    */a    any    Fire every a values, starting from the minimum
    a-b    any    Fire on any value within the a-b range (a must be smaller than b)
    a-b/c    any    Fire every c values within the a-b range
    xth y    day    Fire on the x -th occurrence of weekday y within the month
    last x    day    Fire on the last occurrence of weekday x within the month
    last    day    Fire on the last day within the month
    x,y,z    any    Fire on any matching expression; can combine any number of any of the above expressions
    '''

    scheduler.start()

示例7、

import time
from pymongo import MongoClient
from apscheduler.schedulers.blocking import BlockingScheduler
from apscheduler.jobstores.mongodb import MongoDBJobStore

def job():
    print(time.strftime('%Y-%m-%d %H:%M:%S', time.localtime(time.time())))
if __name__ == '__main__':
    # mongodb存储job
    scheduler = BlockingScheduler()
    client = MongoClient(host='127.0.0.1', port=27017)
    store = MongoDBJobStore(collection='job', database='test', client=client)
    scheduler.add_jobstore(store)
    scheduler.add_job(job, 'interval', second=5)
    scheduler.start()

实例 利用延迟线程周期执行任务

参考

例子:每天凌晨3点执行func方法
'''
import datetime
import threading

def func():
    print("haha")
    #如果需要循环调用,就要添加以下方法
    timer = threading.Timer(86400, func)
    timer.start()

# 获取现在时间
now_time = datetime.datetime.now()
# 获取明天时间
next_time = now_time + datetime.timedelta(days=+1)
next_year = next_time.date().year
next_month = next_time.date().month
next_day = next_time.date().day
# 获取明天3点时间
next_time = datetime.datetime.strptime(str(next_year)+"-"+str(next_month)+"-"+str(next_day)+" 03:00:00", "%Y-%m-%d %H:%M:%S")
# # 获取昨天时间
# last_time = now_time + datetime.timedelta(days=-1)

# 获取距离明天3点时间,单位为秒
timer_start_time = (next_time - now_time).total_seconds()
print(timer_start_time)
# 54186.75975


#定时器,参数为(多少时间后执行,单位为秒,执行的方法)
timer = threading.Timer(timer_start_time, func)
timer.start()

实例

import threading
import datetime
import django
import sys
import os
import time


class Decorator(type):
    _instance_lock = threading.Lock()

    def __call__(cls, *args, **kwargs):
        if not hasattr(cls, '_instance'):
            with Decorator._instance_lock:
                if not hasattr(cls, '_instance'):
                    cls._instance = super(Decorator, cls).__call__(*args, **kwargs)
        return cls._instance


class TimingTask(metaclass=Decorator):

    def __new__(cls, *args, **kwargs) -> None:
        sys.path.append(os.path.dirname(os.path.dirname(os.path.dirname(os.path.abspath(__file__)))))
        os.environ.setdefault("DJANGO_SETTINGS_MODULE", "red_external.settings")
        django.setup()

    def __init__(self) -> None:
        self.__file_create_date: str = str(time.strftime('%Y-%m-%d'))
        self.__remarks: str = self.__file_create_date
        self.__auto_or_manual: int = 0  # 自动
        self.__user_id: None = None

    @staticmethod
    def difference() -> int:
        '''算时差'''
        now_time: datetime = datetime.datetime.now()
        next_time: datetime = now_time + datetime.timedelta(days=+1)
        next_date: datetime = next_time.date()
        year, month, day = next_date.year, next_date.month, next_date.day
        next_time = datetime.datetime.strptime(
            str(year) + "-" + str(month) + "-" + str(day) + " 00:00:00", "%Y-%m-%d %H:%M:%S")

        timer_start_time: int or float = (next_time - now_time).total_seconds()
        print('距离明天0点还剩:', timer_start_time, '/秒')
        return timer_start_time


def task():
    file_create_date = str(time.strftime('%Y-%m-%d'))
    from red_server.models.content import Backups
    Backups.objects.create(
        auto_or_manual=0,
        file_path=f'data-{file_create_date}.json',
        user_id=None,
        remarks=str(time.strftime('%Y-%m-%d %H:%M:%S'))
    )
    os.system(rf'python manage.py dumpdata > data-{file_create_date}.json')


def cycle(func, second):
    TimingTask()
    while True:
        r = TimingTask.difference()
        timer = threading.Timer(r, func)
        timer.start()
        time.sleep(second)


cycle(task, 86400)

Windows下定时任务



import subprocess
from loguru import logger

class ScheduledTaskManager(object):
    '''定时任务'''

    def __init__(self):
        self.schedule_name ='MySchedule'

    def add_task(self, bat):
        '''
        添加任务
        每天指定时间启动一次  schtasks /create /sc daily /tn "RunDailyAtSpecificTime" /tr "C:\Scripts\run_daily_at_specific_time.bat" /st 08:00
        每5分钟运行一次  schtasks /create /sc minute /mo 5 /tn "RunEvery5Minutes" /tr "C:\Scripts\run_every_5_minutes.bat"
        每周三运行一次  schtasks /create /sc weekly /d WED /tn "RunWeeklyOnWednesday" /tr "C:\Scripts\run_weekly_on_wednesday.bat"
        每周三和周四各运行一次 schtasks /create /sc weekly /d WED,THU /tn "RunWeeklyOnWedAndThu" /tr "C:\Scripts\run_weekly_on_wed_and_thu.bat"
        每月5号运行一次 schtasks /create /sc monthly /d 5 /tn "RunMonthlyOn5th" /tr "C:\Scripts\run_monthly_on_5th.bat"
        '''
        task_create_command = f'schtasks /create /sc minute /mo 1 /tn "{self.schedule_name}" /tr "{bat}"'
        result = self._run(task_create_command)
        return result

    def delete_task(self):
        '''删除任务'''
        task_delete_command = f'schtasks /delete /tn {self.schedule_name} /f'
        result = self._run(task_delete_command)
        return result

    def list_tasks(self):
        '''查询任务'''
        task_list_command = 'schtasks /query'
        result = self._run(task_list_command)
        return result

    def _run(self, cmd):
        result = subprocess.Popen(cmd, stdout=subprocess.PIPE, encoding='gb2312')
        return result.stdout.read()

if __name__ == '__main__':
    task_manager = ScheduledTaskManager()
    task_all = task_manager.list_tasks()  # 所有任务
    # logger.debug(task_all)
    if not task_manager.schedule_name in task_all:
        task_manager.add_task(r"C:\Program Files\VideoLAN\VLC\vlc.exe")
        logger.debug(f'【{task_manager.schedule_name}】计划任务添加成功!')
    else:
        logger.success(f'【{task_manager.schedule_name}】任务已存在')


  • 0
    点赞
  • 3
    收藏
    觉得还不错? 一键收藏
  • 打赏
    打赏
  • 0
    评论
评论
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包

打赏作者

像风一样的男人@

你的鼓励将是我创作的最大动力

¥1 ¥2 ¥4 ¥6 ¥10 ¥20
扫码支付:¥1
获取中
扫码支付

您的余额不足,请更换扫码支付或充值

打赏作者

实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

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

余额充值