欧美bbbwbbbw肥妇,免费乱码人妻系列日韩,一级黄片

Python Asyncio調(diào)度原理詳情

 更新時間:2022年06月27日 11:30:24   作者:? so1n?  ?  
這篇文章主要介紹了Python Asyncio調(diào)度原理詳情,Python.Asyncio是一個大而全的庫,它包括很多功能,而跟核心調(diào)度相關(guān)的邏輯除了三種可等待對象外,還有其它一些功能,它們分別位于runners.py,base_event.py,event.py三個文件中

前言

在文章《Python Asyncio中Coroutines,Tasks,Future可等待對象的關(guān)系及作用》中介紹了Python的可等待對象作用,特別是Task對象在啟動的時候可以自我驅(qū)動,但是一個Task對象只能驅(qū)動一條執(zhí)行鏈,如果要多條鏈執(zhí)行(并發(fā)),還是需要EventLoop來安排驅(qū)動,接下來將通過Python.Asyncio庫的源碼來了解EventLoop是如何運作的。

1.基本介紹

Python.Asyncio是一個大而全的庫,它包括很多功能,而跟核心調(diào)度相關(guān)的邏輯除了三種可等待對象外,還有其它一些功能,它們分別位于runners.pybase_event.py,event.py三個文件中。

runners.py文件有一個主要的類--Runner,它的主要職責是做好進入?yún)f(xié)程模式的事件循環(huán)等到初始化工作,以及在退出協(xié)程模式時清理還在內(nèi)存的協(xié)程,生成器等對象。

協(xié)程模式只是為了能方便理解,對于計算機而言,并沒有這樣區(qū)分

event.py文件除了存放著EventLoop對象的接口以及獲取和設(shè)置EventLoop的函數(shù)外,還有兩個EventLoop可調(diào)度的對象,分別為HandlerTimerHandler,它們可以認為是EvnetLoop調(diào)用其它對象的容器,用于連接待調(diào)度對象和事件循環(huán)的關(guān)系,不過它們的實現(xiàn)非常簡單,對于Handler它的源碼如下:

# 已經(jīng)移除了一些不想關(guān)的代碼
class Handle:
    def __init__(self, callback, args, loop, context=None):
        # 初始化上下文,確保執(zhí)行的時候能找到Handle所在的上下文
        if context is None:
            context = contextvars.copy_context()
        self._context = context
        self._loop = loop
        self._callback = callback
        self._args = args
        self._cancelled = False

    def cancel(self):
        # 設(shè)置當前Handle為取消狀態(tài)
        if not self._cancelled:
            self._cancelled = True
            self._callback = None
            self._args = None
    def cancelled(self):
        return self._cancelled
    def _run(self):
        # 用于執(zhí)行真正的函數(shù),且通過context.run方法來確保在自己的上下文內(nèi)執(zhí)行。
        try:
            # 保持在自己持有的上下文中執(zhí)行對應(yīng)的回調(diào)
            self._context.run(self._callback, *self._args)
        except (SystemExit, KeyboardInterrupt):
            raise
        except BaseException as exc:
            cb = format_helpers._format_callback_source(
                self._callback, self._args)
            msg = f'Exception in callback {cb}'
            context = {
                'message': msg,
                'exception': exc,
                'handle': self,
            }
            self._loop.call_exception_handler(context)

通過源碼可以發(fā)現(xiàn),Handle功能十分簡單,提供了可以被取消以及可以在自己所處的上下文執(zhí)行的功能,而TimerHandle繼承于HandleHandle多了一些和時間以及排序相關(guān)的參數(shù),源碼如下:

class TimerHandle(Handle):
    def __init__(self, when, callback, args, loop, context=None):
        super().__init__(callback, args, loop, context)
        self._when = when
        self._scheduled = False
    def __hash__(self):
        return hash(self._when)
    def __lt__(self, other):
        if isinstance(other, TimerHandle):
            return self._when < other._when
        return NotImplemented
    def __le__(self, other):
        if isinstance(other, TimerHandle):
            return self._when < other._when or self.__eq__(other)
        return NotImplemented
    def __gt__(self, other):
        if isinstance(other, TimerHandle):
            return self._when > other._when
        return NotImplemented
    def __ge__(self, other):
        if isinstance(other, TimerHandle):
            return self._when > other._when or self.__eq__(other)
        return NotImplemented
    def __eq__(self, other):
        if isinstance(other, TimerHandle):
            return (self._when == other._when and
                    self._callback == other._callback and
                    self._args == other._args and
                    self._cancelled == other._cancelled)
        return NotImplemented
    def cancel(self):
        if not self._cancelled:
            # 用于通知事件循環(huán)當前Handle已經(jīng)退出了
            self._loop._timer_handle_cancelled(self)
        super().cancel()
    def when(self):
        return self._when

通過代碼可以發(fā)現(xiàn),這兩個對象十分簡單,而我們在使用Python.Asyncio時并不會直接使用到這兩個對象,而是通過loop.call_xxx系列方法來把調(diào)用封裝成Handle對象,然后等待EventLoop執(zhí)行。 所以loop.call_xxx系列方法可以認為是EventLoop的注冊操作,基本上所有非IO的異步操作都需要通過loop.call_xxx方法來把自己的調(diào)用注冊到EventLoop中,比如Task對象就在初始化后通過調(diào)用loop.call_soon方法來注冊到EventLoop中,loop.call_sonn的實現(xiàn)很簡單,

它的源碼如下:

class BaseEventLoop:
    ...
    def call_soon(self, callback, *args, context=None):
        # 檢查是否事件循環(huán)是否關(guān)閉,如果是則直接拋出異常
        self._check_closed()
        handle = self._call_soon(callback, args, context)
        return handle

   def _call_soon(self, callback, args, context):
        # 把調(diào)用封裝成一個handle,這樣方便被事件循環(huán)調(diào)用
        handle = events.Handle(callback, args, self, context)
        # 添加一個handle到_ready,等待被調(diào)用
        self._ready.append(handle)
        return handle

可以看到call_soon真正相關(guān)的代碼只有10幾行,它負責把一個調(diào)用封裝成一個Handle,并添加到self._reday中,從而實現(xiàn)把調(diào)用注冊到事件循環(huán)之中。

loop.call_xxx系列函數(shù)除了loop.call_soon系列函數(shù)外,還有另外兩個方法--loop.call_atloop.call_later,它們類似于loop.call_soon,不過多了一個時間參數(shù),來告訴EventLoop在什么時間后才可以調(diào)用,同時通過loop.call_atloop.call_later注冊的調(diào)用會通過Python的堆排序模塊headpq注冊到self._scheduled變量中,

具體代碼如下:

class BaseEventLoop:
    ...
    def call_later(self, delay, callback, *args, context=None):
        if delay is None:
            raise TypeError('delay must not be None')
        timer = self.call_at(self.time() + delay, callback, *args, context=context)
        return timer

    def call_at(self, when, callback, *args, context=None):
        if when is None:
            raise TypeError("when cannot be None")
        self._check_closed()
        # 創(chuàng)建一個timer handle,然后添加到事件循環(huán)的_scheduled中,等待被調(diào)用
        timer = events.TimerHandle(when, callback, args, self, context)
        heapq.heappush(self._scheduled, timer)
        timer._scheduled = True
        return timer

2.EventLoop的調(diào)度實現(xiàn)

在文章《Python Asyncio中Coroutines,Tasks,Future可等待對象的關(guān)系及作用》中已經(jīng)分析到了runner會通過loop.run_until_complete來調(diào)用mainTask從而開啟EventLoop的調(diào)度,所以在分析EventLoop的調(diào)度時,應(yīng)該先從loop.run_until_complete入手,

對應(yīng)的源碼如下:

class BaseEventLoop:
    def run_until_complete(self, future):
        ...
        new_task = not futures.isfuture(future)
        # 把coroutine轉(zhuǎn)換成task,這樣事件循環(huán)就可以調(diào)度了,事件循環(huán)的最小調(diào)度單位為task
        # 需要注意的是此時事件循環(huán)并沒注冊到全局變量中,所以需要顯示的傳進去,
        # 同時Task對象注冊的時候,已經(jīng)通過loop.call_soon把自己注冊到事件循環(huán)中,等待調(diào)度
        future = tasks.ensure_future(future, loop=self)
        if new_task:
            # An exception is raised if the future didn't complete, so there
            # is no need to log the "destroy pending task" message
            future._log_destroy_pending = False
        # 當該task完成時,意味著當前事件循環(huán)失去了調(diào)度對象,無法繼續(xù)調(diào)度,所以需要關(guān)閉當前事件循環(huán),程序會由協(xié)程模式返回到線程模式
        future.add_done_callback(_run_until_complete_cb)
        try:
            # 事件循環(huán)開始運行
            self.run_forever()
        except:
            if new_task and future.done() and not future.cancelled():
                # The coroutine raised a BaseException. Consume the exception
                # to not log a warning, the caller doesn't have access to the
                # local task.
                future.exception()
            raise
        finally:
            future.remove_done_callback(_run_until_complete_cb)
        if not future.done():
            raise RuntimeError('Event loop stopped before Future completed.')

        return future.result()

    def run_forever(self):
        # 進行一些初始化工作
        self._check_closed()
        self._check_running()
        self._set_coroutine_origin_tracking(self._debug)
        self._thread_id = threading.get_ident()

        old_agen_hooks = sys.get_asyncgen_hooks()
        # 通過asyncgen鉤子來自動關(guān)閉asyncgen函數(shù),這樣可以提醒用戶生成器還未關(guān)閉
        sys.set_asyncgen_hooks(firstiter=self._asyncgen_firstiter_hook,
                               finalizer=self._asyncgen_finalizer_hook)
        try:
            # 設(shè)置當前在運行的事件循環(huán)到全局變量中,這樣就可以在任一階段獲取到當前的事件循環(huán)了
            events._set_running_loop(self)
            while True:
                # 正真執(zhí)行任務(wù)的邏輯
                self._run_once()
                if self._stopping:
                    break
        finally:
            # 關(guān)閉循環(huán), 并且清理一些資源
            self._stopping = False
            self._thread_id = None
            events._set_running_loop(None)
            self._set_coroutine_origin_tracking(False)
            sys.set_asyncgen_hooks(*old_agen_hooks)

這段源碼并不復雜,它的主要邏輯是通過把Corotinue轉(zhuǎn)為一個Task對象,然后通過Task對象初始化時調(diào)用loop.call_sonn方法把自己注冊到EventLoop中,最后再通過loop.run_forever中的循環(huán)代碼一直運行著,直到_stopping被標記為True:

while True:
    # 正真執(zhí)行任務(wù)的邏輯
    self._run_once()
    if self._stopping:
        break

可以看出,這段代碼是確保事件循環(huán)能一直執(zhí)行著,自動循環(huán)結(jié)束,而真正調(diào)度的核心是_run_once函數(shù),

它的源碼如下:

class BaseEventLoop:
    ...
    def _run_once(self):
        # self._scheduled是一個列表,它只存放TimerHandle
        sched_count = len(self._scheduled)
        ###############################
        # 第一階段,整理self._scheduled #
        ###############################
        if (sched_count > _MIN_SCHEDULED_TIMER_HANDLES and
            self._timer_cancelled_count / sched_count > _MIN_CANCELLED_TIMER_HANDLES_FRACTION):
            # 當待調(diào)度的任務(wù)數(shù)量超過100且待取消的任務(wù)占總?cè)蝿?wù)的50%時,才進入這個邏輯
            # 把需要取消的任務(wù)移除
            new_scheduled = []
            for handle in self._scheduled:
                if handle._cancelled:
                    # 設(shè)置handle的_cancelled為True,并且把handle從_scheduled中移除
                    handle._scheduled = False
                else:
                    new_scheduled.append(handle)

            # 重新排列堆
            heapq.heapify(new_scheduled)
            self._scheduled = new_scheduled
            self._timer_cancelled_count = 0
        else:
            # 需要取消的handle不多,則只會走這個邏輯,這里會把堆頂?shù)膆andle彈出,并標記為不可調(diào)度,但不會訪問整個堆
            while self._scheduled and self._scheduled[0]._cancelled:
                self._timer_cancelled_count -= 1
                handle = heapq.heappop(self._scheduled)
                handle._scheduled = False

        #################################
        # 第二階段,計算超時值以及等待事件IO #
        #################################
        timeout = None
        # 當有準備調(diào)度的handle或者是正在關(guān)閉時,不等待,方便盡快的調(diào)度
        if self._ready or self._stopping:
            timeout = 0
        elif self._scheduled:
            # Compute the desired timeout.
            # 如果堆有數(shù)據(jù)時,通過堆頂?shù)膆andle計算最短的超時時間,但是最多不能超過MAXIMUM_SELECT_TIMEOUT,以免超過系統(tǒng)限制
            when = self._scheduled[0]._when
            timeout = min(max(0, when - self.time()), MAXIMUM_SELECT_TIMEOUT)

        # 事件循環(huán)等待事件,直到有事件或者超時
        event_list = self._selector.select(timeout)

        ##################################################
        # 第三階段,把滿足條件的TimeHandle放入到self._ready中 #
        ##################################################
        # 獲取得到的事件的回調(diào),然后裝填到_ready
        self._process_events(event_list)

        # 把一些在self._scheduled且滿足調(diào)度條件的handle放到_ready中,比如TimerHandle。
        # end_time為當前時間+一個時間單位,猜測是能多處理一些這段時間內(nèi)產(chǎn)生的事件
        end_time = self.time() + self._clock_resolution
        while self._scheduled:
            handle = self._scheduled[0]
            if handle._when >= end_time:
                break
            handle = heapq.heappop(self._scheduled)
            handle._scheduled = False
            self._ready.append(handle)

        ################################################################################
        # 第四階段,遍歷所有準備調(diào)度的handle,并且通過handle的context來執(zhí)行handle對應(yīng)的callback #
        ################################################################################
        ntodo = len(self._ready)
        for i in range(ntodo):
            handle = self._ready.popleft()
            # 如果handle已經(jīng)被取消,則不調(diào)用
            if handle._cancelled:
                continue
            if self._debug:
                try:
                    self._current_handle = handle
                    t0 = self.time()
                    handle._run()
                    dt = self.time() - t0
                    if dt >= self.slow_callback_duration:
                        # 執(zhí)行太久的回調(diào),記錄下來,這些需要開發(fā)者自己優(yōu)化
                        logger.warning('Executing %s took %.3f seconds',
                                       _format_handle(handle), dt)
                finally:
                    self._current_handle = None
            else:
                handle._run()
        handle = None  # Needed to break cycles when an exception occurs.

通過源碼分析,可以很明確的知道調(diào)度邏輯中第一步是先規(guī)整self._scheduled,在規(guī)整的過程是使用堆排序來進行的,因為堆排序在調(diào)度的場景下效率是非常高的,不過這段規(guī)整代碼分成兩種,我猜測是當需要取消的數(shù)量過多時直接遍歷的效率會更高。 在規(guī)整self._scheduled后,就進入第二步,該步驟開始等待系統(tǒng)事件循環(huán)返回對應(yīng)的事件,如果self._ready中有數(shù)據(jù),就不做等待了,需要馬上到下一步驟,以便能趕緊安排調(diào)度。 在得到系統(tǒng)事件循環(huán)得到的事件后,就進入到了第三步,該步驟會通過self._process_events方法處理對應(yīng)的事件,并把事件對應(yīng)的回調(diào)存放到了self._ready中,最后再遍歷self._ready中的所有Handle并逐一執(zhí)行(執(zhí)行時可以認為EventLoop把控制權(quán)返回給對應(yīng)的調(diào)用邏輯),至此一個完整的調(diào)度邏輯就結(jié)束了,并進入下一個調(diào)度邏輯。

3.網(wǎng)絡(luò)IO事件的處理

注:由于系統(tǒng)事件循環(huán)的限制,所以文件IO一般還是使用多線程來執(zhí)行,具體見:github.com/python/asyn…

在分析EventLoop調(diào)度實現(xiàn)的時候忽略了self._process_events的具體實現(xiàn)邏輯,因為_process_events方法所在asyncio.base_event.py文件中的BaseEventLoop類并未有具體實現(xiàn)的,因為網(wǎng)絡(luò)IO相關(guān)的需要系統(tǒng)的事件循環(huán)來幫忙處理,所以與系統(tǒng)事件循環(huán)相關(guān)的邏輯都在asyncio.selector_events.py中的BaseSelectorEventLoop類中。BaseSelectorEventLoop類封裝了selector模塊與系統(tǒng)事件循環(huán)交互,使調(diào)用者不需要去考慮sock的創(chuàng)建以及sock產(chǎn)生的文件描述符的監(jiān)聽與注銷等操作,下面以BaseSelectorEventLoop中自帶的pipe為例子,分析BaseSelectorEventLoop是如何進行網(wǎng)絡(luò)IO事件處理的。

在分析之前,先看一個例子,代碼如下:

import asyncio
import threading
def task():
    print("task")
def run_loop_inside_thread(loop):
    loop.run_forever()
loop = asyncio.get_event_loop()
threading.Thread(target=run_loop_inside_thread, args=(loop,)).start()
loop.call_soon(task)

如果直接運行這個例子,它并不會輸出task(不過在IDE使用DEBUG模式下線程啟動會慢一點,所以會輸出的),因為在調(diào)用loop.run_foreverEventLoop會一直卡在這段邏輯中:

event_list = self._selector.select(timeout)

所以調(diào)用loop.call_soon并不會使EventLoop馬上安排調(diào)度,而如果把call_soon換成call_soon_threadsafe則可以正常輸出,這是因為call_soon_threadsafe中多了一個self._write_to_self的調(diào)用,它的源碼如下:

class BaseEventLoop:
    ...
    def call_soon_threadsafe(self, callback, *args, context=None):
        """Like call_soon(), but thread-safe."""
        self._check_closed()
        handle = self._call_soon(callback, args, context)
        self._write_to_self()
        return handle

由于這個調(diào)用是涉及到IO相關(guān)的,所以需要到BaseSelectorEventLoop類查看,接下來以pipe相關(guān)的網(wǎng)絡(luò)IO操作來分析EventLoop是如何處理IO事件的(只演示reader對象,writer對象操作與reader類似),

對應(yīng)的源碼如下:

class BaseSelectorEventLoop(base_events.BaseEventLoop):
    #######
    # 創(chuàng)建 #
    #######
    def __init__(self, selector=None):
        super().__init__()

        if selector is None:
            # 獲取最優(yōu)的selector
            selector = selectors.DefaultSelector()
        self._selector = selector
        # 創(chuàng)建pipe
        self._make_self_pipe()
        self._transports = weakref.WeakValueDictionary()
    def _make_self_pipe(self):
        # 創(chuàng)建Pipe對應(yīng)的sock 
        self._ssock, self._csock = socket.socketpair()
        # 設(shè)置sock為非阻塞
        self._ssock.setblocking(False)
        self._csock.setblocking(False)
        self._internal_fds += 1
        # 阻塞服務(wù)端sock讀事件對應(yīng)的回調(diào)
        self._add_reader(self._ssock.fileno(), self._read_from_self)
    def _add_reader(self, fd, callback, *args):
        # 檢查事件循環(huán)是否關(guān)閉
        self._check_closed()
        # 封裝回調(diào)為handle對象
        handle = events.Handle(callback, args, self, None)
        try:
            key = self._selector.get_key(fd)
        except KeyError:
            # 如果沒有注冊到系統(tǒng)的事件循環(huán),則注冊
            self._selector.register(fd, selectors.EVENT_READ,
                                    (handle, None))
        else:
            # 如果已經(jīng)注冊過,則更新
            mask, (reader, writer) = key.events, key.data
            self._selector.modify(fd, mask | selectors.EVENT_READ,
                                  (handle, writer))
            if reader is not None:
                reader.cancel()
        return handle

    def _read_from_self(self):
        # 負責消費sock數(shù)據(jù)
        while True:
            try:
                data = self._ssock.recv(4096)
                if not data:
                    break
                self._process_self_data(data)
            except InterruptedError:
                continue
            except BlockingIOError:
                break
    #######
    # 刪除 #
    #######
    def _close_self_pipe(self):
        # 注銷Pipe對應(yīng)的描述符 
        self._remove_reader(self._ssock.fileno())
        # 關(guān)閉sock
        self._ssock.close()
        self._ssock = None
        self._csock.close()
        self._csock = None
        self._internal_fds -= 1

    def _remove_reader(self, fd):
        # 如果事件循環(huán)已經(jīng)關(guān)閉了,就不用操作了
        if self.is_closed():
            return False
        try:
            # 查詢文件描述符是否在selector中
            key = self._selector.get_key(fd)
        except KeyError:
            # 不存在則返回
            return False
        else:
            # 存在則進入移除的工作
            mask, (reader, writer) = key.events, key.data
            # 通過事件掩碼判斷是否有其它事件
            mask &= ~selectors.EVENT_READ
            if not mask:
                # 移除已經(jīng)注冊到selector的文件描述符
                self._selector.unregister(fd)
            else:
                # 移除已經(jīng)注冊到selector的文件描述符,并注冊新的事件
                self._selector.modify(fd, mask, (None, writer))

            # 如果reader不為空,則取消reader
            if reader is not None:
                reader.cancel()
                return True
            else:
                return False

通過源碼中的創(chuàng)建部分可以看到,EventLoop在啟動的時候會創(chuàng)建一對建立通信的sock,并設(shè)置為非阻塞,然后把對應(yīng)的回調(diào)封裝成一個Handle對象并注冊到系統(tǒng)事件循環(huán)中(刪除則進行對應(yīng)的反向操作),之后系統(tǒng)事件循環(huán)就會一直監(jiān)聽對應(yīng)的事件,也就是EventLoop的執(zhí)行邏輯會阻塞在下面的調(diào)用中,等待事件響應(yīng):

event_list = self._selector.select(timeout)

這時如果執(zhí)行loop.call_soon_threadsafe,那么會通過write_to_self寫入一點信息:

    def _write_to_self(self):
        csock = self._csock
        if csock is None:
            return
        try:
            csock.send(b'\0')
        except OSError:
            if self._debug:
                logger.debug("Fail to write a null byte into the self-pipe socket", exc_info=True)

由于csock被寫入了數(shù)據(jù),那么它對應(yīng)的ssock就會收到一個讀事件,系統(tǒng)事件循環(huán)在收到這個事件通知后就會把數(shù)據(jù)返回,然后EventLoop就會獲得到對應(yīng)的數(shù)據(jù),并交給process_events方法進行處理,

它的相關(guān)代碼如下:

class BaseSelectorEventLoop:
    def _process_events(self, event_list):
        for key, mask in event_list:
            # 從回調(diào)事件中獲取到對應(yīng)的數(shù)據(jù),key.data在注冊時是一個元祖,所以這里要對元祖進行解包
            fileobj, (reader, writer) = key.fileobj, key.data
            if mask & selectors.EVENT_READ and reader is not None:
                # 得到reader handle,如果是被標記為取消,就移除對應(yīng)的文件描述符
                if reader._cancelled:
                    self._remove_reader(fileobj)
                else:
                    # 如果沒被標記為取消,則安排到self._ready中
                    self._add_callback(reader)
            if mask & selectors.EVENT_WRITE and writer is not None:
                # 對于寫對象,也是同樣的道理。
                if writer._cancelled:
                    self._remove_writer(fileobj)
                else:
                    self._add_callback(writer)

    def _add_callback(self, handle):
        # 把回調(diào)的handle添加到_ready中
        assert isinstance(handle, events.Handle), 'A Handle is required here'
        if handle._cancelled:
            return
        assert not isinstance(handle, events.TimerHandle)
        self._ready.append(handle)

    def _remove_reader(self, fd):
        # 如果事件循環(huán)已經(jīng)關(guān)閉了,就不用操作了
        if self.is_closed():
            return False
        try:
            # 查詢文件描述符是否在selector中
            key = self._selector.get_key(fd)
        except KeyError:
            # 不存在則返回
            return False
        else:
            # 存在則進入移除的工作
            mask, (reader, writer) = key.events, key.data
            mask &= ~selectors.EVENT_READ
            if not mask:
                # 移除已經(jīng)注冊到selector的文件描述符
                self._selector.unregister(fd)
            else:
                self._selector.modify(fd, mask, (None, writer))

            if reader is not None:
                reader.cancel()
                return True
            else:
                return False

從代碼中可以看出_process_events會對事件對應(yīng)的文件描述符進行處理,并從事件回調(diào)中獲取到對應(yīng)的Handle對象添加到self._ready中,由EventLoop在接下來遍歷self._ready并執(zhí)行。

可以看到網(wǎng)絡(luò)IO事件的處理并不復雜,因為系統(tǒng)事件循環(huán)已經(jīng)為我們做了很多工作了,但是用戶所有與網(wǎng)絡(luò)IO相關(guān)的操作都需要有一個類似的操作,這樣是非常的繁瑣的,幸好asyncio庫已經(jīng)為我們做了封裝,我們只要調(diào)用就可以了,方便了很多。

到此這篇關(guān)于Python Asyncio調(diào)度原理詳情的文章就介紹到這了,更多相關(guān)Python Asyncio 內(nèi)容請搜索腳本之家以前的文章或繼續(xù)瀏覽下面的相關(guān)文章希望大家以后多多支持腳本之家!

相關(guān)文章

  • Python如何在循環(huán)內(nèi)使用list.remove()

    Python如何在循環(huán)內(nèi)使用list.remove()

    這篇文章主要介紹了Python如何在循環(huán)內(nèi)使用list.remove(),文中通過示例代碼介紹的非常詳細,對大家的學習或者工作具有一定的參考學習價值,需要的朋友可以參考下
    2020-06-06
  • Python實現(xiàn)獲取當前目錄下文件名代碼詳解

    Python實現(xiàn)獲取當前目錄下文件名代碼詳解

    這篇文章主要介紹了Python實現(xiàn)獲取當前目錄下文件名,本文通過實例代碼給大家介紹的非常詳細,對大家的學習或工作具有一定的參考借鑒價值,需要的朋友可以參考下
    2020-03-03
  • TensorFlow MNIST手寫數(shù)據(jù)集的實現(xiàn)方法

    TensorFlow MNIST手寫數(shù)據(jù)集的實現(xiàn)方法

    MNIST數(shù)據(jù)集中包含了各種各樣的手寫數(shù)字圖片,這篇文章主要介紹了TensorFlow MNIST手寫數(shù)據(jù)集的實現(xiàn)方法,需要的朋友可以參考下
    2020-02-02
  • 使用 Python 在京東上搶口罩的思路詳解

    使用 Python 在京東上搶口罩的思路詳解

    受疫情影響全民真的在搶口罩,而且還是搶不到的那種。這篇文章主要介紹了用 Python 在京東上搶口罩的實例代碼,代碼簡單易懂,非常不錯,具有一定的參考借鑒價值,需要的朋友可以參考下
    2020-02-02
  • 使用PyTorch構(gòu)建神經(jīng)網(wǎng)絡(luò)的操作指南

    使用PyTorch構(gòu)建神經(jīng)網(wǎng)絡(luò)的操作指南

    PyTorch 是一個在研究領(lǐng)域廣泛使用的深度學習框架,提供了大量的靈活性和效率,本文將向你介紹如何使用 PyTorch 構(gòu)建你的第一個神經(jīng)網(wǎng)絡(luò),感興趣的小伙伴可以參考閱讀
    2023-07-07
  • 舉例講解Python面向?qū)ο缶幊讨蓄惖睦^承

    舉例講解Python面向?qū)ο缶幊讨蓄惖睦^承

    類是面向?qū)ο笳Z言中的標配,同樣類的繼承也是體現(xiàn)面向?qū)ο蟮闹匾匦?這里我們就來舉例講解Python面向?qū)ο缶幊讨蓄惖睦^承,需要的朋友可以參考下
    2016-06-06
  • Python基于xlrd模塊處理合并單元格

    Python基于xlrd模塊處理合并單元格

    這篇文章主要介紹了Python基于xlrd模塊處理合并單元格,文中通過示例代碼介紹的非常詳細,對大家的學習或者工作具有一定的參考學習價值,需要的朋友可以參考下
    2020-07-07
  • 在python下使用tensorflow判斷是否存在文件夾的實例

    在python下使用tensorflow判斷是否存在文件夾的實例

    今天小編就為大家分享一篇在python下使用tensorflow判斷是否存在文件夾的實例,具有很好的參考價值,希望對大家有所幫助。一起跟隨小編過來看看吧
    2019-06-06
  • python獲取redis memory使用情況場景分析

    python獲取redis memory使用情況場景分析

    這篇文章主要介紹了python獲取redis memory使用情況,項目研發(fā)過程中,用到Python操作Redis場景,記錄學習過程中的心得體會,需要的朋友可以參考下
    2022-12-12
  • 聊聊Python中的@符號是什么意思

    聊聊Python中的@符號是什么意思

    @符號用做函數(shù)的修飾符,可以在模塊或者類的定義層內(nèi)對函數(shù)進行修飾,下面這篇文章主要給大家介紹了關(guān)于Python中@符號是什么意思的相關(guān)資料,需要的朋友可以參考下
    2021-09-09

最新評論