Home
last modified time | relevance | path

Searched refs:create_task (Results 1 – 25 of 66) sorted by relevance

123

/external/python/cpython3/Lib/test/test_asyncio/
Dtest_locks.py114 t1 = asyncio.create_task(c1(result))
115 t2 = asyncio.create_task(c2(result))
127 t3 = asyncio.create_task(c3(result))
148 task = asyncio.create_task(lock.acquire())
180 ta = asyncio.create_task(lockit('A', fa))
183 tb = asyncio.create_task(lockit('B', None))
186 tc = asyncio.create_task(lockit('C', None))
223 t1 = asyncio.create_task(lockit())
224 t2 = asyncio.create_task(lockit())
225 t3 = asyncio.create_task(lockit())
[all …]
Dtest_queues.py45 loop.create_task(q.get())
58 loop.create_task(q.put(2))
127 t = loop.create_task(putter())
193 queue_get_task = loop.create_task(queue_get())
230 get_task = loop.create_task(queue_get())
241 t1 = self.loop.create_task(q.get())
242 t2 = self.loop.create_task(q.get())
254 self.loop.create_task(q.put('a'))
255 self.loop.create_task(q.put('b'))
301 self.loop.run_until_complete(self.loop.create_task(consumer(queue)))
[all …]
Dtest_sock_lowlevel.py139 task = asyncio.create_task(self.loop.sock_recv(sock, 1024))
143 asyncio.create_task(
157 task = asyncio.create_task(
162 task = asyncio.create_task(
178 task = asyncio.create_task(
196 task = asyncio.create_task(
209 task = asyncio.create_task(recv_all())
231 task = asyncio.create_task(self.loop.sock_connect(sock, addr))
292 task = asyncio.create_task(self.loop.sock_sendall(sock, chunk))
341 task = asyncio.create_task(self.loop.sock_sendall(sock, chunk))
Dtest_streams.py151 read_task = self.loop.create_task(stream.read(30))
175 read_task = self.loop.create_task(stream.read(1024))
188 read_task = self.loop.create_task(stream.read(-1))
231 read_task = self.loop.create_task(stream.readline())
487 read_task = self.loop.create_task(stream.readexactly(n))
510 read_task = self.loop.create_task(stream.readexactly(n))
550 t1 = self.loop.create_task(stream.readline())
551 t2 = self.loop.create_task(set_err())
560 t = self.loop.create_task(stream.readline())
592 self.loop.create_task(self.handle_client(client_reader,
[all …]
Dtest_runners.py118 lo_task = asyncio.create_task(leftover())
139 lo_task = asyncio.create_task(leftover())
177 lazyboy = asyncio.create_task(spin())
Dtest_server.py53 main_task = self.loop.create_task(main(srv))
107 main_task = self.loop.create_task(main(srv))
Dtest_asyncio_waitfor.py36 waitfortask = asyncio.create_task(asyncio.wait_for(t.run(), t.TASK_TIMEOUT * 2))
Dtest_base_events.py740 task = self.loop.create_task(coro())
747 task = self.loop.create_task(coro())
790 def create_task(self, coro): member in BaseEventLoopTests.test_create_task.EventLoop
820 task = loop.create_task(test(), name='test_task')
836 task = loop.create_task(test(), name='test_task')
968 asyncio.create_task(iter_one())
970 asyncio.create_task(iter_one())
1098 return self.loop.create_task(getaddrinfo(*args, **kwds))
1215 return self.loop.create_task(getaddrinfo(*args, **kwds))
1227 return self.loop.create_task(getaddrinfo(*args, **kwds))
[all …]
/external/python/bumble/bumble/
Dutils.py89 def __init__(self, create_task=True): argument
92 self.create_task = create_task
96 if self.create_task and self.task is None:
97 self.task = asyncio.create_task(self.run())
135 asyncio.create_task(run())
Dlink.py166 asyncio.create_task(self.run_connection())
167 asyncio.create_task(self.run_executor_loop())
218 asyncio.create_task(websocket.close())
Dsmp.py727 asyncio.create_task(prompt())
740 asyncio.create_task(prompt())
752 asyncio.create_task(self.pairing_config.delegate.display_number(self.passkey, digits=6))
869 asyncio.create_task(
1093 asyncio.create_task(self.on_smp_pairing_request_command_async(command))
1418 asyncio.create_task(next_steps())
1530 asyncio.create_task(store_keys())
/external/pigweed/pw_transfer/py/pw_transfer/
Dclient.py178 self._loop.create_task(self._transfer_event_loop())
183 exit_thread = self._loop.create_task(self._quit_event.wait())
184 new_transfer = self._loop.create_task(self._new_transfer_queue.get())
185 read_chunk = self._loop.create_task(self._read_chunk_queue.get())
186 write_chunk = self._loop.create_task(self._write_chunk_queue.get())
199 new_transfer = self._loop.create_task(
203 self._loop.create_task(
206 read_chunk = self._loop.create_task(
210 self._loop.create_task(
213 write_chunk = self._loop.create_task(
/external/tensorflow/tensorflow/core/data/service/
Ddispatcher_state.cc75 CreateTask(update.create_task()); in Apply()
243 void DispatcherState::CreateTask(const CreateTaskUpdate& create_task) { in CreateTask() argument
244 int64_t task_id = create_task.task_id(); in CreateTask()
247 auto& job = jobs_[create_task.job_id()]; in CreateTask()
249 task = std::make_shared<Task>(task_id, job, create_task.worker_address(), in CreateTask()
250 create_task.transfer_address()); in CreateTask()
251 tasks_by_job_[create_task.job_id()].push_back(task); in CreateTask()
252 tasks_by_worker_[create_task.worker_address()][task->task_id] = task; in CreateTask()
Ddispatcher_impl.cc706 CreatePendingTaskUpdate* create_task = update.mutable_create_pending_task(); in CreatePendingTask() local
707 create_task->set_task_id(task_id); in CreatePendingTask()
708 create_task->set_job_id(job->job_id); in CreatePendingTask()
709 create_task->set_worker_address(worker_address); in CreatePendingTask()
710 create_task->set_starting_round(round_robin_rounds_[job->job_id] + 1); in CreatePendingTask()
713 create_task->set_transfer_address(worker->transfer_address); in CreatePendingTask()
724 CreateTaskUpdate* create_task = update.mutable_create_task(); in CreateTask() local
725 create_task->set_task_id(task_id); in CreateTask()
726 create_task->set_job_id(job->job_id); in CreateTask()
727 create_task->set_worker_address(worker_address); in CreateTask()
[all …]
Ddispatcher_state_test.cc128 CreateTaskUpdate* create_task = update.mutable_create_task(); in CreateTask() local
129 create_task->set_task_id(task_id); in CreateTask()
130 create_task->set_job_id(job_id); in CreateTask()
131 create_task->set_worker_address(worker_address); in CreateTask()
/external/python/cpython3/Lib/asyncio/
Dstaggered.py99 next_task = loop.create_task(run_one_coro(this_failed))
130 first_task = loop.create_task(run_one_coro(None))
D__main__.py50 repl_future = self.loop.create_task(coro)
/external/python/bumble/apps/
Dgg_bridge.py118 asyncio.create_task(self.peer.write_value(self.rx_characteristic, data))
138 asyncio.create_task(self.peer.write_value(self.rx_characteristic, data))
Dgatt_dump.py84 …device.on('connection', lambda connection: asyncio.create_task(dump_gatt_db(Peer(connection), done…
/external/python/cpython3/Doc/library/
Dasyncio-future.rst54 See also the :func:`create_task` function which is the
240 # We are using the low-level "loop.create_task()" API here because
242 # Otherwise we could have just used "asyncio.create_task()".
243 loop.create_task(
Dasyncio-task.rst76 * The :func:`asyncio.create_task` function to run coroutines
83 task1 = asyncio.create_task(
86 task2 = asyncio.create_task(
160 :func:`asyncio.create_task` the coroutine is automatically
171 task = asyncio.create_task(nested())
250 .. function:: create_task(coro, *, name=None)
270 task = asyncio.create_task(coro())
613 task = asyncio.create_task(foo())
804 Use the high-level :func:`asyncio.create_task` function to create
805 Tasks, or the low-level :meth:`loop.create_task` or
[all …]
Dasyncio-dev.rst158 or the coroutine is not scheduled with :meth:`asyncio.create_task`, asyncio
190 :meth:`asyncio.create_task` function::
212 asyncio.create_task(bug())
/external/python/bumble/examples/
Dasync_runner.py26 my_work_queue2 = AsyncRunner.WorkQueue(create_task=False)
/external/python/bumble/bumble/transport/
Dcommon.py277 self.pump_task = asyncio.get_running_loop().create_task(pump_packets())
307 self.pump_task = asyncio.get_running_loop().create_task(pump_packets())
/external/python/python-api-core/google/api_core/future/
Dasync_future.py151 self._background_task = asyncio.get_event_loop().create_task(

123