Home
last modified time | relevance | path

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

12345678910>>...183

/external/chromium-trace/catapult/systrace/systrace/test_data/
Datrace_procfs_dump1 proc/1/task/1
2 /proc/10/task/10
3 /proc/100/task/100
4 /proc/101/task/101
5 /proc/102/task/102
6 /proc/103/task/103
7 /proc/104/task/104
8 /proc/105/task/105
9 /proc/106/task/106
10 /proc/1068/task/1068
[all …]
/external/python/google-api-python-client/docs/dyn/
Dtasks_v1.tasks.html79 … specified task list. The affected tasks will be marked as 'hidden' and no longer be returned by d…
81 <code><a href="#delete">delete(tasklist, task)</a></code></p>
82 <p class="firstline">Deletes the specified task from the task list.</p>
84 <code><a href="#get">get(tasklist, task)</a></code></p>
85 <p class="firstline">Returns the specified task.</p>
88 <p class="firstline">Creates a new task on the specified task list.</p>
91 <p class="firstline">Returns all tasks in the specified task list.</p>
96 <code><a href="#move">move(tasklist, task, parent=None, previous=None)</a></code></p>
97 …="firstline">Moves the specified task to another position in the task list. This can include putti…
99 <code><a href="#patch">patch(tasklist, task, body)</a></code></p>
[all …]
Dtaskqueue_v1beta2.tasks.html78 <code><a href="#delete">delete(project, taskqueue, task)</a></code></p>
79 <p class="firstline">Delete a task from a TaskQueue.</p>
81 <code><a href="#get">get(project, taskqueue, task)</a></code></p>
82 <p class="firstline">Get a particular task from a TaskQueue.</p>
85 <p class="firstline">Insert a new task in a TaskQueue</p>
93 <code><a href="#patch">patch(project, taskqueue, task, newLeaseSeconds, body)</a></code></p>
96 <code><a href="#update">update(project, taskqueue, task, newLeaseSeconds, body)</a></code></p>
100 <code class="details" id="delete">delete(project, taskqueue, task)</code>
101 <pre>Delete a task from a TaskQueue.
105 taskqueue: string, The taskqueue to delete a task from. (required)
[all …]
Dtasks_v1.tasklists.html79 <p class="firstline">Deletes the authenticated user's specified task list.</p>
82 <p class="firstline">Returns the authenticated user's specified task list.</p>
85 <p class="firstline">Creates a new task list and adds it to the authenticated user's task lists.</p>
88 <p class="firstline">Returns all the authenticated user's task lists.</p>
94 <p class="firstline">Updates the authenticated user's specified task list. This method supports pat…
97 <p class="firstline">Updates the authenticated user's specified task list.</p>
101 <pre>Deletes the authenticated user's specified task list.
104 tasklist: string, Task list identifier. (required)
110 <pre>Returns the authenticated user's specified task list.
113 tasklist: string, Task list identifier. (required)
[all …]
/external/libwebsockets/lib/misc/threadpool/
Dthreadpool.c66 pthread_mutex_t lock; /* part of task wake_idle */
67 struct lws_threadpool_task *task; member
117 __lws_threadpool_task_dump(struct lws_threadpool_task *task, char *buf, int len) in __lws_threadpool_task_dump() argument
123 if (!task->acquired) { in __lws_threadpool_task_dump()
125 "task: %s, QUEUED queued: %dms", in __lws_threadpool_task_dump()
126 task->name, ms_delta(now, task->created)); in __lws_threadpool_task_dump()
131 if (task->acc_running) in __lws_threadpool_task_dump()
132 runms = task->acc_running; in __lws_threadpool_task_dump()
134 if (task->acc_syncing) in __lws_threadpool_task_dump()
135 syncms = 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 …]
/external/llvm-project/clang/test/OpenMP/
Dtask_messages.cpp12 #pragma omp task in xxx()
17 #pragma omp task detach(0) // omp45-error {{unexpected OpenMP clause 'detach' in directive '#pragma… in foo()
27 #pragma omp task // expected-error {{unexpected OpenMP directive '#pragma omp task'}}
57 #pragma omp task in foo()
59 #pragma omp task default(none) // expected-note 2 {{explicit data sharing attribute requested here}} in foo()
60 #pragma omp task default(shared) in foo()
63 #pragma omp task default(firstprivate) // expected-note 4 {{explicit data sharing attribute request… in foo()
64 #pragma omp task in foo()
71 #pragma omp task default(none) // expected-note 2 {{explicit data sharing attribute requested here}} in foo()
72 #pragma omp task in foo()
[all …]
Dtask_if_messages.cpp17 #pragma omp task if(cond) // expected-warning {{variable 'cond' is uninitialized when used here}} in xxx()
27 #pragma omp task if // expected-error {{expected '(' after 'if'}} in tmain()
28 …#pragma omp task if ( // expected-error {{expected expression}} expected-error {{expected ')'}} ex… in tmain()
29 #pragma omp task if () // expected-error {{expected expression}} in tmain()
30 #pragma omp task if (argc // expected-error {{expected ')'}} expected-note {{to match this '('}} in tmain()
31 …#pragma omp task if (argc)) // expected-warning {{extra tokens at the end of '#pragma omp task' ar… in tmain()
32 #pragma omp task if (argc > 0 ? argv[1] : argv[2]) in tmain()
33 …#pragma omp task if (foobool(argc)), if (true) // expected-error {{directive '#pragma omp task' ca… in tmain()
34 #pragma omp task if (S) // expected-error {{'S' does not refer to a value}} in tmain()
35 …#pragma omp task if (argv[1]=2) // expected-error {{expected ')'}} expected-note {{to match this '… in tmain()
[all …]
/external/vogar/src/vogar/tasks/
DTaskQueue.java39 private final LinkedList<Task> tasks = new LinkedList<Task>();
40 private final LinkedList<Task> runnableActions = new LinkedList<Task>();
41 private final LinkedList<Task> runnableTasks = new LinkedList<Task>();
42 private final List<Task> failedTasks = new ArrayList<Task>();
50 * Adds a task to the queue.
52 public synchronized void enqueue(Task task) { in enqueue() argument
53 tasks.add(task); in enqueue()
56 public void enqueueAll(Collection<Task> tasks) { in enqueueAll()
60 public synchronized List<Task> getTasks() { in getTasks()
61 return new ArrayList<Task>(tasks); in getTasks()
[all …]
/external/clang/test/OpenMP/
Dtask_messages.cpp6 #pragma omp task // expected-error {{unexpected OpenMP directive '#pragma omp task'}}
36 #pragma omp task in foo()
37 // expected-note@+1 2 {{predetermined as a firstprivate in a task construct here}} in foo()
39 #pragma omp task default(none) in foo()
40 #pragma omp task default(shared) in foo()
42 #pragma omp task default(none) in foo()
43 #pragma omp task in foo()
46 #pragma omp task in foo()
47 #pragma omp task in foo()
50 #pragma omp task default(shared) in foo()
[all …]
Dtask_if_messages.cpp14 #pragma omp task if // expected-error {{expected '(' after 'if'}} in tmain()
15 …#pragma omp task if ( // expected-error {{expected expression}} expected-error {{expected ')'}} ex… in tmain()
16 #pragma omp task if () // expected-error {{expected expression}} in tmain()
17 #pragma omp task if (argc // expected-error {{expected ')'}} expected-note {{to match this '('}} in tmain()
18 …#pragma omp task if (argc)) // expected-warning {{extra tokens at the end of '#pragma omp task' ar… in tmain()
19 #pragma omp task if (argc > 0 ? argv[1] : argv[2]) in tmain()
20 …#pragma omp task if (foobool(argc)), if (true) // expected-error {{directive '#pragma omp task' ca… in tmain()
21 #pragma omp task if (S) // expected-error {{'S' does not refer to a value}} in tmain()
22 …#pragma omp task if (argv[1]=2) // expected-error {{expected ')'}} expected-note {{to match this '… in tmain()
23 …#pragma omp task if (argc argc) // expected-error {{expected ')'}} expected-note {{to match this '… in tmain()
[all …]
/external/python/google-api-python-client/tests/data/
Dtasks.json7 "description": "Lets you manage your tasks and task lists.",
73 "Task": { object
74 "id": "Task",
79 …"description": "Completion date of the task (as a RFC 3339 timestamp). This field is omitted if th…
84 "description": "Flag indicating whether the task has been deleted. The default if False."
88 "description": "Due date of the task (as a RFC 3339 timestamp). Optional.",
97 …on": "Flag indicating whether the task is hidden. This is the case if the task had been marked com…
101 "description": "Task identifier."
105 "description": "Type of the resource. This is always \"tasks#task\".",
106 "default": "tasks#task"
[all …]
/external/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 …]
/external/rust/crates/tokio/src/runtime/task/
Dmod.rs36 /// An owned handle to the task, tracked by ref count
38 pub(crate) struct Task<S: 'static> { struct
43 unsafe impl<S> Send for Task<S> {} argument
44 unsafe impl<S> Sync for Task<S> {} implementation
46 /// A task was notified
48 pub(crate) struct Notified<S: 'static>(Task<S>);
53 /// Task result sent back
57 /// Bind a task to the executor.
59 /// Guaranteed to be called from the thread that called `poll` on the task.
60 /// The returned `Schedule` instance is associated with the task and is used
[all …]
/external/ims/rcs/rcsservice/src/com/android/service/ims/
DTaskManager.java66 private Map<String, Task> mTaskMap;
77 mTaskMap = new HashMap<String, Task>(); in TaskManager()
99 public void putTask(int taskId, Task task){ in putTask() argument
101 putTaskInternal(taskId, task); in putTask()
105 private synchronized void putTaskInternal(int taskId, Task task){ in putTaskInternal() argument
106 Task sameKeyTask = mTaskMap.put(String.valueOf(taskId), task); in putTaskInternal()
108 logger.debug("Added Task: " + task + "Original same key task:" + sameKeyTask); in putTaskInternal()
115 Task task = new PresenceCapabilityTask(context, taskId, TASK_TYPE_GET_CAPABILITY, in addCapabilityTask() local
117 putTaskInternal(taskId, task); in addCapabilityTask()
128 Task task = new PresenceAvailabilityTask(taskId, TASK_TYPE_GET_AVAILABILITY, in addAvailabilityTask() local
[all …]
/external/tensorflow/tensorflow/lite/delegates/gpu/common/tasks/
DBUILD14 "//tensorflow/lite/delegates/gpu/common/task:gpu_operation",
28 "//tensorflow/lite/delegates/gpu/common/task:testing_util",
40 "//tensorflow/lite/delegates/gpu/common/task:gpu_operation",
41 "//tensorflow/lite/delegates/gpu/common/task:work_group_picking",
52 "//tensorflow/lite/delegates/gpu/common/task:gpu_operation",
53 "//tensorflow/lite/delegates/gpu/common/task:work_group_picking",
67 "//tensorflow/lite/delegates/gpu/common/task:testing_util",
83 "//tensorflow/lite/delegates/gpu/common/task:buffer_desc",
84 "//tensorflow/lite/delegates/gpu/common/task:gpu_operation",
85 "//tensorflow/lite/delegates/gpu/common/task:tensor_linear_desc",
[all …]
/external/jacoco/org.jacoco.ant/src/org/jacoco/ant/
DCoverageTask.java23 import org.apache.tools.ant.Task;
28 * Container task to run Java/JUnit tasks with the JaCoCo agent jar. Coverage
31 * <li>Exactly one sub task may be present</li>
32 * <li>Task must be either Java or JUnit</li>
33 * <li>Task must be using a forked VM (so vm args can be passed)</li>
39 private Task childTask;
42 * Creates a new default coverage task
52 * Add child task to this container and reconfigure it to run with coverage
55 public void addTask(final Task task) { in addTask() argument
58 "Only one child task can be supplied to the coverge task", in addTask()
[all …]
/external/rust/crates/async-task/src/
Dtask.rs8 use core::task::{Context, Poll};
13 /// A spawned task.
15 /// A [`Task`] can be awaited to retrieve the output of its future.
17 /// Dropping a [`Task`] cancels it, which means its future won't be polled again. To drop the
18 /// [`Task`] handle without canceling it, use [`detach()`][`Task::detach()`] instead. To cancel a
19 /// task gracefully and wait until it is fully destroyed, use the [`cancel()`][Task::cancel()]
22 /// Note that canceling a task actually wakes it and reschedules one last time. Then, the executor
23 /// can destroy the task by simply dropping its [`Runnable`][`super::Runnable`] or by invoking
35 /// let task = ex.spawn(async {
36 /// println!("Hello from a task!");
[all …]
Draw.rs8 use core::task::{Context, Poll, RawWaker, RawWakerVTable, Waker};
15 /// The vtable for a task.
17 /// Schedules the task.
20 /// Drops the future inside the task.
26 /// Drops the task reference (`Runnable` or `Waker`).
29 /// Destroys the task.
32 /// Runs the task.
35 /// Creates a new waker associated with the task.
39 /// Memory layout of a task.
43 /// 1. How to allocate and deallocate the task.
[all …]
/external/rust/crates/tokio/src/runtime/tests/
Dtask.rs1 use crate::runtime::task::{self, Schedule, Task};
10 let _ = task::joinable::<_, Runtime>(async { unreachable!() }); in create_drop()
16 let (task, _) = task::joinable(async { in schedule()
17 crate::task::yield_now().await; in schedule()
20 rt.schedule(task); in schedule()
29 let (task, _) = task::joinable(async { in shutdown()
31 crate::task::yield_now().await; in shutdown()
35 rt.schedule(task); in shutdown()
54 released: task::TransferStack::new(), in with()
69 released: task::TransferStack<Runtime>,
[all …]
/external/toolchain-utils/bestflags/
Dtask_test.py4 """Task unittest.
15 import task
16 from task import Task
55 """This class test the Task class."""
58 """Test the equal method of the task.
68 assert Task(flag_set) == Task(flag_set)
72 test_task = Task(flag_set)
75 assert test_task != Task(flag_set1)
78 """Test the hash method of the task.
88 # The hash of a task is the same as the hash of its flag set.
[all …]
/external/tflite-support/tensorflow_lite_support/cc/task/vision/
DBUILD16 "//tensorflow_lite_support/cc/task/core:external_file_handler",
17 "//tensorflow_lite_support/cc/task/core:task_api_factory",
18 "//tensorflow_lite_support/cc/task/core:task_utils",
19 "//tensorflow_lite_support/cc/task/core:tflite_engine",
20 "//tensorflow_lite_support/cc/task/vision/core:base_vision_task_api",
21 "//tensorflow_lite_support/cc/task/vision/core:frame_buffer",
22 "//tensorflow_lite_support/cc/task/vision/core:label_map_item",
23 "//tensorflow_lite_support/cc/task/vision/proto:bounding_box_proto_inc",
24 "//tensorflow_lite_support/cc/task/vision/proto:class_proto_inc",
25 "//tensorflow_lite_support/cc/task/vision/proto:detections_proto_inc",
[all …]
/external/libchrome/base/task_scheduler/
Dtask_tracker_unittest.cc29 #include "base/task_scheduler/task.h"
90 Task* task, in ThreadPostingAndRunningTask() argument
96 task_(task), in ThreadPostingAndRunningTask()
101 // Ownership of the Task is required to run it. in ThreadPostingAndRunningTask()
107 Task task, in ThreadPostingAndRunningTask() argument
112 owned_task_(std::move(task)), in ThreadPostingAndRunningTask()
116 EXPECT_TRUE(owned_task_.task); in ThreadPostingAndRunningTask()
128 EXPECT_TRUE(owned_task_.task); in Run()
137 // after popping a task from it. in Run()
144 Task owned_task_;
[all …]
Dsequence_unittest.cc27 Task CreateTask(MockTask* mock_task) { in CreateTask()
28 return Task(FROM_HERE, BindOnce(&MockTask::Run, Unretained(mock_task)), in CreateTask()
32 void ExpectMockTask(MockTask* mock_task, Task* task) { in ExpectMockTask() argument
34 std::move(task->task).Run(); in ExpectMockTask()
49 // Push task A in the sequence. PushTask() should return true since it's the in TEST()
50 // first task-> in TEST()
53 // Push task B, C and D in the sequence. PushTask() should return false since in TEST()
54 // there is already a task in a sequence. in TEST()
59 // Take the task in front of the sequence. It should be task A. in TEST()
60 Optional<Task> task = sequence->TakeTask(); in TEST() local
[all …]
/external/rust/crates/futures-util/src/stream/futures_unordered/
Dmod.rs8 use futures_core::task::{Context, Poll};
10 use crate::task::AtomicWaker;
27 mod task; module
28 use self::task::Task;
57 head_all: AtomicPtr<Task<Fut>>,
92 // When a future is submitted to the set, a task is allocated and inserted in
94 // task and call `poll` on the future.
99 // `FuturesUnordered`. When a wake-up notification is received, the task is
102 // Each task is wrapped in an `Arc` and thereby atomically reference counted.
103 // Also, each task contains an `AtomicBool` which acts as a flag that indicates
[all …]

12345678910>>...183