当前位置: 首页>>代码示例>>Python>>正文


Python asyncio.wrap_future方法代码示例

本文整理汇总了Python中asyncio.wrap_future方法的典型用法代码示例。如果您正苦于以下问题:Python asyncio.wrap_future方法的具体用法?Python asyncio.wrap_future怎么用?Python asyncio.wrap_future使用的例子?那么恭喜您, 这里精选的方法代码示例或许可以为您提供帮助。您也可以进一步了解该方法所在asyncio的用法示例。


在下文中一共展示了asyncio.wrap_future方法的15个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于系统推荐出更棒的Python代码示例。

示例1: run_in_executor

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def run_in_executor(self, executor, callback, *args):
        """Run callback in executor.

        If no executor is provided, the default executor will be used, which defers execution to
        a background thread.
        """
        self._logger.debug('Running callback {} with args {} in executor'.format(callback, args))
        if isinstance(callback, asyncio.Handle):
            assert not args
            assert not isinstance(callback, asyncio.TimerHandle)
            if callback._cancelled:
                f = asyncio.Future()
                f.set_result(None)
                return f
            callback, args = callback.callback, callback.args

        if executor is None:
            self._logger.debug('Using default executor')
            executor = self.__default_executor

        if executor is None:
            self._logger.debug('Creating default executor')
            executor = self.__default_executor = QThreadExecutor()

        return asyncio.wrap_future(executor.submit(callback, *args)) 
开发者ID:gmarull,项目名称:asyncqt,代码行数:27,代码来源:__init__.py

示例2: _Compute

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def _Compute(
      self,
      request: executor_pb2.ComputeRequest,
      context: grpc.ServicerContext,
  ) -> executor_pb2.ComputeResponse:
    """Asynchronous implemention of `Compute`."""
    py_typecheck.check_type(request, executor_pb2.ComputeRequest)
    try:
      value_id = str(request.value_ref.id)
      with self._lock:
        future_val = asyncio.wrap_future(self._values[value_id])
      val = await future_val
      result_val = await val.compute()
      val_type = val.type_signature
      value_proto, _ = executor_service_utils.serialize_value(
          result_val, val_type)
      return executor_pb2.ComputeResponse(value=value_proto)
    except (ValueError, TypeError) as err:
      _set_invalid_arg_err(context, err)
      return executor_pb2.ComputeResponse() 
开发者ID:tensorflow,项目名称:federated,代码行数:22,代码来源:executor_service.py

示例3: get

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def get(self):
        consumer_token = ConsumerToken(
            self.authenticator.client_id,
            self.authenticator.client_secret,
        )

        handshaker = Handshaker(
            self.authenticator.mw_index_url, consumer_token
        )

        redirect, request_token = await wrap_future(
            self.authenticator.executor.submit(handshaker.initiate)
        )

        self.set_secure_cookie(
            AUTH_REQUEST_COOKIE_NAME,
            jsonify(request_token),
            expires_days=1,
            path=url_path_join(self.base_url, 'hub', 'oauth_callback'),
            httponly=True)
        self.log.info('oauth redirect: %r', redirect)

        self.redirect(redirect) 
开发者ID:jupyterhub,项目名称:oauthenticator,代码行数:25,代码来源:mediawiki.py

示例4: run_in_order_threadsafe

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def run_in_order_threadsafe(awaitables, loop, timeout=0.5, block=True):
    """"Given a sequence of awaitables, schedule each threadsafe in order
    optionally blocking until completion.

    Returns a `concurrent.futures.Future` which can be used to wait on the
    result returned from the last awaitable. If `block` is `True` the final
    result will be waited on before returning control to the caller.
    """
    future = asyncio.run_coroutine_threadsafe(
        await_in_order(awaitables, loop, timeout),
        loop
    )

    if block:
        if not loop.is_running():
            result = loop.run_until_complete(
                asyncio.wrap_future(future, loop=loop))
            assert result is future.result()
        else:
            future.result(timeout)

    return future 
开发者ID:friends-of-freeswitch,项目名称:switchio,代码行数:24,代码来源:connection.py

示例5: ask

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def ask(self, dst, content=None, dst_node=None):
        """Send request and wait response"""
        if not dst_node:
            dst_node = self.registery.choice_dst_node(dst)
        msg = self.registery.create_message(
            dst=dst,
            is_ask=True,
            content=content,
            src=self.actor.name,
            dst_node=dst_node,
        )
        if msg.is_local:
            future = ThreadFuture()
            msg.future = future
            if self.actor.is_async:
                return asyncio.wrap_future(future)
            else:
                return future.result()
        else:
            return self._actor_client.ask(msg) 
开发者ID:anyant,项目名称:rssant,代码行数:22,代码来源:context.py

示例6: watch_build_pods

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def watch_build_pods(self):
        """Watch build pods

        Every build_cleanup_interval:
        - delete stopped build pods
        - delete running build pods older than build_max_age
        """
        while True:
            try:
                await asyncio.wrap_future(
                    self.executor.submit(
                        lambda: Build.cleanup_builds(
                            self.kube_client,
                            self.build_namespace,
                            self.build_max_age,
                        )
                    )
                )
            except Exception:
                app_log.exception("Failed to cleanup build pods")
            await asyncio.sleep(self.build_cleanup_interval) 
开发者ID:jupyterhub,项目名称:binderhub,代码行数:23,代码来源:app.py

示例7: _get_pods

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def _get_pods(self):
        """Get information about build and user pods"""
        app_log.info("Getting pod statistics")
        k8s = self.settings["kubernetes_client"]
        pool = self.settings["executor"]

        get_user_pods = asyncio.wrap_future(
            pool.submit(
                k8s.list_namespaced_pod,
                self.settings["build_namespace"],
                label_selector="app=jupyterhub,component=singleuser-server",
            )
        )

        get_build_pods = asyncio.wrap_future(
            pool.submit(
                k8s.list_namespaced_pod,
                self.settings["build_namespace"],
                label_selector="component=binderhub-build",
            )
        )

        return await asyncio.gather(get_user_pods, get_build_pods) 
开发者ID:jupyterhub,项目名称:binderhub,代码行数:25,代码来源:health.py

示例8: test_fetchall_prevents_sqlite_misuse

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def test_fetchall_prevents_sqlite_misuse(self):
        # test that calling fetchall sufficiently avoids the race
        attempts = 0

        def executemany_fetchall(query, params):
            self.db.executemany(query, params).fetchall()

        while attempts < self.max_misuse_attempts:
            f1 = asyncio.wrap_future(
                self.loop.run_in_executor(
                    self.executor, executemany_fetchall, "update test1 set val='derp' where id=?",
                    ((str(i),) for i in range(2))
                )
            )
            f2 = asyncio.wrap_future(
                self.loop.run_in_executor(
                    self.executor, executemany_fetchall, "update test2 set val='derp' where id=?",
                    ((str(i),) for i in range(2))
                )
            )
            attempts += 1
            await asyncio.gather(f1, f2) 
开发者ID:lbryio,项目名称:lbry-sdk,代码行数:24,代码来源:test_database.py

示例9: _await_loopsafe

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def _await_loopsafe(self, *coros_or_futures):
        """ 事件循环安全的异步等待。

        Args:
            *coros_or_futures: coroutine或future对象列表。

        Returns:
            返回coros_or_futures的返回结果列表。
        """
        current_loop = asyncio.get_running_loop()
        loop = self._loop
        if loop is None:
            loop = current_loop

        async def _execute_loop():
            with h.enter(self._handlers):
                r = await asyncio.gather(*coros_or_futures)
                return r
        fut = asyncio.run_coroutine_threadsafe(_execute_loop(), loop)
        result = await asyncio.wrap_future(fut)

        return result 
开发者ID:ZSAIm,项目名称:Nbdler,代码行数:24,代码来源:download.py

示例10: connect

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def connect(cls, path: Union[bytes, str], *args, **kwargs):
        db = cls()
        db.connection = await wrap_future(db.executor.submit(sqlite3.connect, path, *args, **kwargs))
        return db 
开发者ID:lbryio,项目名称:torba,代码行数:6,代码来源:basedatabase.py

示例11: executescript

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def executescript(self, script: str) -> Awaitable:
        return wrap_future(self.executor.submit(self.connection.executescript, script)) 
开发者ID:lbryio,项目名称:torba,代码行数:4,代码来源:basedatabase.py

示例12: execute_fetchall

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def execute_fetchall(self, sql: str, parameters: Iterable = None) -> Awaitable[Iterable[sqlite3.Row]]:
        parameters = parameters if parameters is not None else []
        def __fetchall(conn: sqlite3.Connection, *args, **kwargs):
            return conn.execute(*args, **kwargs).fetchall()
        return wrap_future(self.executor.submit(__fetchall, self.connection, sql, parameters)) 
开发者ID:lbryio,项目名称:torba,代码行数:7,代码来源:basedatabase.py

示例13: run

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def run(self, fun, *args, **kwargs) -> Awaitable:
        return wrap_future(self.executor.submit(self.__run_transaction, fun, *args, **kwargs)) 
开发者ID:lbryio,项目名称:torba,代码行数:4,代码来源:basedatabase.py

示例14: run_with_foreign_keys_disabled

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def run_with_foreign_keys_disabled(self, fun, *args, **kwargs) -> Awaitable:
        return wrap_future(
            self.executor.submit(self.__run_transaction_with_foreign_keys_disabled, fun, *args, **kwargs)
        ) 
开发者ID:lbryio,项目名称:torba,代码行数:6,代码来源:basedatabase.py

示例15: test_submit

# 需要导入模块: import asyncio [as 别名]
# 或者: from asyncio import wrap_future [as 别名]
def test_submit(self):
        with warnings.catch_warnings(record=True) as w:
            expected = g(10, 9, z=8)
            f = self.pool.submit(g, 10, 9, z=8)
            actual = loop.run_until_complete(asyncio.wrap_future(f))
            self.assertEqual(actual, expected)

            self.assertNoWarnings(w) 
开发者ID:erdewit,项目名称:distex,代码行数:10,代码来源:pool_test.py


注:本文中的asyncio.wrap_future方法示例由纯净天空整理自Github/MSDocs等开源代码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。