Home
last modified time | relevance | path

Searched full:task (Results 1 – 25 of 1694) sorted by relevance

12345678910>>...68

/third_party/libwebsockets/lib/misc/threadpool/
Dthreadpool.c74 pthread_mutex_t lock; /* part of task wake_idle */
75 struct lws_threadpool_task *task; member
125 __lws_threadpool_task_dump(struct lws_threadpool_task *task, char *buf, int len) in __lws_threadpool_task_dump() argument
131 if (!task->acquired) { in __lws_threadpool_task_dump()
133 "task: %s, QUEUED queued: %dms", in __lws_threadpool_task_dump()
134 task->name, ms_delta(now, task->created)); in __lws_threadpool_task_dump()
139 if (task->acc_running) in __lws_threadpool_task_dump()
140 runms = (int)task->acc_running; in __lws_threadpool_task_dump()
142 if (task->acc_syncing) in __lws_threadpool_task_dump()
143 syncms = (int)task->acc_syncing; in __lws_threadpool_task_dump()
[all …]
DREADME.md13 thread context, where the output can be consumed, and the task told to continue,
29 of a task and that of the wsi are not necessarily linked.
31 You may start a long task, eg, that runs atomically in its thread for 30s, and
34 There are arrangements that a task can "check in" periodically with lws to see
35 if it has been asked to stop, allowing the task lifetime to be related to the
38 For that reason, at wsi close an ongoing task can detach from the wsi and
40 that work, the task is created with a `cleanup` callback that performs any
41 freeing independent of still having a wsi around to do it... the task takes over
42 responsibility to free the user pointer on destruction when the task is created.
48 Once created, although tasks may run asynchronously, the task itself does not
[all …]
/third_party/vk-gl-cts/android/cts/main/vk-master-2023-03-01/
Dycbcr.txt64 dEQP-VK.ycbcr.query.levels.task.b10x6g10x6r10x6g10x6_422_unorm_4pack16
65 dEQP-VK.ycbcr.query.levels.task.b12x4g12x4r12x4g12x4_422_unorm_4pack16
66 dEQP-VK.ycbcr.query.levels.task.b16g16r16g16_422_unorm
67 dEQP-VK.ycbcr.query.levels.task.b8g8r8g8_422_unorm
68 dEQP-VK.ycbcr.query.levels.task.g10x6_b10x6_r10x6_3plane_420_unorm_3pack16
69 dEQP-VK.ycbcr.query.levels.task.g10x6_b10x6_r10x6_3plane_420_unorm_3pack16_disjoint
70 dEQP-VK.ycbcr.query.levels.task.g10x6_b10x6_r10x6_3plane_422_unorm_3pack16
71 dEQP-VK.ycbcr.query.levels.task.g10x6_b10x6_r10x6_3plane_422_unorm_3pack16_disjoint
72 dEQP-VK.ycbcr.query.levels.task.g10x6_b10x6_r10x6_3plane_444_unorm_3pack16
73 dEQP-VK.ycbcr.query.levels.task.g10x6_b10x6_r10x6_3plane_444_unorm_3pack16_disjoint
[all …]
Dbinding-model.txt2260 ….sets16.constant.ubolimithigh.sbolimitlow.sampledimglow.outimgtexlow.iublimithigh.nouab.task.noia.0
2262 …om.sets16.constant.ubolimithigh.sbolimitlow.sampledimglow.outimgtexlow.iublimithigh.uab.task.noia.0
2264 …m.sets16.constant.ubolimithigh.sbolimitlow.sampledimglow.outimgtexlow.iublimitlow.nouab.task.noia.0
2266 …dom.sets16.constant.ubolimithigh.sbolimitlow.sampledimglow.outimgtexlow.iublimitlow.uab.task.noia.0
2268 …_random.sets16.constant.ubolimithigh.sbolimitlow.sampledimglow.outimgtexlow.noiub.nouab.task.noia.0
2270 …et_random.sets16.constant.ubolimithigh.sbolimitlow.sampledimglow.outimgtexlow.noiub.uab.task.noia.0
2272 ….sets16.constant.ubolimitlow.sbolimithigh.sampledimglow.outimgtexlow.iublimithigh.nouab.task.noia.0
2274 …om.sets16.constant.ubolimitlow.sbolimithigh.sampledimglow.outimgtexlow.iublimithigh.uab.task.noia.0
2276 …m.sets16.constant.ubolimitlow.sbolimithigh.sampledimglow.outimgtexlow.iublimitlow.nouab.task.noia.0
2278 …dom.sets16.constant.ubolimitlow.sbolimithigh.sampledimglow.outimgtexlow.iublimitlow.uab.task.noia.0
[all …]
/third_party/skia/third_party/externals/swiftshader/third_party/marl/include/marl/
Dtask.h24 // Task is a unit of work for the scheduler.
25 class Task {
32 // SameThread ensures the task will be run on the same thread that scheduled
33 // the task. This can offer performance improvements if the current thread
34 // is immediately going to block on the newly scheduled task, by reducing
39 MARL_NO_EXPORT inline Task();
40 MARL_NO_EXPORT inline Task(const Task&);
41 MARL_NO_EXPORT inline Task(Task&&);
42 MARL_NO_EXPORT inline Task(const Function& function,
44 MARL_NO_EXPORT inline Task(Function&& function, Flags flags = Flags::None);
[all …]
/third_party/node/deps/v8/src/libplatform/
Ddefault-foreground-task-runner.cc5 #include "src/libplatform/default-foreground-task-runner.h"
33 // Drain the task queues. in Terminate()
39 void DefaultForegroundTaskRunner::PostTaskLocked(std::unique_ptr<Task> task, in PostTaskLocked() argument
43 task_queue_.push_back(std::make_pair(nestability, std::move(task))); in PostTaskLocked()
47 void DefaultForegroundTaskRunner::PostTask(std::unique_ptr<Task> task) { in PostTask() argument
49 PostTaskLocked(std::move(task), kNestable, guard); in PostTask()
57 std::unique_ptr<Task> task, double delay_in_seconds, in PostDelayedTaskLocked() argument
62 delayed_task_queue_.push({deadline, nestability, std::move(task)}); in PostDelayedTaskLocked()
66 void DefaultForegroundTaskRunner::PostDelayedTask(std::unique_ptr<Task> task, in PostDelayedTask() argument
69 PostDelayedTaskLocked(std::move(task), delay_in_seconds, kNestable, guard); in PostDelayedTask()
[all …]
Ddefault-foreground-task-runner.h40 std::unique_ptr<Task> PopTaskFromQueue(MessageLoopBehavior wait_for_work); in NON_EXPORTED_BASE()
47 void PostTask(std::unique_ptr<Task> task) override; in NON_EXPORTED_BASE()
48 void PostDelayedTask(std::unique_ptr<Task> task, in NON_EXPORTED_BASE()
51 void PostIdleTask(std::unique_ptr<IdleTask> task) override; in NON_EXPORTED_BASE()
54 void PostNonNestableTask(std::unique_ptr<Task> task) override; in NON_EXPORTED_BASE()
55 void PostNonNestableDelayedTask(std::unique_ptr<Task> task, in NON_EXPORTED_BASE()
67 void PostTaskLocked(std::unique_ptr<Task> task, Nestability nestability, in NON_EXPORTED_BASE()
73 void PostDelayedTaskLocked(std::unique_ptr<Task> task, in NON_EXPORTED_BASE()
79 std::unique_ptr<Task> PopTaskFromDelayedQueueLocked(const base::MutexGuard&, in NON_EXPORTED_BASE()
82 // A non-nestable task is poppable only if the task runner is not nested, in NON_EXPORTED_BASE()
[all …]
/third_party/libwebsockets/include/libwebsockets/
Dlws-threadpool.h46 LWS_TP_STATUS_FINISHED, /* lws_threadpool_task_status() frees task */
47 LWS_TP_STATUS_STOPPED, /* lws_threadpool_task_status() frees task */
64 /* OR on to indicate this task wishes to outlive its wsi */
80 const char *name; /**< user may set to describe task */
81 char async_task; /**< set to allow the task to shrug off the loss
84 enum lws_threadpool_task_return (*task)(void *user, member
86 /**< user must set to actual task function */
88 /**< socket lifecycle may end while task is not stoppable, so the task
93 * wsi may be NULL on entry, indicating the task got detached due to the
103 * \param format: printf-type format for the task name
[all …]
/third_party/libuv/test/
Drunner.c27 #include "task.h"
70 task_entry_t* task; in run_tests() local
75 for (task = TASKS; task->main; task++, actual++) { in run_tests()
76 if (!task->is_helper) { in run_tests()
91 for (task = TASKS; task->main; task++) { in run_tests()
92 if (task->is_helper) { in run_tests()
96 test_result = run_test(task->task_name, benchmark_output, current); in run_tests()
152 task_entry_t* task; in run_test() local
171 for (task = TASKS; task->main; task++) { in run_test()
172 if (task->is_helper && strcmp(test, task->process_name) == 0) { in run_test()
[all …]
/third_party/mesa3d/src/gallium/drivers/llvmpipe/
Dlp_cs_tpool.c45 struct lp_cs_tpool_task *task; in lp_cs_tpool_worker() local
54 task = list_first_entry(&pool->workqueue, struct lp_cs_tpool_task, in lp_cs_tpool_worker()
57 unsigned this_iter = task->iter_start; in lp_cs_tpool_worker()
59 iter_per_thread = task->iter_per_thread; in lp_cs_tpool_worker()
61 if (task->iter_remainder && in lp_cs_tpool_worker()
62 task->iter_start + task->iter_remainder == task->iter_total) { in lp_cs_tpool_worker()
63 task->iter_remainder--; in lp_cs_tpool_worker()
67 task->iter_start += iter_per_thread; in lp_cs_tpool_worker()
69 if (task->iter_start == task->iter_total) in lp_cs_tpool_worker()
70 list_del(&task->list); in lp_cs_tpool_worker()
[all …]
Dlp_rast.c95 lp_rast_tile_begin(struct lp_rasterizer_task *task, in lp_rast_tile_begin() argument
99 struct lp_scene *scene = task->scene; in lp_rast_tile_begin()
103 task->bin = bin; in lp_rast_tile_begin()
104 task->x = x * TILE_SIZE; in lp_rast_tile_begin()
105 task->y = y * TILE_SIZE; in lp_rast_tile_begin()
106 task->width = TILE_SIZE + x * TILE_SIZE > scene->fb.width ? in lp_rast_tile_begin()
108 task->height = TILE_SIZE + y * TILE_SIZE > scene->fb.height ? in lp_rast_tile_begin()
111 task->thread_data.vis_counter = 0; in lp_rast_tile_begin()
112 task->thread_data.ps_invocations = 0; in lp_rast_tile_begin()
116 task->color_tiles[i] = scene->cbufs[i].map + in lp_rast_tile_begin()
[all …]
Dlp_rast_linear.c46 lp_rast_linear_clear(struct lp_rasterizer_task *task, in lp_rast_linear_clear() argument
53 const struct lp_scene *scene = task->scene; in lp_rast_linear_clear()
57 task->x, in lp_rast_linear_clear()
58 task->y, in lp_rast_linear_clear()
59 task->width, in lp_rast_linear_clear()
60 task->height, in lp_rast_linear_clear()
68 lp_rast_linear_tile(struct lp_rasterizer_task *task, in lp_rast_linear_tile() argument
75 const struct lp_rast_state *state = task->state; in lp_rast_linear_tile()
82 const struct lp_scene *scene = task->scene; in lp_rast_linear_tile()
86 task->x, in lp_rast_linear_tile()
[all …]
/third_party/python/Lib/asyncio/
Dbase_tasks.py9 def _task_repr_info(task): argument
10 info = base_futures._future_repr_info(task)
12 if task.cancelling() and not task.done():
16 info.insert(1, 'name=%r' % task.get_name())
18 coro = coroutines._format_coroutine(task._coro)
21 if task._fut_waiter is not None:
22 info.insert(3, f'wait_for={task._fut_waiter!r}')
27 def _task_repr(task): argument
28 info = ' '.join(_task_repr_info(task))
29 return f'<{task.__class__.__name__} {info}>'
[all …]
Dtasks.py4 'Task', 'create_task',
29 # Helper to generate new task names
36 """Return a currently executed task."""
65 def _set_task_name(task, name): argument
68 set_name = task.set_name
70 warnings.warn("Task.set_name() was added in Python 3.8, "
72 "task implementations since 3.13.",
78 class Task(futures._PyFuture): # Inherit Python Task implementation class
83 # An important invariant maintained while a Task not done:
92 # If False, don't log a message if the task is destroyed whereas its
[all …]
/third_party/typescript/tests/baselines/reference/user/
Dgrunt.log4 lib/grunt.js(91,13): error TS2551: Property 'task' does not exist on type 'typeof import("/grunt/gr…
5 lib/grunt.js(96,34): error TS2551: Property 'task' does not exist on type 'typeof import("/grunt/gr…
48 lib/grunt/help.js(81,9): error TS2551: Property 'task' does not exist on type 'typeof import("/grun…
49 lib/grunt/help.js(85,21): error TS2551: Property 'task' does not exist on type 'typeof import("/gru…
50 lib/grunt/help.js(87,22): error TS2551: Property 'task' does not exist on type 'typeof import("/gru…
51 lib/grunt/task.js(26,23): error TS2345: Argument of type 'any' is not assignable to parameter of ty…
52 lib/grunt/task.js(39,24): error TS2339: Property 'fail' does not exist on type 'typeof import("/gru…
53 lib/grunt/task.js(44,22): error TS2339: Property 'fail' does not exist on type 'typeof import("/gru…
54 lib/grunt/task.js(50,33): error TS2339: Property 'config' does not exist on type 'typeof import("/g…
55 lib/grunt/task.js(55,15): error TS2339: Property 'config' does not exist on type 'typeof import("/g…
[all …]
/third_party/typescript/
DGulpfile.mjs20 const { src, dest, task, parallel, series, watch } = gulp;
26 task("scripts", buildScripts);
27 task("scripts").description = "Builds files in the 'scripts' folder.";
46 task("lib", generateLibs);
47 task("lib").description = "Builds the library targets";
62 task("generate-diagnostics", generateDiagnostics);
63 task("generate-diagnostics").description = "Generates a diagnostic file in TypeScript based on an i…
68 const watchDiagnostics = () => watch(["src/compiler/diagnosticMessages.json"], task("generate-diagn…
107 task("tsc", series(lkgPreBuild, buildTsc));
108 task("tsc").description = "Builds the command-line compiler";
[all …]
/third_party/musl/ldso/linux/
Ddynlink_rand.c154 void free_task(struct loadtask *task) in free_task() argument
156 if (task == NULL) { in free_task()
159 if (task->name) { in free_task()
160 __libc_free(task->name); in free_task()
161 task->name = NULL; in free_task()
163 if (task->allocated_buf) { in free_task()
164 __libc_free(task->allocated_buf); in free_task()
165 task->allocated_buf = NULL; in free_task()
167 if (task->dyn_map_len) { in free_task()
168 munmap(task->dyn_map, task->dyn_map_len); in free_task()
[all …]
/third_party/musl/porting/linux/user/ldso/
Ddynlink_rand.c154 void free_task(struct loadtask *task) in free_task() argument
156 if (task == NULL) { in free_task()
159 if (task->name) { in free_task()
160 __libc_free(task->name); in free_task()
161 task->name = NULL; in free_task()
163 if (task->allocated_buf) { in free_task()
164 __libc_free(task->allocated_buf); in free_task()
165 task->allocated_buf = NULL; in free_task()
167 if (task->dyn_map_len) { in free_task()
168 munmap(task->dyn_map, task->dyn_map_len); in free_task()
[all …]
/third_party/musl/libc-test/src/functionalext/unittest/
Dunit_test_mock_dynlink.c24 void free_task(struct loadtask *task) in free_task() argument
26 if (task == NULL) { in free_task()
29 if (task->name) { in free_task()
30 free((void *)task->name); in free_task()
31 task->name = NULL; in free_task()
33 if (task->allocated_buf) { in free_task()
34 free(task->allocated_buf); in free_task()
35 task->allocated_buf = NULL; in free_task()
37 if (task->dyn_map_len) { in free_task()
38 munmap(task->dyn_map, task->dyn_map_len); in free_task()
[all …]
/third_party/python/Lib/test/test_asyncio/
Dtest_tasks.py89 Task = None variable in BaseTaskTests
93 return self.__class__.Task(coro, loop=loop, name=name, context=context)
105 task = self.__class__.Task[str]
106 self.assertEqual(task.__args__, (str,))
107 self.assertIsInstance(task, GenericAlias)
159 r'Task .* got Future .* attached'):
167 await task
169 task = asyncio.ensure_future(test(), loop=self.loop)
172 'Task cannot await on itself'):
173 self.loop.run_until_complete(task)
[all …]
/third_party/node/src/
Dnode_platform.cc15 using v8::Task;
20 TaskQueue<Task>* task_queue;
31 TaskQueue<Task>* pending_worker_tasks = worker_data->task_queue; in PlatformWorkerThread()
42 while (std::unique_ptr<Task> task = pending_worker_tasks->BlockingPop()) { in PlatformWorkerThread() local
43 task->Run(); in PlatformWorkerThread()
59 explicit DelayedTaskScheduler(TaskQueue<Task>* tasks) in DelayedTaskScheduler()
74 void PostDelayedTask(std::unique_ptr<Task> task, double delay_in_seconds) { in PostDelayedTask() argument
75 tasks_.Push(std::make_unique<ScheduleTask>(this, std::move(task), in PostDelayedTask()
102 while (std::unique_ptr<Task> task = scheduler->tasks_.Pop()) in FlushTasks() local
103 task->Run(); in FlushTasks()
[all …]
/third_party/mesa3d/src/gallium/frontends/nine/
Dthreadpool.c49 struct threadpool_task *task; in threadpool_worker() local
58 /* Pull the first task from the list. We don't free it -- it now lacks in threadpool_worker()
62 task = pool->workqueue; in threadpool_worker()
63 pool->workqueue = task->next; in threadpool_worker()
65 /* Call the task's work func. */ in threadpool_worker()
67 task->work(task->data); in threadpool_worker()
69 task->finished = TRUE; in threadpool_worker()
70 pthread_cond_broadcast(&task->finish); in threadpool_worker()
145 struct threadpool_task *task, *previous; in _mesa_threadpool_queue_task() local
152 task = calloc(1, sizeof(*task)); in _mesa_threadpool_queue_task()
[all …]
/third_party/glib/patch/
Dbackport-gdbusconnection-Fix-double-unref-on-timeout-cancel-sending-a-message.patch54 @@ -1822,7 +1822,7 @@ send_message_data_deliver_reply_unlocked (GTask *task,
59 +/* Called from a user thread, lock is not held; @task is (transfer full) */
61 send_message_data_deliver_error (GTask *task,
63 @@ -1849,13 +1849,14 @@ send_message_data_deliver_error (GTask *task,
67 -/* Called from a user thread, lock is not held; @task is (transfer full) */
68 +/* Called from a user thread, lock is not held; @task is (transfer none) */
72 GTask *task = user_data;
74 - send_message_data_deliver_error (task, G_IO_ERROR, G_IO_ERROR_CANCELLED,
75 + g_object_ref (task);
76 + send_message_data_deliver_error (g_steal_pointer (&task), G_IO_ERROR, G_IO_ERROR_CANCELLED,
[all …]
/third_party/libabigail/src/
Dabg-workers.cc45 /// until at least one @ref task is added to the queue.
47 /// When a @ref task is added to the @ref queue, one thread is woken
48 /// up, picks the @ref task, removes it from the @ref queue, and
50 /// performs the @ref task.
52 /// When the worker thread is done performing the @ref task, the
53 /// performed @ref task is added to another queue, named as the "done
55 /// performed again, and if there is at least one task in that queue,
57 /// waiting for a new task to be added to the queue.
67 /// Or she can choose to be asynchronously notified whenever a task is
98 /// The private data structure of the task queue.
[all …]
/third_party/python/Doc/library/
Dasyncio-task.rst81 concurrently as asyncio :class:`Tasks <Task>`.
183 When a coroutine is wrapped into a *Task* with functions like
195 task = asyncio.create_task(nested())
197 # "task" can now be used to cancel "nested()", or
199 await task
243 Wrap the *coro* :ref:`coroutine <coroutine>` into a :class:`Task`
244 and schedule its execution. Return the Task object.
246 If *name* is not ``None``, it is set as the name of the task using
247 :meth:`Task.set_name`.
253 The task is executed in the loop returned by :func:`get_running_loop`,
[all …]

12345678910>>...68