當前位置: 首頁>>代碼示例>>Python>>正文


Python asyncio.StreamReaderProtocol方法代碼示例

本文整理匯總了Python中asyncio.StreamReaderProtocol方法的典型用法代碼示例。如果您正苦於以下問題:Python asyncio.StreamReaderProtocol方法的具體用法?Python asyncio.StreamReaderProtocol怎麽用?Python asyncio.StreamReaderProtocol使用的例子?那麽, 這裏精選的方法代碼示例或許可以為您提供幫助。您也可以進一步了解該方法所在asyncio的用法示例。


在下文中一共展示了asyncio.StreamReaderProtocol方法的15個代碼示例,這些例子默認根據受歡迎程度排序。您可以為喜歡或者感覺有用的代碼點讚,您的評價將有助於係統推薦出更棒的Python代碼示例。

示例1: test_it_logs_messages

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def test_it_logs_messages(self):
        asyncio.set_event_loop_policy(uvloop.EventLoopPolicy())
        loop = asyncio.get_event_loop()

        async def test():
            reader = asyncio.StreamReader(loop=loop)
            protocol = asyncio.StreamReaderProtocol(reader)

            transport, _ = await loop.connect_read_pipe(
                lambda: protocol, self.read_pipe
            )

            logger = Logger.with_default_handlers()
            await logger.info("Xablau")

            logged_content = await reader.readline()
            self.assertEqual(logged_content, b"Xablau\n")

            transport.close()
            await logger.shutdown()

        loop.run_until_complete(test()) 
開發者ID:b2wdigital,項目名稱:aiologger,代碼行數:24,代碼來源:test_uvloop_integration.py

示例2: create_pipe_streams_pair

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def create_pipe_streams_pair():
    path = tempfile.mktemp()
    loop = asyncio.get_event_loop()
    server_side = asyncio.Future()

    def factory():

        def client_connected_cb(reader, writer):
            server_side.set_result((reader, writer))
        reader = asyncio.StreamReader(loop=loop)
        return asyncio.StreamReaderProtocol(reader, client_connected_cb, loop=loop)

    server = yield from loop.create_unix_server(factory, path)

    r1 = asyncio.StreamReader(loop=loop)
    protocol = asyncio.StreamReaderProtocol(r1, loop=loop)
    transport, _ = yield from loop.create_unix_connection(
        lambda: protocol, path)
    w1 = asyncio.StreamWriter(transport, protocol, r1, loop)

    r2, w2 = yield from server_side
    server.close()
    return (r1, w1), (r2, w2) 
開發者ID:gdassori,項目名稱:spruned,代碼行數:25,代碼來源:pipes.py

示例3: handshake

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def handshake(self):
        if sys.platform == 'linux' or sys.platform == 'darwin':
            self.sock_reader, self.sock_writer = await asyncio.open_unix_connection(self.ipc_path, loop=self.loop)
        elif sys.platform == 'win32' or sys.platform == 'win64':
            self.sock_reader = asyncio.StreamReader(loop=self.loop)
            reader_protocol = asyncio.StreamReaderProtocol(
                self.sock_reader, loop=self.loop)
            try:
                self.sock_writer, _ = await self.loop.create_pipe_connection(lambda: reader_protocol, self.ipc_path)
            except FileNotFoundError:
                raise InvalidPipe
        self.send_data(0, {'v': 1, 'client_id': self.client_id})
        data = await self.sock_reader.read(1024)
        code, length = struct.unpack('<ii', data[:8])
        if self._events_on:
            self.sock_reader.feed_data = self.on_event 
開發者ID:qwertyquerty,項目名稱:pypresence,代碼行數:18,代碼來源:baseclient.py

示例4: test_socks5_http_create_connection

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def test_socks5_http_create_connection(event_loop):
    reader = asyncio.StreamReader(loop=event_loop)
    protocol = asyncio.StreamReaderProtocol(reader, loop=event_loop)

    transport, _ = await create_connection(
        proxy_url=SOCKS5_IPV4_URL,
        protocol_factory=lambda: protocol,
        host=HTTP_TEST_HOST,
        port=HTTP_TEST_PORT,
    )

    writer = asyncio.StreamWriter(transport, protocol, reader, event_loop)

    request = ("GET /ip HTTP/1.1\r\n"
               "Host: %s\r\n"
               "Connection: close\r\n\r\n" % HTTP_TEST_HOST)

    writer.write(request.encode())
    response = await reader.read(-1)
    assert b'200 OK' in response 
開發者ID:romis2012,項目名稱:aiohttp-socks,代碼行數:22,代碼來源:test_socks.py

示例5: stream_from_fd

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def stream_from_fd(fd, loop):
    """Recieve a streamer for a given file descriptor."""
    reader = asyncio.StreamReader(loop=loop)
    protocol = asyncio.StreamReaderProtocol(reader, loop=loop)
    waiter = asyncio.futures.Future(loop=loop)

    transport = UnixFileDescriptorTransport(
        loop=loop,
        fileno=fd,
        protocol=protocol,
        waiter=waiter,
    )

    try:
        yield from waiter
    except Exception:
        transport.close()

    if loop.get_debug():
        logger.debug("Read fd %r connected: (%r, %r)", fd, transport, protocol)
    return reader, transport 
開發者ID:rbarrois,項目名稱:aionotify,代碼行數:23,代碼來源:aioutils.py

示例6: open_serial_connection

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def open_serial_connection(*,
                           loop=None,
                           limit=asyncio.streams._DEFAULT_LIMIT,
                           **kwargs):
    """A wrapper for create_serial_connection() returning a (reader,
    writer) pair.

    The reader returned is a StreamReader instance; the writer is a
    StreamWriter instance.

    The arguments are all the usual arguments to Serial(). Additional
    optional keyword arguments are loop (to set the event loop instance
    to use) and limit (to set the buffer limit passed to the
    StreamReader.

    This function is a coroutine.
    """
    if loop is None:
        loop = asyncio.get_event_loop()
    reader = asyncio.StreamReader(limit=limit, loop=loop)
    protocol = asyncio.StreamReaderProtocol(reader, loop=loop)
    transport, _ = yield from create_serial_connection(
        loop=loop,
        protocol_factory=lambda: protocol,
        **kwargs)
    writer = asyncio.StreamWriter(transport, protocol, reader, loop)
    return reader, writer


# - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - -
# test 
開發者ID:wolfmanjm,項目名稱:kivy-smoothie-host,代碼行數:33,代碼來源:serial_asyncio.py

示例7: open_connection

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def open_connection(host=None, port=None, *,
                          limit, loop=None,
                          parser=None, **kwds):
    # XXX: parser is not used (yet)
    if loop is not None and sys.version_info >= (3, 8):
        warnings.warn("The loop argument is deprecated",
                      DeprecationWarning)
    reader = StreamReader(limit=limit)
    protocol = asyncio.StreamReaderProtocol(reader)
    transport, _ = await get_event_loop().create_connection(
        lambda: protocol, host, port, **kwds)
    writer = asyncio.StreamWriter(transport, protocol, reader,
                                  loop=get_event_loop())
    return reader, writer 
開發者ID:aio-libs,項目名稱:aioredis,代碼行數:16,代碼來源:stream.py

示例8: open_unix_connection

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def open_unix_connection(address, *,
                               limit, loop=None,
                               parser=None, **kwds):
    # XXX: parser is not used (yet)
    if loop is not None and sys.version_info >= (3, 8):
        warnings.warn("The loop argument is deprecated",
                      DeprecationWarning)
    reader = StreamReader(limit=limit)
    protocol = asyncio.StreamReaderProtocol(reader)
    transport, _ = await get_event_loop().create_unix_connection(
        lambda: protocol, address, **kwds)
    writer = asyncio.StreamWriter(transport, protocol, reader,
                                  loop=get_event_loop())
    return reader, writer 
開發者ID:aio-libs,項目名稱:aioredis,代碼行數:16,代碼來源:stream.py

示例9: __init__

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def __init__(self, num_tokens_per_source, input_queue_maxsize, write, read):
        super().__init__(num_tokens_per_source)
        self._input_queue = asyncio.Queue(input_queue_maxsize)
        self._write = write

        loop = asyncio.get_event_loop()
        self._stream_reader = asyncio.StreamReader()
        def protocol_factory():
            return asyncio.StreamReaderProtocol(self._stream_reader)
        pipe = os.fdopen(read, mode='r')
        self._transport, _ = loop.run_until_complete(
            loop.connect_read_pipe(protocol_factory, pipe)) 
開發者ID:cmusatyalab,項目名稱:gabriel,代碼行數:14,代碼來源:local_engine.py

示例10: get_producer_wrapper

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def get_producer_wrapper(self):
        async def receiver():
            stream_reader = asyncio.StreamReader()
            def protocol_factory():
                return asyncio.StreamReaderProtocol(stream_reader)
            transport = await asyncio.get_event_loop().connect_read_pipe(
                protocol_factory, os.fdopen(self._read, mode='r'))

            # TODO do we need to close transport when filter gets garbage
            # collected?

            while True:
                size_bytes = await stream_reader.readexactly(
                    _NUM_BYTES_FOR_SIZE)
                size_of_message = int.from_bytes(size_bytes, _BYTEORDER)

                input_frame = gabriel_pb2.InputFrame()
                input_frame.ParseFromString(
                    await stream_reader.readexactly(size_of_message))
                self._latest_input_frame = input_frame
                self._frame_available.set()

        async def producer():
            if not self._started_receiver:
                self._started_receiver = True
                assert os.getpid() == self._constructor_pid
                asyncio.ensure_future(receiver())

            await self._frame_available.wait()

            # Clear because we are sending self._latest_input_frame
            self._frame_available.clear()

            return self._latest_input_frame

        return ProducerWrapper(producer=producer, source_name=self._source_name) 
開發者ID:cmusatyalab,項目名稱:gabriel,代碼行數:38,代碼來源:push_source.py

示例11: get_reader

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def get_reader(self):
        if self._reader is None:
            self._reader = asyncio.StreamReader()
            protocol = asyncio.StreamReaderProtocol(self._reader)
            loop = asyncio.get_event_loop()
            await loop.connect_read_pipe(lambda: protocol, sys.stdin)
        return self._reader 
開發者ID:vit-,項目名稱:telegram-uz-bot,代碼行數:9,代碼來源:dev_bot.py

示例12: get_pipe_reader

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def get_pipe_reader(self, fd_reader):
        reader = asyncio.StreamReader()
        protocol = asyncio.StreamReaderProtocol(reader)
        try:
            await self.loop.connect_read_pipe(lambda: protocol, fd_reader)
        except:
            return None
        return reader 
開發者ID:bitaps-com,項目名稱:pybtc,代碼行數:10,代碼來源:block_loader.py

示例13: wait_on_fail

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def wait_on_fail(func):
    """Test decorator for debugging. It pause test execution on failure and wait
    for user input. It's useful to manually inspect system state just after test
    fails, before executing any cleanup.

    Usage: decorate a test you are debugging.
    DO IT ONLY TEMPORARILY, DO NOT COMMIT!
    """

    @functools.wraps(func)
    def wrapper(self, *args, **kwargs):
        try:
            func(self, *args, **kwargs)
        except:
            print('FAIL\n')
            traceback.print_exc()
            print('Press return to continue:', end='')
            sys.stdout.flush()
            reader = asyncio.StreamReader(loop=self.loop)
            transport, protocol = self.loop.run_until_complete(
                self.loop.connect_read_pipe(
                    lambda: asyncio.StreamReaderProtocol(reader),
                    sys.stdin))
            self.loop.run_until_complete(reader.readline())
            raise

    return wrapper 
開發者ID:QubesOS,項目名稱:qubes-core-admin,代碼行數:29,代碼來源:__init__.py

示例14: stream_as_generator

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def stream_as_generator(loop, stream):
        reader = asyncio.StreamReader(loop=loop)
        reader_protocol = asyncio.StreamReaderProtocol(reader)
        await loop.connect_read_pipe(lambda: reader_protocol, stream)

        while True:
            line = await reader.readline()
            if not line:  # EOF.
                break
            yield line 
開發者ID:aliasrobotics,項目名稱:aztarna,代碼行數:12,代碼來源:commons.py

示例15: make_read_pipe_stream_reader

# 需要導入模塊: import asyncio [as 別名]
# 或者: from asyncio import StreamReaderProtocol [as 別名]
def make_read_pipe_stream_reader(
    loop, read_pipe
) -> Tuple[asyncio.StreamReader, asyncio.ReadTransport]:
    reader = asyncio.StreamReader(loop=loop)
    protocol = asyncio.StreamReaderProtocol(reader)

    transport, protocol = await loop.connect_read_pipe(
        lambda: protocol, read_pipe
    )
    return reader, transport 
開發者ID:b2wdigital,項目名稱:aiologger,代碼行數:12,代碼來源:utils.py


注:本文中的asyncio.StreamReaderProtocol方法示例由純淨天空整理自Github/MSDocs等開源代碼及文檔管理平台,相關代碼片段篩選自各路編程大神貢獻的開源項目,源碼版權歸原作者所有,傳播和使用請參考對應項目的License;未經允許,請勿轉載。