funboost 46.6__py3-none-any.whl → 46.8__py3-none-any.whl
This diff represents the content of publicly available package versions that have been released to one of the supported registries. The information contained in this diff is provided for informational purposes only and reflects changes between package versions as they appear in their respective public registries.
Potentially problematic release.
This version of funboost might be problematic. Click here for more details.
- funboost/__init__.py +1 -1
- funboost/consumers/base_consumer.py +15 -5
- funboost/consumers/rabbitmq_amqpstorm_consumer.py +7 -6
- funboost/core/booster.py +1 -1
- funboost/timing_job/__init__.py +33 -4
- funboost/timing_job/apscheduler_use_mysql_store.py +1 -0
- funboost/timing_job/apscheduler_use_redis_store.py +41 -10
- funboost/utils/decorators.py +27 -0
- {funboost-46.6.dist-info → funboost-46.8.dist-info}/METADATA +1 -1
- {funboost-46.6.dist-info → funboost-46.8.dist-info}/RECORD +14 -14
- {funboost-46.6.dist-info → funboost-46.8.dist-info}/LICENSE +0 -0
- {funboost-46.6.dist-info → funboost-46.8.dist-info}/WHEEL +0 -0
- {funboost-46.6.dist-info → funboost-46.8.dist-info}/entry_points.txt +0 -0
- {funboost-46.6.dist-info → funboost-46.8.dist-info}/top_level.txt +0 -0
funboost/__init__.py
CHANGED
|
@@ -40,6 +40,7 @@ from funboost.core.serialization import Serialization
|
|
|
40
40
|
from funboost.core.task_id_logger import TaskIdLogger
|
|
41
41
|
from funboost.constant import FunctionKind
|
|
42
42
|
|
|
43
|
+
|
|
43
44
|
from nb_libs.path_helper import PathHelper
|
|
44
45
|
from nb_log import (get_logger, LoggerLevelSetterMixin, LogManager, is_main_process,
|
|
45
46
|
nb_log_config_default)
|
|
@@ -368,6 +369,7 @@ class AbstractConsumer(LoggerLevelSetterMixin, metaclass=abc.ABCMeta, ):
|
|
|
368
369
|
|
|
369
370
|
def _start_delay_task_scheduler(self):
|
|
370
371
|
from funboost.timing_job import FsdfBackgroundScheduler
|
|
372
|
+
from funboost.timing_job.apscheduler_use_redis_store import FunboostBackgroundSchedulerProcessJobsWithinRedisLock
|
|
371
373
|
# print(self.consumer_params.delay_task_apsscheduler_jobstores_kind )
|
|
372
374
|
if self.consumer_params.delay_task_apscheduler_jobstores_kind == 'redis':
|
|
373
375
|
jobstores = {
|
|
@@ -376,14 +378,21 @@ class AbstractConsumer(LoggerLevelSetterMixin, metaclass=abc.ABCMeta, ):
|
|
|
376
378
|
run_times_key=f'funboost.apscheduler.{self.queue_name}.run_times',
|
|
377
379
|
)
|
|
378
380
|
}
|
|
381
|
+
self._delay_task_scheduler = FunboostBackgroundSchedulerProcessJobsWithinRedisLock(timezone=FunboostCommonConfig.TIMEZONE, daemon=False,
|
|
382
|
+
jobstores=jobstores # push 方法的序列化带thredignn.lock
|
|
383
|
+
)
|
|
384
|
+
self._delay_task_scheduler.set_process_jobs_redis_lock_key(f'funboost.BackgroundSchedulerProcessJobsWithinRedisLock.{self.queue_name}')
|
|
379
385
|
elif self.consumer_params.delay_task_apscheduler_jobstores_kind == 'memory':
|
|
380
386
|
jobstores = {"default": MemoryJobStore()}
|
|
387
|
+
self._delay_task_scheduler = FsdfBackgroundScheduler(timezone=FunboostCommonConfig.TIMEZONE, daemon=False,
|
|
388
|
+
jobstores=jobstores # push 方法的序列化带thredignn.lock
|
|
389
|
+
)
|
|
390
|
+
|
|
381
391
|
else:
|
|
382
392
|
raise Exception(f'delay_task_apsscheduler_jobstores_kind is error: {self.consumer_params.delay_task_apscheduler_jobstores_kind}')
|
|
383
|
-
|
|
384
|
-
|
|
385
|
-
|
|
386
|
-
self._delay_task_scheduler.add_executor(ApschedulerThreadPoolExecutor(2)) # 只是运行submit任务到并发池,不需要很多线程。
|
|
393
|
+
|
|
394
|
+
|
|
395
|
+
# self._delay_task_scheduler.add_executor(ApschedulerThreadPoolExecutor(2)) # 只是运行submit任务到并发池,不需要很多线程。
|
|
387
396
|
# self._delay_task_scheduler.add_listener(self._apscheduler_job_miss, EVENT_JOB_MISSED)
|
|
388
397
|
self._delay_task_scheduler.start()
|
|
389
398
|
|
|
@@ -500,7 +509,8 @@ class AbstractConsumer(LoggerLevelSetterMixin, metaclass=abc.ABCMeta, ):
|
|
|
500
509
|
# 数据库作为apscheduler的jobstores时候, 不能用 self.pbulisher_of_same_queue.publish,self不能序列化
|
|
501
510
|
self._delay_task_scheduler.add_job(self._push_for_apscheduler_use_database_store, 'date', run_date=run_date,
|
|
502
511
|
kwargs={'queue_name': self.queue_name, 'msg': msg_no_delay, 'runonce_uuid': str(uuid.uuid4())},
|
|
503
|
-
misfire_grace_time=misfire_grace_time
|
|
512
|
+
misfire_grace_time=misfire_grace_time,
|
|
513
|
+
)
|
|
504
514
|
self._confirm_consume(kw)
|
|
505
515
|
|
|
506
516
|
else: # 普通任务
|
|
@@ -14,7 +14,7 @@ class RabbitmqConsumerAmqpStorm(AbstractConsumer):
|
|
|
14
14
|
使用AmqpStorm实现的,多线程安全的,不用加锁。
|
|
15
15
|
funboost 强烈推荐使用这个做消息队列中间件。
|
|
16
16
|
"""
|
|
17
|
-
BROKER_EXCLUSIVE_CONFIG_DEFAULT = {'x-max-priority': None} # x-max-priority 是 rabbitmq的优先级队列配置,必须为整数,强烈建议要小于5。为None就代表队列不支持优先级。
|
|
17
|
+
BROKER_EXCLUSIVE_CONFIG_DEFAULT = {'x-max-priority': None,'no_ack':False} # x-max-priority 是 rabbitmq的优先级队列配置,必须为整数,强烈建议要小于5。为None就代表队列不支持优先级。
|
|
18
18
|
|
|
19
19
|
def _shedual_task(self):
|
|
20
20
|
# noinspection PyTypeChecker
|
|
@@ -28,16 +28,17 @@ class RabbitmqConsumerAmqpStorm(AbstractConsumer):
|
|
|
28
28
|
broker_exclusive_config=self.consumer_params.broker_exclusive_config))
|
|
29
29
|
rp.init_broker()
|
|
30
30
|
rp.channel_wrapper_by_ampqstormbaic.qos(self.consumer_params.concurrent_num)
|
|
31
|
-
rp.channel_wrapper_by_ampqstormbaic.consume(callback=callback, queue=self.queue_name, no_ack=
|
|
31
|
+
rp.channel_wrapper_by_ampqstormbaic.consume(callback=callback, queue=self.queue_name, no_ack=self.consumer_params.broker_exclusive_config['no_ack'],
|
|
32
32
|
)
|
|
33
33
|
rp.channel.start_consuming(auto_decode=True)
|
|
34
34
|
|
|
35
35
|
def _confirm_consume(self, kw):
|
|
36
36
|
# noinspection PyBroadException
|
|
37
|
-
|
|
38
|
-
|
|
39
|
-
|
|
40
|
-
|
|
37
|
+
if self.consumer_params.broker_exclusive_config['no_ack'] is False:
|
|
38
|
+
try:
|
|
39
|
+
kw['amqpstorm_message'].ack() # 确认消费
|
|
40
|
+
except BaseException as e:
|
|
41
|
+
self.logger.error(f'AmqpStorm确认消费失败 {type(e)} {e}')
|
|
41
42
|
|
|
42
43
|
def _requeue(self, kw):
|
|
43
44
|
# amqpstorm.Message.delivery_tag
|
funboost/core/booster.py
CHANGED
|
@@ -206,7 +206,7 @@ class Booster:
|
|
|
206
206
|
fabric_deploy(self, **params)
|
|
207
207
|
|
|
208
208
|
|
|
209
|
-
boost = Booster
|
|
209
|
+
boost = Booster # @boost 后消费函数. 不能自动补全方法就用 Booster就可以。 2024版本的 pycharm抽风了,@boost的消费函数不能自动补全提示 .consume .push 这些方法。
|
|
210
210
|
task_deco = boost # 两个装饰器名字都可以。task_deco是原来名字,兼容一下。
|
|
211
211
|
|
|
212
212
|
|
funboost/timing_job/__init__.py
CHANGED
|
@@ -8,6 +8,9 @@ import importlib
|
|
|
8
8
|
import pickle
|
|
9
9
|
|
|
10
10
|
import time
|
|
11
|
+
from apscheduler.executors.pool import BasePoolExecutor
|
|
12
|
+
|
|
13
|
+
from funboost.utils.decorators import RedisDistributedLockContextManager,RedisDistributedBlockLockContextManager
|
|
11
14
|
from typing import Union
|
|
12
15
|
import threading
|
|
13
16
|
|
|
@@ -15,7 +18,7 @@ from apscheduler.schedulers.background import BackgroundScheduler
|
|
|
15
18
|
from apscheduler.jobstores.redis import RedisJobStore
|
|
16
19
|
# noinspection PyProtectedMember
|
|
17
20
|
from apscheduler.schedulers.base import STATE_STOPPED, STATE_RUNNING
|
|
18
|
-
from apscheduler.util import undefined
|
|
21
|
+
from apscheduler.util import undefined,TIMEOUT_MAX
|
|
19
22
|
import deprecated
|
|
20
23
|
from funboost.utils.redis_manager import RedisMixin
|
|
21
24
|
|
|
@@ -25,7 +28,8 @@ from funboost.consumers.base_consumer import AbstractConsumer
|
|
|
25
28
|
from funboost.core.booster import BoostersManager, Booster
|
|
26
29
|
from funboost.publishers.base_publisher import AbstractPublisher
|
|
27
30
|
from funboost import BoosterParams
|
|
28
|
-
|
|
31
|
+
from funboost.concurrent_pool.flexible_thread_pool import FlexibleThreadPool
|
|
32
|
+
from funboost.concurrent_pool.custom_threadpool_executor import ThreadPoolExecutorShrinkAble
|
|
29
33
|
|
|
30
34
|
@deprecated.deprecated(reason='以后不要再使用这种方式,对于job_store为数据库时候需要序列化不好。使用内存和数据库都兼容的添加任务方式: add_push_job')
|
|
31
35
|
def timing_publish_deco(consuming_func_decorated_or_consumer: Union[callable, AbstractConsumer]):
|
|
@@ -53,6 +57,20 @@ def push_fun_params_to_broker(queue_name: str, *args, runonce_uuid=None, **kwarg
|
|
|
53
57
|
else:
|
|
54
58
|
BoostersManager.get_or_create_booster_by_queue_name(queue_name).push(*args, **kwargs)
|
|
55
59
|
|
|
60
|
+
class ThreadPoolExecutorForAps(BasePoolExecutor):
|
|
61
|
+
"""
|
|
62
|
+
An executor that runs jobs in a concurrent.futures thread pool.
|
|
63
|
+
|
|
64
|
+
Plugin alias: ``threadpool``
|
|
65
|
+
|
|
66
|
+
:param max_workers: the maximum number of spawned threads.
|
|
67
|
+
:param pool_kwargs: dict of keyword arguments to pass to the underlying
|
|
68
|
+
ThreadPoolExecutor constructor
|
|
69
|
+
"""
|
|
70
|
+
|
|
71
|
+
def __init__(self, max_workers=10, ):
|
|
72
|
+
pool = ThreadPoolExecutorShrinkAble(int(max_workers),)
|
|
73
|
+
super().__init__(pool)
|
|
56
74
|
|
|
57
75
|
class FunboostBackgroundScheduler(BackgroundScheduler):
|
|
58
76
|
"""
|
|
@@ -60,6 +78,9 @@ class FunboostBackgroundScheduler(BackgroundScheduler):
|
|
|
60
78
|
通过重写 _main_loop ,使得动态修改增加删除定时任务配置更好。
|
|
61
79
|
"""
|
|
62
80
|
|
|
81
|
+
_last_wait_seconds = None
|
|
82
|
+
_last_has_task = False
|
|
83
|
+
|
|
63
84
|
@deprecated.deprecated(reason='以后不要再使用这种方式,对于job_store为数据库时候需要序列化不好。使用内存和数据库都兼容的添加任务方式: add_push_job')
|
|
64
85
|
def add_timing_publish_job(self, func, trigger=None, args=None, kwargs=None, id=None, name=None,
|
|
65
86
|
misfire_grace_time=undefined, coalesce=undefined, max_instances=undefined,
|
|
@@ -146,14 +167,22 @@ class FunboostBackgroundScheduler(BackgroundScheduler):
|
|
|
146
167
|
或者下一个需要运行的任务的wait_seconds是3600秒后,此时新加了一个动态任务需要3600秒后,
|
|
147
168
|
现在最多只需要1秒就能扫描到动态新增的定时任务了。
|
|
148
169
|
"""
|
|
149
|
-
MAX_WAIT_SECONDS_FOR_NEX_PROCESS_JOBS =
|
|
170
|
+
MAX_WAIT_SECONDS_FOR_NEX_PROCESS_JOBS = 0.5
|
|
150
171
|
wait_seconds = None
|
|
151
172
|
while self.state == STATE_RUNNING:
|
|
152
173
|
if wait_seconds is None:
|
|
153
174
|
wait_seconds = MAX_WAIT_SECONDS_FOR_NEX_PROCESS_JOBS
|
|
154
|
-
|
|
175
|
+
self._last_wait_seconds = min(wait_seconds, MAX_WAIT_SECONDS_FOR_NEX_PROCESS_JOBS)
|
|
176
|
+
if wait_seconds in (None,TIMEOUT_MAX):
|
|
177
|
+
self._last_has_task = False
|
|
178
|
+
else:
|
|
179
|
+
self._last_has_task = True
|
|
180
|
+
time.sleep(self._last_wait_seconds) # 这个要取最小值,不然例如定时间隔0.1秒运行,不取最小值,不会每隔0.1秒运行。
|
|
155
181
|
wait_seconds = self._process_jobs()
|
|
156
182
|
|
|
183
|
+
def _create_default_executor(self):
|
|
184
|
+
return ThreadPoolExecutorForAps() # 必须是apscheduler pool的子类
|
|
185
|
+
|
|
157
186
|
|
|
158
187
|
FsdfBackgroundScheduler = FunboostBackgroundScheduler # 兼容一下名字,fsdf是 function-scheduling-distributed-framework 老框架名字的缩写
|
|
159
188
|
# funboost_aps_scheduler定时配置基于内存的,不可以跨机器远程动态添加/修改/删除定时任务配置。如果需要动态增删改查定时任务,可以使用funboost_background_scheduler_redis_store
|
|
@@ -1,24 +1,55 @@
|
|
|
1
1
|
from apscheduler.jobstores.redis import RedisJobStore
|
|
2
|
-
|
|
3
|
-
from funboost.funboost_config_deafult import BrokerConnConfig,FunboostCommonConfig
|
|
2
|
+
from funboost.utils.redis_manager import RedisMixin
|
|
4
3
|
|
|
5
4
|
from funboost.timing_job import FunboostBackgroundScheduler
|
|
5
|
+
from funboost.funboost_config_deafult import BrokerConnConfig, FunboostCommonConfig
|
|
6
|
+
from funboost.utils.decorators import RedisDistributedBlockLockContextManager
|
|
6
7
|
|
|
7
8
|
"""
|
|
8
|
-
这个是使用redis
|
|
9
|
+
这个是使用redis作为定时任务持久化,支持跨机器好跨进程,外部远程 动态修改/添加/删除定时任务
|
|
9
10
|
"""
|
|
10
11
|
|
|
11
|
-
jobstores = {
|
|
12
|
-
"default": RedisJobStore(db=BrokerConnConfig.REDIS_DB, host=BrokerConnConfig.REDIS_HOST,
|
|
13
|
-
port=BrokerConnConfig.REDIS_PORT, password=BrokerConnConfig.REDIS_PASSWORD,
|
|
14
|
-
username=BrokerConnConfig.REDIS_USERNAME,jobs_key='funboost.apscheduler.jobs')
|
|
15
|
-
}
|
|
16
12
|
|
|
17
|
-
|
|
13
|
+
class FunboostBackgroundSchedulerProcessJobsWithinRedisLock(FunboostBackgroundScheduler):
|
|
14
|
+
"""
|
|
15
|
+
分布式或多进程都启动某个apscheduler实例,如果都使用的同一个数据库类型的jobstores ,_process_jobs有很大概率会造成报错, 因为_process_jobs使用的是线程锁,管不了其他进程和分布式机器。
|
|
16
|
+
|
|
17
|
+
https://groups.google.com/g/apscheduler/c/Gjc_JQMPePc 问题也提到了这个bug
|
|
18
|
+
|
|
19
|
+
继承 Custom schedulers https://apscheduler.readthedocs.io/en/3.x/extending.html 可以重写 _create_lock
|
|
20
|
+
"""
|
|
21
|
+
|
|
22
|
+
process_jobs_redis_lock_key = f'funboost.BackgroundSchedulerProcessJobsWithinRedisLock'
|
|
18
23
|
|
|
24
|
+
def set_process_jobs_redis_lock_key(self, lock_key):
|
|
25
|
+
self.process_jobs_redis_lock_key = lock_key
|
|
19
26
|
|
|
27
|
+
# def _create_lock(self):
|
|
28
|
+
# return RedisDistributedBlockLockContextManager(RedisMixin().redis_db_frame,self.process_jobs_redis_lock_key,) 这个类的写法不适合固定的单例,
|
|
29
|
+
# RedisDistributedBlockLockContextManager的写法不适合 永远用一个 对象,所以还是放到 def _process_jobs 里面运行
|
|
20
30
|
|
|
31
|
+
# def _process_jobs(self):
|
|
32
|
+
# for i in range(10) :
|
|
33
|
+
# with RedisDistributedLockContextManager(RedisMixin().redis_db_frame, self.process_jobs_redis_lock_key, ) as lock:
|
|
34
|
+
# if lock.has_aquire_lock:
|
|
35
|
+
# wait_seconds = super()._process_jobs()
|
|
36
|
+
# return wait_seconds
|
|
37
|
+
# else:
|
|
38
|
+
# time.sleep(0.1)
|
|
39
|
+
# return 0.1
|
|
21
40
|
|
|
41
|
+
def _process_jobs(self):
|
|
42
|
+
with RedisDistributedBlockLockContextManager(RedisMixin().redis_db_frame, self.process_jobs_redis_lock_key, ):
|
|
43
|
+
return super()._process_jobs()
|
|
44
|
+
|
|
45
|
+
|
|
46
|
+
jobstores = {
|
|
47
|
+
"default": RedisJobStore(db=BrokerConnConfig.REDIS_DB, host=BrokerConnConfig.REDIS_HOST,
|
|
48
|
+
port=BrokerConnConfig.REDIS_PORT, password=BrokerConnConfig.REDIS_PASSWORD,
|
|
49
|
+
username=BrokerConnConfig.REDIS_USERNAME, jobs_key='funboost.apscheduler.jobs')
|
|
50
|
+
}
|
|
51
|
+
|
|
52
|
+
funboost_background_scheduler_redis_store = FunboostBackgroundSchedulerProcessJobsWithinRedisLock(timezone=FunboostCommonConfig.TIMEZONE, daemon=False, jobstores=jobstores)
|
|
22
53
|
|
|
23
54
|
"""
|
|
24
55
|
|
|
@@ -27,4 +58,4 @@ funboost_background_scheduler_redis_store = FunboostBackgroundScheduler(timezone
|
|
|
27
58
|
test_frame/test_apschedual/test_aps_redis_store.py
|
|
28
59
|
test_frame/test_apschedual/test_change_aps_conf.py
|
|
29
60
|
|
|
30
|
-
"""
|
|
61
|
+
"""
|
funboost/utils/decorators.py
CHANGED
|
@@ -361,6 +361,30 @@ class RedisDistributedLockContextManager(LoggerMixin, LoggerLevelSetterMixin):
|
|
|
361
361
|
return False
|
|
362
362
|
|
|
363
363
|
|
|
364
|
+
class RedisDistributedBlockLockContextManager(RedisDistributedLockContextManager):
|
|
365
|
+
def __init__(self, redis_client, redis_lock_key, expire_seconds=30, check_interval=0.1):
|
|
366
|
+
super().__init__(redis_client,redis_lock_key,expire_seconds)
|
|
367
|
+
self.check_interval = check_interval
|
|
368
|
+
# self.logger.setLevel(logging.DEBUG)
|
|
369
|
+
|
|
370
|
+
def __enter__(self):
|
|
371
|
+
while True:
|
|
372
|
+
self._line = sys._getframe().f_back.f_lineno # 调用此方法的代码的函数
|
|
373
|
+
self._file_name = sys._getframe(1).f_code.co_filename # 哪个文件调了用此方法
|
|
374
|
+
ret = self.redis_client.set(self.redis_lock_key, value=self.identifier, ex=self._expire_seconds, nx=True)
|
|
375
|
+
has_aquire_lock = False if ret is None else True
|
|
376
|
+
if has_aquire_lock:
|
|
377
|
+
log_msg = f'\n"{self._file_name}:{self._line}" 这行代码获得了redis锁 {self.redis_lock_key}'
|
|
378
|
+
else:
|
|
379
|
+
log_msg = f'\n"{self._file_name}:{self._line}" 这行代码此次没有获得redis锁 {self.redis_lock_key}'
|
|
380
|
+
# print(self.logger.level,log_msg)
|
|
381
|
+
self.logger.debug(log_msg)
|
|
382
|
+
if has_aquire_lock:
|
|
383
|
+
break
|
|
384
|
+
else:
|
|
385
|
+
time.sleep(self.check_interval)
|
|
386
|
+
|
|
387
|
+
|
|
364
388
|
"""
|
|
365
389
|
@contextmanager
|
|
366
390
|
def some_generator(<arguments>):
|
|
@@ -372,6 +396,9 @@ class RedisDistributedLockContextManager(LoggerMixin, LoggerLevelSetterMixin):
|
|
|
372
396
|
"""
|
|
373
397
|
|
|
374
398
|
|
|
399
|
+
|
|
400
|
+
|
|
401
|
+
|
|
375
402
|
class ExceptionContextManager:
|
|
376
403
|
"""
|
|
377
404
|
用上下文管理器捕获异常,可对代码片段进行错误捕捉,比装饰器更细腻
|
|
@@ -1,6 +1,6 @@
|
|
|
1
1
|
Metadata-Version: 2.1
|
|
2
2
|
Name: funboost
|
|
3
|
-
Version: 46.
|
|
3
|
+
Version: 46.8
|
|
4
4
|
Summary: pip install funboost,python全功能分布式函数调度框架,funboost的功能是全面性重量级,用户能想得到的功能99%全都有;funboost的使用方式是轻量级,只有@boost一行代码需要写。支持python所有类型的并发模式和一切知名消息队列中间件,支持如 celery dramatiq等框架整体作为funboost中间件,python函数加速器,框架包罗万象,用户能想到的控制功能全都有。一统编程思维,兼容50% python业务场景,适用范围广。只需要一行代码即可分布式执行python一切函数,99%用过funboost的pythoner 感受是 简易 方便 强劲 强大,相见恨晚
|
|
5
5
|
Home-page: https://github.com/ydf0509/funboost
|
|
6
6
|
Author: bfzs
|
|
@@ -1,4 +1,4 @@
|
|
|
1
|
-
funboost/__init__.py,sha256=
|
|
1
|
+
funboost/__init__.py,sha256=cnQABGz4I9cAvUXg57u7bUJRhrElwmZrM7LR1CR3JbE,3956
|
|
2
2
|
funboost/__init__old.py,sha256=9Kv3cPLnPkbzMRnuJFVkPsuDdx1CdcSIuITkpdncZSc,20382
|
|
3
3
|
funboost/__main__.py,sha256=-6Nogi666Y0LN8fVm3JmHGTOk8xEGWvotW_GDbSaZME,1065
|
|
4
4
|
funboost/constant.py,sha256=STzRDZbuCC5FFV-uD_0r2beGsD1Zni4kregzR11z3Ok,8148
|
|
@@ -35,7 +35,7 @@ funboost/concurrent_pool/backup/async_pool_executor0223.py,sha256=RVUZiylUvpTm6U
|
|
|
35
35
|
funboost/concurrent_pool/backup/async_pool_executor_back.py,sha256=KL6zEQaa1KkZOlAO85mCC1gwLm-YC5Ghn21IUom0UKM,9598
|
|
36
36
|
funboost/concurrent_pool/backup/async_pool_executor_janus.py,sha256=OHMWJ9l3EYTpPpcrPrGGKd4K0tmQ2PN8HiX0Dta0EOo,5728
|
|
37
37
|
funboost/consumers/__init__.py,sha256=ZXY_6Kut1VYNQiF5aWEgIWobsW1ht9YUP0TdRZRWFqI,126
|
|
38
|
-
funboost/consumers/base_consumer.py,sha256=
|
|
38
|
+
funboost/consumers/base_consumer.py,sha256=29KgSWGuA6xoINi6_K9XKKr0aSOES4Xhb5nIX-rnPc8,82250
|
|
39
39
|
funboost/consumers/celery_consumer.py,sha256=nQpSkzPBJ4bRpxn4i9ms0axrJiq9RWhb4lG2nAdCIig,9254
|
|
40
40
|
funboost/consumers/confirm_mixin.py,sha256=5xC9AAQr_MY4tbSed8U-M6tOVmh69Qv9X0ld0JLT9Tk,6185
|
|
41
41
|
funboost/consumers/dramatiq_consumer.py,sha256=ozmeAfeF0U-YNYHK4suQB0N264h5AZdfMH0O45Mh-8A,2229
|
|
@@ -58,7 +58,7 @@ funboost/consumers/nsq_consumer.py,sha256=KcP4wT656LyvuwyQXnVp0B6DwYvnZ6z_Vyzt0K
|
|
|
58
58
|
funboost/consumers/peewee_conusmer.py,sha256=VqbSu9AdKO4_wgu0XhTWRO3VeWctecbbz2X_V04_kXw,1115
|
|
59
59
|
funboost/consumers/persist_queue_consumer.py,sha256=PUfelfW84YiqcsbcIAveWMC50rw2DScZ3u_aiaS0Kk8,1015
|
|
60
60
|
funboost/consumers/pulsar_consumer.py,sha256=eorN61kCvP3yg4fNAB3ZCfqpJJxPnAN6PJY48uiYX5Y,2385
|
|
61
|
-
funboost/consumers/rabbitmq_amqpstorm_consumer.py,sha256=
|
|
61
|
+
funboost/consumers/rabbitmq_amqpstorm_consumer.py,sha256=zcSX16cw087MgnrHsiZibNUzIZRKfGBtVVnhnYyYku0,2371
|
|
62
62
|
funboost/consumers/rabbitmq_pika_consumer.py,sha256=51IkRUSR0v2v7BUlA8oInx81VGeO5OaD2pk0UXHdY78,5408
|
|
63
63
|
funboost/consumers/rabbitmq_pika_consumerv0.py,sha256=rIQToBTBqGdjnzMhg0vyZMY87NtK_Uw8ggiTu39JQ_w,4777
|
|
64
64
|
funboost/consumers/rabbitmq_rabbitpy_consumer.py,sha256=xxINY037pmgF3_lJA-zhf9qUIUx6DdqC7tsUOQL3dL4,1330
|
|
@@ -86,7 +86,7 @@ funboost/contrib/redis_consume_latest_msg_broker.py,sha256=ESortBZ2qu_4PBCa3e3Fe
|
|
|
86
86
|
funboost/contrib/save_result_status_to_sqldb.py,sha256=AxvD7nHs4sjr9U0kwEZzyPKrsGdU_JzEgzzhh_V1_4w,4071
|
|
87
87
|
funboost/core/__init__.py,sha256=47DEQpj8HBSa-_TImW-5JCeuQeRkm5NMpJWZG3hSuFU,0
|
|
88
88
|
funboost/core/active_cousumer_info_getter.py,sha256=09fEc-BTEIRfDDfHmOvKnMjLjtOyp4edLsUlAXUR_Qs,4966
|
|
89
|
-
funboost/core/booster.py,sha256=
|
|
89
|
+
funboost/core/booster.py,sha256=xxuDTCb3WrjTzEqfGSPMIz-JYtFIpKJPj9uscupCrgs,19038
|
|
90
90
|
funboost/core/current_task.py,sha256=Oils18_vAqGvV4pqM6yYwnhMaFn3nrpzo1PO48HHidQ,5799
|
|
91
91
|
funboost/core/exceptions.py,sha256=pLF7BkRJAfDiWp2_xGZqencmwdPiSQI1NENbImExknY,1311
|
|
92
92
|
funboost/core/fabric_deploy_helper.py,sha256=foieeqlNySuU9axJzNF6TavPjIUSYBx9UO3syVKUiyY,9999
|
|
@@ -172,9 +172,9 @@ funboost/queues/__init__.py,sha256=47DEQpj8HBSa-_TImW-5JCeuQeRkm5NMpJWZG3hSuFU,0
|
|
|
172
172
|
funboost/queues/memory_queues_map.py,sha256=e1S_cnjnCVI4DBsA_iupF51S_eX4OvCtlefQCqS1TYA,424
|
|
173
173
|
funboost/queues/peewee_queue.py,sha256=FrwegrilkHZG6Y1cGdl5Bt_UtA25f7m5TJQJMZ9YnJI,5280
|
|
174
174
|
funboost/queues/sqla_queue.py,sha256=b-2QPvvuMxklm41ibZhGKehaAV9trXBQFCOHzgThx_s,11080
|
|
175
|
-
funboost/timing_job/__init__.py,sha256=
|
|
176
|
-
funboost/timing_job/apscheduler_use_mysql_store.py,sha256=
|
|
177
|
-
funboost/timing_job/apscheduler_use_redis_store.py,sha256=
|
|
175
|
+
funboost/timing_job/__init__.py,sha256=R-qXGtgnBD6fGxKzTclY980iYLZSj4wv72kVXcjmYWQ,10362
|
|
176
|
+
funboost/timing_job/apscheduler_use_mysql_store.py,sha256=ss92DiSLzbWuVIo19sTLgC99GessltWLOlqqOd4AIL4,471
|
|
177
|
+
funboost/timing_job/apscheduler_use_redis_store.py,sha256=RNZVerUTTzpSFMFEHWkDrUOSz71B4Ml_hlcavkL1tAA,2933
|
|
178
178
|
funboost/utils/__init__.py,sha256=rAyXE7lgCo_3VdMvGrIJiqsTHv2nZPTJDTj1f6s_KgE,586
|
|
179
179
|
funboost/utils/apscheduler_monkey.py,sha256=CcUISbqX6nMWSxr_QjZ26IvvhUk_ojYZWRaKenpsKfE,3124
|
|
180
180
|
funboost/utils/block_exit.py,sha256=BnfxNYo3lnmhk686RAEoc4u3D4RU_iEMMMgu5L8gIuI,96
|
|
@@ -182,7 +182,7 @@ funboost/utils/bulk_operation.py,sha256=B4FBxlz5f4oqlKDWqer7axn4gnDSfsYoMW2zSUCn
|
|
|
182
182
|
funboost/utils/class_utils.py,sha256=yDsGF4-SaO7k4gtkpYLlACSeejS5FfdIHn087BE_4Cw,3579
|
|
183
183
|
funboost/utils/ctrl_c_end.py,sha256=FgT9An-qsUA5gW-V-UKWqOh5shC7C_uvTFn0fS7i8GI,439
|
|
184
184
|
funboost/utils/custom_pysnooper.py,sha256=7yXLKEMY_JjPRRt0Y0N-wV2CFhILlYNh40Y6uRBUaj8,5923
|
|
185
|
-
funboost/utils/decorators.py,sha256=
|
|
185
|
+
funboost/utils/decorators.py,sha256=gpwof-Nw__iFjeJjVQWx1l-scnxTivxcCI_0XqhMu6c,27885
|
|
186
186
|
funboost/utils/develop_log.py,sha256=Wsx0ongGjTit5xqgk1BztYlVEkC6d0-Y7GENXLedVqY,271
|
|
187
187
|
funboost/utils/expire_lock.py,sha256=AOkd1KlvZeIwQaz8ZoKxLpGxWgqQ4mfNHcFphh04o8Q,4732
|
|
188
188
|
funboost/utils/json_helper.py,sha256=kwN5O-0Z3_9KS3JdBx-BltS9LI3Rfoq329vgkxMPVw4,2286
|
|
@@ -277,9 +277,9 @@ funboost/utils/pysnooper_ydf/utils.py,sha256=evSmGi_Oul7vSP47AJ0DLjFwoCYCfunJZ1m
|
|
|
277
277
|
funboost/utils/pysnooper_ydf/variables.py,sha256=QejRDESBA06KG9OH4sBT4J1M55eaU29EIHg8K_igaXo,3693
|
|
278
278
|
funboost/utils/times/__init__.py,sha256=Y4bQD3SIA_E7W2YvHq2Qdi0dGM4H2DxyFNdDOuFOq1w,2417
|
|
279
279
|
funboost/utils/times/version.py,sha256=11XfnZVVzOgIhXXdeN_mYfdXThfrsbQHpA0wCjz-hpg,17
|
|
280
|
-
funboost-46.
|
|
281
|
-
funboost-46.
|
|
282
|
-
funboost-46.
|
|
283
|
-
funboost-46.
|
|
284
|
-
funboost-46.
|
|
285
|
-
funboost-46.
|
|
280
|
+
funboost-46.8.dist-info/LICENSE,sha256=9EPP2ktG_lAPB8PjmWV-c9BiaJHc_FP6pPLcUrUwx0E,11562
|
|
281
|
+
funboost-46.8.dist-info/METADATA,sha256=WoRBshgxIusIER8SK4_DC3iIzpB89_Le-VWEmkTYW_w,32849
|
|
282
|
+
funboost-46.8.dist-info/WHEEL,sha256=G16H4A3IeoQmnOrYV4ueZGKSjhipXx8zc8nu9FGlvMA,92
|
|
283
|
+
funboost-46.8.dist-info/entry_points.txt,sha256=BQMqRALuw-QT9x2d7puWaUHriXfy3wIzvfzF61AnSSI,97
|
|
284
|
+
funboost-46.8.dist-info/top_level.txt,sha256=K8WuKnS6MRcEWxP1NvbmCeujJq6TEfbsB150YROlRw0,9
|
|
285
|
+
funboost-46.8.dist-info/RECORD,,
|
|
File without changes
|
|
File without changes
|
|
File without changes
|
|
File without changes
|